Class DoFnRunnerWithMetricsUpdate<InputT,OutputT>

java.lang.Object
org.apache.beam.runners.flink.metrics.DoFnRunnerWithMetricsUpdate<InputT,OutputT>
All Implemented Interfaces:
org.apache.beam.runners.core.DoFnRunner<InputT,OutputT>

public class DoFnRunnerWithMetricsUpdate<InputT,OutputT> extends Object implements org.apache.beam.runners.core.DoFnRunner<InputT,OutputT>
DoFnRunner decorator which registers MetricsContainerImpl. It updates metrics to Flink metrics and accumulators in finishBundle().
  • Constructor Details

  • Method Details

    • startBundle

      public void startBundle()
      Specified by:
      startBundle in interface org.apache.beam.runners.core.DoFnRunner<InputT,OutputT>
    • processElement

      public void processElement(WindowedValue<InputT> elem)
      Specified by:
      processElement in interface org.apache.beam.runners.core.DoFnRunner<InputT,OutputT>
    • onTimer

      public <KeyT> void onTimer(String timerId, String timerFamilyId, KeyT key, BoundedWindow window, Instant timestamp, Instant outputTimestamp, TimeDomain timeDomain)
      Specified by:
      onTimer in interface org.apache.beam.runners.core.DoFnRunner<InputT,OutputT>
    • finishBundle

      public void finishBundle()
      Specified by:
      finishBundle in interface org.apache.beam.runners.core.DoFnRunner<InputT,OutputT>
    • onWindowExpiration

      public <KeyT> void onWindowExpiration(BoundedWindow window, Instant timestamp, KeyT key)
      Specified by:
      onWindowExpiration in interface org.apache.beam.runners.core.DoFnRunner<InputT,OutputT>
    • getFn

      public DoFn<InputT,OutputT> getFn()
      Specified by:
      getFn in interface org.apache.beam.runners.core.DoFnRunner<InputT,OutputT>