public abstract class FusionStreamOperatorBase extends AbstractStreamOperatorV2<RowData> implements MultipleInputStreamOperator<RowData>, InputSelectable, BoundedMultiInput
MultipleInputStreamOperator
to handle multiple operator fusion codegen in table
module.Modifier and Type | Field and Description |
---|---|
protected StreamOperatorParameters |
parameters |
combinedWatermark, config, lastRecordAttributes, latencyStats, LOG, metrics, output, processingTimeService, stateHandler, timeServiceManager
Constructor and Description |
---|
FusionStreamOperatorBase(StreamOperatorParameters<RowData> parameters,
int numberOfInputs) |
Modifier and Type | Method and Description |
---|---|
long |
computeMemorySize(double operatorFraction) |
StreamTask<?,?> |
getContainingTask() |
close, finish, getCurrentKey, getExecutionConfig, getInternalTimerService, getKeyedStateBackend, getKeyedStateStore, getMetricGroup, getOperatorConfig, getOperatorID, getOperatorName, getOperatorStateBackend, getOrCreateKeyedState, getPartitionedState, getPartitionedState, getProcessingTimeService, getRuntimeContext, getTimeServiceManager, getUserCodeClassloader, initializeState, initializeState, internalSetKeyContextElement, isUsingCustomRawKeyedState, notifyCheckpointAborted, notifyCheckpointComplete, open, prepareSnapshotPreBarrier, processRecordAttributes, processWatermark, processWatermarkStatus, reportOrForwardLatencyMarker, reportWatermark, setCurrentKey, setKeyContextElement1, setKeyContextElement2, snapshotState, snapshotState, useSplittableTimers
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
getInputs
close, finish, getMetricGroup, getOperatorAttributes, getOperatorID, initializeState, open, prepareSnapshotPreBarrier, setKeyContextElement1, setKeyContextElement2, snapshotState
notifyCheckpointAborted, notifyCheckpointComplete
getCurrentKey, setCurrentKey
nextSelection
endInput
protected final StreamOperatorParameters parameters
public FusionStreamOperatorBase(StreamOperatorParameters<RowData> parameters, int numberOfInputs)
public StreamTask<?,?> getContainingTask()
public long computeMemorySize(double operatorFraction)
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.