T
- The type of the input elementspublic class TimestampsAndPunctuatedWatermarksOperator<T> extends AbstractUdfStreamOperator<T,AssignerWithPunctuatedWatermarks<T>> implements OneInputStreamOperator<T,T>
AbstractStreamOperator.CountingOutput<OUT>
userFunction
chainingStrategy, config, latencyStats, LOG, metrics, output, timeServiceManager
Constructor and Description |
---|
TimestampsAndPunctuatedWatermarksOperator(AssignerWithPunctuatedWatermarks<T> assigner) |
Modifier and Type | Method and Description |
---|---|
void |
processElement(StreamRecord<T> element)
Processes one element that arrived at this operator.
|
void |
processWatermark(Watermark mark)
Override the base implementation to completely ignore watermarks propagated from
upstream (we rely only on the
AssignerWithPunctuatedWatermarks to emit
watermarks from here). |
close, dispose, getUserFunction, getUserFunctionParameters, initializeState, notifyCheckpointComplete, open, setOutputType, setup, snapshotState
getChainingStrategy, getContainingTask, getCurrentKey, getExecutionConfig, getInternalTimerService, getKeyedStateBackend, getKeyedStateStore, getMetricGroup, getOperatorConfig, getOperatorID, getOperatorName, getOperatorStateBackend, getOrCreateKeyedState, getPartitionedState, getPartitionedState, getProcessingTimeService, getRuntimeContext, getUserCodeClassloader, initializeState, numEventTimeTimers, numProcessingTimeTimers, prepareSnapshotPreBarrier, processLatencyMarker, processLatencyMarker1, processLatencyMarker2, processWatermark1, processWatermark2, reportOrForwardLatencyMarker, setChainingStrategy, setCurrentKey, setKeyContextElement1, setKeyContextElement2, snapshotState
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
processLatencyMarker
close, dispose, getChainingStrategy, getMetricGroup, getOperatorID, initializeState, open, prepareSnapshotPreBarrier, setChainingStrategy, setKeyContextElement1, setKeyContextElement2, setup, snapshotState
notifyCheckpointComplete
getCurrentKey, setCurrentKey
public TimestampsAndPunctuatedWatermarksOperator(AssignerWithPunctuatedWatermarks<T> assigner)
public void processElement(StreamRecord<T> element) throws Exception
OneInputStreamOperator
processElement
in interface OneInputStreamOperator<T,T>
Exception
public void processWatermark(Watermark mark) throws Exception
AssignerWithPunctuatedWatermarks
to emit
watermarks from here).processWatermark
in interface OneInputStreamOperator<T,T>
processWatermark
in class AbstractStreamOperator<T>
Exception
Watermark
Copyright © 2014–2020 The Apache Software Foundation. All rights reserved.