Class DoFnRunnerWithMetrics<InputT,OutputT>

java.lang.Object
org.apache.beam.runners.spark.translation.DoFnRunnerWithMetrics<InputT,OutputT>
All Implemented Interfaces:
org.apache.beam.runners.core.DoFnRunner<InputT,OutputT>

public class DoFnRunnerWithMetrics<InputT,OutputT> extends Object implements org.apache.beam.runners.core.DoFnRunner<InputT,OutputT>
DoFnRunner decorator which registers MetricsContainerImpl.
  • Constructor Details

  • Method Details

    • getFn

      public DoFn<InputT,OutputT> getFn()
      Specified by:
      getFn in interface org.apache.beam.runners.core.DoFnRunner<InputT,OutputT>
    • 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>