Package | Description |
---|---|
org.apache.flink.runtime.checkpoint |
Modifier and Type | Method and Description |
---|---|
CompletedCheckpoint |
PendingCheckpoint.finalizeCheckpoint() |
CompletedCheckpoint |
ZooKeeperCompletedCheckpointStore.getLatestCheckpoint() |
CompletedCheckpoint |
StandaloneCompletedCheckpointStore.getLatestCheckpoint() |
CompletedCheckpoint |
CompletedCheckpointStore.getLatestCheckpoint()
Returns the latest
CompletedCheckpoint instance or null if none was
added. |
static CompletedCheckpoint |
Checkpoints.loadAndValidateCheckpoint(JobID jobId,
Map<JobVertexID,ExecutionJobVertex> tasks,
CompletedCheckpointStorageLocation location,
ClassLoader classLoader,
boolean allowNonRestoredState) |
Modifier and Type | Method and Description |
---|---|
List<CompletedCheckpoint> |
ZooKeeperCompletedCheckpointStore.getAllCheckpoints() |
List<CompletedCheckpoint> |
StandaloneCompletedCheckpointStore.getAllCheckpoints() |
List<CompletedCheckpoint> |
CompletedCheckpointStore.getAllCheckpoints()
Returns all
CompletedCheckpoint instances. |
CompletableFuture<CompletedCheckpoint> |
PendingCheckpoint.getCompletionFuture()
Returns the completion future.
|
List<CompletedCheckpoint> |
CheckpointCoordinator.getSuccessfulCheckpoints() |
CompletableFuture<CompletedCheckpoint> |
CheckpointCoordinator.triggerSavepoint(long timestamp,
String targetLocation)
Triggers a savepoint with the given savepoint directory as a target.
|
Modifier and Type | Method and Description |
---|---|
void |
ZooKeeperCompletedCheckpointStore.addCheckpoint(CompletedCheckpoint checkpoint)
Synchronously writes the new checkpoints to ZooKeeper and asynchronously removes older ones.
|
void |
StandaloneCompletedCheckpointStore.addCheckpoint(CompletedCheckpoint checkpoint) |
void |
CompletedCheckpointStore.addCheckpoint(CompletedCheckpoint checkpoint)
Adds a
CompletedCheckpoint instance to the list of completed checkpoints. |
Modifier and Type | Method and Description |
---|---|
static boolean |
CompletedCheckpoint.checkpointsMatch(Collection<CompletedCheckpoint> first,
Collection<CompletedCheckpoint> second) |
static boolean |
CompletedCheckpoint.checkpointsMatch(Collection<CompletedCheckpoint> first,
Collection<CompletedCheckpoint> second) |
Constructor and Description |
---|
ZooKeeperCompletedCheckpointStore(int maxNumberOfCheckpointsToRetain,
ZooKeeperStateHandleStore<CompletedCheckpoint> checkpointsInZooKeeper,
Executor executor)
Creates a
ZooKeeperCompletedCheckpointStore instance. |
Copyright © 2014–2020 The Apache Software Foundation. All rights reserved.