public class ActorGatewayPartitionProducerStateChecker extends Object implements PartitionProducerStateChecker
ActorGateway
to trigger the partition state check at the job
manager.构造器和说明 |
---|
ActorGatewayPartitionProducerStateChecker(ActorGateway jobManager,
scala.concurrent.duration.FiniteDuration timeout) |
限定符和类型 | 方法和说明 |
---|---|
CompletableFuture<ExecutionState> |
requestPartitionProducerState(org.apache.flink.api.common.JobID jobId,
IntermediateDataSetID intermediateDataSetId,
ResultPartitionID resultPartitionId)
Requests the execution state of the execution producing a result partition.
|
public ActorGatewayPartitionProducerStateChecker(ActorGateway jobManager, scala.concurrent.duration.FiniteDuration timeout)
public CompletableFuture<ExecutionState> requestPartitionProducerState(org.apache.flink.api.common.JobID jobId, IntermediateDataSetID intermediateDataSetId, ResultPartitionID resultPartitionId)
PartitionProducerStateChecker
requestPartitionProducerState
在接口中 PartitionProducerStateChecker
jobId
- ID of the job the partition belongs to.intermediateDataSetId
- ID of the parent intermediate data set.resultPartitionId
- ID of the result partition to check. This
identifies the producing execution and partition.Copyright © 2014–2019 The Apache Software Foundation. All rights reserved.