KS
- The key type of the input keyed stream.IN1
- The input type of the keyed (non-broadcast) side.IN2
- The input type of the broadcast side.OUT
- The output type of the operator.@Internal public class BatchCoBroadcastWithKeyedOperator<KS,IN1,IN2,OUT> extends CoBroadcastWithKeyedOperator<KS,IN1,IN2,OUT> implements BoundedMultiInput
TwoInputStreamOperator
for executing KeyedBroadcastProcessFunctions
in RuntimeExecutionMode.BATCH
execution mode.
Compared to CoBroadcastWithKeyedOperator
this does an additional sanity check on the
input processing order requirement.
userFunction
chainingStrategy, config, lastRecordAttributes1, lastRecordAttributes2, latencyStats, LOG, metrics, output, processingTimeService, stateHandler, stateKeySelector1, stateKeySelector2, timeServiceManager
Constructor and Description |
---|
BatchCoBroadcastWithKeyedOperator(KeyedBroadcastProcessFunction<KS,IN1,IN2,OUT> function,
List<MapStateDescriptor<?,?>> broadcastStateDescriptors) |
Modifier and Type | Method and Description |
---|---|
void |
endInput(int inputId)
It is notified that no more data will arrive from the input identified by the
inputId . |
void |
processElement1(StreamRecord<IN1> element)
Processes one element that arrived on the first input of this two-input operator.
|
onEventTime, onProcessingTime, open, 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, getStateKeySelector1, getStateKeySelector2, getTimeServiceManager, getUserCodeClassloader, hasKeyContext1, hasKeyContext2, initializeState, isUsingCustomRawKeyedState, prepareSnapshotPreBarrier, processLatencyMarker, processLatencyMarker1, processLatencyMarker2, processRecordAttributes, processRecordAttributes1, processRecordAttributes2, processWatermark, processWatermark1, processWatermark2, processWatermarkStatus, processWatermarkStatus1, processWatermarkStatus2, reportOrForwardLatencyMarker, setChainingStrategy, setCurrentKey, setKeyContextElement1, setKeyContextElement2, setMailboxExecutor, setProcessingTimeService, snapshotState, useSplittableTimers
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
processLatencyMarker1, processLatencyMarker2, processRecordAttributes1, processRecordAttributes2, processWatermark1, processWatermark2, processWatermarkStatus1, processWatermarkStatus2
close, finish, getMetricGroup, getOperatorAttributes, getOperatorID, initializeState, prepareSnapshotPreBarrier, setKeyContextElement1, setKeyContextElement2, snapshotState
notifyCheckpointAborted, notifyCheckpointComplete
getCurrentKey, setCurrentKey
hasKeyContext
public BatchCoBroadcastWithKeyedOperator(KeyedBroadcastProcessFunction<KS,IN1,IN2,OUT> function, List<MapStateDescriptor<?,?>> broadcastStateDescriptors)
public void endInput(int inputId) throws Exception
BoundedMultiInput
inputId
. The inputId
is numbered starting from 1, and `1` indicates the first input.
WARNING: It is not safe to use this method to commit any transactions or other side
effects! You can use this method to e.g. flush data buffered for the given input or implement
an ordered reading from multiple inputs via InputSelectable
.
endInput
in interface BoundedMultiInput
Exception
public void processElement1(StreamRecord<IN1> element) throws Exception
TwoInputStreamOperator
processElement1
in interface TwoInputStreamOperator<IN1,IN2,OUT>
processElement1
in class CoBroadcastWithKeyedOperator<KS,IN1,IN2,OUT>
Exception
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.