Class InternalSourceReaderMetricGroup
- java.lang.Object
-
- org.apache.flink.runtime.metrics.groups.ProxyMetricGroup<org.apache.flink.metrics.MetricGroup>
-
- org.apache.flink.runtime.metrics.groups.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
SpecialMetricGroup
representing an Operator.
-
-
Field Summary
Fields Modifier and Type Field Description static long
UNDEFINED
-
Fields inherited from class org.apache.flink.runtime.metrics.groups.ProxyMetricGroup
parentMetricGroup
-
-
Method Summary
All Methods Static Methods Instance Methods Concrete Methods Modifier and Type Method Description org.apache.flink.metrics.groups.OperatorIOMetricGroup
getIOMetricGroup()
org.apache.flink.metrics.Counter
getNumRecordsInErrorsCounter()
void
idlingStarted()
static InternalSourceReaderMetricGroup
mock(org.apache.flink.metrics.MetricGroup metricGroup)
void
recordEmitted(long timestamp)
Called when a new record was emitted with the given timestamp.void
setPendingBytesGauge(org.apache.flink.metrics.Gauge<Long> pendingBytesGauge)
void
setPendingRecordsGauge(org.apache.flink.metrics.Gauge<Long> pendingRecordsGauge)
void
updateMaxDesiredWatermark(long currentMaxDesiredWatermark)
void
watermarkEmitted(long watermark)
Called when a watermark was emitted.static InternalSourceReaderMetricGroup
wrap(org.apache.flink.metrics.groups.OperatorMetricGroup operatorMetricGroup)
-
Methods inherited from class org.apache.flink.runtime.metrics.groups.ProxyMetricGroup
addGroup, addGroup, addSpan, counter, counter, gauge, getAllVariables, getMetricIdentifier, getMetricIdentifier, getScopeComponents, histogram, meter
-
-
-
-
Field Detail
-
UNDEFINED
public static final long UNDEFINED
- See Also:
- Constant Field Values
-
-
Method Detail
-
wrap
public static InternalSourceReaderMetricGroup wrap(org.apache.flink.metrics.groups.OperatorMetricGroup operatorMetricGroup)
-
mock
@VisibleForTesting public static InternalSourceReaderMetricGroup mock(org.apache.flink.metrics.MetricGroup metricGroup)
-
getNumRecordsInErrorsCounter
public org.apache.flink.metrics.Counter getNumRecordsInErrorsCounter()
- Specified by:
getNumRecordsInErrorsCounter
in interfaceorg.apache.flink.metrics.groups.SourceReaderMetricGroup
-
setPendingBytesGauge
public void setPendingBytesGauge(org.apache.flink.metrics.Gauge<Long> pendingBytesGauge)
- Specified by:
setPendingBytesGauge
in interfaceorg.apache.flink.metrics.groups.SourceReaderMetricGroup
-
setPendingRecordsGauge
public void setPendingRecordsGauge(org.apache.flink.metrics.Gauge<Long> pendingRecordsGauge)
- Specified by:
setPendingRecordsGauge
in interfaceorg.apache.flink.metrics.groups.SourceReaderMetricGroup
-
getIOMetricGroup
public org.apache.flink.metrics.groups.OperatorIOMetricGroup getIOMetricGroup()
- Specified by:
getIOMetricGroup
in interfaceorg.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)
-
-