Package | Description |
---|---|
org.apache.flink.contrib.streaming.state | |
org.apache.flink.runtime.checkpoint | |
org.apache.flink.runtime.executiongraph | |
org.apache.flink.runtime.jobgraph.tasks | |
org.apache.flink.runtime.state | |
org.apache.flink.runtime.state.filesystem | |
org.apache.flink.runtime.state.memory | |
org.apache.flink.streaming.api.environment | |
org.apache.flink.streaming.api.graph | |
org.apache.flink.streaming.api.operators | |
org.apache.flink.streaming.runtime.tasks |
This package contains classes that realize streaming tasks.
|
Modifier and Type | Class and Description |
---|---|
class |
RocksDBStateBackend
A State Backend that stores its state in
RocksDB . |
Modifier and Type | Method and Description |
---|---|
StateBackend |
RocksDBStateBackend.getCheckpointBackend()
Gets the state backend that this RocksDB state backend uses to persist
its bytes to.
|
Constructor and Description |
---|
RocksDBStateBackend(StateBackend checkpointStreamBackend)
Creates a new
RocksDBStateBackend that uses the given state backend to store its
checkpoint data streams. |
RocksDBStateBackend(StateBackend checkpointStreamBackend,
TernaryBoolean enableIncrementalCheckpointing)
Creates a new
RocksDBStateBackend that uses the given state backend to store its
checkpoint data streams. |
Modifier and Type | Method and Description |
---|---|
static StateBackend |
Checkpoints.loadStateBackend(Configuration configuration,
ClassLoader classLoader,
org.slf4j.Logger logger) |
Modifier and Type | Method and Description |
---|---|
static void |
Checkpoints.disposeSavepoint(String pointer,
StateBackend stateBackend,
ClassLoader classLoader) |
Constructor and Description |
---|
CheckpointCoordinator(JobID job,
long baseInterval,
long checkpointTimeout,
long minPauseBetweenCheckpoints,
int maxConcurrentCheckpointAttempts,
CheckpointRetentionPolicy retentionPolicy,
ExecutionVertex[] tasksToTrigger,
ExecutionVertex[] tasksToWaitFor,
ExecutionVertex[] tasksToCommitTo,
CheckpointIDCounter checkpointIDCounter,
CompletedCheckpointStore completedCheckpointStore,
StateBackend checkpointStateBackend,
Executor executor,
SharedStateRegistryFactory sharedStateRegistryFactory) |
Modifier and Type | Method and Description |
---|---|
void |
ExecutionGraph.enableCheckpointing(long interval,
long checkpointTimeout,
long minPauseBetweenCheckpoints,
int maxConcurrentCheckpoints,
CheckpointRetentionPolicy retentionPolicy,
List<ExecutionJobVertex> verticesToTrigger,
List<ExecutionJobVertex> verticesToWaitFor,
List<ExecutionJobVertex> verticesToCommitTo,
List<MasterTriggerRestoreHook<?>> masterHooks,
CheckpointIDCounter checkpointIDCounter,
CompletedCheckpointStore checkpointStore,
StateBackend checkpointStateBackend,
CheckpointStatsTracker statsTracker) |
Modifier and Type | Method and Description |
---|---|
SerializedValue<StateBackend> |
JobCheckpointingSettings.getDefaultStateBackend() |
Constructor and Description |
---|
JobCheckpointingSettings(List<JobVertexID> verticesToTrigger,
List<JobVertexID> verticesToAcknowledge,
List<JobVertexID> verticesToConfirm,
CheckpointCoordinatorConfiguration checkpointCoordinatorConfiguration,
SerializedValue<StateBackend> defaultStateBackend) |
JobCheckpointingSettings(List<JobVertexID> verticesToTrigger,
List<JobVertexID> verticesToAcknowledge,
List<JobVertexID> verticesToConfirm,
CheckpointCoordinatorConfiguration checkpointCoordinatorConfiguration,
SerializedValue<StateBackend> defaultStateBackend,
SerializedValue<MasterTriggerRestoreHook.Factory[]> masterHooks) |
Modifier and Type | Interface and Description |
---|---|
interface |
StateBackendFactory<T extends StateBackend>
A factory to create a specific state backend.
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractStateBackend
An abstract base implementation of the
StateBackend interface. |
Modifier and Type | Method and Description |
---|---|
StateBackend |
ConfigurableStateBackend.configure(Configuration config,
ClassLoader classLoader)
Creates a variant of the state backend that applies additional configuration parameters.
|
static StateBackend |
StateBackendLoader.fromApplicationOrConfigOrDefault(StateBackend fromApplication,
Configuration config,
ClassLoader classLoader,
org.slf4j.Logger logger)
Checks if an application-defined state backend is given, and if not, loads the state
backend from the configuration, from the parameter 'state.backend', as defined
in
CheckpointingOptions.STATE_BACKEND . |
static StateBackend |
StateBackendLoader.loadStateBackendFromConfig(Configuration config,
ClassLoader classLoader,
org.slf4j.Logger logger)
Loads the state backend from the configuration, from the parameter 'state.backend', as defined
in
CheckpointingOptions.STATE_BACKEND . |
Modifier and Type | Method and Description |
---|---|
static StateBackend |
StateBackendLoader.fromApplicationOrConfigOrDefault(StateBackend fromApplication,
Configuration config,
ClassLoader classLoader,
org.slf4j.Logger logger)
Checks if an application-defined state backend is given, and if not, loads the state
backend from the configuration, from the parameter 'state.backend', as defined
in
CheckpointingOptions.STATE_BACKEND . |
Modifier and Type | Class and Description |
---|---|
class |
AbstractFileStateBackend
A base class for all state backends that store their metadata (and data) in files.
|
class |
FsStateBackend
This state backend holds the working state in the memory (JVM heap) of the TaskManagers.
|
Modifier and Type | Class and Description |
---|---|
class |
MemoryStateBackend
This state backend holds the working state in the memory (JVM heap) of the TaskManagers.
|
Modifier and Type | Method and Description |
---|---|
StateBackend |
StreamExecutionEnvironment.getStateBackend()
Gets the state backend that defines how to store and checkpoint state.
|
Modifier and Type | Method and Description |
---|---|
StreamExecutionEnvironment |
StreamExecutionEnvironment.setStateBackend(StateBackend backend)
Sets the state backend that describes how to store and checkpoint operator state.
|
Modifier and Type | Method and Description |
---|---|
StateBackend |
StreamGraph.getStateBackend() |
StateBackend |
StreamConfig.getStateBackend(ClassLoader cl) |
Modifier and Type | Method and Description |
---|---|
void |
StreamGraph.setStateBackend(StateBackend backend) |
void |
StreamConfig.setStateBackend(StateBackend backend) |
Constructor and Description |
---|
StreamTaskStateInitializerImpl(Environment environment,
StateBackend stateBackend,
ProcessingTimeService processingTimeService) |
Modifier and Type | Field and Description |
---|---|
protected StateBackend |
StreamTask.stateBackend
Our state backend.
|
Copyright © 2014–2020 The Apache Software Foundation. All rights reserved.