Package | Description |
---|---|
org.apache.flink.runtime.checkpoint | |
org.apache.flink.runtime.executiongraph | |
org.apache.flink.runtime.util |
Modifier and Type | Class and Description |
---|---|
class |
ZooKeeperCompletedCheckpointStore
CompletedCheckpointStore for JobManagers running in RecoveryMode.ZOOKEEPER . |
Modifier and Type | Method and Description |
---|---|
CompletedCheckpointStore |
StandaloneCheckpointRecoveryFactory.createCompletedCheckpoints(org.apache.flink.api.common.JobID jobId,
ClassLoader userClassLoader) |
CompletedCheckpointStore |
CheckpointRecoveryFactory.createCompletedCheckpoints(org.apache.flink.api.common.JobID jobId,
ClassLoader userClassLoader)
Creates a
CompletedCheckpointStore instance for a job. |
CompletedCheckpointStore |
ZooKeeperCheckpointRecoveryFactory.createCompletedCheckpoints(org.apache.flink.api.common.JobID jobId,
ClassLoader userClassLoader) |
Constructor and Description |
---|
CheckpointCoordinator(org.apache.flink.api.common.JobID job,
long checkpointTimeout,
ExecutionVertex[] tasksToTrigger,
ExecutionVertex[] tasksToWaitFor,
ExecutionVertex[] tasksToCommitTo,
ClassLoader userClassLoader,
CheckpointIDCounter checkpointIDCounter,
CompletedCheckpointStore completedCheckpointStore,
RecoveryMode recoveryMode) |
Modifier and Type | Method and Description |
---|---|
void |
ExecutionGraph.enableSnapshotCheckpointing(long interval,
long checkpointTimeout,
List<ExecutionJobVertex> verticesToTrigger,
List<ExecutionJobVertex> verticesToWaitFor,
List<ExecutionJobVertex> verticesToCommitTo,
akka.actor.ActorSystem actorSystem,
UUID leaderSessionID,
CheckpointIDCounter checkpointIDCounter,
CompletedCheckpointStore completedCheckpointStore,
RecoveryMode recoveryMode) |
Modifier and Type | Method and Description |
---|---|
static CompletedCheckpointStore |
ZooKeeperUtils.createCompletedCheckpoints(org.apache.curator.framework.CuratorFramework client,
org.apache.flink.configuration.Configuration configuration,
org.apache.flink.api.common.JobID jobId,
int maxNumberOfCheckpointsToRetain,
ClassLoader userClassLoader)
Creates a
ZooKeeperCompletedCheckpointStore instance. |
Copyright © 2014–2015 The Apache Software Foundation. All rights reserved.