Uses of Class
org.apache.flink.state.api.SavepointWriter
-
Packages that use SavepointWriter Package Description org.apache.flink.state.api -
-
Uses of SavepointWriter in org.apache.flink.state.api
Methods in org.apache.flink.state.api that return SavepointWriter Modifier and Type Method Description SavepointWriterSavepointWriter. changeOperatorIdentifier(OperatorIdentifier from, OperatorIdentifier to)Changes the identifier of an operator.static SavepointWriterSavepointWriter. fromExistingSavepoint(org.apache.flink.streaming.api.environment.StreamExecutionEnvironment executionEnvironment, String path)Loads an existing savepoint.static SavepointWriterSavepointWriter. fromExistingSavepoint(org.apache.flink.streaming.api.environment.StreamExecutionEnvironment executionEnvironment, String path, org.apache.flink.runtime.state.StateBackend stateBackend)Loads an existing savepoint.static SavepointWriterSavepointWriter. newSavepoint(org.apache.flink.streaming.api.environment.StreamExecutionEnvironment executionEnvironment, int maxParallelism)Creates a new savepoint.static SavepointWriterSavepointWriter. newSavepoint(org.apache.flink.streaming.api.environment.StreamExecutionEnvironment executionEnvironment, long checkpointId, int maxParallelism)Creates a new savepoint.static SavepointWriterSavepointWriter. newSavepoint(org.apache.flink.streaming.api.environment.StreamExecutionEnvironment executionEnvironment, org.apache.flink.runtime.state.StateBackend stateBackend, int maxParallelism)Creates a new savepoint.static SavepointWriterSavepointWriter. newSavepoint(org.apache.flink.streaming.api.environment.StreamExecutionEnvironment executionEnvironment, org.apache.flink.runtime.state.StateBackend stateBackend, long checkpointId, int maxParallelism)Creates a new savepoint.SavepointWriterSavepointWriter. removeOperator(OperatorIdentifier identifier)Drop an existing operator from the savepoint.<T> SavepointWriterSavepointWriter. withConfiguration(org.apache.flink.configuration.ConfigOption<T> option, T value)Sets a configuration that will be applied to the stream operators used to bootstrap a new savepoint.<T> SavepointWriterSavepointWriter. withOperator(OperatorIdentifier identifier, StateBootstrapTransformation<T> transformation)Adds a new operator to the savepoint.
-