Class IOMetrics

    • 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
    • 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()