public class BatchMultipleInputStreamOperator extends MultipleInputStreamOperatorBase implements BoundedMultiInput, InputSelectable
MultipleInputStreamOperatorBase
to handle batch operators.inputSpecMap, topologicalOrderingOperators
combinedWatermark, config, lastRecordAttributes, latencyStats, LOG, metrics, output, processingTimeService, stateHandler, timeServiceManager
Constructor and Description |
---|
BatchMultipleInputStreamOperator(StreamOperatorParameters<RowData> parameters,
List<InputSpec> inputSpecs,
List<TableOperatorWrapper<?>> headWrapper,
TableOperatorWrapper<?> tailWrapper) |
Modifier and Type | Method and Description |
---|---|
protected StreamConfig |
createStreamConfig(StreamOperatorParameters<RowData> multipleInputOperatorParameters,
TableOperatorWrapper<?> wrapper) |
void |
endInput(int inputId)
It is notified that no more data will arrive from the input identified by the
inputId . |
InputSelection |
nextSelection()
Returns the next
InputSelection that wants to get the record. |
close, finish, getInputs, open
getCurrentKey, getExecutionConfig, getInternalTimerService, getKeyedStateBackend, getKeyedStateStore, getMetricGroup, getOperatorConfig, getOperatorID, getOperatorName, getOperatorStateBackend, getOrCreateKeyedState, getPartitionedState, getPartitionedState, getProcessingTimeService, getRuntimeContext, getTimeServiceManager, getUserCodeClassloader, initializeState, initializeState, internalSetKeyContextElement, isUsingCustomRawKeyedState, notifyCheckpointAborted, notifyCheckpointComplete, prepareSnapshotPreBarrier, processRecordAttributes, processWatermark, processWatermarkStatus, reportOrForwardLatencyMarker, reportWatermark, setCurrentKey, setKeyContextElement1, setKeyContextElement2, snapshotState, snapshotState, useSplittableTimers
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
getMetricGroup, getOperatorAttributes, getOperatorID, initializeState, prepareSnapshotPreBarrier, setKeyContextElement1, setKeyContextElement2, snapshotState
notifyCheckpointAborted, notifyCheckpointComplete
getCurrentKey, setCurrentKey
public BatchMultipleInputStreamOperator(StreamOperatorParameters<RowData> parameters, List<InputSpec> inputSpecs, List<TableOperatorWrapper<?>> headWrapper, TableOperatorWrapper<?> tailWrapper)
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 InputSelection nextSelection()
InputSelectable
InputSelection
that wants to get the record. This method is
guaranteed to not be called concurrently with other methods of the operator.nextSelection
in interface InputSelectable
protected StreamConfig createStreamConfig(StreamOperatorParameters<RowData> multipleInputOperatorParameters, TableOperatorWrapper<?> wrapper)
createStreamConfig
in class MultipleInputStreamOperatorBase
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.