@Internal public class CheckpointBarrierTracker extends CheckpointBarrierHandler
CheckpointBarrierTracker
keeps track of what checkpoint barriers have been received from
which input channels. Once it has observed all checkpoint barriers for a checkpoint ID,
it notifies its listener of a completed checkpoint.
Unlike the CheckpointBarrierAligner
, the BarrierTracker does not block the input
channels that have sent barriers, so it cannot be used to gain "exactly-once" processing
guarantees. It can, however, be used to gain "at least once" processing guarantees.
NOTE: This implementation strictly assumes that newer checkpoints have higher checkpoint IDs.
构造器和说明 |
---|
CheckpointBarrierTracker(int totalNumberOfInputChannels,
org.apache.flink.runtime.jobgraph.tasks.AbstractInvokable toNotifyOnCheckpoint) |
限定符和类型 | 方法和说明 |
---|---|
long |
getLatestCheckpointId() |
boolean |
isCheckpointPending() |
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() |
abortPendingCheckpoint, close, executeInTaskThread, getAlignmentDurationNanos, getAllBarriersReceivedFuture, getBufferReceivedListener, getCheckpointStartDelayNanos, hasInflightData, isBlocked, markCheckpointStart, notifyAbort, notifyAbortOnCancellationBarrier, notifyCheckpoint, releaseBlocksAndResetBarriers
public CheckpointBarrierTracker(int totalNumberOfInputChannels, org.apache.flink.runtime.jobgraph.tasks.AbstractInvokable toNotifyOnCheckpoint)
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
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 boolean isCheckpointPending()
Copyright © 2014–2020 The Apache Software Foundation. All rights reserved.