public class DoFnRunnerWithMetricsUpdate<InputT,OutputT>
extends java.lang.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 and Description |
---|
DoFnRunnerWithMetricsUpdate(java.lang.String stepName,
org.apache.beam.runners.core.DoFnRunner<InputT,OutputT> delegate,
org.apache.flink.api.common.functions.RuntimeContext runtimeContext) |
Modifier and Type | Method and Description |
---|---|
void |
finishBundle()
Calls a
DoFn's @FinishBundle method and performs
additional tasks, such as flushing in-memory states. |
void |
onTimer(java.lang.String timerId,
BoundedWindow window,
Instant timestamp,
TimeDomain timeDomain)
Calls a
DoFn's @OnTimer method for the given timer
in the given window. |
void |
processElement(org.apache.beam.sdk.util.WindowedValue<InputT> elem)
|
void |
startBundle()
Prepares and calls a
DoFn's @StartBundle method. |
public void startBundle()
org.apache.beam.runners.core.DoFnRunner
DoFn's
@StartBundle
method.public void processElement(org.apache.beam.sdk.util.WindowedValue<InputT> elem)
org.apache.beam.runners.core.DoFnRunner
public void onTimer(java.lang.String timerId, BoundedWindow window, Instant timestamp, TimeDomain timeDomain)
org.apache.beam.runners.core.DoFnRunner
DoFn's
@OnTimer
method for the given timer
in the given window.public void finishBundle()
org.apache.beam.runners.core.DoFnRunner
DoFn's
@FinishBundle
method and performs
additional tasks, such as flushing in-memory states.