Class KeyedCoProcessOperatorWithWatermarkDelay<K,IN1,IN2,OUT>
- java.lang.Object
-
- org.apache.flink.streaming.api.operators.AbstractStreamOperator<OUT>
-
- org.apache.flink.streaming.api.operators.AbstractUdfStreamOperator<OUT,KeyedCoProcessFunction<K,IN1,IN2,OUT>>
-
- org.apache.flink.streaming.api.operators.co.KeyedCoProcessOperator<K,IN1,IN2,OUT>
-
- org.apache.flink.table.runtime.operators.join.KeyedCoProcessOperatorWithWatermarkDelay<K,IN1,IN2,OUT>
-
- All Implemented Interfaces:
Serializable
,CheckpointListener
,KeyContext
,KeyContextHandler
,OutputTypeConfigurable<OUT>
,StreamOperator<OUT>
,StreamOperatorStateHandler.CheckpointedStreamOperator
,Triggerable<K,VoidNamespace>
,TwoInputStreamOperator<IN1,IN2,OUT>
,UserFunctionProvider<KeyedCoProcessFunction<K,IN1,IN2,OUT>>
,YieldingOperator<OUT>
public class KeyedCoProcessOperatorWithWatermarkDelay<K,IN1,IN2,OUT> extends KeyedCoProcessOperator<K,IN1,IN2,OUT>
AKeyedCoProcessOperator
that supports holding back watermarks with a static delay.- See Also:
- Serialized Form
-
-
Field Summary
-
Fields inherited from class org.apache.flink.streaming.api.operators.AbstractUdfStreamOperator
userFunction
-
Fields inherited from class org.apache.flink.streaming.api.operators.AbstractStreamOperator
config, lastRecordAttributes1, lastRecordAttributes2, latencyStats, LOG, metrics, output, processingTimeService, stateHandler, stateKeySelector1, stateKeySelector2, timeServiceManager
-
-
Constructor Summary
Constructors Constructor Description KeyedCoProcessOperatorWithWatermarkDelay(KeyedCoProcessFunction<K,IN1,IN2,OUT> flatMapper, long watermarkDelay)
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description void
processWatermark(Watermark mark)
-
Methods inherited from class org.apache.flink.streaming.api.operators.co.KeyedCoProcessOperator
getCollector, onEventTime, onProcessingTime, open, processElement1, processElement2
-
Methods inherited from class org.apache.flink.streaming.api.operators.AbstractUdfStreamOperator
close, finish, getUserFunction, getUserFunctionParameters, initializeState, notifyCheckpointAborted, notifyCheckpointComplete, setOutputType, setup, snapshotState
-
Methods inherited from class org.apache.flink.streaming.api.operators.AbstractStreamOperator
getContainingTask, getCurrentKey, getExecutionConfig, getInternalTimerService, getKeyedStateBackend, getKeyedStateStore, getMetricGroup, getOperatorConfig, getOperatorID, getOperatorName, getOperatorStateBackend, getOrCreateKeyedState, getPartitionedState, getPartitionedState, getProcessingTimeService, getRuntimeContext, getStateKeySelector1, getStateKeySelector2, getTimeServiceManager, getUserCodeClassloader, hasKeyContext1, hasKeyContext2, initializeState, isUsingCustomRawKeyedState, prepareSnapshotPreBarrier, processLatencyMarker, processLatencyMarker1, processLatencyMarker2, processRecordAttributes, processRecordAttributes1, processRecordAttributes2, processWatermark1, processWatermark2, processWatermarkStatus, processWatermarkStatus1, processWatermarkStatus2, reportOrForwardLatencyMarker, setCurrentKey, setKeyContextElement1, setKeyContextElement2, setMailboxExecutor, setProcessingTimeService, snapshotState, useSplittableTimers
-
Methods inherited from class java.lang.Object
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
-
Methods inherited from interface org.apache.flink.api.common.state.CheckpointListener
notifyCheckpointAborted, notifyCheckpointComplete
-
Methods inherited from interface org.apache.flink.streaming.api.operators.KeyContext
getCurrentKey, setCurrentKey
-
Methods inherited from interface org.apache.flink.streaming.api.operators.KeyContextHandler
hasKeyContext
-
Methods inherited from interface org.apache.flink.streaming.api.operators.StreamOperator
close, finish, getMetricGroup, getOperatorAttributes, getOperatorID, initializeState, prepareSnapshotPreBarrier, setKeyContextElement1, setKeyContextElement2, snapshotState
-
Methods inherited from interface org.apache.flink.streaming.api.operators.TwoInputStreamOperator
processLatencyMarker1, processLatencyMarker2, processRecordAttributes1, processRecordAttributes2, processWatermark1, processWatermark2, processWatermarkStatus1, processWatermarkStatus2
-
-
-
-
Constructor Detail
-
KeyedCoProcessOperatorWithWatermarkDelay
public KeyedCoProcessOperatorWithWatermarkDelay(KeyedCoProcessFunction<K,IN1,IN2,OUT> flatMapper, long watermarkDelay)
-
-
Method Detail
-
processWatermark
public void processWatermark(Watermark mark) throws Exception
- Overrides:
processWatermark
in classAbstractStreamOperator<OUT>
- Throws:
Exception
-
-