Uses of Class
org.apache.flink.runtime.executiongraph.PartitionInfo
-
-
Uses of PartitionInfo in org.apache.flink.runtime.io.network
Methods in org.apache.flink.runtime.io.network with parameters of type PartitionInfo Modifier and Type Method Description boolean
NettyShuffleEnvironment. updatePartitionInfo(ExecutionAttemptID consumerID, PartitionInfo partitionInfo)
-
Uses of PartitionInfo in org.apache.flink.runtime.jobmanager.slots
Method parameters in org.apache.flink.runtime.jobmanager.slots with type arguments of type PartitionInfo Modifier and Type Method Description CompletableFuture<Acknowledge>
TaskManagerGateway. updatePartitions(ExecutionAttemptID executionAttemptID, Iterable<PartitionInfo> partitionInfos, Duration timeout)
Update the task where the given partitions can be found. -
Uses of PartitionInfo in org.apache.flink.runtime.jobmaster
Method parameters in org.apache.flink.runtime.jobmaster with type arguments of type PartitionInfo Modifier and Type Method Description CompletableFuture<Acknowledge>
RpcTaskManagerGateway. updatePartitions(ExecutionAttemptID executionAttemptID, Iterable<PartitionInfo> partitionInfos, Duration timeout)
-
Uses of PartitionInfo in org.apache.flink.runtime.shuffle
Methods in org.apache.flink.runtime.shuffle with parameters of type PartitionInfo Modifier and Type Method Description boolean
ShuffleEnvironment. updatePartitionInfo(ExecutionAttemptID consumerID, PartitionInfo partitionInfo)
Update a gate with the newly available partition information, previously unknown. -
Uses of PartitionInfo in org.apache.flink.runtime.taskexecutor
Method parameters in org.apache.flink.runtime.taskexecutor with type arguments of type PartitionInfo Modifier and Type Method Description CompletableFuture<Acknowledge>
TaskExecutor. updatePartitions(ExecutionAttemptID executionAttemptID, Iterable<PartitionInfo> partitionInfos, Duration timeout)
CompletableFuture<Acknowledge>
TaskExecutorGateway. updatePartitions(ExecutionAttemptID executionAttemptID, Iterable<PartitionInfo> partitionInfos, Duration timeout)
Update the task where the given partitions can be found.CompletableFuture<Acknowledge>
TaskExecutorGatewayDecoratorBase. updatePartitions(ExecutionAttemptID executionAttemptID, Iterable<PartitionInfo> partitionInfos, Duration timeout)
-