public interface MetricsContainer
extends java.io.Serializable
Modifier and Type | Method and Description |
---|---|
Counter |
getCounter(MetricName metricName)
Return the
Counter that should be used for implementing the given metricName in
this container. |
Distribution |
getDistribution(MetricName metricName)
Return the
Distribution that should be used for implementing the given metricName in this container. |
Gauge |
getGauge(MetricName metricName)
Return the
Gauge that should be used for implementing the given metricName in
this container. |
default Histogram |
getHistogram(MetricName metricName,
org.apache.beam.sdk.util.HistogramData.BucketType bucketType)
Return the
Histogram that should be used for implementing the given metricName
in this container. |
default java.lang.Iterable<org.apache.beam.model.pipeline.v1.MetricsApi.MonitoringInfo> |
getMonitoringInfos()
Return the cumulative values for any metrics in this container as MonitoringInfos.
|
default Counter |
getPerWorkerCounter(MetricName metricName)
Return the
Counter that should be used for implementing the given per-worker {@code metricName)
in this container. |
default Histogram |
getPerWorkerHistogram(MetricName metricName,
org.apache.beam.sdk.util.HistogramData.BucketType bucketType)
Return the
Histogram that should be used for implementing the given per-worker metricName in this container. |
Counter getCounter(MetricName metricName)
Counter
that should be used for implementing the given metricName
in
this container.default Counter getPerWorkerCounter(MetricName metricName)
Counter
that should be used for implementing the given per-worker {@code metricName)
in this container.Distribution getDistribution(MetricName metricName)
Distribution
that should be used for implementing the given metricName
in this container.Gauge getGauge(MetricName metricName)
Gauge
that should be used for implementing the given metricName
in
this container.default Histogram getHistogram(MetricName metricName, org.apache.beam.sdk.util.HistogramData.BucketType bucketType)
Histogram
that should be used for implementing the given metricName
in this container.default Histogram getPerWorkerHistogram(MetricName metricName, org.apache.beam.sdk.util.HistogramData.BucketType bucketType)
Histogram
that should be used for implementing the given per-worker metricName
in this container.default java.lang.Iterable<org.apache.beam.model.pipeline.v1.MetricsApi.MonitoringInfo> getMonitoringInfos()