@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.限定符和类型 | 方法和说明 |
---|---|
void |
abortPendingCheckpoint(long checkpointId,
org.apache.flink.runtime.checkpoint.CheckpointException exception) |
protected void |
beginNewAlignment(long checkpointId,
org.apache.flink.runtime.checkpoint.channel.InputChannelInfo channelInfo,
long checkpointTimestamp) |
long |
getAlignmentDurationNanos() |
long |
getLatestCheckpointId() |
int |
getNumClosedChannels() |
boolean |
isBlocked(org.apache.flink.runtime.checkpoint.channel.InputChannelInfo channelInfo)
Checks whether the channel with the given index is blocked.
|
protected boolean |
isCheckpointPending() |
protected void |
onBarrier(org.apache.flink.runtime.checkpoint.channel.InputChannelInfo channelInfo)
Blocks the given channel index, from which a barrier has been received.
|
void |
processBarrier(org.apache.flink.runtime.io.network.api.CheckpointBarrier receivedBarrier,
org.apache.flink.runtime.checkpoint.channel.InputChannelInfo channelInfo) |
void |
processCancellationBarrier(org.apache.flink.runtime.io.network.api.CancelCheckpointMarker cancelBarrier) |
void |
processEndOfPartition() |
void |
releaseBlocksAndResetBarriers() |
String |
toString() |
close, executeInTaskThread, getAllBarriersReceivedFuture, getBufferReceivedListener, getCheckpointStartDelayNanos, hasInflightData, markCheckpointStart, notifyAbort, notifyAbortOnCancellationBarrier, notifyCheckpoint
public void abortPendingCheckpoint(long checkpointId, org.apache.flink.runtime.checkpoint.CheckpointException exception) throws IOException
public void releaseBlocksAndResetBarriers() throws IOException
public boolean isBlocked(org.apache.flink.runtime.checkpoint.channel.InputChannelInfo channelInfo)
CheckpointBarrierHandler
isBlocked
在类中 CheckpointBarrierHandler
channelInfo
- The channel index to check.public void processBarrier(org.apache.flink.runtime.io.network.api.CheckpointBarrier receivedBarrier, org.apache.flink.runtime.checkpoint.channel.InputChannelInfo channelInfo) throws Exception
processBarrier
在类中 CheckpointBarrierHandler
Exception
protected void beginNewAlignment(long checkpointId, org.apache.flink.runtime.checkpoint.channel.InputChannelInfo channelInfo, long checkpointTimestamp) throws IOException
IOException
protected void onBarrier(org.apache.flink.runtime.checkpoint.channel.InputChannelInfo channelInfo) throws IOException
channelInfo
- The channel to block.IOException
public void processCancellationBarrier(org.apache.flink.runtime.io.network.api.CancelCheckpointMarker cancelBarrier) throws Exception
processCancellationBarrier
在类中 CheckpointBarrierHandler
Exception
public void processEndOfPartition() throws Exception
processEndOfPartition
在类中 CheckpointBarrierHandler
Exception
public long getLatestCheckpointId()
public long getAlignmentDurationNanos()
protected boolean isCheckpointPending()
@VisibleForTesting public int getNumClosedChannels()
Copyright © 2014–2020 The Apache Software Foundation. All rights reserved.