@Internal @NotThreadSafe public class SingleCheckpointBarrierHandler extends CheckpointBarrierHandler
SingleCheckpointBarrierHandler
is used for triggering checkpoint while reading the first
barrier and keeping track of the number of received barriers and consumed barriers. It can
handle/track just single checkpoint at a time. The behaviour when to actually trigger the
checkpoint and what the CheckpointableInput
should do is controlled by CheckpointBarrierBehaviourController
.限定符和类型 | 方法和说明 |
---|---|
void |
close() |
CompletableFuture<Void> |
getAllBarriersReceivedFuture(long checkpointId) |
long |
getLatestCheckpointId() |
protected boolean |
isCheckpointPending() |
void |
processBarrier(org.apache.flink.runtime.io.network.api.CheckpointBarrier barrier,
org.apache.flink.runtime.checkpoint.channel.InputChannelInfo channelInfo) |
void |
processBarrierAnnouncement(org.apache.flink.runtime.io.network.api.CheckpointBarrier announcedBarrier,
int sequenceNumber,
org.apache.flink.runtime.checkpoint.channel.InputChannelInfo channelInfo) |
void |
processCancellationBarrier(org.apache.flink.runtime.io.network.api.CancelCheckpointMarker cancelBarrier) |
void |
processEndOfPartition() |
String |
toString() |
addProcessedBytes, getAlignmentDurationNanos, getCheckpointStartDelayNanos, markAlignmentEnd, markAlignmentEnd, markAlignmentStart, markAlignmentStartAndEnd, notifyAbort, notifyAbortOnCancellationBarrier, notifyCheckpoint
public void processBarrier(org.apache.flink.runtime.io.network.api.CheckpointBarrier barrier, org.apache.flink.runtime.checkpoint.channel.InputChannelInfo channelInfo) throws IOException
processBarrier
在类中 CheckpointBarrierHandler
IOException
public void processBarrierAnnouncement(org.apache.flink.runtime.io.network.api.CheckpointBarrier announcedBarrier, int sequenceNumber, org.apache.flink.runtime.checkpoint.channel.InputChannelInfo channelInfo) throws IOException
public void processCancellationBarrier(org.apache.flink.runtime.io.network.api.CancelCheckpointMarker cancelBarrier) throws IOException
public void processEndOfPartition() throws IOException
processEndOfPartition
在类中 CheckpointBarrierHandler
IOException
public long getLatestCheckpointId()
public void close() throws IOException
close
在接口中 Closeable
close
在接口中 AutoCloseable
close
在类中 CheckpointBarrierHandler
IOException
protected boolean isCheckpointPending()
public CompletableFuture<Void> getAllBarriersReceivedFuture(long checkpointId)
Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.