public class KeyedCoProcessOperatorWithWatermarkDelay<K,IN1,IN2,OUT> extends KeyedCoProcessOperator<K,IN1,IN2,OUT>
KeyedCoProcessOperator
that supports holding back watermarks with a static delay.userFunction
chainingStrategy, config, latencyStats, LOG, metrics, output, processingTimeService
Constructor and Description |
---|
KeyedCoProcessOperatorWithWatermarkDelay(KeyedCoProcessFunction<K,IN1,IN2,OUT> flatMapper,
long watermarkDelay) |
Modifier and Type | Method and Description |
---|---|
void |
processWatermark(Watermark mark) |
getCollector, onEventTime, onProcessingTime, open, processElement1, processElement2
close, finish, getUserFunction, getUserFunctionParameters, initializeState, notifyCheckpointAborted, notifyCheckpointComplete, setOutputType, setup, snapshotState
getChainingStrategy, getContainingTask, getCurrentKey, getExecutionConfig, getInternalTimerService, getKeyedStateBackend, getKeyedStateStore, getMetricGroup, getOperatorConfig, getOperatorID, getOperatorName, getOperatorStateBackend, getOrCreateKeyedState, getPartitionedState, getPartitionedState, getProcessingTimeService, getRuntimeContext, getTimeServiceManager, getUserCodeClassloader, hasKeyContext1, hasKeyContext2, initializeState, isUsingCustomRawKeyedState, prepareSnapshotPreBarrier, processLatencyMarker, processLatencyMarker1, processLatencyMarker2, processWatermark1, processWatermark2, processWatermarkStatus, processWatermarkStatus1, processWatermarkStatus2, reportOrForwardLatencyMarker, setChainingStrategy, setCurrentKey, setKeyContextElement1, setKeyContextElement2, setProcessingTimeService, snapshotState
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
processLatencyMarker1, processLatencyMarker2, processWatermark1, processWatermark2, processWatermarkStatus1, processWatermarkStatus2
close, finish, getMetricGroup, getOperatorID, initializeState, prepareSnapshotPreBarrier, setKeyContextElement1, setKeyContextElement2, snapshotState
notifyCheckpointAborted, notifyCheckpointComplete
getCurrentKey, setCurrentKey
hasKeyContext
public KeyedCoProcessOperatorWithWatermarkDelay(KeyedCoProcessFunction<K,IN1,IN2,OUT> flatMapper, long watermarkDelay)
public void processWatermark(Watermark mark) throws Exception
processWatermark
in class AbstractStreamOperator<OUT>
Exception
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.