Uses of Interface
org.apache.flink.runtime.shuffle.ShuffleMetrics
-
-
Uses of ShuffleMetrics in org.apache.flink.runtime.io.network
Methods in org.apache.flink.runtime.io.network that return types with arguments of type ShuffleMetrics Modifier and Type Method Description Optional<ShuffleMetrics>
NettyShuffleEnvironment. getMetricsIfPartitionOccupyingLocalResource(ResultPartitionID partitionId)
-
Uses of ShuffleMetrics in org.apache.flink.runtime.io.network.partition
Methods in org.apache.flink.runtime.io.network.partition that return types with arguments of type ShuffleMetrics Modifier and Type Method Description Optional<ShuffleMetrics>
ResultPartitionManager. getMetricsOfPartition(ResultPartitionID partitionId)
-
Uses of ShuffleMetrics in org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier
Methods in org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier that return types with arguments of type ShuffleMetrics Modifier and Type Method Description default CompletableFuture<Map<ResultPartitionID,ShuffleMetrics>>
TierMasterAgent. 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 ShuffleMetrics in org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.remote
Methods in org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.remote that return types with arguments of type ShuffleMetrics Modifier and Type Method Description CompletableFuture<Map<ResultPartitionID,ShuffleMetrics>>
RemoteTierMasterAgent. getPartitionWithMetrics(org.apache.flink.api.common.JobID jobId, Duration timeout, Set<ResultPartitionID> expectedPartitions)
-
Uses of ShuffleMetrics in org.apache.flink.runtime.shuffle
Classes in org.apache.flink.runtime.shuffle that implement ShuffleMetrics Modifier and Type Class Description class
DefaultShuffleMetrics
DefaultShuffleMetrics
implementation.Methods in org.apache.flink.runtime.shuffle that return ShuffleMetrics Modifier and Type Method Description ShuffleMetrics
DefaultPartitionWithMetrics. getPartitionMetrics()
ShuffleMetrics
PartitionWithMetrics. getPartitionMetrics()
Methods in org.apache.flink.runtime.shuffle that return types with arguments of type ShuffleMetrics Modifier and Type Method Description default Optional<ShuffleMetrics>
ShuffleEnvironment. getMetricsIfPartitionOccupyingLocalResource(ResultPartitionID partitionId)
Get metrics of the partition if it still occupies some resources locally and have not been released yet.Constructors in org.apache.flink.runtime.shuffle with parameters of type ShuffleMetrics Constructor Description DefaultPartitionWithMetrics(ShuffleDescriptor shuffleDescriptor, ShuffleMetrics partitionMetrics)
-