Modifier and Type | Method and Description |
---|---|
List<InputGateDeploymentDescriptor> |
TaskDeploymentDescriptor.getInputGates() |
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,
List<ResultPartitionDeploymentDescriptor> resultPartitionDeploymentDescriptors,
List<InputGateDeploymentDescriptor> inputGateDeploymentDescriptors) |
Modifier and Type | Method and Description |
---|---|
List<SingleInputGate> |
NettyShuffleEnvironment.createInputGates(ShuffleIOOwnerContext ownerContext,
PartitionProducerStateProvider partitionProducerStateProvider,
List<InputGateDeploymentDescriptor> inputGateDeploymentDescriptors) |
Modifier and Type | Method and Description |
---|---|
SingleInputGate |
SingleInputGateFactory.create(String owningTaskName,
int gateIndex,
InputGateDeploymentDescriptor igdd,
PartitionProducerStateProvider partitionProducerStateProvider,
InputChannelMetrics metrics)
Creates an input gate and all of its input channels.
|
Modifier and Type | Method and Description |
---|---|
List<G> |
ShuffleEnvironment.createInputGates(ShuffleIOOwnerContext ownerContext,
PartitionProducerStateProvider partitionProducerStateProvider,
List<InputGateDeploymentDescriptor> inputGateDeploymentDescriptors)
Factory method for the
InputGates to consume result partitions. |
Constructor and Description |
---|
Task(JobInformation jobInformation,
TaskInformation taskInformation,
ExecutionAttemptID executionAttemptID,
AllocationID slotAllocationId,
int subtaskIndex,
int attemptNumber,
List<ResultPartitionDeploymentDescriptor> resultPartitionDeploymentDescriptors,
List<InputGateDeploymentDescriptor> inputGateDeploymentDescriptors,
int targetSlotNumber,
MemoryManager memManager,
IOManager ioManager,
ShuffleEnvironment<?,?> shuffleEnvironment,
KvStateService kvStateService,
BroadcastVariableManager bcVarManager,
TaskEventDispatcher taskEventDispatcher,
ExternalResourceInfoProvider externalResourceInfoProvider,
TaskStateManager taskStateManager,
TaskManagerActions taskManagerActions,
InputSplitProvider inputSplitProvider,
CheckpointResponder checkpointResponder,
TaskOperatorEventGateway operatorCoordinatorEventGateway,
GlobalAggregateManager aggregateManager,
LibraryCacheManager.ClassLoaderHandle classLoaderHandle,
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–2021 The Apache Software Foundation. All rights reserved.