Class StreamTaskFinishedOnRestoreSourceInput<T>
- java.lang.Object
-
- org.apache.flink.streaming.runtime.io.StreamTaskSourceInput<T>
-
- org.apache.flink.streaming.runtime.tasks.StreamTaskFinishedOnRestoreSourceInput<T>
-
- All Implemented Interfaces:
Closeable,AutoCloseable,AvailabilityProvider,CheckpointableInput,PushingAsyncDataInput<T>,StreamTaskInput<T>
public class StreamTaskFinishedOnRestoreSourceInput<T> extends StreamTaskSourceInput<T>
A special source input implementation that immediately emit END_OF_INPUT. It is used for sources that finished on restore.
-
-
Nested Class Summary
-
Nested classes/interfaces inherited from interface org.apache.flink.runtime.io.AvailabilityProvider
AvailabilityProvider.AvailabilityHelper
-
Nested classes/interfaces inherited from interface org.apache.flink.streaming.runtime.io.PushingAsyncDataInput
PushingAsyncDataInput.DataOutput<T>
-
-
Field Summary
-
Fields inherited from interface org.apache.flink.runtime.io.AvailabilityProvider
AVAILABLE
-
Fields inherited from interface org.apache.flink.streaming.runtime.io.StreamTaskInput
UNSPECIFIED
-
-
Constructor Summary
Constructors Constructor Description StreamTaskFinishedOnRestoreSourceInput(SourceOperator<T,?> operator, int inputGateIndex, int inputIndex)
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description DataInputStatusemitNext(PushingAsyncDataInput.DataOutput<T> output)Pushes elements to the output from current data input, and returns the input status to indicate whether there are more available data in current input.CompletableFuture<?>getAvailableFuture()-
Methods inherited from class org.apache.flink.streaming.runtime.io.StreamTaskSourceInput
blockConsumption, checkpointStarted, checkpointStopped, close, convertToPriorityEvent, getChannelInfos, getInputGateIndex, getInputIndex, getNumberOfInputChannels, getOperator, getOperatorID, prepareSnapshot, resumeConsumption
-
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.runtime.io.AvailabilityProvider
isApproximatelyAvailable, isAvailable
-
-
-
-
Constructor Detail
-
StreamTaskFinishedOnRestoreSourceInput
public StreamTaskFinishedOnRestoreSourceInput(SourceOperator<T,?> operator, int inputGateIndex, int inputIndex)
-
-
Method Detail
-
emitNext
public DataInputStatus emitNext(PushingAsyncDataInput.DataOutput<T> output) throws Exception
Description copied from interface:PushingAsyncDataInputPushes elements to the output from current data input, and returns the input status to indicate whether there are more available data in current input.This method should be non blocking.
- Specified by:
emitNextin interfacePushingAsyncDataInput<T>- Overrides:
emitNextin classStreamTaskSourceInput<T>- Throws:
Exception
-
getAvailableFuture
public CompletableFuture<?> getAvailableFuture()
- Specified by:
getAvailableFuturein interfaceAvailabilityProvider- Overrides:
getAvailableFuturein classStreamTaskSourceInput<T>- Returns:
- a future that is completed if the respective provider is available.
-
-