@Internal public class CheckpointBarrierAligner extends CheckpointBarrierHandler
CheckpointBarrierAligner
keep tracks of received CheckpointBarrier
on given
channels and controls the alignment, by deciding which channels should be blocked and when to
release blocked channels.限定符和类型 | 方法和说明 |
---|---|
protected void |
beginNewAlignment(long checkpointId,
int channelIndex) |
void |
checkpointSizeLimitExceeded(long maxBufferedBytes) |
long |
getAlignmentDurationNanos() |
long |
getLatestCheckpointId() |
boolean |
isBlocked(int channelIndex)
Checks whether the channel with the given index is blocked.
|
protected void |
onBarrier(int channelIndex)
Blocks the given channel index, from which a barrier has been received.
|
boolean |
processBarrier(org.apache.flink.runtime.io.network.api.CheckpointBarrier receivedBarrier,
int channelIndex,
long bufferedBytes) |
boolean |
processCancellationBarrier(org.apache.flink.runtime.io.network.api.CancelCheckpointMarker cancelBarrier) |
boolean |
processEndOfPartition() |
void |
releaseBlocksAndResetBarriers() |
String |
toString() |
notifyAbort, notifyAbortOnCancellationBarrier, notifyCheckpoint
public void releaseBlocksAndResetBarriers()
public boolean isBlocked(int channelIndex)
CheckpointBarrierHandler
isBlocked
在类中 CheckpointBarrierHandler
channelIndex
- The channel index to check.public boolean processBarrier(org.apache.flink.runtime.io.network.api.CheckpointBarrier receivedBarrier, int channelIndex, long bufferedBytes) throws Exception
processBarrier
在类中 CheckpointBarrierHandler
Exception
protected void beginNewAlignment(long checkpointId, int channelIndex) throws IOException
IOException
protected void onBarrier(int channelIndex) throws IOException
channelIndex
- The channel index to block.IOException
public boolean processCancellationBarrier(org.apache.flink.runtime.io.network.api.CancelCheckpointMarker cancelBarrier) throws Exception
processCancellationBarrier
在类中 CheckpointBarrierHandler
Exception
public boolean processEndOfPartition() throws Exception
processEndOfPartition
在类中 CheckpointBarrierHandler
Exception
public long getLatestCheckpointId()
public long getAlignmentDurationNanos()
public void checkpointSizeLimitExceeded(long maxBufferedBytes) throws Exception
checkpointSizeLimitExceeded
在类中 CheckpointBarrierHandler
Exception
Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.