Package | Description |
---|---|
org.apache.flink.runtime.taskexecutor | |
org.apache.flink.runtime.taskexecutor.rpc | |
org.apache.flink.runtime.taskmanager |
Modifier and Type | Method and Description |
---|---|
ResultPartitionConsumableNotifier |
JobTable.Connection.getResultPartitionConsumableNotifier() |
Modifier and Type | Method and Description |
---|---|
JobTable.Connection |
JobTable.Job.connect(ResourceID resourceId,
JobMasterGateway jobMasterGateway,
TaskManagerActions taskManagerActions,
CheckpointResponder checkpointResponder,
GlobalAggregateManager aggregateManager,
ResultPartitionConsumableNotifier resultPartitionConsumableNotifier,
PartitionProducerStateChecker partitionStateChecker)
Connects the job to a JobManager and associates the provided services with this
connection.
|
Modifier and Type | Class and Description |
---|---|
class |
RpcResultPartitionConsumableNotifier |
Modifier and Type | Method and Description |
---|---|
static ResultPartitionWriter[] |
ConsumableNotifyingResultPartitionWriterDecorator.decorate(Collection<ResultPartitionDeploymentDescriptor> descs,
ResultPartitionWriter[] partitionWriters,
TaskActions taskActions,
JobID jobId,
ResultPartitionConsumableNotifier notifier)
Optionally decorate the ResultPartitionWriter to call
notifyPartitionConsumable(JobID, ResultPartitionID,
TaskActions) on the first record, iff ResultPartitionDeploymentDescriptor.notifyPartitionDataAvailable() is true. |
Constructor and Description |
---|
Task(JobInformation jobInformation,
TaskInformation taskInformation,
ExecutionAttemptID executionAttemptID,
AllocationID slotAllocationId,
int subtaskIndex,
int attemptNumber,
List<ResultPartitionDeploymentDescriptor> resultPartitionDeploymentDescriptors,
List<InputGateDeploymentDescriptor> inputGateDeploymentDescriptors,
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–2023 The Apache Software Foundation. All rights reserved.