public class StreamTaskFinishedOnRestoreSourceInput<T> extends StreamTaskSourceInput<T>
PushingAsyncDataInput.DataOutput<T>
UNSPECIFIED
Constructor and Description |
---|
StreamTaskFinishedOnRestoreSourceInput(SourceOperator<T,?> operator,
int inputGateIndex,
int inputIndex) |
Modifier and Type | Method and Description |
---|---|
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() |
blockConsumption, checkpointStarted, checkpointStopped, close, convertToPriorityEvent, getChannelInfos, getInputGateIndex, getInputIndex, getNumberOfInputChannels, getOperator, getOperatorID, prepareSnapshot, resumeConsumption
public StreamTaskFinishedOnRestoreSourceInput(SourceOperator<T,?> operator, int inputGateIndex, int inputIndex)
public DataInputStatus emitNext(PushingAsyncDataInput.DataOutput<T> output) throws Exception
PushingAsyncDataInput
This method should be non blocking.
emitNext
in interface PushingAsyncDataInput<T>
emitNext
in class StreamTaskSourceInput<T>
Exception
public CompletableFuture<?> getAvailableFuture()
getAvailableFuture
in interface org.apache.flink.runtime.io.AvailabilityProvider
getAvailableFuture
in class StreamTaskSourceInput<T>
Copyright © 2014–2023 The Apache Software Foundation. All rights reserved.