Class WindowDoFnOperator<K,InputT,OutputT>
java.lang.Object
org.apache.flink.streaming.api.operators.AbstractStreamOperator<WindowedValue<KV<K,OutputT>>>
org.apache.beam.runners.flink.translation.wrappers.streaming.DoFnOperator<KV<K,InputT>,org.apache.beam.runners.core.KeyedWorkItem<K,InputT>,KV<K,OutputT>>
org.apache.beam.runners.flink.translation.wrappers.streaming.WindowDoFnOperator<K,InputT,OutputT>
- All Implemented Interfaces:
Serializable
,org.apache.flink.api.common.state.CheckpointListener
,org.apache.flink.streaming.api.operators.Input<WindowedValue<KV<K,
,InputT>>> org.apache.flink.streaming.api.operators.KeyContext
,org.apache.flink.streaming.api.operators.KeyContextHandler
,org.apache.flink.streaming.api.operators.OneInputStreamOperator<WindowedValue<KV<K,
,InputT>>, WindowedValue<KV<K, OutputT>>> org.apache.flink.streaming.api.operators.SetupableStreamOperator<WindowedValue<KV<K,
,OutputT>>> org.apache.flink.streaming.api.operators.StreamOperator<WindowedValue<KV<K,
,OutputT>>> org.apache.flink.streaming.api.operators.StreamOperatorStateHandler.CheckpointedStreamOperator
,org.apache.flink.streaming.api.operators.Triggerable<FlinkKey,
,org.apache.beam.runners.core.TimerInternals.TimerData> org.apache.flink.streaming.api.operators.TwoInputStreamOperator<WindowedValue<KV<K,
InputT>>, RawUnionValue, WindowedValue<KV<K, OutputT>>>
public class WindowDoFnOperator<K,InputT,OutputT>
extends DoFnOperator<KV<K,InputT>,org.apache.beam.runners.core.KeyedWorkItem<K,InputT>,KV<K,OutputT>>
Flink operator for executing window
DoFns
.- See Also:
-
Nested Class Summary
Nested classes/interfaces inherited from class org.apache.beam.runners.flink.translation.wrappers.streaming.DoFnOperator
DoFnOperator.BufferedOutputManager<OutputT>, DoFnOperator.FlinkStepContext, DoFnOperator.MultiOutputOutputManagerFactory<OutputT>
-
Field Summary
Fields inherited from class org.apache.beam.runners.flink.translation.wrappers.streaming.DoFnOperator
additionalOutputTags, bufferingDoFnRunner, doFn, doFnRunner, keyedStateInternals, mainOutputTag, outputManager, outputManagerFactory, pushbackDoFnRunner, serializedOptions, sideInputHandler, sideInputReader, sideInputs, sideInputTagMapping, stepName, timerInternals, timerService, windowingStrategy
Fields inherited from class org.apache.flink.streaming.api.operators.AbstractStreamOperator
chainingStrategy, config, latencyStats, metrics, output, processingTimeService
-
Constructor Summary
ConstructorsConstructorDescriptionWindowDoFnOperator
(org.apache.beam.runners.core.SystemReduceFn<K, InputT, ?, OutputT, BoundedWindow> systemReduceFn, String stepName, Coder<WindowedValue<org.apache.beam.runners.core.KeyedWorkItem<K, InputT>>> windowedInputCoder, TupleTag<KV<K, OutputT>> mainOutputTag, List<TupleTag<?>> additionalOutputTags, org.apache.beam.runners.flink.translation.wrappers.streaming.DoFnOperator.OutputManagerFactory<KV<K, OutputT>> outputManagerFactory, WindowingStrategy<?, ?> windowingStrategy, Map<Integer, PCollectionView<?>> sideInputTagMapping, Collection<PCollectionView<?>> sideInputs, PipelineOptions options, Coder<K> keyCoder, org.apache.flink.api.java.functions.KeySelector<WindowedValue<org.apache.beam.runners.core.KeyedWorkItem<K, InputT>>, ?> keySelector) -
Method Summary
Modifier and TypeMethodDescriptionprotected org.apache.beam.runners.core.DoFnRunner
<org.apache.beam.runners.core.KeyedWorkItem<K, InputT>, KV<K, OutputT>> createWrappingDoFnRunner
(org.apache.beam.runners.core.DoFnRunner<org.apache.beam.runners.core.KeyedWorkItem<K, InputT>, KV<K, OutputT>> wrappedRunner, org.apache.beam.runners.core.StepContext stepContext) protected void
fireTimer
(org.apache.beam.runners.core.TimerInternals.TimerData timer) getDoFn()
protected Iterable
<WindowedValue<org.apache.beam.runners.core.KeyedWorkItem<K, InputT>>> preProcess
(WindowedValue<KV<K, InputT>> inWithMultipleWindows) Methods inherited from class org.apache.beam.runners.flink.translation.wrappers.streaming.DoFnOperator
addSideInputValue, applyInputWatermarkHold, applyOutputWatermarkHold, close, finish, fireTimerInternal, getBundleFinalizer, getCurrentOutputWatermark, getEffectiveInputWatermark, getLockToAcquireForStateAccessDuringBundles, initializeState, invokeFinishBundle, notifyCheckpointComplete, numProcessingTimeTimers, onEventTime, onProcessingTime, open, prepareSnapshotPreBarrier, processElement, processElement1, processElement2, processWatermark, processWatermark1, processWatermark2, scheduleForCurrentProcessingTime, setBundleFinishedCallback, setPreBundleCallback, setup, shoudBundleElements, snapshotState
Methods inherited from class org.apache.flink.streaming.api.operators.AbstractStreamOperator
getChainingStrategy, getContainingTask, getCurrentKey, getExecutionConfig, getInternalTimerService, getKeyedStateBackend, getKeyedStateStore, getMetricGroup, getOperatorConfig, getOperatorID, getOperatorName, getOperatorStateBackend, getOrCreateKeyedState, getPartitionedState, getPartitionedState, getProcessingTimeService, getRuntimeContext, getTimeServiceManager, getUserCodeClassloader, hasKeyContext1, hasKeyContext2, initializeState, isUsingCustomRawKeyedState, notifyCheckpointAborted, processLatencyMarker, processLatencyMarker1, processLatencyMarker2, processWatermarkStatus, processWatermarkStatus1, processWatermarkStatus2, reportOrForwardLatencyMarker, setChainingStrategy, setCurrentKey, setKeyContextElement1, setKeyContextElement2, setProcessingTimeService, snapshotState
Methods inherited from class java.lang.Object
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
Methods inherited from interface org.apache.flink.api.common.state.CheckpointListener
notifyCheckpointAborted
Methods inherited from interface org.apache.flink.streaming.api.operators.Input
processLatencyMarker, processWatermarkStatus
Methods inherited from interface org.apache.flink.streaming.api.operators.KeyContext
getCurrentKey, setCurrentKey
Methods inherited from interface org.apache.flink.streaming.api.operators.KeyContextHandler
hasKeyContext
Methods inherited from interface org.apache.flink.streaming.api.operators.OneInputStreamOperator
setKeyContextElement
Methods inherited from interface org.apache.flink.streaming.api.operators.StreamOperator
getMetricGroup, getOperatorID, initializeState, setKeyContextElement1, setKeyContextElement2, snapshotState
Methods inherited from interface org.apache.flink.streaming.api.operators.TwoInputStreamOperator
processLatencyMarker1, processLatencyMarker2, processWatermarkStatus1, processWatermarkStatus2
-
Constructor Details
-
WindowDoFnOperator
public WindowDoFnOperator(org.apache.beam.runners.core.SystemReduceFn<K, InputT, ?, OutputT, BoundedWindow> systemReduceFn, String stepName, Coder<WindowedValue<org.apache.beam.runners.core.KeyedWorkItem<K, InputT>>> windowedInputCoder, TupleTag<KV<K, OutputT>> mainOutputTag, List<TupleTag<?>> additionalOutputTags, org.apache.beam.runners.flink.translation.wrappers.streaming.DoFnOperator.OutputManagerFactory<KV<K, OutputT>> outputManagerFactory, WindowingStrategy<?, ?> windowingStrategy, Map<Integer, PCollectionView<?>> sideInputTagMapping, Collection<PCollectionView<?>> sideInputs, PipelineOptions options, Coder<K> keyCoder, org.apache.flink.api.java.functions.KeySelector<WindowedValue<org.apache.beam.runners.core.KeyedWorkItem<K, InputT>>, ?> keySelector)
-
-
Method Details
-
preProcess
protected Iterable<WindowedValue<org.apache.beam.runners.core.KeyedWorkItem<K,InputT>>> preProcess(WindowedValue<KV<K, InputT>> inWithMultipleWindows) - Overrides:
preProcess
in classDoFnOperator<KV<K,
InputT>, org.apache.beam.runners.core.KeyedWorkItem<K, InputT>, KV<K, OutputT>>
-
createWrappingDoFnRunner
protected org.apache.beam.runners.core.DoFnRunner<org.apache.beam.runners.core.KeyedWorkItem<K,InputT>, createWrappingDoFnRunnerKV<K, OutputT>> (org.apache.beam.runners.core.DoFnRunner<org.apache.beam.runners.core.KeyedWorkItem<K, InputT>, KV<K, OutputT>> wrappedRunner, org.apache.beam.runners.core.StepContext stepContext) - Overrides:
createWrappingDoFnRunner
in classDoFnOperator<KV<K,
InputT>, org.apache.beam.runners.core.KeyedWorkItem<K, InputT>, KV<K, OutputT>>
-
getDoFn
-
fireTimer
protected void fireTimer(org.apache.beam.runners.core.TimerInternals.TimerData timer)
-