Class FinishedOnRestoreInput<IN>
- java.lang.Object
-
- org.apache.flink.streaming.runtime.tasks.FinishedOnRestoreInput<IN>
-
-
Constructor Summary
Constructors Constructor Description FinishedOnRestoreInput(RecordWriterOutput<?>[] streamOutputs, int inputCount)
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description voidprocessElement(StreamRecord<IN> element)Processes one element that arrived on this input of theMultipleInputStreamOperator.voidprocessLatencyMarker(LatencyMarker latencyMarker)Processes aLatencyMarkerthat arrived on the first input of this two-input operator.voidprocessWatermark(Watermark watermark)Processes aWatermarkthat arrived on the first input of this two-input operator.voidprocessWatermarkStatus(WatermarkStatus watermarkStatus)Processes aWatermarkStatusthat arrived on this input of theMultipleInputStreamOperator.voidsetKeyContextElement(StreamRecord<IN> record)Set the correct key context before processing therecord.-
Methods inherited from class java.lang.Object
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
-
Methods inherited from interface org.apache.flink.streaming.api.operators.Input
processRecordAttributes, processWatermark
-
-
-
-
Constructor Detail
-
FinishedOnRestoreInput
public FinishedOnRestoreInput(RecordWriterOutput<?>[] streamOutputs, int inputCount)
-
-
Method Detail
-
processElement
public void processElement(StreamRecord<IN> element) throws Exception
Description copied from interface:InputProcesses one element that arrived on this input of theMultipleInputStreamOperator. This method is guaranteed to not be called concurrently with other methods of the operator.- Specified by:
processElementin interfaceInput<IN>- Throws:
Exception
-
processWatermark
public void processWatermark(Watermark watermark)
Description copied from interface:InputProcesses aWatermarkthat 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.- Specified by:
processWatermarkin interfaceInput<IN>- See Also:
Watermark
-
processWatermarkStatus
public void processWatermarkStatus(WatermarkStatus watermarkStatus) throws Exception
Description copied from interface:InputProcesses aWatermarkStatusthat arrived on this input of theMultipleInputStreamOperator. This method is guaranteed to not be called concurrently with other methods of the operator.- Specified by:
processWatermarkStatusin interfaceInput<IN>- Throws:
Exception- See Also:
WatermarkStatus
-
processLatencyMarker
public void processLatencyMarker(LatencyMarker latencyMarker) throws Exception
Description copied from interface:InputProcesses aLatencyMarkerthat 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.- Specified by:
processLatencyMarkerin interfaceInput<IN>- Throws:
Exception- See Also:
LatencyMarker
-
setKeyContextElement
public void setKeyContextElement(StreamRecord<IN> record) throws Exception
Description copied from interface:InputSet the correct key context before processing therecord. Used for example to extract key from therecordand pass that key to the state backends. This method is guaranteed to not be called concurrently with other methods of the operator.- Specified by:
setKeyContextElementin interfaceInput<IN>- Throws:
Exception
-
-