Uses of Class
org.apache.flink.runtime.messages.Acknowledge
-
Packages that use Acknowledge Package Description org.apache.flink.runtime.blocklist org.apache.flink.runtime.dispatcher org.apache.flink.runtime.dispatcher.cleanup org.apache.flink.runtime.executiongraph org.apache.flink.runtime.jobmanager.slots org.apache.flink.runtime.jobmaster org.apache.flink.runtime.jobmaster.slotpool org.apache.flink.runtime.messages This package contains the messages that are sent between Flink's distributed components to coordinate the distributed operations.org.apache.flink.runtime.minicluster org.apache.flink.runtime.operators.coordination org.apache.flink.runtime.resourcemanager org.apache.flink.runtime.rest.handler.job.rescaling org.apache.flink.runtime.rest.handler.job.savepoints org.apache.flink.runtime.taskexecutor org.apache.flink.runtime.webmonitor -
-
Uses of Acknowledge in org.apache.flink.runtime.blocklist
Methods in org.apache.flink.runtime.blocklist that return types with arguments of type Acknowledge Modifier and Type Method Description CompletableFuture<Acknowledge>
BlocklistListener. notifyNewBlockedNodes(Collection<BlockedNode> newNodes)
Notify new blocked node records. -
Uses of Acknowledge in org.apache.flink.runtime.dispatcher
Methods in org.apache.flink.runtime.dispatcher that return types with arguments of type Acknowledge Modifier and Type Method Description CompletableFuture<Acknowledge>
HistoryServerArchivist. archiveExecutionGraph(ExecutionGraphInfo executionGraphInfo)
Archives the givenExecutionGraphInfo
on the history server.CompletableFuture<Acknowledge>
VoidHistoryServerArchivist. archiveExecutionGraph(ExecutionGraphInfo executionGraph)
CompletableFuture<Acknowledge>
Dispatcher. cancelJob(org.apache.flink.api.common.JobID jobId, Duration timeout)
CompletableFuture<Acknowledge>
Dispatcher. disposeSavepoint(String savepointPath, Duration timeout)
CompletableFuture<Acknowledge>
Dispatcher. shutDownCluster()
CompletableFuture<Acknowledge>
Dispatcher. shutDownCluster(ApplicationStatus applicationStatus)
default CompletableFuture<Acknowledge>
DispatcherGateway. shutDownCluster(ApplicationStatus applicationStatus)
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<Acknowledge>
Dispatcher. submitFailedJob(org.apache.flink.api.common.JobID jobId, String jobName, Throwable exception)
CompletableFuture<Acknowledge>
DispatcherGateway. submitFailedJob(org.apache.flink.api.common.JobID jobId, String jobName, Throwable exception)
CompletableFuture<Acknowledge>
Dispatcher. submitJob(ExecutionPlan executionPlan, Duration timeout)
CompletableFuture<Acknowledge>
DispatcherGateway. submitJob(ExecutionPlan executionPlan, Duration timeout)
Submit a job to the dispatcher.CompletableFuture<Acknowledge>
Dispatcher. triggerCheckpoint(AsynchronousJobOperationKey operationKey, org.apache.flink.core.execution.CheckpointType checkpointType, Duration timeout)
CompletableFuture<Acknowledge>
DispatcherCachedOperationsHandler. triggerCheckpoint(AsynchronousJobOperationKey operationKey, org.apache.flink.core.execution.CheckpointType checkpointType, Duration timeout)
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<Acknowledge>
Dispatcher. updateJobResourceRequirements(org.apache.flink.api.common.JobID jobId, JobResourceRequirements jobResourceRequirements)
-
Uses of Acknowledge in org.apache.flink.runtime.dispatcher.cleanup
Methods in org.apache.flink.runtime.dispatcher.cleanup that return types with arguments of type Acknowledge Modifier and Type Method Description CompletableFuture<Acknowledge>
CheckpointResourcesCleanupRunner. cancel(Duration timeout)
-
Uses of Acknowledge in org.apache.flink.runtime.executiongraph
Methods in org.apache.flink.runtime.executiongraph that return types with arguments of type Acknowledge Modifier and Type Method Description CompletableFuture<Acknowledge>
Execution. sendOperatorEvent(OperatorID operatorId, org.apache.flink.util.SerializedValue<OperatorEvent> event)
Sends the operator event to the Task on the Task Executor.CompletableFuture<Acknowledge>
Execution. triggerCheckpoint(long checkpointId, long timestamp, CheckpointOptions checkpointOptions)
Trigger a new checkpoint on the task of this execution.CompletableFuture<Acknowledge>
Execution. triggerSynchronousSavepoint(long checkpointId, long timestamp, CheckpointOptions checkpointOptions)
Trigger a new checkpoint on the task of this execution. -
Uses of Acknowledge in org.apache.flink.runtime.jobmanager.slots
Methods in org.apache.flink.runtime.jobmanager.slots that return types with arguments of type Acknowledge Modifier and Type Method Description CompletableFuture<Acknowledge>
TaskManagerGateway. cancelTask(ExecutionAttemptID executionAttemptID, Duration timeout)
Cancel the given task.CompletableFuture<Acknowledge>
TaskManagerGateway. freeSlot(AllocationID allocationId, Throwable cause, Duration timeout)
Frees the slot with the given allocation ID.CompletableFuture<Acknowledge>
TaskManagerGateway. sendOperatorEventToTask(ExecutionAttemptID task, OperatorID operator, org.apache.flink.util.SerializedValue<OperatorEvent> evt)
CompletableFuture<Acknowledge>
TaskManagerGateway. submitTask(TaskDeploymentDescriptor tdd, Duration timeout)
Submit a task to the task manager.CompletableFuture<Acknowledge>
TaskManagerGateway. triggerCheckpoint(ExecutionAttemptID executionAttemptID, org.apache.flink.api.common.JobID jobId, long checkpointId, long timestamp, CheckpointOptions checkpointOptions)
Trigger for the given task a checkpoint.CompletableFuture<Acknowledge>
TaskManagerGateway. updatePartitions(ExecutionAttemptID executionAttemptID, Iterable<PartitionInfo> partitionInfos, Duration timeout)
Update the task where the given partitions can be found. -
Uses of Acknowledge in org.apache.flink.runtime.jobmaster
Methods in org.apache.flink.runtime.jobmaster that return types with arguments of type Acknowledge Modifier and Type Method Description CompletableFuture<Acknowledge>
JobManagerRunner. cancel(Duration timeout)
Cancels the currently executed job.CompletableFuture<Acknowledge>
JobMaster. cancel(Duration timeout)
CompletableFuture<Acknowledge>
JobMasterGateway. cancel(Duration timeout)
Cancels the currently executed job.CompletableFuture<Acknowledge>
JobMasterServiceLeadershipRunner. cancel(Duration timeout)
CompletableFuture<Acknowledge>
RpcTaskManagerGateway. cancelTask(ExecutionAttemptID executionAttemptID, Duration timeout)
CompletableFuture<Acknowledge>
JobMaster. disconnectTaskManager(ResourceID resourceID, Exception cause)
CompletableFuture<Acknowledge>
JobMasterGateway. disconnectTaskManager(ResourceID resourceID, Exception cause)
Disconnects the givenTaskExecutor
from theJobMaster
.CompletableFuture<Acknowledge>
RpcTaskManagerGateway. freeSlot(AllocationID allocationId, Throwable cause, Duration timeout)
CompletableFuture<Acknowledge>
JobMaster. notifyKvStateRegistered(org.apache.flink.api.common.JobID jobId, JobVertexID jobVertexId, KeyGroupRange keyGroupRange, String registrationName, org.apache.flink.queryablestate.KvStateID kvStateId, InetSocketAddress kvStateServerAddress)
CompletableFuture<Acknowledge>
KvStateRegistryGateway. notifyKvStateRegistered(org.apache.flink.api.common.JobID jobId, JobVertexID jobVertexId, KeyGroupRange keyGroupRange, String registrationName, org.apache.flink.queryablestate.KvStateID kvStateId, InetSocketAddress kvStateServerAddress)
Notifies that queryable state has been registered.CompletableFuture<Acknowledge>
JobMaster. notifyKvStateUnregistered(org.apache.flink.api.common.JobID jobId, JobVertexID jobVertexId, KeyGroupRange keyGroupRange, String registrationName)
CompletableFuture<Acknowledge>
KvStateRegistryGateway. notifyKvStateUnregistered(org.apache.flink.api.common.JobID jobId, JobVertexID jobVertexId, KeyGroupRange keyGroupRange, String registrationName)
Notifies that queryable state has been unregistered.CompletableFuture<Acknowledge>
JobMaster. notifyNewBlockedNodes(Collection<BlockedNode> newNodes)
CompletableFuture<Acknowledge>
JobMaster. sendOperatorEventToCoordinator(ExecutionAttemptID task, OperatorID operatorID, org.apache.flink.util.SerializedValue<OperatorEvent> serializedEvent)
CompletableFuture<Acknowledge>
JobMasterOperatorEventGateway. sendOperatorEventToCoordinator(ExecutionAttemptID task, OperatorID operatorID, org.apache.flink.util.SerializedValue<OperatorEvent> event)
CompletableFuture<Acknowledge>
RpcTaskManagerGateway. sendOperatorEventToTask(ExecutionAttemptID task, OperatorID operator, org.apache.flink.util.SerializedValue<OperatorEvent> evt)
CompletableFuture<Acknowledge>
RpcTaskManagerGateway. submitTask(TaskDeploymentDescriptor tdd, Duration timeout)
CompletableFuture<Acknowledge>
RpcTaskManagerGateway. triggerCheckpoint(ExecutionAttemptID executionAttemptID, org.apache.flink.api.common.JobID jobId, long checkpointId, long timestamp, CheckpointOptions checkpointOptions)
CompletableFuture<Acknowledge>
JobMaster. updateJobResourceRequirements(JobResourceRequirements jobResourceRequirements)
CompletableFuture<Acknowledge>
JobMasterGateway. updateJobResourceRequirements(JobResourceRequirements jobResourceRequirements)
Updatejob resource requirements
.CompletableFuture<Acknowledge>
RpcTaskManagerGateway. updatePartitions(ExecutionAttemptID executionAttemptID, Iterable<PartitionInfo> partitionInfos, Duration timeout)
CompletableFuture<Acknowledge>
JobMaster. updateTaskExecutionState(TaskExecutionState taskExecutionState)
Updates the task execution state for a given task.CompletableFuture<Acknowledge>
JobMasterGateway. updateTaskExecutionState(TaskExecutionState taskExecutionState)
Updates the task execution state for a given task. -
Uses of Acknowledge in org.apache.flink.runtime.jobmaster.slotpool
Methods in org.apache.flink.runtime.jobmaster.slotpool that return types with arguments of type Acknowledge Modifier and Type Method Description CompletableFuture<Acknowledge>
DeclareResourceRequirementServiceConnectionManager.DeclareResourceRequirementsService. declareResourceRequirements(ResourceRequirements resourceRequirements)
-
Uses of Acknowledge in org.apache.flink.runtime.messages
Methods in org.apache.flink.runtime.messages that return Acknowledge Modifier and Type Method Description static Acknowledge
Acknowledge. get()
Gets the singleton instance. -
Uses of Acknowledge in org.apache.flink.runtime.minicluster
Methods in org.apache.flink.runtime.minicluster that return types with arguments of type Acknowledge Modifier and Type Method Description CompletableFuture<Acknowledge>
MiniCluster. cancelJob(org.apache.flink.api.common.JobID jobId)
CompletableFuture<Acknowledge>
MiniCluster. disposeSavepoint(String savepointPath)
-
Uses of Acknowledge in org.apache.flink.runtime.operators.coordination
Methods in org.apache.flink.runtime.operators.coordination that return types with arguments of type Acknowledge Modifier and Type Method Description CompletableFuture<Acknowledge>
OperatorCoordinator.SubtaskGateway. sendEvent(OperatorEvent evt)
Sends an event to the parallel subtask with the given subtask index. -
Uses of Acknowledge in org.apache.flink.runtime.resourcemanager
Methods in org.apache.flink.runtime.resourcemanager that return types with arguments of type Acknowledge Modifier and Type Method Description CompletableFuture<Acknowledge>
ResourceManager. declareRequiredResources(JobMasterId jobMasterId, ResourceRequirements resourceRequirements, Duration timeout)
CompletableFuture<Acknowledge>
ResourceManagerGateway. declareRequiredResources(JobMasterId jobMasterId, ResourceRequirements resourceRequirements, Duration timeout)
Declares the absolute resource requirements for a job.CompletableFuture<Acknowledge>
ResourceManager. deregisterApplication(ApplicationStatus finalStatus, String diagnostics)
Cleanup application and shut down cluster.CompletableFuture<Acknowledge>
ResourceManagerGateway. deregisterApplication(ApplicationStatus finalStatus, String diagnostics)
Deregister Flink from the underlying resource management system.CompletableFuture<Acknowledge>
ResourceManager. notifyNewBlockedNodes(Collection<BlockedNode> newNodes)
CompletableFuture<Acknowledge>
ResourceManager. sendSlotReport(ResourceID taskManagerResourceId, InstanceID taskManagerRegistrationId, SlotReport slotReport, Duration timeout)
CompletableFuture<Acknowledge>
ResourceManagerGateway. sendSlotReport(ResourceID taskManagerResourceId, InstanceID taskManagerRegistrationId, SlotReport slotReport, Duration timeout)
Sends the givenSlotReport
to the ResourceManager. -
Uses of Acknowledge in org.apache.flink.runtime.rest.handler.job.rescaling
Methods in org.apache.flink.runtime.rest.handler.job.rescaling that return types with arguments of type Acknowledge Modifier and Type Method Description protected CompletableFuture<Acknowledge>
RescalingHandlers.RescalingTriggerHandler. triggerOperation(HandlerRequest<EmptyRequestBody> request, RestfulGateway gateway)
Methods in org.apache.flink.runtime.rest.handler.job.rescaling with parameters of type Acknowledge Modifier and Type Method Description protected AsynchronousOperationInfo
RescalingHandlers.RescalingStatusHandler. operationResultResponse(Acknowledge operationResult)
-
Uses of Acknowledge in org.apache.flink.runtime.rest.handler.job.savepoints
Methods in org.apache.flink.runtime.rest.handler.job.savepoints that return types with arguments of type Acknowledge Modifier and Type Method Description protected CompletableFuture<Acknowledge>
SavepointDisposalHandlers.SavepointDisposalTriggerHandler. triggerOperation(HandlerRequest<SavepointDisposalRequest> request, RestfulGateway gateway)
protected CompletableFuture<Acknowledge>
SavepointHandlers.SavepointTriggerHandler. triggerOperation(HandlerRequest<SavepointTriggerRequestBody> request, AsynchronousJobOperationKey operationKey, RestfulGateway gateway)
protected CompletableFuture<Acknowledge>
SavepointHandlers.StopWithSavepointHandler. triggerOperation(HandlerRequest<StopWithSavepointRequestBody> request, AsynchronousJobOperationKey operationKey, RestfulGateway gateway)
Methods in org.apache.flink.runtime.rest.handler.job.savepoints with parameters of type Acknowledge Modifier and Type Method Description protected AsynchronousOperationInfo
SavepointDisposalHandlers.SavepointDisposalStatusHandler. operationResultResponse(Acknowledge operationResult)
-
Uses of Acknowledge in org.apache.flink.runtime.taskexecutor
Methods in org.apache.flink.runtime.taskexecutor that return types with arguments of type Acknowledge Modifier and Type Method Description CompletableFuture<Acknowledge>
TaskExecutor. abortCheckpoint(ExecutionAttemptID executionAttemptID, long checkpointId, long latestCompletedCheckpointId, long checkpointTimestamp)
CompletableFuture<Acknowledge>
TaskExecutorGateway. abortCheckpoint(ExecutionAttemptID executionAttemptID, long checkpointId, long latestCompletedCheckpointId, long checkpointTimestamp)
Abort a checkpoint for the given task.CompletableFuture<Acknowledge>
TaskExecutorGatewayDecoratorBase. abortCheckpoint(ExecutionAttemptID executionAttemptID, long checkpointId, long latestCompletedCheckpointId, long checkpointTimestamp)
CompletableFuture<Acknowledge>
TaskExecutor. cancelTask(ExecutionAttemptID executionAttemptID, Duration timeout)
CompletableFuture<Acknowledge>
TaskExecutorGateway. cancelTask(ExecutionAttemptID executionAttemptID, Duration timeout)
Cancel the given task.CompletableFuture<Acknowledge>
TaskExecutorGatewayDecoratorBase. cancelTask(ExecutionAttemptID executionAttemptID, Duration timeout)
CompletableFuture<Acknowledge>
TaskExecutor. confirmCheckpoint(ExecutionAttemptID executionAttemptID, long completedCheckpointId, long completedCheckpointTimestamp, long lastSubsumedCheckpointId)
CompletableFuture<Acknowledge>
TaskExecutorGateway. confirmCheckpoint(ExecutionAttemptID executionAttemptID, long completedCheckpointId, long completedCheckpointTimestamp, long lastSubsumedCheckpointId)
Confirm a checkpoint for the given task.CompletableFuture<Acknowledge>
TaskExecutorGatewayDecoratorBase. confirmCheckpoint(ExecutionAttemptID executionAttemptID, long completedCheckpointId, long completedCheckpointTimestamp, long lastSubsumedCheckpointId)
CompletableFuture<Acknowledge>
TaskExecutor. freeSlot(AllocationID allocationId, Throwable cause, Duration timeout)
CompletableFuture<Acknowledge>
TaskExecutorGateway. freeSlot(AllocationID allocationId, Throwable cause, Duration timeout)
Frees the slot with the given allocation ID.CompletableFuture<Acknowledge>
TaskExecutorGatewayDecoratorBase. freeSlot(AllocationID allocationId, Throwable cause, Duration timeout)
CompletableFuture<Acknowledge>
TaskExecutor. promotePartitions(org.apache.flink.api.common.JobID jobId, Set<ResultPartitionID> partitionIds)
CompletableFuture<Acknowledge>
TaskExecutorGateway. promotePartitions(org.apache.flink.api.common.JobID jobId, Set<ResultPartitionID> partitionIds)
Batch promote intermediate result partitions.CompletableFuture<Acknowledge>
TaskExecutorGatewayDecoratorBase. promotePartitions(org.apache.flink.api.common.JobID jobId, Set<ResultPartitionID> partitionIds)
CompletableFuture<Acknowledge>
TaskExecutor. releaseClusterPartitions(Collection<IntermediateDataSetID> dataSetsToRelease, Duration timeout)
CompletableFuture<Acknowledge>
TaskExecutorGateway. releaseClusterPartitions(Collection<IntermediateDataSetID> dataSetsToRelease, Duration timeout)
Releases all cluster partitions belong to any of the given data sets.CompletableFuture<Acknowledge>
TaskExecutorGatewayDecoratorBase. releaseClusterPartitions(Collection<IntermediateDataSetID> dataSetsToRelease, Duration timeout)
CompletableFuture<Acknowledge>
TaskExecutor. requestSlot(SlotID slotId, org.apache.flink.api.common.JobID jobId, AllocationID allocationId, ResourceProfile resourceProfile, String targetAddress, ResourceManagerId resourceManagerId, Duration timeout)
CompletableFuture<Acknowledge>
TaskExecutorGateway. requestSlot(SlotID slotId, org.apache.flink.api.common.JobID jobId, AllocationID allocationId, ResourceProfile resourceProfile, String targetAddress, ResourceManagerId resourceManagerId, Duration timeout)
Requests a slot from the TaskManager.CompletableFuture<Acknowledge>
TaskExecutorGatewayDecoratorBase. requestSlot(SlotID slotId, org.apache.flink.api.common.JobID jobId, AllocationID allocationId, ResourceProfile resourceProfile, String targetAddress, ResourceManagerId resourceManagerId, Duration timeout)
CompletableFuture<Acknowledge>
TaskExecutor. sendOperatorEventToTask(ExecutionAttemptID executionAttemptID, OperatorID operatorId, org.apache.flink.util.SerializedValue<OperatorEvent> evt)
CompletableFuture<Acknowledge>
TaskExecutorGateway. sendOperatorEventToTask(ExecutionAttemptID task, OperatorID operator, org.apache.flink.util.SerializedValue<OperatorEvent> evt)
CompletableFuture<Acknowledge>
TaskExecutorGatewayDecoratorBase. sendOperatorEventToTask(ExecutionAttemptID task, OperatorID operator, org.apache.flink.util.SerializedValue<OperatorEvent> evt)
CompletableFuture<Acknowledge>
TaskExecutorOperatorEventGateway. sendOperatorEventToTask(ExecutionAttemptID task, OperatorID operator, org.apache.flink.util.SerializedValue<OperatorEvent> evt)
Sends an operator event to an operator in a task executed by the Task Manager (Task Executor).CompletableFuture<Acknowledge>
TaskExecutor. submitTask(TaskDeploymentDescriptor tdd, JobMasterId jobMasterId, Duration timeout)
CompletableFuture<Acknowledge>
TaskExecutorGateway. submitTask(TaskDeploymentDescriptor tdd, JobMasterId jobMasterId, Duration timeout)
Submit aTask
to theTaskExecutor
.CompletableFuture<Acknowledge>
TaskExecutorGatewayDecoratorBase. submitTask(TaskDeploymentDescriptor tdd, JobMasterId jobMasterId, Duration timeout)
CompletableFuture<Acknowledge>
TaskExecutor. triggerCheckpoint(ExecutionAttemptID executionAttemptID, long checkpointId, long checkpointTimestamp, CheckpointOptions checkpointOptions)
CompletableFuture<Acknowledge>
TaskExecutorGateway. triggerCheckpoint(ExecutionAttemptID executionAttemptID, long checkpointID, long checkpointTimestamp, CheckpointOptions checkpointOptions)
Trigger the checkpoint for the given task.CompletableFuture<Acknowledge>
TaskExecutorGatewayDecoratorBase. triggerCheckpoint(ExecutionAttemptID executionAttemptID, long checkpointID, long checkpointTimestamp, CheckpointOptions checkpointOptions)
CompletableFuture<Acknowledge>
TaskExecutor. updateDelegationTokens(ResourceManagerId resourceManagerId, byte[] tokens)
CompletableFuture<Acknowledge>
TaskExecutorGateway. updateDelegationTokens(ResourceManagerId resourceManagerId, byte[] tokens)
Sends new delegation tokens to this TaskManager.CompletableFuture<Acknowledge>
TaskExecutorGatewayDecoratorBase. updateDelegationTokens(ResourceManagerId resourceManagerId, byte[] tokens)
CompletableFuture<Acknowledge>
TaskExecutor. updatePartitions(ExecutionAttemptID executionAttemptID, Iterable<PartitionInfo> partitionInfos, Duration timeout)
CompletableFuture<Acknowledge>
TaskExecutorGateway. updatePartitions(ExecutionAttemptID executionAttemptID, Iterable<PartitionInfo> partitionInfos, Duration timeout)
Update the task where the given partitions can be found.CompletableFuture<Acknowledge>
TaskExecutorGatewayDecoratorBase. updatePartitions(ExecutionAttemptID executionAttemptID, Iterable<PartitionInfo> partitionInfos, Duration timeout)
-
Uses of Acknowledge in org.apache.flink.runtime.webmonitor
Methods in org.apache.flink.runtime.webmonitor that return types with arguments of type Acknowledge Modifier and Type Method Description CompletableFuture<Acknowledge>
NonLeaderRetrievalRestfulGateway. cancelJob(org.apache.flink.api.common.JobID jobId, Duration timeout)
CompletableFuture<Acknowledge>
RestfulGateway. cancelJob(org.apache.flink.api.common.JobID jobId, Duration timeout)
Cancel the given job.default CompletableFuture<Acknowledge>
RestfulGateway. disposeSavepoint(String savepointPath, Duration timeout)
Dispose the given savepoint.default CompletableFuture<Acknowledge>
RestfulGateway. shutDownCluster()
default CompletableFuture<Acknowledge>
RestfulGateway. stopWithSavepoint(AsynchronousJobOperationKey operationKey, String targetDirectory, org.apache.flink.core.execution.SavepointFormatType formatType, TriggerSavepointMode savepointMode, Duration timeout)
Stops the job with a savepoint, returning a future that completes when the operation is started.default CompletableFuture<Acknowledge>
RestfulGateway. triggerCheckpoint(AsynchronousJobOperationKey operationKey, org.apache.flink.core.execution.CheckpointType checkpointType, Duration timeout)
Triggers a checkpoint with the given savepoint directory as a target.default CompletableFuture<Acknowledge>
RestfulGateway. triggerSavepoint(AsynchronousJobOperationKey operationKey, 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 when the operation is started.default CompletableFuture<Acknowledge>
RestfulGateway. updateJobResourceRequirements(org.apache.flink.api.common.JobID jobId, JobResourceRequirements jobResourceRequirements)
Updatejob resource requirements
for a given job.
-