@Internal public class AggregatingProcessingTimeWindowOperator<KEY,IN> extends AbstractAlignedProcessingTimeWindowOperator<KEY,IN,IN,IN,ReduceFunction<IN>>
userFunction
chainingStrategy, LOG, output
Constructor and Description |
---|
AggregatingProcessingTimeWindowOperator(ReduceFunction<IN> function,
KeySelector<IN,KEY> keySelector,
TypeSerializer<KEY> keySerializer,
TypeSerializer<IN> aggregateSerializer,
long windowLength,
long windowSlide) |
Modifier and Type | Method and Description |
---|---|
protected AggregatingKeyedTimePanes<IN,KEY> |
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 AggregatingProcessingTimeWindowOperator(ReduceFunction<IN> function, KeySelector<IN,KEY> keySelector, TypeSerializer<KEY> keySerializer, TypeSerializer<IN> aggregateSerializer, long windowLength, long windowSlide)
protected AggregatingKeyedTimePanes<IN,KEY> createPanes(KeySelector<IN,KEY> keySelector, Function function)
createPanes
in class AbstractAlignedProcessingTimeWindowOperator<KEY,IN,IN,IN,ReduceFunction<IN>>
Copyright © 2014–2017 The Apache Software Foundation. All rights reserved.