Modifier and Type | Method and Description |
---|---|
CompletedCheckpointStore |
KubernetesCheckpointRecoveryFactory.createRecoveredCompletedCheckpointStore(JobID jobID,
int maxNumberOfCheckpointsToRetain,
SharedStateRegistryFactory sharedStateRegistryFactory,
Executor ioExecutor,
RestoreMode restoreMode) |
Modifier and Type | Method and Description |
---|---|
static CompletedCheckpointStore |
KubernetesUtils.createCompletedCheckpointStore(Configuration configuration,
FlinkKubeClient kubeClient,
Executor executor,
String configMapName,
String lockIdentity,
int maxNumberOfCheckpointsToRetain,
SharedStateRegistryFactory sharedStateRegistryFactory,
Executor ioExecutor,
RestoreMode restoreMode)
Create a
DefaultCompletedCheckpointStore with KubernetesStateHandleStore . |
Modifier and Type | Method and Description |
---|---|
CompletedCheckpointStore |
StandaloneCheckpointRecoveryFactory.createRecoveredCompletedCheckpointStore(JobID jobId,
int maxNumberOfCheckpointsToRetain,
SharedStateRegistryFactory sharedStateRegistryFactory,
Executor ioExecutor,
RestoreMode restoreMode) |
CompletedCheckpointStore |
CheckpointRecoveryFactory.createRecoveredCompletedCheckpointStore(JobID jobId,
int maxNumberOfCheckpointsToRetain,
SharedStateRegistryFactory sharedStateRegistryFactory,
Executor ioExecutor,
RestoreMode restoreMode)
Creates a RECOVERED
CompletedCheckpointStore instance for a job. |
CompletedCheckpointStore |
PerJobCheckpointRecoveryFactory.createRecoveredCompletedCheckpointStore(JobID jobId,
int maxNumberOfCheckpointsToRetain,
SharedStateRegistryFactory sharedStateRegistryFactory,
Executor ioExecutor,
RestoreMode restoreMode) |
CompletedCheckpointStore |
ZooKeeperCheckpointRecoveryFactory.createRecoveredCompletedCheckpointStore(JobID jobId,
int maxNumberOfCheckpointsToRetain,
SharedStateRegistryFactory sharedStateRegistryFactory,
Executor ioExecutor,
RestoreMode restoreMode) |
static CompletedCheckpoint |
Checkpoints.loadAndValidateCheckpoint(JobID jobId,
Map<JobVertexID,ExecutionJobVertex> tasks,
CompletedCheckpointStorageLocation location,
ClassLoader classLoader,
boolean allowNonRestoredState,
CheckpointProperties checkpointProperties,
RestoreMode restoreMode) |
StoreType |
PerJobCheckpointRecoveryFactory.CheckpointStoreRecoveryHelper.recoverCheckpointStore(int maxNumberOfCheckpointsToRetain,
StoreType previousStore,
SharedStateRegistryFactory sharedStateRegistryFactory,
Executor ioExecutor,
RestoreMode restoreMode) |
void |
CompletedCheckpoint.registerSharedStatesAfterRestored(SharedStateRegistry sharedStateRegistry,
RestoreMode restoreMode)
Register all shared states in the given registry.
|
Constructor and Description |
---|
EmbeddedCompletedCheckpointStore(int maxRetainedCheckpoints,
Collection<CompletedCheckpoint> initialCheckpoints,
RestoreMode restoreMode) |
StandaloneCompletedCheckpointStore(int maxNumberOfCheckpointsToRetain,
SharedStateRegistryFactory sharedStateRegistryFactory,
Executor ioExecutor,
RestoreMode restoreMode)
Creates
StandaloneCompletedCheckpointStore . |
Modifier and Type | Field and Description |
---|---|
static RestoreMode |
RestoreMode.DEFAULT |
Modifier and Type | Field and Description |
---|---|
static ConfigOption<RestoreMode> |
SavepointConfigOptions.RESTORE_MODE
Describes the mode how Flink should restore from the given savepoint or retained checkpoint.
|
Modifier and Type | Method and Description |
---|---|
RestoreMode |
SavepointRestoreSettings.getRestoreMode()
Tells how to restore from the given savepoint.
|
static RestoreMode |
RestoreMode.valueOf(String name)
Returns the enum constant of this type with the specified name.
|
static RestoreMode[] |
RestoreMode.values()
Returns an array containing the constants of this enum type, in
the order they are declared.
|
Modifier and Type | Method and Description |
---|---|
static SavepointRestoreSettings |
SavepointRestoreSettings.forPath(String savepointPath,
boolean allowNonRestoredState,
RestoreMode restoreMode) |
Modifier and Type | Method and Description |
---|---|
SharedStateRegistry |
SharedStateRegistryFactory.create(Executor deleteExecutor,
Collection<CompletedCheckpoint> checkpoints,
RestoreMode restoreMode)
Factory method for
SharedStateRegistry . |
void |
SharedStateRegistryImpl.registerAllAfterRestored(CompletedCheckpoint checkpoint,
RestoreMode mode) |
void |
SharedStateRegistry.registerAllAfterRestored(CompletedCheckpoint checkpoint,
RestoreMode mode)
Set the lowest checkpoint ID below which no state is discarded, inclusive.
|
Modifier and Type | Method and Description |
---|---|
static CompletedCheckpointStore |
ZooKeeperUtils.createCompletedCheckpoints(org.apache.flink.shaded.curator5.org.apache.curator.framework.CuratorFramework client,
Configuration configuration,
int maxNumberOfCheckpointsToRetain,
SharedStateRegistryFactory sharedStateRegistryFactory,
Executor ioExecutor,
Executor executor,
RestoreMode restoreMode)
Creates a
DefaultCompletedCheckpointStore instance with ZooKeeperStateHandleStore . |
Modifier and Type | Method and Description |
---|---|
RestoreMode |
JarRunRequestBody.getRestoreMode() |
Constructor and Description |
---|
JarRunRequestBody(String entryClassName,
String programArguments,
List<String> programArgumentsList,
Integer parallelism,
JobID jobId,
Boolean allowNonRestoredState,
String savepointPath,
RestoreMode restoreMode) |
Copyright © 2014–2023 The Apache Software Foundation. All rights reserved.