F - The implementation type.@PublicEvolving public abstract class WritableSavepoint<F extends WritableSavepoint> extends Object
WritableSavepoint is any savepoint that can be written to from a batch context.
 Internally, a SavepointMetadata object is maintained that keeps track of the set
 of existing operator states in the savepoint, as well as newly added operator states defined by their
 BootstrapTransformation.| Modifier and Type | Field and Description | 
|---|---|
protected SavepointMetadata | 
metadata
The savepoint metadata, which maintains the current set of existing / newly added operator states. 
 | 
protected org.apache.flink.runtime.state.StateBackend | 
stateBackend
The state backend to use when writing this savepoint. 
 | 
| Modifier and Type | Method and Description | 
|---|---|
F | 
removeOperator(String uid)
Drop an existing operator from the savepoint. 
 | 
<T> F | 
withOperator(String uid,
            BootstrapTransformation<T> transformation)
Adds a new operator to the savepoint. 
 | 
void | 
write(String path)
Write out a new or updated savepoint. 
 | 
protected final SavepointMetadata metadata
protected final org.apache.flink.runtime.state.StateBackend stateBackend
public F removeOperator(String uid)
uid - The uid of the operator.public <T> F withOperator(String uid, BootstrapTransformation<T> transformation)
uid - The uid of the operator.transformation - The operator to be included.public final void write(String path)
path - The path to where the savepoint should be written.Copyright © 2014–2020 The Apache Software Foundation. All rights reserved.