Uses of Interface
org.apache.flink.runtime.shuffle.PartitionWithMetrics
-
-
Uses of PartitionWithMetrics in org.apache.flink.runtime.io.network.partition.hybrid.tiered.shuffle
Methods in org.apache.flink.runtime.io.network.partition.hybrid.tiered.shuffle that return types with arguments of type PartitionWithMetrics Modifier and Type Method Description CompletableFuture<Collection<PartitionWithMetrics>>
TieredInternalShuffleMaster. getPartitionWithMetrics(JobShuffleContext jobShuffleContext, Duration timeout, Set<ResultPartitionID> expectedPartitions)
-
Uses of PartitionWithMetrics in org.apache.flink.runtime.io.network.partition.hybrid.tiered.storage
Methods in org.apache.flink.runtime.io.network.partition.hybrid.tiered.storage that return types with arguments of type PartitionWithMetrics Modifier and Type Method Description CompletableFuture<Collection<PartitionWithMetrics>>
TieredStorageMasterClient. getPartitionWithMetrics(JobShuffleContext jobShuffleContext, Duration timeout, Set<ResultPartitionID> expectedPartitions)
-
Uses of PartitionWithMetrics in org.apache.flink.runtime.jobmaster
Methods in org.apache.flink.runtime.jobmaster that return types with arguments of type PartitionWithMetrics Modifier and Type Method Description CompletableFuture<Collection<PartitionWithMetrics>>
JobMaster. getPartitionWithMetrics(Duration timeout, Set<ResultPartitionID> expectedPartitions)
default CompletableFuture<Collection<PartitionWithMetrics>>
JobMasterGateway. getPartitionWithMetrics(Duration timeout, Set<ResultPartitionID> expectedPartitions)
Get specified partitions and their metrics (identified byexpectedPartitions
), the metrics include sizes of sub-partitions in a result partition. -
Uses of PartitionWithMetrics in org.apache.flink.runtime.shuffle
Classes in org.apache.flink.runtime.shuffle that implement PartitionWithMetrics Modifier and Type Class Description class
DefaultPartitionWithMetrics
DefaultPartitionWithMetrics
implementation.Methods in org.apache.flink.runtime.shuffle that return types with arguments of type PartitionWithMetrics Modifier and Type Method Description CompletableFuture<Collection<PartitionWithMetrics>>
JobShuffleContext. getPartitionWithMetrics(Duration timeout, Set<ResultPartitionID> expectedPartitions)
Retrieves specified partitions and their metrics (identified byexpectedPartitions
), the metrics include sizes of sub-partitions in a result partition.CompletableFuture<Collection<PartitionWithMetrics>>
JobShuffleContextImpl. getPartitionWithMetrics(Duration timeout, Set<ResultPartitionID> expectedPartitions)
CompletableFuture<Collection<PartitionWithMetrics>>
NettyShuffleMaster. getPartitionWithMetrics(org.apache.flink.api.common.JobID jobId, Duration timeout, Set<ResultPartitionID> expectedPartitions)
default CompletableFuture<Collection<PartitionWithMetrics>>
ShuffleMaster. getPartitionWithMetrics(org.apache.flink.api.common.JobID jobId, Duration timeout, Set<ResultPartitionID> expectedPartitions)
Retrieves specified partitions and their metrics (identified byexpectedPartitions
), the metrics include sizes of sub-partitions in a result partition. -
Uses of PartitionWithMetrics in org.apache.flink.runtime.taskexecutor
Methods in org.apache.flink.runtime.taskexecutor that return types with arguments of type PartitionWithMetrics Modifier and Type Method Description CompletableFuture<Collection<PartitionWithMetrics>>
TaskExecutor. getAndRetainPartitionWithMetrics(org.apache.flink.api.common.JobID jobId)
default CompletableFuture<Collection<PartitionWithMetrics>>
TaskExecutorGateway. getAndRetainPartitionWithMetrics(org.apache.flink.api.common.JobID jobId)
Get and retain all partitions and their metrics located on this task executor, the metrics mainly includes the meta information of partition(partition bytes, etc).
-