@Internal public class AccumulatingProcessingTimeWindowOperator<KEY,IN,OUT> extends AbstractAlignedProcessingTimeWindowOperator<KEY,IN,OUT,ArrayList<IN>,WindowFunction<IN,OUT,KEY,TimeWindow>>
userFunction
chainingStrategy, LOG, output
Constructor and Description |
---|
AccumulatingProcessingTimeWindowOperator(WindowFunction<IN,OUT,KEY,TimeWindow> function,
KeySelector<IN,KEY> keySelector,
TypeSerializer<KEY> keySerializer,
TypeSerializer<IN> valueSerializer,
long windowLength,
long windowSlide) |
Modifier and Type | Method and Description |
---|---|
protected AccumulatingKeyedTimePanes<IN,KEY,OUT> |
createPanes(KeySelector<IN,KEY> keySelector,
Function function) |
close, dispose, getNextEvaluationTime, getNextSlideTime, getNumPanesPerWindow, getPaneSize, getWindowSize, getWindowSlide, open, processElement, processWatermark, restoreState, snapshotOperatorState, toString, trigger
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, wait, wait, wait
getChainingStrategy, isInputCopyingDisabled, notifyOfCompletedCheckpoint, setChainingStrategy, setKeyContextElement1, setKeyContextElement2, setup
public AccumulatingProcessingTimeWindowOperator(WindowFunction<IN,OUT,KEY,TimeWindow> function, KeySelector<IN,KEY> keySelector, TypeSerializer<KEY> keySerializer, TypeSerializer<IN> valueSerializer, long windowLength, long windowSlide)
protected AccumulatingKeyedTimePanes<IN,KEY,OUT> createPanes(KeySelector<IN,KEY> keySelector, Function function)
createPanes
in class AbstractAlignedProcessingTimeWindowOperator<KEY,IN,OUT,ArrayList<IN>,WindowFunction<IN,OUT,KEY,TimeWindow>>
Copyright © 2014–2017 The Apache Software Foundation. All rights reserved.