Interface YieldingOperator<OUT>
-
- All Superinterfaces:
CheckpointListener
,KeyContext
,Serializable
,StreamOperator<OUT>
- All Known Implementing Classes:
AbstractArrowPythonAggregateFunctionOperator
,AbstractAsyncStateStreamingJoinOperator
,AbstractAsyncStateStreamOperator
,AbstractAsyncStateUdfStreamOperator
,AbstractEmbeddedDataStreamPythonFunctionOperator
,AbstractEmbeddedPythonFunctionOperator
,AbstractEmbeddedStatelessFunctionOperator
,AbstractExternalDataStreamPythonFunctionOperator
,AbstractExternalOneInputPythonFunctionOperator
,AbstractExternalPythonFunctionOperator
,AbstractExternalTwoInputPythonFunctionOperator
,AbstractMapBundleOperator
,AbstractOneInputEmbeddedPythonFunctionOperator
,AbstractOneInputPythonFunctionOperator
,AbstractPythonFunctionOperator
,AbstractPythonScalarFunctionOperator
,AbstractPythonStreamAggregateOperator
,AbstractPythonStreamGroupAggregateOperator
,AbstractStatelessFunctionOperator
,AbstractStreamArrowPythonBoundedRangeOperator
,AbstractStreamArrowPythonBoundedRowsOperator
,AbstractStreamArrowPythonOverWindowAggregateFunctionOperator
,AbstractStreamingJoinOperator
,AbstractStreamingWriter
,AbstractStreamOperator
,AbstractTwoInputEmbeddedPythonFunctionOperator
,AbstractUdfStreamOperator
,AggregateWindowOperator
,AlignedWindowTableFunctionOperator
,ArrowPythonScalarFunctionOperator
,AsyncStateStreamingJoinOperator
,AsyncWaitOperator
,BaseTwoInputStreamOperatorWithStateRetention
,BatchArrowPythonGroupAggregateFunctionOperator
,BatchArrowPythonGroupWindowAggregateFunctionOperator
,BatchArrowPythonOverWindowAggregateFunctionOperator
,BatchCoBroadcastWithKeyedOperator
,BatchCoBroadcastWithNonKeyedOperator
,BatchCompactCoordinator
,BatchCompactOperator
,BatchFileWriter
,BatchGroupedReduceOperator
,BootstrapStreamTaskRunner
,BroadcastStateBootstrapOperator
,BufferDataOverWindowOperator
,CacheTransformationTranslator.IdentityStreamOperator
,CacheTransformationTranslator.NoOpStreamOperator
,CepOperator
,CoBroadcastWithKeyedOperator
,CoBroadcastWithNonKeyedOperator
,CollectSinkOperator
,CompactCoordinator
,CompactCoordinator
,CompactCoordinatorStateHandler
,CompactFileWriter
,CompactOperator
,CompactorOperator
,CompactorOperatorStateHandler
,ConstraintEnforcer
,ContinuousFileReaderOperator
,CoProcessOperator
,CoStreamFlatMap
,CoStreamMap
,DelegateOperatorTransformation.DelegateOperator
,DynamicFilteringDataCollectorOperator
,EmbeddedPythonBatchCoBroadcastProcessOperator
,EmbeddedPythonBatchKeyedCoBroadcastProcessOperator
,EmbeddedPythonCoProcessOperator
,EmbeddedPythonKeyedCoProcessOperator
,EmbeddedPythonKeyedProcessOperator
,EmbeddedPythonProcessOperator
,EmbeddedPythonScalarFunctionOperator
,EmbeddedPythonTableFunctionOperator
,EmbeddedPythonWindowOperator
,EvictingWindowOperator
,ExternalPythonBatchCoBroadcastProcessOperator
,ExternalPythonBatchKeyedCoBroadcastProcessOperator
,ExternalPythonCoProcessOperator
,ExternalPythonKeyedCoProcessOperator
,ExternalPythonKeyedProcessOperator
,ExternalPythonProcessOperator
,GenericWriteAheadSink
,GlobalRuntimeFilterBuilderOperator
,GroupReduceOperator
,HashJoinOperator
,InputConversionOperator
,IntervalJoinOperator
,KeyedCoProcessOperator
,KeyedCoProcessOperatorWithWatermarkDelay
,KeyedMapBundleOperator
,KeyedProcessOperator
,KeyedProcessOperator
,KeyedSortPartitionOperator
,KeyedStateBootstrapOperator
,KeyedTwoInputBroadcastProcessOperator
,KeyedTwoInputNonBroadcastProcessOperator
,KeyedTwoOutputProcessOperator
,LegacyKeyedCoProcessOperator
,LegacyKeyedProcessOperator
,LimitOperator
,LocalRuntimeFilterBuilderOperator
,LocalSlicingWindowAggOperator
,MapBundleOperator
,MapPartitionOperator
,MiniBatchStreamingJoinOperator
,NonBufferOverWindowOperator
,OutputConversionOperator
,PartitionAggregateOperator
,PartitionCommitter
,PartitionReduceOperator
,ProcessOperator
,ProcessOperator
,ProcTimeMiniBatchAssignerOperator
,ProcTimeSortOperator
,PythonScalarFunctionOperator
,PythonStreamGroupAggregateOperator
,PythonStreamGroupTableAggregateOperator
,PythonStreamGroupWindowAggregateOperator
,PythonTableFunctionOperator
,QueryableAppendingStateOperator
,QueryableValueStateOperator
,RankOperator
,RowKindSetter
,RowTimeMiniBatchAssginerOperator
,RowTimeSortOperator
,SinkOperator
,SinkUpsertMaterializer
,SortLimitOperator
,SortMergeJoinOperator
,SortOperator
,SortPartitionOperator
,SourceOperator
,StateBootstrapOperator
,StreamArrowPythonGroupWindowAggregateFunctionOperator
,StreamArrowPythonProcTimeBoundedRangeOperator
,StreamArrowPythonProcTimeBoundedRowsOperator
,StreamArrowPythonRowTimeBoundedRangeOperator
,StreamArrowPythonRowTimeBoundedRowsOperator
,StreamFilter
,StreamFlatMap
,StreamGroupedReduceOperator
,StreamingFileWriter
,StreamingJoinOperator
,StreamingSemiAntiJoinOperator
,StreamMap
,StreamProject
,StreamRecordTimestampInserter
,StreamSink
,StreamSortOperator
,StreamSource
,TableAggregateWindowOperator
,TableStreamOperator
,TemporalProcessTimeJoinOperator
,TemporalRowTimeJoinOperator
,TimestampsAndWatermarksOperator
,TwoInputBroadcastProcessOperator
,TwoInputNonBroadcastProcessOperator
,TwoOutputProcessOperator
,UnalignedWindowTableFunctionOperator
,UnionStreamOperator
,WatermarkAssignerOperator
,WindowAggOperator
,WindowJoinOperator
,WindowOperator
,WindowOperator
,WindowTableFunctionOperatorBase
@Internal public interface YieldingOperator<OUT> extends StreamOperator<OUT>
A V1 operator that needs access to theMailboxExecutor
should implement this interface. Note, this interface is not needed when usingStreamOperatorFactory
orAbstractStreamOperatorV2
as those have access to theMailboxExecutor
viaStreamOperatorParameters.getMailboxExecutor()
-
-
Method Summary
All Methods Instance Methods Abstract Methods Modifier and Type Method Description void
setMailboxExecutor(MailboxExecutor mailboxExecutor)
-
Methods inherited from interface org.apache.flink.api.common.state.CheckpointListener
notifyCheckpointAborted, notifyCheckpointComplete
-
Methods inherited from interface org.apache.flink.streaming.api.operators.KeyContext
getCurrentKey, setCurrentKey
-
Methods inherited from interface org.apache.flink.streaming.api.operators.StreamOperator
close, finish, getMetricGroup, getOperatorAttributes, getOperatorID, initializeState, open, prepareSnapshotPreBarrier, setKeyContextElement1, setKeyContextElement2, snapshotState
-
-
-
-
Method Detail
-
setMailboxExecutor
void setMailboxExecutor(MailboxExecutor mailboxExecutor)
-
-