Class RpcPartitionStateChecker
- java.lang.Object
-
- org.apache.flink.runtime.taskexecutor.rpc.RpcPartitionStateChecker
-
- All Implemented Interfaces:
PartitionProducerStateChecker
public class RpcPartitionStateChecker extends Object implements PartitionProducerStateChecker
-
-
Constructor Summary
Constructors Constructor Description RpcPartitionStateChecker(JobMasterGateway jobMasterGateway)
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description CompletableFuture<ExecutionState>
requestPartitionProducerState(org.apache.flink.api.common.JobID jobId, IntermediateDataSetID resultId, ResultPartitionID partitionId)
Requests the execution state of the execution producing a result partition.
-
-
-
Constructor Detail
-
RpcPartitionStateChecker
public RpcPartitionStateChecker(JobMasterGateway jobMasterGateway)
-
-
Method Detail
-
requestPartitionProducerState
public CompletableFuture<ExecutionState> requestPartitionProducerState(org.apache.flink.api.common.JobID jobId, IntermediateDataSetID resultId, ResultPartitionID partitionId)
Description copied from interface:PartitionProducerStateChecker
Requests the execution state of the execution producing a result partition.- Specified by:
requestPartitionProducerState
in interfacePartitionProducerStateChecker
- Parameters:
jobId
- ID of the job the partition belongs to.resultId
- ID of the parent intermediate data set.partitionId
- ID of the result partition to check. This identifies the producing execution and partition.- Returns:
- Future holding the execution state of the producing execution.
-
-