CompletableFuture<String> |
TriggerSavepointFunction.apply(org.apache.flink.api.common.JobID jobId,
String targetDirectory,
org.apache.flink.core.execution.SavepointFormatType formatType,
TriggerSavepointMode savepointMode,
Duration timeout) |
|
CompletableFuture<Acknowledge> |
Dispatcher.stopWithSavepoint(AsynchronousJobOperationKey operationKey,
String targetDirectory,
org.apache.flink.core.execution.SavepointFormatType formatType,
TriggerSavepointMode savepointMode,
Duration timeout) |
|
CompletableFuture<Acknowledge> |
DispatcherCachedOperationsHandler.stopWithSavepoint(AsynchronousJobOperationKey operationKey,
String targetDirectory,
org.apache.flink.core.execution.SavepointFormatType formatType,
TriggerSavepointMode savepointMode,
Duration timeout) |
|
CompletableFuture<String> |
Dispatcher.stopWithSavepointAndGetLocation(org.apache.flink.api.common.JobID jobId,
String targetDirectory,
org.apache.flink.core.execution.SavepointFormatType formatType,
TriggerSavepointMode savepointMode,
Duration timeout) |
|
default CompletableFuture<String> |
DispatcherGateway.stopWithSavepointAndGetLocation(org.apache.flink.api.common.JobID jobId,
String targetDirectory,
org.apache.flink.core.execution.SavepointFormatType formatType,
TriggerSavepointMode savepointMode,
Duration timeout) |
Stops the job with a savepoint, returning a future that completes with the savepoint location
when the savepoint is completed.
|
CompletableFuture<Acknowledge> |
Dispatcher.triggerSavepoint(AsynchronousJobOperationKey operationKey,
String targetDirectory,
org.apache.flink.core.execution.SavepointFormatType formatType,
TriggerSavepointMode savepointMode,
Duration timeout) |
|
CompletableFuture<Acknowledge> |
DispatcherCachedOperationsHandler.triggerSavepoint(AsynchronousJobOperationKey operationKey,
String targetDirectory,
org.apache.flink.core.execution.SavepointFormatType formatType,
TriggerSavepointMode savepointMode,
Duration timeout) |
|
CompletableFuture<String> |
Dispatcher.triggerSavepointAndGetLocation(org.apache.flink.api.common.JobID jobId,
String targetDirectory,
org.apache.flink.core.execution.SavepointFormatType formatType,
TriggerSavepointMode savepointMode,
Duration timeout) |
|
default CompletableFuture<String> |
DispatcherGateway.triggerSavepointAndGetLocation(org.apache.flink.api.common.JobID jobId,
String targetDirectory,
org.apache.flink.core.execution.SavepointFormatType formatType,
TriggerSavepointMode savepointMode,
Duration 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.
|