@Internal public class StreamTaskSourceInput<T> extends Object implements StreamTaskInput<T>, CheckpointableInput
StreamTaskInput
that reads data from the SourceOperator
and
returns the DataInputStatus
to indicate whether the source state is available,
unavailable or finished.PushingAsyncDataInput.DataOutput<T>
AvailabilityProvider.AvailabilityHelper
UNSPECIFIED
AVAILABLE
Constructor and Description |
---|
StreamTaskSourceInput(SourceOperator<T,?> operator,
int inputGateIndex,
int inputIndex) |
Modifier and Type | Method and Description |
---|---|
void |
blockConsumption(InputChannelInfo channelInfo) |
void |
checkpointStarted(CheckpointBarrier barrier)
This method is used with unaligned checkpoints to mark the arrival of a first
CheckpointBarrier . |
void |
checkpointStopped(long cancelledCheckpointId) |
void |
close() |
void |
convertToPriorityEvent(int channelIndex,
int sequenceNumber) |
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() |
List<InputChannelInfo> |
getChannelInfos() |
int |
getInputGateIndex() |
int |
getInputIndex()
Returns the input index of this input.
|
int |
getNumberOfInputChannels() |
SourceOperator<T,?> |
getOperator() |
OperatorID |
getOperatorID() |
CompletableFuture<Void> |
prepareSnapshot(ChannelStateWriter channelStateWriter,
long checkpointId)
Prepares to spill the in-flight input buffers as checkpoint snapshot.
|
void |
resumeConsumption(InputChannelInfo channelInfo) |
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
and, isApproximatelyAvailable, isAvailable, or
public StreamTaskSourceInput(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>
Exception
public CompletableFuture<?> getAvailableFuture()
getAvailableFuture
in interface AvailabilityProvider
public void blockConsumption(InputChannelInfo channelInfo)
blockConsumption
in interface CheckpointableInput
public void resumeConsumption(InputChannelInfo channelInfo)
resumeConsumption
in interface CheckpointableInput
public List<InputChannelInfo> getChannelInfos()
getChannelInfos
in interface CheckpointableInput
public int getNumberOfInputChannels()
getNumberOfInputChannels
in interface CheckpointableInput
public void checkpointStarted(CheckpointBarrier barrier)
CheckpointBarrier
. For chained sources, there is no CheckpointBarrier
per se flowing
through the job graph. We can assume that an imaginary CheckpointBarrier
was produced
by the source, at any point of time of our choosing.
We are choosing to interpret it, that CheckpointBarrier
for sources was received
immediately as soon as we receive either checkpoint start RPC, or CheckpointBarrier
from a network input. So that we can checkpoint state of the source and all of the other
operators at the same time.
Also we are choosing to block the source, as a best effort optimisation as: - either there is no backpressure and the checkpoint "alignment" will happen very quickly anyway - or there is a backpressure, and it's better to prioritize processing data from the network to speed up checkpointing. From the cluster resource utilisation perspective, by blocking chained source doesn't block any resources from being used, as this task running the source has a backlog of buffered input data waiting to be processed.
However from the correctness point of view, checkpointStarted(CheckpointBarrier)
and checkpointStopped(long)
methods could be empty no-op.
checkpointStarted
in interface CheckpointableInput
public void checkpointStopped(long cancelledCheckpointId)
checkpointStopped
in interface CheckpointableInput
public int getInputGateIndex()
getInputGateIndex
in interface CheckpointableInput
public void convertToPriorityEvent(int channelIndex, int sequenceNumber) throws IOException
convertToPriorityEvent
in interface CheckpointableInput
IOException
public int getInputIndex()
StreamTaskInput
getInputIndex
in interface StreamTaskInput<T>
public void close()
close
in interface Closeable
close
in interface AutoCloseable
public CompletableFuture<Void> prepareSnapshot(ChannelStateWriter channelStateWriter, long checkpointId) throws CheckpointException
StreamTaskInput
prepareSnapshot
in interface StreamTaskInput<T>
CheckpointException
public OperatorID getOperatorID()
public SourceOperator<T,?> getOperator()
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.