public abstract class CheckpointBarrierHandler extends Object implements Closeable
CheckpointBarrierHandler
reacts to checkpoint barrier arriving from the input
channels. Different implementations may either simply track barriers, or block certain inputs on
barriers.构造器和说明 |
---|
CheckpointBarrierHandler(org.apache.flink.runtime.jobgraph.tasks.AbstractInvokable toNotifyOnCheckpoint) |
限定符和类型 | 方法和说明 |
---|---|
void |
addProcessedBytes(int bytes) |
void |
close() |
long |
getAlignmentDurationNanos() |
CompletableFuture<Void> |
getAllBarriersReceivedFuture(long checkpointId) |
long |
getCheckpointStartDelayNanos() |
abstract long |
getLatestCheckpointId() |
protected abstract boolean |
isCheckpointPending() |
protected void |
markAlignmentEnd() |
protected void |
markAlignmentEnd(long alignmentDuration) |
protected void |
markAlignmentStart(long checkpointId,
long checkpointCreationTimestamp) |
protected void |
markAlignmentStartAndEnd(long checkpointId,
long checkpointCreationTimestamp) |
protected void |
notifyAbort(long checkpointId,
org.apache.flink.runtime.checkpoint.CheckpointException cause) |
protected void |
notifyAbortOnCancellationBarrier(long checkpointId) |
protected void |
notifyCheckpoint(org.apache.flink.runtime.io.network.api.CheckpointBarrier checkpointBarrier) |
abstract void |
processBarrier(org.apache.flink.runtime.io.network.api.CheckpointBarrier receivedBarrier,
org.apache.flink.runtime.checkpoint.channel.InputChannelInfo channelInfo) |
abstract void |
processBarrierAnnouncement(org.apache.flink.runtime.io.network.api.CheckpointBarrier announcedBarrier,
int sequenceNumber,
org.apache.flink.runtime.checkpoint.channel.InputChannelInfo channelInfo) |
abstract void |
processCancellationBarrier(org.apache.flink.runtime.io.network.api.CancelCheckpointMarker cancelBarrier) |
abstract void |
processEndOfPartition() |
protected void |
resetAlignment() |
public CheckpointBarrierHandler(org.apache.flink.runtime.jobgraph.tasks.AbstractInvokable toNotifyOnCheckpoint)
public void close() throws IOException
close
在接口中 Closeable
close
在接口中 AutoCloseable
IOException
public abstract void processBarrier(org.apache.flink.runtime.io.network.api.CheckpointBarrier receivedBarrier, org.apache.flink.runtime.checkpoint.channel.InputChannelInfo channelInfo) throws IOException
IOException
public abstract void processBarrierAnnouncement(org.apache.flink.runtime.io.network.api.CheckpointBarrier announcedBarrier, int sequenceNumber, org.apache.flink.runtime.checkpoint.channel.InputChannelInfo channelInfo) throws IOException
IOException
public abstract void processCancellationBarrier(org.apache.flink.runtime.io.network.api.CancelCheckpointMarker cancelBarrier) throws IOException
IOException
public abstract void processEndOfPartition() throws IOException
IOException
public abstract long getLatestCheckpointId()
public long getAlignmentDurationNanos()
public long getCheckpointStartDelayNanos()
public CompletableFuture<Void> getAllBarriersReceivedFuture(long checkpointId)
protected void notifyCheckpoint(org.apache.flink.runtime.io.network.api.CheckpointBarrier checkpointBarrier) throws IOException
IOException
protected void notifyAbortOnCancellationBarrier(long checkpointId) throws IOException
IOException
protected void notifyAbort(long checkpointId, org.apache.flink.runtime.checkpoint.CheckpointException cause) throws IOException
IOException
protected void markAlignmentStartAndEnd(long checkpointId, long checkpointCreationTimestamp)
protected void markAlignmentStart(long checkpointId, long checkpointCreationTimestamp)
protected void markAlignmentEnd()
protected void markAlignmentEnd(long alignmentDuration)
protected void resetAlignment()
protected abstract boolean isCheckpointPending()
public void addProcessedBytes(int bytes)
Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.