Class IOMetrics
- java.lang.Object
-
- org.apache.flink.runtime.executiongraph.IOMetrics
-
- All Implemented Interfaces:
Serializable
- Direct Known Subclasses:
MutableIOMetrics
public class IOMetrics extends Object implements Serializable
An instance of this class represents a snapshot of the io-related metrics of a single task.- See Also:
- Serialized Form
-
-
Field Summary
Fields Modifier and Type Field Description protected longaccumulateBackPressuredTimeprotected doubleaccumulateBusyTimeprotected longaccumulateIdleTimeprotected longnumBytesInprotected longnumBytesOutprotected longnumRecordsInprotected longnumRecordsOutprotected Map<IntermediateResultPartitionID,ResultPartitionBytes>resultPartitionBytes
-
Constructor Summary
Constructors Constructor Description IOMetrics(long numBytesIn, long numBytesOut, long numRecordsIn, long numRecordsOut, long accumulateIdleTime, double accumulateBusyTime, long accumulateBackPressuredTime)IOMetrics(long numBytesIn, long numBytesOut, long numRecordsIn, long numRecordsOut, long accumulateIdleTime, double accumulateBusyTime, long accumulateBackPressuredTime, Map<IntermediateResultPartitionID,ResultPartitionBytes> resultPartitionBytes)IOMetrics(org.apache.flink.metrics.Meter recordsIn, org.apache.flink.metrics.Meter recordsOut, org.apache.flink.metrics.Meter bytesIn, org.apache.flink.metrics.Meter bytesOut, org.apache.flink.metrics.Gauge<Long> accumulatedBackPressuredTime, org.apache.flink.metrics.Gauge<Long> accumulatedIdleTime, org.apache.flink.metrics.Gauge<Double> accumulatedBusyTime, Map<IntermediateResultPartitionID,ResultPartitionBytesCounter> resultPartitionBytesCounters)
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description longgetAccumulateBackPressuredTime()doublegetAccumulateBusyTime()longgetAccumulateIdleTime()longgetNumBytesIn()longgetNumBytesOut()longgetNumRecordsIn()longgetNumRecordsOut()Map<IntermediateResultPartitionID,ResultPartitionBytes>getResultPartitionBytes()
-
-
-
Field Detail
-
numRecordsIn
protected long numRecordsIn
-
numRecordsOut
protected long numRecordsOut
-
numBytesIn
protected long numBytesIn
-
numBytesOut
protected long numBytesOut
-
accumulateBackPressuredTime
protected long accumulateBackPressuredTime
-
accumulateBusyTime
protected double accumulateBusyTime
-
accumulateIdleTime
protected long accumulateIdleTime
-
resultPartitionBytes
@Nullable protected Map<IntermediateResultPartitionID,ResultPartitionBytes> resultPartitionBytes
-
-
Constructor Detail
-
IOMetrics
public IOMetrics(org.apache.flink.metrics.Meter recordsIn, org.apache.flink.metrics.Meter recordsOut, org.apache.flink.metrics.Meter bytesIn, org.apache.flink.metrics.Meter bytesOut, org.apache.flink.metrics.Gauge<Long> accumulatedBackPressuredTime, org.apache.flink.metrics.Gauge<Long> accumulatedIdleTime, org.apache.flink.metrics.Gauge<Double> accumulatedBusyTime, Map<IntermediateResultPartitionID,ResultPartitionBytesCounter> resultPartitionBytesCounters)
-
IOMetrics
public IOMetrics(long numBytesIn, long numBytesOut, long numRecordsIn, long numRecordsOut, long accumulateIdleTime, double accumulateBusyTime, long accumulateBackPressuredTime)
-
IOMetrics
@VisibleForTesting public IOMetrics(long numBytesIn, long numBytesOut, long numRecordsIn, long numRecordsOut, long accumulateIdleTime, double accumulateBusyTime, long accumulateBackPressuredTime, @Nullable Map<IntermediateResultPartitionID,ResultPartitionBytes> resultPartitionBytes)
-
-
Method Detail
-
getNumRecordsIn
public long getNumRecordsIn()
-
getNumRecordsOut
public long getNumRecordsOut()
-
getNumBytesIn
public long getNumBytesIn()
-
getNumBytesOut
public long getNumBytesOut()
-
getAccumulateBusyTime
public double getAccumulateBusyTime()
-
getAccumulateBackPressuredTime
public long getAccumulateBackPressuredTime()
-
getAccumulateIdleTime
public long getAccumulateIdleTime()
-
getResultPartitionBytes
public Map<IntermediateResultPartitionID,ResultPartitionBytes> getResultPartitionBytes()
-
-