public abstract class MultipleInputStreamOperatorBase extends AbstractStreamOperatorV2<RowData> implements MultipleInputStreamOperator<RowData>
MultipleInputStreamOperator
to handle multiple inputs in table module.Modifier and Type | Field and Description |
---|---|
protected Map<Integer,InputSpec> |
inputSpecMap |
protected Deque<TableOperatorWrapper<?>> |
topologicalOrderingOperators
all operator as topological ordering in this multiple input operator.
|
config, latencyStats, LOG, metrics, output, processingTimeService
Constructor and Description |
---|
MultipleInputStreamOperatorBase(StreamOperatorParameters<RowData> parameters,
List<InputSpec> inputSpecs,
List<TableOperatorWrapper<?>> headWrappers,
TableOperatorWrapper<?> tailWrapper) |
Modifier and Type | Method and Description |
---|---|
void |
close()
Closes all sub-operators in a multiple input operator effect way.
|
protected StreamConfig |
createStreamConfig(StreamOperatorParameters<RowData> multipleInputOperatorParameters,
TableOperatorWrapper<?> wrapper) |
void |
finish()
Finish all sub-operators in a multiple input operator effect way.
|
List<Input> |
getInputs() |
void |
open()
Open all sub-operators in a multiple input operator from tail to head, contrary to
StreamOperator.close() which happens head to tail (see close() ). |
getCurrentKey, getExecutionConfig, getInternalTimerService, getKeyedStateBackend, getKeyedStateStore, getMetricGroup, getOperatorConfig, getOperatorID, getOperatorName, getOperatorStateBackend, getOrCreateKeyedState, getPartitionedState, getPartitionedState, getProcessingTimeService, getRuntimeContext, getTimeServiceManager, getUserCodeClassloader, initializeState, initializeState, internalSetKeyContextElement, isUsingCustomRawKeyedState, notifyCheckpointAborted, notifyCheckpointComplete, prepareSnapshotPreBarrier, processWatermark, processWatermarkStatus, reportOrForwardLatencyMarker, reportWatermark, setCurrentKey, setKeyContextElement1, setKeyContextElement2, snapshotState, snapshotState
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
getMetricGroup, getOperatorID, initializeState, prepareSnapshotPreBarrier, setKeyContextElement1, setKeyContextElement2, snapshotState
notifyCheckpointAborted, notifyCheckpointComplete
getCurrentKey, setCurrentKey
protected final Deque<TableOperatorWrapper<?>> topologicalOrderingOperators
public MultipleInputStreamOperatorBase(StreamOperatorParameters<RowData> parameters, List<InputSpec> inputSpecs, List<TableOperatorWrapper<?>> headWrappers, TableOperatorWrapper<?> tailWrapper)
public List<Input> getInputs()
getInputs
in interface MultipleInputStreamOperator<RowData>
public void open() throws Exception
StreamOperator.close()
which happens head to tail (see close()
).open
in interface StreamOperator<RowData>
open
in class AbstractStreamOperatorV2<RowData>
Exception
- An exception in this method causes the operator to fail.public void finish() throws Exception
StreamOperator.open()
which happens tail to head.finish
in interface StreamOperator<RowData>
finish
in class AbstractStreamOperatorV2<RowData>
Exception
- An exception in this method causes the operator to fail.public void close() throws Exception
StreamOperator.open()
which happens tail to head.close
in interface StreamOperator<RowData>
close
in class AbstractStreamOperatorV2<RowData>
Exception
protected StreamConfig createStreamConfig(StreamOperatorParameters<RowData> multipleInputOperatorParameters, TableOperatorWrapper<?> wrapper)
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.