public abstract class AbstractStreamTaskNetworkInput<T,R extends org.apache.flink.runtime.io.network.api.serialization.RecordDeserializer<org.apache.flink.runtime.plugable.DeserializationDelegate<StreamElement>>> extends Object implements StreamTaskInput<T>
RecordDeserializer
for spanning records. Specific implementation bind it to a specific RecordDeserializer
.PushingAsyncDataInput.DataOutput<T>
Modifier and Type | Field and Description |
---|---|
protected StreamTask.CanEmitBatchOfRecordsChecker |
canEmitBatchOfRecords |
protected CheckpointedInputGate |
checkpointedInputGate |
protected org.apache.flink.runtime.plugable.DeserializationDelegate<StreamElement> |
deserializationDelegate |
protected Map<org.apache.flink.runtime.checkpoint.channel.InputChannelInfo,Integer> |
flattenedChannelIndices |
protected int |
inputIndex |
protected org.apache.flink.api.common.typeutils.TypeSerializer<T> |
inputSerializer |
protected Map<org.apache.flink.runtime.checkpoint.channel.InputChannelInfo,R> |
recordDeserializers |
protected StatusWatermarkValve |
statusWatermarkValve
Valve that controls how watermarks and watermark statuses are forwarded.
|
UNSPECIFIED
Constructor and Description |
---|
AbstractStreamTaskNetworkInput(CheckpointedInputGate checkpointedInputGate,
org.apache.flink.api.common.typeutils.TypeSerializer<T> inputSerializer,
StatusWatermarkValve statusWatermarkValve,
int inputIndex,
Map<org.apache.flink.runtime.checkpoint.channel.InputChannelInfo,R> recordDeserializers,
StreamTask.CanEmitBatchOfRecordsChecker canEmitBatchOfRecords) |
Modifier and Type | Method and Description |
---|---|
void |
close() |
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.
|
protected R |
getActiveSerializer(org.apache.flink.runtime.checkpoint.channel.InputChannelInfo channelInfo) |
CompletableFuture<?> |
getAvailableFuture() |
int |
getInputIndex()
Returns the input index of this input.
|
protected void |
processBuffer(org.apache.flink.runtime.io.network.partition.consumer.BufferOrEvent bufferOrEvent) |
protected DataInputStatus |
processEvent(org.apache.flink.runtime.io.network.partition.consumer.BufferOrEvent bufferOrEvent) |
protected void |
releaseDeserializer(org.apache.flink.runtime.checkpoint.channel.InputChannelInfo channelInfo) |
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
prepareSnapshot
protected final CheckpointedInputGate checkpointedInputGate
protected final org.apache.flink.runtime.plugable.DeserializationDelegate<StreamElement> deserializationDelegate
protected final org.apache.flink.api.common.typeutils.TypeSerializer<T> inputSerializer
protected final Map<org.apache.flink.runtime.checkpoint.channel.InputChannelInfo,R extends org.apache.flink.runtime.io.network.api.serialization.RecordDeserializer<org.apache.flink.runtime.plugable.DeserializationDelegate<StreamElement>>> recordDeserializers
protected final Map<org.apache.flink.runtime.checkpoint.channel.InputChannelInfo,Integer> flattenedChannelIndices
protected final StatusWatermarkValve statusWatermarkValve
protected final int inputIndex
protected final StreamTask.CanEmitBatchOfRecordsChecker canEmitBatchOfRecords
public AbstractStreamTaskNetworkInput(CheckpointedInputGate checkpointedInputGate, org.apache.flink.api.common.typeutils.TypeSerializer<T> inputSerializer, StatusWatermarkValve statusWatermarkValve, int inputIndex, Map<org.apache.flink.runtime.checkpoint.channel.InputChannelInfo,R> recordDeserializers, StreamTask.CanEmitBatchOfRecordsChecker canEmitBatchOfRecords)
public DataInputStatus emitNext(PushingAsyncDataInput.DataOutput<T> output) throws Exception
PushingAsyncDataInput
This method should be non blocking.
emitNext
in interface PushingAsyncDataInput<T>
Exception
protected DataInputStatus processEvent(org.apache.flink.runtime.io.network.partition.consumer.BufferOrEvent bufferOrEvent)
protected void processBuffer(org.apache.flink.runtime.io.network.partition.consumer.BufferOrEvent bufferOrEvent) throws IOException
IOException
protected R getActiveSerializer(org.apache.flink.runtime.checkpoint.channel.InputChannelInfo channelInfo)
public int getInputIndex()
StreamTaskInput
getInputIndex
in interface StreamTaskInput<T>
public CompletableFuture<?> getAvailableFuture()
getAvailableFuture
in interface org.apache.flink.runtime.io.AvailabilityProvider
public void close() throws IOException
close
in interface Closeable
close
in interface AutoCloseable
IOException
protected void releaseDeserializer(org.apache.flink.runtime.checkpoint.channel.InputChannelInfo channelInfo)
Copyright © 2014–2023 The Apache Software Foundation. All rights reserved.