Class RemoteRecoveredInputChannel
- java.lang.Object
-
- org.apache.flink.runtime.io.network.partition.consumer.InputChannel
-
- org.apache.flink.runtime.io.network.partition.consumer.RecoveredInputChannel
-
- org.apache.flink.runtime.io.network.partition.consumer.RemoteRecoveredInputChannel
-
- All Implemented Interfaces:
ChannelStateHolder
public class RemoteRecoveredInputChannel extends RecoveredInputChannel
An input channel reads recovered state from previous unaligned checkpoint snapshots and then converts intoRemoteInputChannel
finally.
-
-
Nested Class Summary
-
Nested classes/interfaces inherited from class org.apache.flink.runtime.io.network.partition.consumer.InputChannel
InputChannel.BufferAndAvailability
-
-
Field Summary
-
Fields inherited from class org.apache.flink.runtime.io.network.partition.consumer.RecoveredInputChannel
bufferManager, channelStateWriter, networkBuffersPerChannel
-
Fields inherited from class org.apache.flink.runtime.io.network.partition.consumer.InputChannel
channelInfo, consumedSubpartitionIndexSet, currentBackoff, initialBackoff, inputGate, maxBackoff, numBuffersIn, numBytesIn, partitionId
-
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description protected InputChannel
toInputChannelInternal()
-
Methods inherited from class org.apache.flink.runtime.io.network.partition.consumer.RecoveredInputChannel
acknowledgeAllRecordsProcessed, checkpointStarted, checkpointStopped, finishReadRecoveredState, getNextBuffer, getNumberOfQueuedBuffers, onRecoveredStateBuffer, peekNextBufferSubpartitionIdInternal, requestBufferBlocking, resumeConsumption, setChannelStateWriter, toInputChannel
-
Methods inherited from class org.apache.flink.runtime.io.network.partition.consumer.InputChannel
checkError, convertToPriorityEvent, getChannelIndex, getChannelInfo, getConsumedSubpartitionIndexSet, getCurrentBackoff, getPartitionId, increaseBackoff, notifyBufferAvailable, notifyChannelNonEmpty, notifyPriorityEvent, notifyRequiredSegmentId, peekNextBufferSubpartitionId, setError, unsynchronizedGetNumberOfQueuedBuffers, unsynchronizedGetSizeOfQueuedBuffers
-
-
-
-
Method Detail
-
toInputChannelInternal
protected InputChannel toInputChannelInternal() throws IOException
- Specified by:
toInputChannelInternal
in classRecoveredInputChannel
- Throws:
IOException
-
-