Class InternalSourceReaderMetricGroup

  • All Implemented Interfaces:
    org.apache.flink.metrics.groups.OperatorMetricGroup, org.apache.flink.metrics.groups.SourceReaderMetricGroup, org.apache.flink.metrics.MetricGroup

    @Internal
    public class InternalSourceReaderMetricGroup
    extends ProxyMetricGroup<org.apache.flink.metrics.MetricGroup>
    implements org.apache.flink.metrics.groups.SourceReaderMetricGroup
    Special MetricGroup representing an Operator.
    • Method Detail

      • getNumRecordsInErrorsCounter

        public org.apache.flink.metrics.Counter getNumRecordsInErrorsCounter()
        Specified by:
        getNumRecordsInErrorsCounter in interface org.apache.flink.metrics.groups.SourceReaderMetricGroup
      • setPendingBytesGauge

        public void setPendingBytesGauge​(org.apache.flink.metrics.Gauge<Long> pendingBytesGauge)
        Specified by:
        setPendingBytesGauge in interface org.apache.flink.metrics.groups.SourceReaderMetricGroup
      • setPendingRecordsGauge

        public void setPendingRecordsGauge​(org.apache.flink.metrics.Gauge<Long> pendingRecordsGauge)
        Specified by:
        setPendingRecordsGauge in interface org.apache.flink.metrics.groups.SourceReaderMetricGroup
      • getIOMetricGroup

        public org.apache.flink.metrics.groups.OperatorIOMetricGroup getIOMetricGroup()
        Specified by:
        getIOMetricGroup in interface org.apache.flink.metrics.groups.OperatorMetricGroup
      • recordEmitted

        public void recordEmitted​(long timestamp)
        Called when a new record was emitted with the given timestamp. TimestampAssigner.NO_TIMESTAMP should be indicated that the record did not have a timestamp.

        Note this function should be called before the actual record is emitted such that chained processing does not influence the statistics.

      • idlingStarted

        public void idlingStarted()
      • watermarkEmitted

        public void watermarkEmitted​(long watermark)
        Called when a watermark was emitted.

        Note this function should be called before the actual watermark is emitted such that chained processing does not influence the statistics.

      • updateMaxDesiredWatermark

        public void updateMaxDesiredWatermark​(long currentMaxDesiredWatermark)