public abstract class AbstractStreamTaskNetworkInput<T,R extends RecordDeserializer<DeserializationDelegate<StreamElement>>> extends Object implements StreamTaskInput<T>
RecordDeserializer
for spanning records. Specific implementation bind it to a specific RecordDeserializer
.PushingAsyncDataInput.DataOutput<T>
AvailabilityProvider.AvailabilityHelper
Modifier and Type | Field and Description |
---|---|
protected StreamTask.CanEmitBatchOfRecordsChecker |
canEmitBatchOfRecords |
protected CheckpointedInputGate |
checkpointedInputGate |
protected DeserializationDelegate<StreamElement> |
deserializationDelegate |
protected Map<InputChannelInfo,Integer> |
flattenedChannelIndices |
protected int |
inputIndex |
protected TypeSerializer<T> |
inputSerializer |
protected Map<InputChannelInfo,R> |
recordDeserializers |
protected StatusWatermarkValve |
statusWatermarkValve
Valve that controls how watermarks and watermark statuses are forwarded.
|
UNSPECIFIED
AVAILABLE
Constructor and Description |
---|
AbstractStreamTaskNetworkInput(CheckpointedInputGate checkpointedInputGate,
TypeSerializer<T> inputSerializer,
StatusWatermarkValve statusWatermarkValve,
int inputIndex,
Map<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(InputChannelInfo channelInfo) |
CompletableFuture<?> |
getAvailableFuture() |
int |
getInputIndex()
Returns the input index of this input.
|
protected void |
processBuffer(BufferOrEvent bufferOrEvent) |
protected DataInputStatus |
processEvent(BufferOrEvent bufferOrEvent) |
protected void |
releaseDeserializer(InputChannelInfo channelInfo) |
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
prepareSnapshot
and, isApproximatelyAvailable, isAvailable, or
protected final CheckpointedInputGate checkpointedInputGate
protected final DeserializationDelegate<StreamElement> deserializationDelegate
protected final TypeSerializer<T> inputSerializer
protected final Map<InputChannelInfo,R extends RecordDeserializer<DeserializationDelegate<StreamElement>>> recordDeserializers
protected final Map<InputChannelInfo,Integer> flattenedChannelIndices
protected final StatusWatermarkValve statusWatermarkValve
protected final int inputIndex
protected final StreamTask.CanEmitBatchOfRecordsChecker canEmitBatchOfRecords
public AbstractStreamTaskNetworkInput(CheckpointedInputGate checkpointedInputGate, TypeSerializer<T> inputSerializer, StatusWatermarkValve statusWatermarkValve, int inputIndex, Map<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(BufferOrEvent bufferOrEvent)
protected void processBuffer(BufferOrEvent bufferOrEvent) throws IOException
IOException
protected R getActiveSerializer(InputChannelInfo channelInfo)
public int getInputIndex()
StreamTaskInput
getInputIndex
in interface StreamTaskInput<T>
public CompletableFuture<?> getAvailableFuture()
getAvailableFuture
in interface AvailabilityProvider
public void close() throws IOException
close
in interface Closeable
close
in interface AutoCloseable
IOException
protected void releaseDeserializer(InputChannelInfo channelInfo)
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.