@Internal public interface StreamTaskInput<T> extends PushingAsyncDataInput<T>, Closeable
PushingAsyncDataInput.DataOutput<T>
限定符和类型 | 字段和说明 |
---|---|
static int |
UNSPECIFIED |
限定符和类型 | 方法和说明 |
---|---|
int |
getInputIndex()
Returns the input index of this input.
|
CompletableFuture<Void> |
prepareSnapshot(org.apache.flink.runtime.checkpoint.channel.ChannelStateWriter channelStateWriter,
long checkpointId)
Prepares to spill the in-flight input buffers as checkpoint snapshot.
|
emitNext
static final int UNSPECIFIED
int getInputIndex()
CompletableFuture<Void> prepareSnapshot(org.apache.flink.runtime.checkpoint.channel.ChannelStateWriter channelStateWriter, long checkpointId) throws org.apache.flink.runtime.checkpoint.CheckpointException
org.apache.flink.runtime.checkpoint.CheckpointException
Copyright © 2014–2022 The Apache Software Foundation. All rights reserved.