Package | Description |
---|---|
org.apache.flink.runtime.checkpoint | |
org.apache.flink.runtime.deployment | |
org.apache.flink.runtime.execution | |
org.apache.flink.runtime.executiongraph | |
org.apache.flink.runtime.jobgraph.tasks | |
org.apache.flink.runtime.messages.checkpoint |
This package contains the messages that are sent between
JobManager
and TaskManager to coordinate the checkpoint snapshots of the
distributed dataflow. |
org.apache.flink.runtime.state | |
org.apache.flink.runtime.state.filesystem | |
org.apache.flink.runtime.state.memory | |
org.apache.flink.runtime.taskmanager | |
org.apache.flink.runtime.zookeeper | |
org.apache.flink.runtime.zookeeper.filesystem |
Class and Description |
---|
StateHandle
StateHandle is a general handle interface meant to abstract operator state fetching.
|
Class and Description |
---|
StateHandle
StateHandle is a general handle interface meant to abstract operator state fetching.
|
Class and Description |
---|
StateHandle
StateHandle is a general handle interface meant to abstract operator state fetching.
|
Class and Description |
---|
StateHandle
StateHandle is a general handle interface meant to abstract operator state fetching.
|
Class and Description |
---|
StateHandle
StateHandle is a general handle interface meant to abstract operator state fetching.
|
Class and Description |
---|
StateHandle
StateHandle is a general handle interface meant to abstract operator state fetching.
|
Class and Description |
---|
AbstractStateBackend
A state backend defines how state is stored and snapshotted during checkpoints.
|
AbstractStateBackend.CheckpointStateOutputStream
A dedicated output stream that produces a
StreamStateHandle when closed. |
AbstractStateBackend.CheckpointStateOutputView
A dedicated DataOutputView stream that produces a
StateHandle<DataInputView> when closed. |
KvState
Key/Value state implementation for user-defined state.
|
KvStateSnapshot
This class represents a snapshot of the
KvState , taken for a checkpoint. |
SerializedCheckpointData
This class represents serialized checkpoint data for a collection of elements.
|
StateHandle
StateHandle is a general handle interface meant to abstract operator state fetching.
|
StateObject
Base of all types that represent checkpointed state.
|
StreamStateHandle
A state handle that produces an input stream when resolved.
|
Class and Description |
---|
AbstractCloseableHandle
A simple base for closable handles.
|
AbstractHeapState
Base class for partitioned
ListState implementations that are backed by a regular
heap hash map. |
AbstractStateBackend
A state backend defines how state is stored and snapshotted during checkpoints.
|
AbstractStateBackend.CheckpointStateOutputStream
A dedicated output stream that produces a
StreamStateHandle when closed. |
KvState
Key/Value state implementation for user-defined state.
|
KvStateSnapshot
This class represents a snapshot of the
KvState , taken for a checkpoint. |
StateBackendFactory
A factory to create a specific state backend.
|
StateHandle
StateHandle is a general handle interface meant to abstract operator state fetching.
|
StateObject
Base of all types that represent checkpointed state.
|
StreamStateHandle
A state handle that produces an input stream when resolved.
|
Class and Description |
---|
AbstractCloseableHandle
A simple base for closable handles.
|
AbstractHeapState
Base class for partitioned
ListState implementations that are backed by a regular
heap hash map. |
AbstractStateBackend
A state backend defines how state is stored and snapshotted during checkpoints.
|
AbstractStateBackend.CheckpointStateOutputStream
A dedicated output stream that produces a
StreamStateHandle when closed. |
KvState
Key/Value state implementation for user-defined state.
|
KvStateSnapshot
This class represents a snapshot of the
KvState , taken for a checkpoint. |
StateHandle
StateHandle is a general handle interface meant to abstract operator state fetching.
|
StateObject
Base of all types that represent checkpointed state.
|
StreamStateHandle
A state handle that produces an input stream when resolved.
|
Class and Description |
---|
StateHandle
StateHandle is a general handle interface meant to abstract operator state fetching.
|
Class and Description |
---|
StateHandle
StateHandle is a general handle interface meant to abstract operator state fetching.
|
Class and Description |
---|
StateHandle
StateHandle is a general handle interface meant to abstract operator state fetching.
|
Copyright © 2014–2016 The Apache Software Foundation. All rights reserved.