Uses of Interface
org.apache.flink.runtime.taskexecutor.PartitionProducerStateChecker
-
Packages that use PartitionProducerStateChecker Package Description org.apache.flink.runtime.taskexecutor org.apache.flink.runtime.taskexecutor.rpc org.apache.flink.runtime.taskmanager -
-
Uses of PartitionProducerStateChecker in org.apache.flink.runtime.taskexecutor
Methods in org.apache.flink.runtime.taskexecutor that return PartitionProducerStateChecker Modifier and Type Method Description PartitionProducerStateChecker
JobTable.Connection. getPartitionStateChecker()
Methods in org.apache.flink.runtime.taskexecutor with parameters of type PartitionProducerStateChecker Modifier and Type Method Description JobTable.Connection
JobTable.Job. connect(ResourceID resourceId, JobMasterGateway jobMasterGateway, TaskManagerActions taskManagerActions, CheckpointResponder checkpointResponder, GlobalAggregateManager aggregateManager, PartitionProducerStateChecker partitionStateChecker)
Connects the job to a JobManager and associates the provided services with this connection. -
Uses of PartitionProducerStateChecker in org.apache.flink.runtime.taskexecutor.rpc
Classes in org.apache.flink.runtime.taskexecutor.rpc that implement PartitionProducerStateChecker Modifier and Type Class Description class
RpcPartitionStateChecker
-
Uses of PartitionProducerStateChecker in org.apache.flink.runtime.taskmanager
Constructors in org.apache.flink.runtime.taskmanager with parameters of type PartitionProducerStateChecker Constructor Description Task(JobInformation jobInformation, TaskInformation taskInformation, ExecutionAttemptID executionAttemptID, AllocationID slotAllocationId, List<ResultPartitionDeploymentDescriptor> resultPartitionDeploymentDescriptors, List<InputGateDeploymentDescriptor> inputGateDeploymentDescriptors, MemoryManager memManager, SharedResources sharedResources, 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, PartitionProducerStateChecker partitionProducerStateChecker, Executor executor, ChannelStateWriteRequestExecutorFactory channelStateExecutorFactory)
IMPORTANT: This constructor may not start any work that would need to be undone in the case of a failing task deployment.
-