Class FusionStreamOperatorBase
- java.lang.Object
-
- org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2<RowData>
-
- org.apache.flink.table.runtime.operators.fusion.FusionStreamOperatorBase
-
- All Implemented Interfaces:
Serializable
,CheckpointListener
,BoundedMultiInput
,InputSelectable
,KeyContext
,MultipleInputStreamOperator<RowData>
,StreamOperator<RowData>
,StreamOperatorStateHandler.CheckpointedStreamOperator
public abstract class FusionStreamOperatorBase extends AbstractStreamOperatorV2<RowData> implements MultipleInputStreamOperator<RowData>, InputSelectable, BoundedMultiInput
BaseMultipleInputStreamOperator
to handle multiple operator fusion codegen in table module.- See Also:
- Serialized Form
-
-
Field Summary
Fields Modifier and Type Field Description protected StreamOperatorParameters
parameters
-
Fields inherited from class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
combinedWatermark, config, lastRecordAttributes, latencyStats, LOG, metrics, output, processingTimeService, stateHandler, timeServiceManager
-
-
Constructor Summary
Constructors Constructor Description FusionStreamOperatorBase(StreamOperatorParameters<RowData> parameters, int numberOfInputs)
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description long
computeMemorySize(double operatorFraction)
StreamTask<?,?>
getContainingTask()
-
Methods inherited from class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
close, finish, getCurrentKey, getExecutionConfig, getInternalTimerService, getKeyedStateBackend, getKeyedStateStore, getMetricGroup, getOperatorConfig, getOperatorID, getOperatorName, getOperatorStateBackend, getOrCreateKeyedState, getPartitionedState, getPartitionedState, getProcessingTimeService, getRuntimeContext, getTimeServiceManager, getUserCodeClassloader, initializeState, initializeState, internalSetKeyContextElement, isAsyncStateProcessingEnabled, isUsingCustomRawKeyedState, notifyCheckpointAborted, notifyCheckpointComplete, open, prepareSnapshotPreBarrier, processRecordAttributes, processWatermark, processWatermarkStatus, reportOrForwardLatencyMarker, reportWatermark, setCurrentKey, setKeyContextElement1, setKeyContextElement2, snapshotState, 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.streaming.api.operators.BoundedMultiInput
endInput
-
Methods inherited from interface org.apache.flink.api.common.state.CheckpointListener
notifyCheckpointAborted, notifyCheckpointComplete
-
Methods inherited from interface org.apache.flink.streaming.api.operators.InputSelectable
nextSelection
-
Methods inherited from interface org.apache.flink.streaming.api.operators.KeyContext
getCurrentKey, setCurrentKey
-
Methods inherited from interface org.apache.flink.streaming.api.operators.MultipleInputStreamOperator
getInputs
-
Methods inherited from interface org.apache.flink.streaming.api.operators.StreamOperator
close, finish, getMetricGroup, getOperatorAttributes, getOperatorID, initializeState, open, prepareSnapshotPreBarrier, setKeyContextElement1, setKeyContextElement2, snapshotState
-
-
-
-
Field Detail
-
parameters
protected final StreamOperatorParameters parameters
-
-
Constructor Detail
-
FusionStreamOperatorBase
public FusionStreamOperatorBase(StreamOperatorParameters<RowData> parameters, int numberOfInputs)
-
-
Method Detail
-
getContainingTask
public StreamTask<?,?> getContainingTask()
-
computeMemorySize
public long computeMemorySize(double operatorFraction)
-
-