Interface MultipleInputStreamOperator<OUT>
-
- All Superinterfaces:
CheckpointListener
,KeyContext
,Serializable
,StreamOperator<OUT>
- All Known Implementing Classes:
BatchMultipleInputStreamOperator
,FusionStreamOperatorBase
,MultipleInputStreamOperatorBase
@PublicEvolving public interface MultipleInputStreamOperator<OUT> extends StreamOperator<OUT>
Interface for stream operators with multipleInput
s.
-
-
Method Summary
All Methods Instance Methods Abstract Methods Modifier and Type Method Description List<Input>
getInputs()
-
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
-
-