public final class TaskDeploymentDescriptor extends Object implements Serializable
Constructor and Description |
---|
TaskDeploymentDescriptor(JobID jobID,
JobVertexID vertexID,
ExecutionAttemptID executionId,
String taskName,
int indexInSubtaskGroup,
int numberOfSubtasks,
int attemptNumber,
Configuration jobConfiguration,
Configuration taskConfiguration,
String invokableClassName,
List<ResultPartitionDeploymentDescriptor> producedPartitions,
List<InputGateDeploymentDescriptor> inputGates,
List<BlobKey> requiredJarFiles,
List<URL> requiredClasspaths,
int targetSlotNumber) |
TaskDeploymentDescriptor(JobID jobID,
JobVertexID vertexID,
ExecutionAttemptID executionId,
String taskName,
int indexInSubtaskGroup,
int numberOfSubtasks,
int attemptNumber,
Configuration jobConfiguration,
Configuration taskConfiguration,
String invokableClassName,
List<ResultPartitionDeploymentDescriptor> producedPartitions,
List<InputGateDeploymentDescriptor> inputGates,
List<BlobKey> requiredJarFiles,
List<URL> requiredClasspaths,
int targetSlotNumber,
SerializedValue<StateHandle<?>> operatorState,
long recoveryTimestamp)
Constructs a task deployment descriptor.
|
Modifier and Type | Method and Description |
---|---|
int |
getAttemptNumber()
Returns the attempt number of the subtask
|
ExecutionAttemptID |
getExecutionId() |
int |
getIndexInSubtaskGroup()
Returns the task's index in the subtask group.
|
List<InputGateDeploymentDescriptor> |
getInputGates() |
String |
getInvokableClassName()
Returns the name of the class containing the task code to be executed.
|
Configuration |
getJobConfiguration()
Returns the configuration of the job the task belongs to.
|
JobID |
getJobID()
Returns the ID of the job the tasks belongs to.
|
int |
getNumberOfSubtasks()
Returns the current number of subtasks.
|
SerializedValue<StateHandle<?>> |
getOperatorState() |
List<ResultPartitionDeploymentDescriptor> |
getProducedPartitions() |
long |
getRecoveryTimestamp() |
List<URL> |
getRequiredClasspaths() |
List<BlobKey> |
getRequiredJarFiles() |
int |
getTargetSlotNumber()
Gets the number of the slot into which the task is to be deployed.
|
Configuration |
getTaskConfiguration()
Returns the task's configuration object.
|
TaskInfo |
getTaskInfo()
Returns the
TaskInfo object for the subtask |
String |
getTaskName()
Returns the task's name.
|
JobVertexID |
getVertexID()
Returns the task's execution vertex ID.
|
String |
toString() |
public TaskDeploymentDescriptor(JobID jobID, JobVertexID vertexID, ExecutionAttemptID executionId, String taskName, int indexInSubtaskGroup, int numberOfSubtasks, int attemptNumber, Configuration jobConfiguration, Configuration taskConfiguration, String invokableClassName, List<ResultPartitionDeploymentDescriptor> producedPartitions, List<InputGateDeploymentDescriptor> inputGates, List<BlobKey> requiredJarFiles, List<URL> requiredClasspaths, int targetSlotNumber, SerializedValue<StateHandle<?>> operatorState, long recoveryTimestamp)
public TaskDeploymentDescriptor(JobID jobID, JobVertexID vertexID, ExecutionAttemptID executionId, String taskName, int indexInSubtaskGroup, int numberOfSubtasks, int attemptNumber, Configuration jobConfiguration, Configuration taskConfiguration, String invokableClassName, List<ResultPartitionDeploymentDescriptor> producedPartitions, List<InputGateDeploymentDescriptor> inputGates, List<BlobKey> requiredJarFiles, List<URL> requiredClasspaths, int targetSlotNumber)
public JobID getJobID()
public JobVertexID getVertexID()
public ExecutionAttemptID getExecutionId()
public String getTaskName()
public int getIndexInSubtaskGroup()
public int getNumberOfSubtasks()
public int getAttemptNumber()
public int getTargetSlotNumber()
public Configuration getJobConfiguration()
public Configuration getTaskConfiguration()
public String getInvokableClassName()
public List<ResultPartitionDeploymentDescriptor> getProducedPartitions()
public List<InputGateDeploymentDescriptor> getInputGates()
public SerializedValue<StateHandle<?>> getOperatorState()
public long getRecoveryTimestamp()
Copyright © 2014–2017 The Apache Software Foundation. All rights reserved.