public class DefaultCheckpointPlanCalculator extends Object implements CheckpointPlanCalculator
CheckpointPlanCalculator
. If all tasks are running, it
directly marks all the sources as tasks to trigger, otherwise it would try to find the running
tasks without running processors as tasks to trigger.Constructor and Description |
---|
DefaultCheckpointPlanCalculator(JobID jobId,
CheckpointPlanCalculatorContext context,
Iterable<ExecutionJobVertex> jobVerticesInTopologyOrderIterable) |
Modifier and Type | Method and Description |
---|---|
CompletableFuture<org.apache.flink.runtime.checkpoint.CheckpointPlan> |
calculateCheckpointPlan()
Calculates the plan of the next checkpoint.
|
void |
setAllowCheckpointsAfterTasksFinished(boolean allowCheckpointsAfterTasksFinished) |
public DefaultCheckpointPlanCalculator(JobID jobId, CheckpointPlanCalculatorContext context, Iterable<ExecutionJobVertex> jobVerticesInTopologyOrderIterable)
public void setAllowCheckpointsAfterTasksFinished(boolean allowCheckpointsAfterTasksFinished)
public CompletableFuture<org.apache.flink.runtime.checkpoint.CheckpointPlan> calculateCheckpointPlan()
CheckpointPlanCalculator
calculateCheckpointPlan
in interface CheckpointPlanCalculator
Copyright © 2014–2022 The Apache Software Foundation. All rights reserved.