Class StreamTaskExternallyInducedSourceInput<T>
- java.lang.Object
-
- org.apache.flink.streaming.runtime.io.StreamTaskSourceInput<T>
-
- org.apache.flink.streaming.runtime.io.StreamTaskExternallyInducedSourceInput<T>
-
- All Implemented Interfaces:
Closeable
,AutoCloseable
,AvailabilityProvider
,CheckpointableInput
,PushingAsyncDataInput<T>
,StreamTaskInput<T>
public class StreamTaskExternallyInducedSourceInput<T> extends StreamTaskSourceInput<T>
A subclass ofStreamTaskSourceInput
forExternallyInducedSourceReader
.
-
-
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 StreamTaskExternallyInducedSourceInput(SourceOperator<T,?> operator, Consumer<Long> checkpointTriggeringHook, int inputGateIndex, int inputIndex)
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description void
blockUntil(CompletableFuture<?> blockFuture)
DataInputStatus
emitNext(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
-
StreamTaskExternallyInducedSourceInput
public StreamTaskExternallyInducedSourceInput(SourceOperator<T,?> operator, Consumer<Long> checkpointTriggeringHook, int inputGateIndex, int inputIndex)
-
-
Method Detail
-
blockUntil
public void blockUntil(CompletableFuture<?> blockFuture)
-
emitNext
public DataInputStatus emitNext(PushingAsyncDataInput.DataOutput<T> output) throws Exception
Description copied from interface:PushingAsyncDataInput
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.This method should be non blocking.
- Specified by:
emitNext
in interfacePushingAsyncDataInput<T>
- Overrides:
emitNext
in classStreamTaskSourceInput<T>
- Throws:
Exception
-
getAvailableFuture
public CompletableFuture<?> getAvailableFuture()
- Specified by:
getAvailableFuture
in interfaceAvailabilityProvider
- Overrides:
getAvailableFuture
in classStreamTaskSourceInput<T>
- Returns:
- a future that is completed if the respective provider is available.
-
-