Class TableStreamOperator<OUT>
- java.lang.Object
-
- org.apache.flink.streaming.api.operators.AbstractStreamOperator<OUT>
-
- org.apache.flink.table.runtime.operators.TableStreamOperator<OUT>
-
- All Implemented Interfaces:
Serializable
,CheckpointListener
,KeyContext
,KeyContextHandler
,StreamOperator<OUT>
,StreamOperatorStateHandler.CheckpointedStreamOperator
,YieldingOperator<OUT>
- Direct Known Subclasses:
BufferDataOverWindowOperator
,ConstraintEnforcer
,GlobalRuntimeFilterBuilderOperator
,HashJoinOperator
,InputConversionOperator
,LimitOperator
,LocalRuntimeFilterBuilderOperator
,NonBufferOverWindowOperator
,OutputConversionOperator
,RankOperator
,RowKindSetter
,SinkUpsertMaterializer
,SortLimitOperator
,SortMergeJoinOperator
,SortOperator
,StreamRecordTimestampInserter
,StreamSortOperator
,WindowAggOperator
,WindowJoinOperator
,WindowTableFunctionOperatorBase
public abstract class TableStreamOperator<OUT> extends AbstractStreamOperator<OUT>
Table operator to invoke close always. This is a base class for both batch and stream operators without key.- See Also:
- Serialized Form
-
-
Nested Class Summary
Nested Classes Modifier and Type Class Description protected class
TableStreamOperator.ContextImpl
Information available in an invocation of processElement.
-
Field Summary
Fields Modifier and Type Field Description protected TableStreamOperator.ContextImpl
ctx
protected long
currentWatermark
We listen to this ourselves because we don't have anInternalTimerService
.-
Fields inherited from class org.apache.flink.streaming.api.operators.AbstractStreamOperator
combinedWatermark, config, lastRecordAttributes1, lastRecordAttributes2, latencyStats, LOG, metrics, output, processingTimeService, stateHandler, stateKeySelector1, stateKeySelector2, timeServiceManager
-
-
Constructor Summary
Constructors Constructor Description TableStreamOperator()
TableStreamOperator(StreamOperatorParameters<OUT> parameters)
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description long
computeMemorySize()
Compute memory size from memory faction.void
open()
This method is called immediately before any elements are processed, it should contain the operator's initialization logic, e.g. state initialization.void
processWatermark(Watermark mark)
boolean
useSplittableTimers()
Can be overridden to disable splittable timers for this particular operator even if config option is enabled.-
Methods inherited from class org.apache.flink.streaming.api.operators.AbstractStreamOperator
close, finish, getContainingTask, getCurrentKey, getExecutionConfig, getInternalTimerService, getKeyedStateBackend, getKeyedStateStore, getMetricGroup, getOperatorConfig, getOperatorID, getOperatorName, getOperatorStateBackend, getOrCreateKeyedState, getPartitionedState, getPartitionedState, getProcessingTimeService, getRuntimeContext, getStateKeySelector1, getStateKeySelector2, getTimeServiceManager, getUserCodeClassloader, hasKeyContext1, hasKeyContext2, initializeState, initializeState, isAsyncStateProcessingEnabled, isUsingCustomRawKeyedState, notifyCheckpointAborted, notifyCheckpointComplete, prepareSnapshotPreBarrier, processLatencyMarker, processLatencyMarker1, processLatencyMarker2, processRecordAttributes, processRecordAttributes1, processRecordAttributes2, processWatermark1, processWatermark2, processWatermarkStatus, processWatermarkStatus, processWatermarkStatus1, processWatermarkStatus2, reportOrForwardLatencyMarker, setCurrentKey, setKeyContextElement1, setKeyContextElement2, setMailboxExecutor, setProcessingTimeService, setup, snapshotState, snapshotState
-
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.KeyContextHandler
hasKeyContext
-
Methods inherited from interface org.apache.flink.streaming.api.operators.StreamOperator
getOperatorAttributes
-
-
-
-
Field Detail
-
currentWatermark
protected long currentWatermark
We listen to this ourselves because we don't have anInternalTimerService
.
-
ctx
protected transient TableStreamOperator.ContextImpl ctx
-
-
Constructor Detail
-
TableStreamOperator
public TableStreamOperator()
-
TableStreamOperator
public TableStreamOperator(StreamOperatorParameters<OUT> parameters)
-
-
Method Detail
-
open
public void open() throws Exception
Description copied from class:AbstractStreamOperator
This method is called immediately before any elements are processed, it should contain the operator's initialization logic, e.g. state initialization.The default implementation does nothing.
- Specified by:
open
in interfaceStreamOperator<OUT>
- Overrides:
open
in classAbstractStreamOperator<OUT>
- Throws:
Exception
- An exception in this method causes the operator to fail.
-
useSplittableTimers
public boolean useSplittableTimers()
Description copied from class:AbstractStreamOperator
Can be overridden to disable splittable timers for this particular operator even if config option is enabled. By default, splittable timers are disabled.- Overrides:
useSplittableTimers
in classAbstractStreamOperator<OUT>
- Returns:
true
if splittable timers should be used (subject toStreamConfig.isUnalignedCheckpointsEnabled()
andStreamConfig.isUnalignedCheckpointsSplittableTimersEnabled()
.false
if splittable timers should never be used.
-
computeMemorySize
public long computeMemorySize()
Compute memory size from memory faction.
-
processWatermark
public void processWatermark(Watermark mark) throws Exception
- Overrides:
processWatermark
in classAbstractStreamOperator<OUT>
- Throws:
Exception
-
-