Uses of Class
org.apache.flink.streaming.api.environment.CheckpointConfig
-
Packages that use CheckpointConfig Package Description org.apache.flink.streaming.api.environment org.apache.flink.streaming.api.graph org.apache.flink.streaming.api.operators.collect -
-
Uses of CheckpointConfig in org.apache.flink.streaming.api.environment
Fields in org.apache.flink.streaming.api.environment declared as CheckpointConfig Modifier and Type Field Description protected CheckpointConfig
StreamExecutionEnvironment. checkpointCfg
Settings that control the checkpointing behavior.Methods in org.apache.flink.streaming.api.environment that return CheckpointConfig Modifier and Type Method Description CheckpointConfig
StreamExecutionEnvironment. getCheckpointConfig()
Gets the checkpoint config, which defines values like checkpoint interval, delay between checkpoints, etc.Constructors in org.apache.flink.streaming.api.environment with parameters of type CheckpointConfig Constructor Description CheckpointConfig(CheckpointConfig checkpointConfig)
Creates a deep copy of the providedCheckpointConfig
. -
Uses of CheckpointConfig in org.apache.flink.streaming.api.graph
Methods in org.apache.flink.streaming.api.graph that return CheckpointConfig Modifier and Type Method Description CheckpointConfig
StreamGraph. getCheckpointConfig()
Methods in org.apache.flink.streaming.api.graph with parameters of type CheckpointConfig Modifier and Type Method Description static org.apache.flink.core.execution.CheckpointingMode
StreamGraph. getCheckpointingMode(CheckpointConfig checkpointConfig)
Constructors in org.apache.flink.streaming.api.graph with parameters of type CheckpointConfig Constructor Description StreamGraph(org.apache.flink.configuration.Configuration jobConfiguration, org.apache.flink.api.common.ExecutionConfig executionConfig, CheckpointConfig checkpointConfig, SavepointRestoreSettings savepointRestoreSettings)
StreamGraphGenerator(List<org.apache.flink.api.dag.Transformation<?>> transformations, org.apache.flink.api.common.ExecutionConfig executionConfig, CheckpointConfig checkpointConfig)
StreamGraphGenerator(List<org.apache.flink.api.dag.Transformation<?>> transformations, org.apache.flink.api.common.ExecutionConfig executionConfig, CheckpointConfig checkpointConfig, org.apache.flink.configuration.Configuration configuration)
-
Uses of CheckpointConfig in org.apache.flink.streaming.api.operators.collect
Constructors in org.apache.flink.streaming.api.operators.collect with parameters of type CheckpointConfig Constructor Description CollectResultIterator(String operatorUid, org.apache.flink.api.common.typeutils.TypeSerializer<T> serializer, String accumulatorName, CheckpointConfig checkpointConfig, long resultFetchTimeout)
-