@Internal public final class StreamTaskSourceInput<T> extends Object implements StreamTaskInput<T>
StreamTaskInput
that reads data from the SourceOperator
and returns the InputStatus
to indicate whether the source state is available,
unavailable or finished.PushingAsyncDataInput.DataOutput<T>
UNSPECIFIED
构造器和说明 |
---|
StreamTaskSourceInput(SourceOperator<T,?> operator) |
限定符和类型 | 方法和说明 |
---|---|
void |
close() |
org.apache.flink.core.io.InputStatus |
emitNext(PushingAsyncDataInput.DataOutput<T> output)
Pushes the next element 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() |
int |
getInputIndex()
This method is invalid and never called by the one/source input processor.
|
CompletableFuture<Void> |
prepareSnapshot(org.apache.flink.runtime.checkpoint.channel.ChannelStateWriter channelStateWriter,
long checkpointId)
Prepares to spill the in-flight input buffers as checkpoint snapshot.
|
public StreamTaskSourceInput(SourceOperator<T,?> operator)
public org.apache.flink.core.io.InputStatus emitNext(PushingAsyncDataInput.DataOutput<T> output) throws Exception
PushingAsyncDataInput
This method should be non blocking.
emitNext
在接口中 PushingAsyncDataInput<T>
Exception
public CompletableFuture<?> getAvailableFuture()
getAvailableFuture
在接口中 org.apache.flink.runtime.io.AvailabilityProvider
public int getInputIndex()
getInputIndex
在接口中 StreamTaskInput<T>
public void close()
close
在接口中 Closeable
close
在接口中 AutoCloseable
public CompletableFuture<Void> prepareSnapshot(org.apache.flink.runtime.checkpoint.channel.ChannelStateWriter channelStateWriter, long checkpointId)
StreamTaskInput
prepareSnapshot
在接口中 StreamTaskInput<T>
Copyright © 2014–2020 The Apache Software Foundation. All rights reserved.