Interface Input<IN>
-
- All Known Subinterfaces:
OneInputStreamOperator<IN,OUT>
- All Known Implementing Classes:
AbstractArrowPythonAggregateFunctionOperator
,AbstractEmbeddedStatelessFunctionOperator
,AbstractExternalOneInputPythonFunctionOperator
,AbstractInput
,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
,FinishedOnRestoreInput
,FirstInputOfTwoInput
,GenericWriteAheadSink
,GlobalRuntimeFilterBuilderOperator
,GroupReduceOperator
,HiveScriptTransformOperator
,InputBase
,InputConversionOperator
,KeyedMapBundleOperator
,KeyedProcessOperator
,KeyedProcessOperator
,KeyedSortPartitionOperator
,KeyedStateBootstrapOperator
,KeyedTwoOutputProcessOperator
,LegacyKeyedProcessOperator
,LimitOperator
,LocalRuntimeFilterBuilderOperator
,LocalSlicingWindowAggOperator
,MapBundleOperator
,MapPartitionOperator
,NonBufferOverWindowOperator
,OneInput
,OutputConversionOperator
,PartitionAggregateOperator
,PartitionCommitter
,PartitionReduceOperator
,ProcessOperator
,ProcessOperator
,ProcTimeMiniBatchAssignerOperator
,ProcTimeSortOperator
,PythonScalarFunctionOperator
,PythonStreamGroupAggregateOperator
,PythonStreamGroupTableAggregateOperator
,PythonStreamGroupWindowAggregateOperator
,PythonTableFunctionOperator
,QueryableAppendingStateOperator
,QueryableValueStateOperator
,RankOperator
,RowKindSetter
,RowTimeMiniBatchAssginerOperator
,RowTimeSortOperator
,SecondInputOfTwoInput
,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 Input<IN>
Input
interface used inMultipleInputStreamOperator
. Most likely you don't want to implement this interface on your own. Instead you can useAbstractInput
andAbstractStreamOperatorV2
to implementMultipleInputStreamOperator
, or justAbstractStreamOperatorV2
to implementOneInputStreamOperator
.
-
-
Method Summary
All Methods Instance Methods Abstract Methods Default Methods Modifier and Type Method Description void
processElement(StreamRecord<IN> element)
Processes one element that arrived on this input of theMultipleInputStreamOperator
.void
processLatencyMarker(LatencyMarker latencyMarker)
Processes aLatencyMarker
that arrived on the first input of this two-input operator.default void
processRecordAttributes(RecordAttributes recordAttributes)
Processes aRecordAttributes
that arrived at this input.void
processWatermark(Watermark mark)
Processes aWatermark
that arrived on the first input of this two-input operator.void
processWatermarkStatus(WatermarkStatus watermarkStatus)
Processes aWatermarkStatus
that arrived on this input of theMultipleInputStreamOperator
.void
setKeyContextElement(StreamRecord<IN> record)
Set the correct key context before processing therecord
.
-
-
-
Method Detail
-
processElement
void processElement(StreamRecord<IN> element) throws Exception
Processes one element that arrived on this input of theMultipleInputStreamOperator
. This method is guaranteed to not be called concurrently with other methods of the operator.- Throws:
Exception
-
processWatermark
void processWatermark(Watermark mark) throws Exception
Processes aWatermark
that arrived on the first input of this two-input operator. This method is guaranteed to not be called concurrently with other methods of the operator.
-
processWatermarkStatus
void processWatermarkStatus(WatermarkStatus watermarkStatus) throws Exception
Processes aWatermarkStatus
that arrived on this input of theMultipleInputStreamOperator
. This method is guaranteed to not be called concurrently with other methods of the operator.- Throws:
Exception
- See Also:
WatermarkStatus
-
processLatencyMarker
void processLatencyMarker(LatencyMarker latencyMarker) throws Exception
Processes aLatencyMarker
that arrived on the first input of this two-input operator. This method is guaranteed to not be called concurrently with other methods of the operator.- Throws:
Exception
- See Also:
LatencyMarker
-
setKeyContextElement
void setKeyContextElement(StreamRecord<IN> record) throws Exception
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.- Throws:
Exception
-
processRecordAttributes
@Experimental default void processRecordAttributes(RecordAttributes recordAttributes) throws Exception
Processes aRecordAttributes
that arrived at this input. This method is guaranteed to not be called concurrently with other methods of the operator.- Throws:
Exception
-
-