Interface KeyContext
-
- All Known Subinterfaces:
MultipleInputStreamOperator<OUT>
,OneInputStreamOperator<IN,OUT>
,StreamOperator<OUT>
,TwoInputStreamOperator<IN1,IN2,OUT>
,YieldingOperator<OUT>
- All Known Implementing Classes:
AbstractArrowPythonAggregateFunctionOperator
,AbstractAsyncStateStreamingJoinOperator
,AbstractAsyncStateStreamOperator
,AbstractAsyncStateStreamOperatorV2
,AbstractAsyncStateUdfStreamOperator
,AbstractEmbeddedDataStreamPythonFunctionOperator
,AbstractEmbeddedPythonFunctionOperator
,AbstractEmbeddedStatelessFunctionOperator
,AbstractExternalDataStreamPythonFunctionOperator
,AbstractExternalOneInputPythonFunctionOperator
,AbstractExternalPythonFunctionOperator
,AbstractExternalTwoInputPythonFunctionOperator
,AbstractMapBundleOperator
,AbstractOneInputEmbeddedPythonFunctionOperator
,AbstractOneInputPythonFunctionOperator
,AbstractPythonFunctionOperator
,AbstractPythonScalarFunctionOperator
,AbstractPythonStreamAggregateOperator
,AbstractPythonStreamGroupAggregateOperator
,AbstractStatelessFunctionOperator
,AbstractStreamArrowPythonBoundedRangeOperator
,AbstractStreamArrowPythonBoundedRowsOperator
,AbstractStreamArrowPythonOverWindowAggregateFunctionOperator
,AbstractStreamingJoinOperator
,AbstractStreamingWriter
,AbstractStreamOperator
,AbstractStreamOperatorV2
,AbstractTwoInputEmbeddedPythonFunctionOperator
,AbstractUdfStreamOperator
,AggregateWindowOperator
,AlignedWindowTableFunctionOperator
,ArrowPythonScalarFunctionOperator
,AsyncStateStreamingJoinOperator
,AsyncWaitOperator
,BaseTwoInputStreamOperatorWithStateRetention
,BatchArrowPythonGroupAggregateFunctionOperator
,BatchArrowPythonGroupWindowAggregateFunctionOperator
,BatchArrowPythonOverWindowAggregateFunctionOperator
,BatchCoBroadcastWithKeyedOperator
,BatchCoBroadcastWithNonKeyedOperator
,BatchCompactCoordinator
,BatchCompactOperator
,BatchFileWriter
,BatchGroupedReduceOperator
,BatchMultipleInputStreamOperator
,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
,FusionStreamOperatorBase
,GenericWriteAheadSink
,GlobalRuntimeFilterBuilderOperator
,GroupReduceOperator
,HashJoinOperator
,HiveScriptTransformOperator
,InputConversionOperator
,IntervalJoinOperator
,KeyedCoProcessOperator
,KeyedCoProcessOperatorWithWatermarkDelay
,KeyedMapBundleOperator
,KeyedProcessOperator
,KeyedProcessOperator
,KeyedSortPartitionOperator
,KeyedStateBootstrapOperator
,KeyedStateReaderOperator
,KeyedTwoInputBroadcastProcessOperator
,KeyedTwoInputNonBroadcastProcessOperator
,KeyedTwoOutputProcessOperator
,LegacyKeyedCoProcessOperator
,LegacyKeyedProcessOperator
,LimitOperator
,LocalRuntimeFilterBuilderOperator
,LocalSlicingWindowAggOperator
,MapBundleOperator
,MapPartitionOperator
,MiniBatchStreamingJoinOperator
,MultipleInputStreamOperatorBase
,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
,StateBootstrapWrapperOperator
,StateReaderOperator
,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
,WindowReaderOperator
,WindowTableFunctionOperatorBase
public interface KeyContext
Interface for setting and querying the current key of keyed operations.This is mainly used by the timer system to query the key when creating timers and to set the correct key context when firing a timer.
-
-
Method Summary
All Methods Instance Methods Abstract Methods Modifier and Type Method Description Object
getCurrentKey()
void
setCurrentKey(Object key)
-