Interface OneInputStreamOperator<IN,OUT>
-
- Type Parameters:
IN
- The input type of the operatorOUT
- The output type of the operator
- All Superinterfaces:
CheckpointListener
,Input<IN>
,KeyContext
,Serializable
,StreamOperator<OUT>
- All Known Implementing Classes:
AbstractArrowPythonAggregateFunctionOperator
,AbstractEmbeddedStatelessFunctionOperator
,AbstractExternalOneInputPythonFunctionOperator
,AbstractMapBundleOperator
,AbstractOneInputEmbeddedPythonFunctionOperator
,AbstractOneInputPythonFunctionOperator
,AbstractPythonScalarFunctionOperator
,AbstractPythonStreamAggregateOperator
,AbstractPythonStreamGroupAggregateOperator
,AbstractStatelessFunctionOperator
,AbstractStreamArrowPythonBoundedRangeOperator
,AbstractStreamArrowPythonBoundedRowsOperator
,AbstractStreamArrowPythonOverWindowAggregateFunctionOperator
,AbstractStreamingWriter
,AggregateWindowOperator
,AlignedWindowTableFunctionOperator
,ArrowPythonScalarFunctionOperator
,AsyncWaitOperator
,BatchArrowPythonGroupAggregateFunctionOperator
,BatchArrowPythonGroupWindowAggregateFunctionOperator
,BatchArrowPythonOverWindowAggregateFunctionOperator
,BatchCompactCoordinator
,BatchCompactOperator
,BatchFileWriter
,BatchGroupedReduceOperator
,BootstrapStreamTaskRunner
,BroadcastStateBootstrapOperator
,BufferDataOverWindowOperator
,CacheTransformationTranslator.IdentityStreamOperator
,CacheTransformationTranslator.NoOpStreamOperator
,CepOperator
,CollectSinkOperator
,CompactCoordinator
,CompactCoordinator
,CompactCoordinatorStateHandler
,CompactFileWriter
,CompactOperator
,CompactorOperator
,CompactorOperatorStateHandler
,ConstraintEnforcer
,ContinuousFileReaderOperator
,DynamicFilteringDataCollectorOperator
,EmbeddedPythonKeyedProcessOperator
,EmbeddedPythonProcessOperator
,EmbeddedPythonScalarFunctionOperator
,EmbeddedPythonTableFunctionOperator
,EmbeddedPythonWindowOperator
,EvictingWindowOperator
,ExternalPythonKeyedProcessOperator
,ExternalPythonProcessOperator
,GenericWriteAheadSink
,GlobalCommitterOperator
,GlobalRuntimeFilterBuilderOperator
,GroupReduceOperator
,InputConversionOperator
,KeyedMapBundleOperator
,KeyedProcessOperator
,KeyedProcessOperator
,KeyedSortPartitionOperator
,KeyedStateBootstrapOperator
,KeyedTwoOutputProcessOperator
,LegacyKeyedProcessOperator
,LimitOperator
,LocalRuntimeFilterBuilderOperator
,LocalSlicingWindowAggOperator
,MapBundleOperator
,MapPartitionOperator
,NonBufferOverWindowOperator
,OutputConversionOperator
,PartitionAggregateOperator
,PartitionCommitter
,PartitionReduceOperator
,ProcessOperator
,ProcessOperator
,ProcTimeMiniBatchAssignerOperator
,ProcTimeSortOperator
,PythonScalarFunctionOperator
,PythonStreamGroupAggregateOperator
,PythonStreamGroupTableAggregateOperator
,PythonStreamGroupWindowAggregateOperator
,PythonTableFunctionOperator
,QueryableAppendingStateOperator
,QueryableValueStateOperator
,RankOperator
,RowKindSetter
,RowTimeMiniBatchAssginerOperator
,RowTimeSortOperator
,SinkOperator
,SinkUpsertMaterializer
,SortLimitOperator
,SortOperator
,SortPartitionOperator
,StateBootstrapOperator
,StateBootstrapWrapperOperator
,StreamArrowPythonGroupWindowAggregateFunctionOperator
,StreamArrowPythonProcTimeBoundedRangeOperator
,StreamArrowPythonProcTimeBoundedRowsOperator
,StreamArrowPythonRowTimeBoundedRangeOperator
,StreamArrowPythonRowTimeBoundedRowsOperator
,StreamFilter
,StreamFlatMap
,StreamGroupedReduceOperator
,StreamingFileWriter
,StreamMap
,StreamProject
,StreamRecordTimestampInserter
,StreamSink
,StreamSortOperator
,TableAggregateWindowOperator
,TimestampsAndWatermarksOperator
,TwoOutputProcessOperator
,UnalignedWindowTableFunctionOperator
,UnionStreamOperator
,WatermarkAssignerOperator
,WindowAggOperator
,WindowOperator
,WindowOperator
,WindowTableFunctionOperatorBase
@PublicEvolving public interface OneInputStreamOperator<IN,OUT> extends StreamOperator<OUT>, Input<IN>
Interface for stream operators with one input. UseAbstractStreamOperator
as a base class if you want to implement a custom operator.
-
-
Method Summary
All Methods Instance Methods Default Methods Modifier and Type Method Description default void
setKeyContextElement(StreamRecord<IN> record)
Set the correct key context before processing therecord
.-
Methods inherited from interface org.apache.flink.api.common.state.CheckpointListener
notifyCheckpointAborted, notifyCheckpointComplete
-
Methods inherited from interface org.apache.flink.streaming.api.operators.Input
processElement, processLatencyMarker, processRecordAttributes, processWatermark, processWatermarkStatus
-
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
-
setKeyContextElement
default void setKeyContextElement(StreamRecord<IN> record) throws Exception
Description copied from interface:Input
Set the correct key context before processing therecord
. Used for example to extract key from therecord
and pass that key to the state backends. This method is guaranteed to not be called concurrently with other methods of the operator.- Specified by:
setKeyContextElement
in interfaceInput<IN>
- Throws:
Exception
-
-