Uses of Class
org.apache.flink.runtime.executiongraph.ResultPartitionBytes
-
-
Uses of ResultPartitionBytes in org.apache.flink.runtime.executiongraph
Fields in org.apache.flink.runtime.executiongraph with type parameters of type ResultPartitionBytes Modifier and Type Field Description protected Map<IntermediateResultPartitionID,ResultPartitionBytes>
IOMetrics. resultPartitionBytes
Methods in org.apache.flink.runtime.executiongraph that return types with arguments of type ResultPartitionBytes Modifier and Type Method Description Map<IntermediateResultPartitionID,ResultPartitionBytes>
IOMetrics. getResultPartitionBytes()
Constructor parameters in org.apache.flink.runtime.executiongraph with type arguments of type ResultPartitionBytes Constructor Description IOMetrics(long numBytesIn, long numBytesOut, long numRecordsIn, long numRecordsOut, long accumulateIdleTime, double accumulateBusyTime, long accumulateBackPressuredTime, Map<IntermediateResultPartitionID,ResultPartitionBytes> resultPartitionBytes)
-
Uses of ResultPartitionBytes in org.apache.flink.runtime.io.network.metrics
Methods in org.apache.flink.runtime.io.network.metrics that return ResultPartitionBytes Modifier and Type Method Description ResultPartitionBytes
ResultPartitionBytesCounter. createSnapshot()
-
Uses of ResultPartitionBytes in org.apache.flink.runtime.scheduler.adaptivebatch
Methods in org.apache.flink.runtime.scheduler.adaptivebatch with parameters of type ResultPartitionBytes Modifier and Type Method Description void
AllToAllBlockingResultInfo. recordPartitionInfo(int partitionIndex, ResultPartitionBytes partitionBytes)
void
BlockingResultInfo. recordPartitionInfo(int partitionIndex, ResultPartitionBytes partitionBytes)
Record the information of the result partition.Method parameters in org.apache.flink.runtime.scheduler.adaptivebatch with type arguments of type ResultPartitionBytes Modifier and Type Method Description void
BatchJobRecoveryContext. updateResultPartitionBytesMetrics(Map<IntermediateResultPartitionID,ResultPartitionBytes> resultPartitionBytes)
Updates the metrics related to the result partition sizes. -
Uses of ResultPartitionBytes in org.apache.flink.runtime.shuffle
Methods in org.apache.flink.runtime.shuffle that return ResultPartitionBytes Modifier and Type Method Description ResultPartitionBytes
DefaultShuffleMetrics. getPartitionBytes()
ResultPartitionBytes
ShuffleMetrics. getPartitionBytes()
Constructors in org.apache.flink.runtime.shuffle with parameters of type ResultPartitionBytes Constructor Description DefaultShuffleMetrics(ResultPartitionBytes partitionBytes)
-