IN
- The type of the incoming elements.ACC
- The type of elements stored in the window buffers.OUT
- The type of elements emitted by the WindowFunction
.W
- The type of Window
that the WindowAssigner
assigns.@Internal public class EvictingNonKeyedWindowOperator<IN,ACC,OUT,W extends Window> extends NonKeyedWindowOperator<IN,ACC,OUT,W>
EvictingWindowOperator
,
Serialized FormNonKeyedWindowOperator.Context
currentWatermark, timestampedCollector, windows
userFunction
chainingStrategy, output
Constructor and Description |
---|
EvictingNonKeyedWindowOperator(WindowAssigner<? super IN,W> windowAssigner,
TypeSerializer<W> windowSerializer,
WindowBufferFactory<? super IN,ACC,? extends EvictingWindowBuffer<IN,ACC>> windowBufferFactory,
AllWindowFunction<ACC,OUT,W> windowFunction,
Trigger<? super IN,? super W> trigger,
Evictor<? super IN,? super W> evictor) |
Modifier and Type | Method and Description |
---|---|
protected void |
emitWindow(NonKeyedWindowOperator.Context context) |
Evictor<? super IN,? super W> |
getEvictor() |
dispose, getTrigger, getWindowAssigner, getWindowBufferFactory, open, processElement, processWatermark, restoreState, setInputType, snapshotOperatorState, trigger
close, getUserFunction, getUserFunctionParameters, notifyOfCompletedCheckpoint, setOutputType, setup
disableInputCopy, getChainingStrategy, getContainingTask, getExecutionConfig, getOperatorConfig, getPartitionedState, getPartitionedState, getRuntimeContext, getStateBackend, getUserCodeClassloader, isInputCopyingDisabled, registerTimer, setChainingStrategy, setKeyContext, setKeyContextElement1, setKeyContextElement2
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
close, getChainingStrategy, isInputCopyingDisabled, notifyOfCompletedCheckpoint, setChainingStrategy, setKeyContextElement1, setKeyContextElement2, setup
public EvictingNonKeyedWindowOperator(WindowAssigner<? super IN,W> windowAssigner, TypeSerializer<W> windowSerializer, WindowBufferFactory<? super IN,ACC,? extends EvictingWindowBuffer<IN,ACC>> windowBufferFactory, AllWindowFunction<ACC,OUT,W> windowFunction, Trigger<? super IN,? super W> trigger, Evictor<? super IN,? super W> evictor)
protected void emitWindow(NonKeyedWindowOperator.Context context) throws Exception
emitWindow
in class NonKeyedWindowOperator<IN,ACC,OUT,W extends Window>
Exception
Copyright © 2014–2017 The Apache Software Foundation. All rights reserved.