Interface MetricsContainer

All Superinterfaces:
Serializable
All Known Implementing Classes:
JetMetricsContainer

public interface MetricsContainer extends Serializable
Holds the metrics for a single step. Each of the methods should return an implementation of the appropriate metrics interface for the "current" step.
  • Method Details

    • getCounter

      Counter getCounter(MetricName metricName)
      Return the Counter that should be used for implementing the given metricName in this container.
    • getPerWorkerCounter

      default Counter getPerWorkerCounter(MetricName metricName)
      Return the Counter that should be used for implementing the given per-worker invalid input: '{@code metricName) in this container.'
    • getDistribution

      Distribution getDistribution(MetricName metricName)
      Return the Distribution that should be used for implementing the given metricName in this container.
    • getGauge

      Gauge getGauge(MetricName metricName)
      Return the Gauge that should be used for implementing the given metricName in this container.
    • getStringSet

      StringSet getStringSet(MetricName metricName)
      Return the StringSet that should be used for implementing the given metricName in this container.
    • getBoundedTrie

      BoundedTrie getBoundedTrie(MetricName metricName)
      Return the BoundedTrie that should be used for implementing the given metricName in this container.
    • getHistogram

      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.
    • getMonitoringInfos

      default Iterable<org.apache.beam.model.pipeline.v1.MetricsApi.MonitoringInfo> getMonitoringInfos()
      Return the cumulative values for any metrics in this container as MonitoringInfos.