Package | Description |
---|---|
org.apache.flink.runtime.deployment | |
org.apache.flink.runtime.executiongraph | |
org.apache.flink.runtime.taskmanager |
Modifier and Type | Method and Description |
---|---|
SerializedValue<TaskInformation> |
TaskDeploymentDescriptor.getSerializedTaskInformation()
Return the sub task's serialized task information.
|
Constructor and Description |
---|
TaskDeploymentDescriptor(JobID jobId,
TaskDeploymentDescriptor.MaybeOffloaded<JobInformation> serializedJobInformation,
TaskDeploymentDescriptor.MaybeOffloaded<TaskInformation> serializedTaskInformation,
ExecutionAttemptID executionAttemptId,
AllocationID allocationId,
int subtaskIndex,
int attemptNumber,
int targetSlotNumber,
JobManagerTaskRestore taskRestore,
Collection<ResultPartitionDeploymentDescriptor> resultPartitionDeploymentDescriptors,
Collection<InputGateDeploymentDescriptor> inputGateDeploymentDescriptors) |
Modifier and Type | Method and Description |
---|---|
Either<SerializedValue<TaskInformation>,PermanentBlobKey> |
ExecutionJobVertex.getTaskInformationOrBlobKey() |
Constructor and Description |
---|
Task(JobInformation jobInformation,
TaskInformation taskInformation,
ExecutionAttemptID executionAttemptID,
AllocationID slotAllocationId,
int subtaskIndex,
int attemptNumber,
Collection<ResultPartitionDeploymentDescriptor> resultPartitionDeploymentDescriptors,
Collection<InputGateDeploymentDescriptor> inputGateDeploymentDescriptors,
int targetSlotNumber,
MemoryManager memManager,
IOManager ioManager,
ShuffleEnvironment<?,?> shuffleEnvironment,
KvStateService kvStateService,
BroadcastVariableManager bcVarManager,
TaskEventDispatcher taskEventDispatcher,
TaskStateManager taskStateManager,
TaskManagerActions taskManagerActions,
InputSplitProvider inputSplitProvider,
CheckpointResponder checkpointResponder,
GlobalAggregateManager aggregateManager,
BlobCacheService blobService,
LibraryCacheManager libraryCache,
FileCache fileCache,
TaskManagerRuntimeInfo taskManagerConfig,
TaskMetricGroup metricGroup,
ResultPartitionConsumableNotifier resultPartitionConsumableNotifier,
PartitionProducerStateChecker partitionProducerStateChecker,
Executor executor)
IMPORTANT: This constructor may not start any work that would need to
be undone in the case of a failing task deployment.
|
Copyright © 2014–2020 The Apache Software Foundation. All rights reserved.