Modifier and Type | Method and Description |
---|---|
SavepointFormatType |
CancelOptions.getFormatType() |
SavepointFormatType |
SavepointOptions.getFormatType() |
Modifier and Type | Method and Description |
---|---|
CompletableFuture<String> |
ClusterClientJobClientAdapter.stopWithSavepoint(boolean advanceToEndOfEventTime,
String savepointDirectory,
SavepointFormatType formatType) |
CompletableFuture<String> |
ClusterClientJobClientAdapter.triggerSavepoint(String savepointDirectory,
SavepointFormatType formatType) |
Modifier and Type | Method and Description |
---|---|
CompletableFuture<String> |
WebSubmissionJobClient.stopWithSavepoint(boolean advanceToEndOfEventTime,
String savepointDirectory,
SavepointFormatType formatType) |
CompletableFuture<String> |
EmbeddedJobClient.stopWithSavepoint(boolean advanceToEndOfEventTime,
String savepointDirectory,
SavepointFormatType formatType) |
CompletableFuture<String> |
WebSubmissionJobClient.triggerSavepoint(String savepointDirectory,
SavepointFormatType formatType) |
CompletableFuture<String> |
EmbeddedJobClient.triggerSavepoint(String savepointDirectory,
SavepointFormatType formatType) |
Modifier and Type | Method and Description |
---|---|
CompletableFuture<String> |
ClusterClient.cancelWithSavepoint(JobID jobId,
String savepointDirectory,
SavepointFormatType formatType)
Cancels a job identified by the job id and triggers a savepoint.
|
CompletableFuture<String> |
MiniClusterClient.cancelWithSavepoint(JobID jobId,
String savepointDirectory,
SavepointFormatType formatType) |
CompletableFuture<String> |
ClusterClient.stopWithDetachedSavepoint(JobID jobId,
boolean advanceToEndOfEventTime,
String savepointDirectory,
SavepointFormatType formatType)
Stops a program on Flink cluster whose job-manager is configured in this client's
configuration.
|
CompletableFuture<String> |
MiniClusterClient.stopWithDetachedSavepoint(JobID jobId,
boolean advanceToEndOfEventTime,
String savepointDirectory,
SavepointFormatType formatType) |
CompletableFuture<String> |
ClusterClient.stopWithSavepoint(JobID jobId,
boolean advanceToEndOfEventTime,
String savepointDirectory,
SavepointFormatType formatType)
Stops a program on Flink cluster whose job-manager is configured in this client's
configuration.
|
CompletableFuture<String> |
MiniClusterClient.stopWithSavepoint(JobID jobId,
boolean advanceToEndOfEventTime,
String savepointDirectory,
SavepointFormatType formatType) |
CompletableFuture<String> |
ClusterClient.triggerDetachedSavepoint(JobID jobId,
String savepointDirectory,
SavepointFormatType formatType)
Triggers a detached savepoint for the job identified by the job id.
|
CompletableFuture<String> |
MiniClusterClient.triggerDetachedSavepoint(JobID jobId,
String savepointDirectory,
SavepointFormatType formatType) |
CompletableFuture<String> |
ClusterClient.triggerSavepoint(JobID jobId,
String savepointDirectory,
SavepointFormatType formatType)
Triggers a savepoint for the job identified by the job id.
|
CompletableFuture<String> |
MiniClusterClient.triggerSavepoint(JobID jobId,
String savepointDirectory,
SavepointFormatType formatType) |
Modifier and Type | Method and Description |
---|---|
CompletableFuture<String> |
RestClusterClient.cancelWithSavepoint(JobID jobId,
String savepointDirectory,
SavepointFormatType formatType) |
CompletableFuture<String> |
RestClusterClient.stopWithDetachedSavepoint(JobID jobId,
boolean advanceToEndOfTime,
String savepointDirectory,
SavepointFormatType formatType) |
CompletableFuture<String> |
RestClusterClient.stopWithSavepoint(JobID jobId,
boolean advanceToEndOfTime,
String savepointDirectory,
SavepointFormatType formatType) |
CompletableFuture<String> |
RestClusterClient.stopWithSavepoint(JobID jobId,
boolean advanceToEndOfTime,
String savepointDirectory,
SavepointFormatType formatType,
boolean isDetachedMode) |
CompletableFuture<String> |
RestClusterClient.triggerDetachedSavepoint(JobID jobId,
String savepointDirectory,
SavepointFormatType formatType) |
CompletableFuture<String> |
RestClusterClient.triggerSavepoint(JobID jobId,
String savepointDirectory,
SavepointFormatType formatType) |
Modifier and Type | Method and Description |
---|---|
boolean |
EmbeddedRocksDBStateBackend.supportsSavepointFormat(SavepointFormatType formatType) |
boolean |
RocksDBStateBackend.supportsSavepointFormat(SavepointFormatType formatType)
Deprecated.
|
Modifier and Type | Field and Description |
---|---|
static SavepointFormatType |
SavepointFormatType.DEFAULT |
Modifier and Type | Method and Description |
---|---|
static SavepointFormatType |
SavepointFormatType.valueOf(String name)
Returns the enum constant of this type with the specified name.
|
static SavepointFormatType[] |
SavepointFormatType.values()
Returns an array containing the constants of this enum type, in
the order they are declared.
|
Modifier and Type | Method and Description |
---|---|
CompletableFuture<String> |
JobClient.stopWithSavepoint(boolean advanceToEndOfEventTime,
String savepointDirectory,
SavepointFormatType formatType)
Stops the associated job on Flink cluster.
|
CompletableFuture<String> |
JobClient.triggerSavepoint(String savepointDirectory,
SavepointFormatType formatType)
Triggers a savepoint for the associated job.
|
Modifier and Type | Method and Description |
---|---|
SavepointFormatType |
SavepointType.getFormatType() |
Modifier and Type | Method and Description |
---|---|
static CheckpointProperties |
CheckpointProperties.forSavepoint(boolean forced,
SavepointFormatType formatType)
Creates the checkpoint properties for a (manually triggered) savepoint.
|
static CheckpointProperties |
CheckpointProperties.forSyncSavepoint(boolean forced,
boolean terminate,
SavepointFormatType formatType) |
static SavepointType |
SavepointType.savepoint(SavepointFormatType formatType) |
static SavepointType |
SavepointType.suspend(SavepointFormatType formatType) |
static SavepointType |
SavepointType.terminate(SavepointFormatType formatType) |
CompletableFuture<CompletedCheckpoint> |
CheckpointCoordinator.triggerSavepoint(String targetLocation,
SavepointFormatType formatType)
Triggers a savepoint with the given savepoint directory as a target.
|
CompletableFuture<CompletedCheckpoint> |
CheckpointCoordinator.triggerSynchronousSavepoint(boolean terminate,
String targetLocation,
SavepointFormatType formatType)
Triggers a synchronous savepoint with the given savepoint directory as a target.
|
Modifier and Type | Method and Description |
---|---|
CompletableFuture<String> |
TriggerSavepointFunction.apply(JobID jobId,
String targetDirectory,
SavepointFormatType formatType,
TriggerSavepointMode savepointMode,
Time timeout) |
CompletableFuture<Acknowledge> |
DispatcherCachedOperationsHandler.stopWithSavepoint(AsynchronousJobOperationKey operationKey,
String targetDirectory,
SavepointFormatType formatType,
TriggerSavepointMode savepointMode,
Time timeout) |
CompletableFuture<Acknowledge> |
Dispatcher.stopWithSavepoint(AsynchronousJobOperationKey operationKey,
String targetDirectory,
SavepointFormatType formatType,
TriggerSavepointMode savepointMode,
Time timeout) |
default CompletableFuture<String> |
DispatcherGateway.stopWithSavepointAndGetLocation(JobID jobId,
String targetDirectory,
SavepointFormatType formatType,
TriggerSavepointMode savepointMode,
Time timeout)
Stops the job with a savepoint, returning a future that completes with the savepoint location
when the savepoint is completed.
|
CompletableFuture<String> |
Dispatcher.stopWithSavepointAndGetLocation(JobID jobId,
String targetDirectory,
SavepointFormatType formatType,
TriggerSavepointMode savepointMode,
Time timeout) |
CompletableFuture<Acknowledge> |
DispatcherCachedOperationsHandler.triggerSavepoint(AsynchronousJobOperationKey operationKey,
String targetDirectory,
SavepointFormatType formatType,
TriggerSavepointMode savepointMode,
Time timeout) |
CompletableFuture<Acknowledge> |
Dispatcher.triggerSavepoint(AsynchronousJobOperationKey operationKey,
String targetDirectory,
SavepointFormatType formatType,
TriggerSavepointMode savepointMode,
Time timeout) |
default CompletableFuture<String> |
DispatcherGateway.triggerSavepointAndGetLocation(JobID jobId,
String targetDirectory,
SavepointFormatType formatType,
TriggerSavepointMode savepointMode,
Time timeout)
Triggers a savepoint with the given savepoint directory as a target, returning a future that
completes with the savepoint location when it is complete.
|
CompletableFuture<String> |
Dispatcher.triggerSavepointAndGetLocation(JobID jobId,
String targetDirectory,
SavepointFormatType formatType,
TriggerSavepointMode savepointMode,
Time timeout) |
Modifier and Type | Method and Description |
---|---|
CompletableFuture<String> |
JobMaster.stopWithSavepoint(String targetDirectory,
SavepointFormatType formatType,
boolean terminate,
Time timeout) |
CompletableFuture<String> |
JobMasterGateway.stopWithSavepoint(String targetDirectory,
SavepointFormatType formatType,
boolean terminate,
Time timeout)
Stops the job with a savepoint.
|
CompletableFuture<String> |
JobMaster.triggerSavepoint(String targetDirectory,
boolean cancelJob,
SavepointFormatType formatType,
Time timeout) |
CompletableFuture<String> |
JobMasterGateway.triggerSavepoint(String targetDirectory,
boolean cancelJob,
SavepointFormatType formatType,
Time timeout)
Triggers taking a savepoint of the executed job.
|
Modifier and Type | Method and Description |
---|---|
CompletableFuture<String> |
MiniCluster.stopWithDetachedSavepoint(JobID jobId,
String targetDirectory,
boolean terminate,
SavepointFormatType formatType) |
CompletableFuture<String> |
MiniClusterJobClient.stopWithSavepoint(boolean terminate,
String savepointDirectory,
SavepointFormatType formatType) |
CompletableFuture<String> |
MiniCluster.stopWithSavepoint(JobID jobId,
String targetDirectory,
boolean terminate,
SavepointFormatType formatType) |
CompletableFuture<String> |
MiniCluster.triggerDetachedSavepoint(JobID jobId,
String targetDirectory,
boolean cancelJob,
SavepointFormatType formatType) |
CompletableFuture<String> |
MiniCluster.triggerSavepoint(JobID jobId,
String targetDirectory,
boolean cancelJob,
SavepointFormatType formatType) |
CompletableFuture<String> |
MiniClusterJobClient.triggerSavepoint(String savepointDirectory,
SavepointFormatType formatType) |
Modifier and Type | Method and Description |
---|---|
SavepointFormatType |
SavepointTriggerRequestBody.getFormatType() |
Constructor and Description |
---|
SavepointTriggerRequestBody(String targetDirectory,
Boolean cancelJob,
SavepointFormatType formatType,
TriggerId triggerId) |
Modifier and Type | Method and Description |
---|---|
SavepointFormatType |
StopWithSavepointRequestBody.getFormatType() |
Constructor and Description |
---|
StopWithSavepointRequestBody(String targetDirectory,
Boolean drain,
SavepointFormatType formatType,
TriggerId triggerId) |
Modifier and Type | Method and Description |
---|---|
CompletableFuture<String> |
SchedulerBase.stopWithSavepoint(String targetDirectory,
boolean terminate,
SavepointFormatType formatType) |
CompletableFuture<String> |
SchedulerNG.stopWithSavepoint(String targetDirectory,
boolean terminate,
SavepointFormatType formatType) |
CompletableFuture<String> |
SchedulerBase.triggerSavepoint(String targetDirectory,
boolean cancelJob,
SavepointFormatType formatType) |
CompletableFuture<String> |
SchedulerNG.triggerSavepoint(String targetDirectory,
boolean cancelJob,
SavepointFormatType formatType) |
Modifier and Type | Method and Description |
---|---|
CompletableFuture<String> |
AdaptiveScheduler.stopWithSavepoint(String targetDirectory,
boolean terminate,
SavepointFormatType formatType) |
CompletableFuture<String> |
AdaptiveScheduler.triggerSavepoint(String targetDirectory,
boolean cancelJob,
SavepointFormatType formatType) |
Modifier and Type | Method and Description |
---|---|
default boolean |
StateBackend.supportsSavepointFormat(SavepointFormatType formatType) |
Modifier and Type | Method and Description |
---|---|
boolean |
FsStateBackend.supportsSavepointFormat(SavepointFormatType formatType)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
boolean |
HashMapStateBackend.supportsSavepointFormat(SavepointFormatType formatType) |
Modifier and Type | Method and Description |
---|---|
boolean |
MemoryStateBackend.supportsSavepointFormat(SavepointFormatType formatType)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
default CompletableFuture<Acknowledge> |
RestfulGateway.stopWithSavepoint(AsynchronousJobOperationKey operationKey,
String targetDirectory,
SavepointFormatType formatType,
TriggerSavepointMode savepointMode,
Time timeout)
Stops the job with a savepoint, returning a future that completes when the operation is
started.
|
default CompletableFuture<Acknowledge> |
RestfulGateway.triggerSavepoint(AsynchronousJobOperationKey operationKey,
String targetDirectory,
SavepointFormatType formatType,
TriggerSavepointMode savepointMode,
Time timeout)
Triggers a savepoint with the given savepoint directory as a target, returning a future that
completes when the operation is started.
|
Modifier and Type | Method and Description |
---|---|
static <OUT,OP extends StreamOperator<OUT>> |
SnapshotUtils.snapshot(OP operator,
int index,
long timestamp,
boolean isExactlyOnceMode,
boolean isUnalignedCheckpoint,
Configuration configuration,
Path savepointPath,
SavepointFormatType savepointFormatType) |
Modifier and Type | Method and Description |
---|---|
boolean |
AbstractChangelogStateBackend.supportsSavepointFormat(SavepointFormatType formatType) |
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.