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. resultPartitionBytesMethods in org.apache.flink.runtime.executiongraph that return ResultPartitionBytes Modifier and Type Method Description static ResultPartitionBytesResultPartitionBytes. mergeAll(List<ResultPartitionBytes> partitions)Merge allResultPartitionBytesby sum up them per-subpartition.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()Method parameters in org.apache.flink.runtime.executiongraph with type arguments of type ResultPartitionBytes Modifier and Type Method Description static ResultPartitionBytesResultPartitionBytes. mergeAll(List<ResultPartitionBytes> partitions)Merge allResultPartitionBytesby sum up them per-subpartition.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 ResultPartitionBytesResultPartitionBytesCounter. 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 voidAllToAllBlockingResultInfo. recordPartitionInfo(int partitionIndex, ResultPartitionBytes partitionBytes)voidBlockingInputInfo. recordPartitionInfo(int partitionIndex, ResultPartitionBytes partitionBytes)voidBlockingResultInfo. 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 voidBatchJobRecoveryContext. 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 ResultPartitionBytesDefaultShuffleMetrics. getPartitionBytes()ResultPartitionBytesShuffleMetrics. getPartitionBytes()Constructors in org.apache.flink.runtime.shuffle with parameters of type ResultPartitionBytes Constructor Description DefaultShuffleMetrics(ResultPartitionBytes partitionBytes)
-