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 |
Modifier and Type | Method and Description |
---|---|
org.apache.flink.util.SerializedValue<StateHandle<?>> |
KeyGroupState.getKeyGroupState() |
org.apache.flink.util.SerializedValue<StateHandle<?>> |
SubtaskState.getState() |
Map<Integer,org.apache.flink.util.SerializedValue<StateHandle<?>>> |
TaskState.getUnwrappedKvStates(Set<Integer> keyGroupPartition)
Retrieve the set of key-value state key groups specified by the given key group partition set.
|
Modifier and Type | Method and Description |
---|---|
boolean |
PendingCheckpoint.acknowledgeTask(ExecutionAttemptID attemptID,
org.apache.flink.util.SerializedValue<StateHandle<?>> state,
long stateSize,
Map<Integer,org.apache.flink.util.SerializedValue<StateHandle<?>>> kvState) |
boolean |
PendingCheckpoint.acknowledgeTask(ExecutionAttemptID attemptID,
org.apache.flink.util.SerializedValue<StateHandle<?>> state,
long stateSize,
Map<Integer,org.apache.flink.util.SerializedValue<StateHandle<?>>> kvState) |
Constructor and Description |
---|
KeyGroupState(org.apache.flink.util.SerializedValue<StateHandle<?>> keyGroupState,
long stateSize,
long duration) |
SubtaskState(org.apache.flink.util.SerializedValue<StateHandle<?>> state,
long stateSize,
long duration) |
Modifier and Type | Method and Description |
---|---|
org.apache.flink.util.SerializedValue<StateHandle<?>> |
TaskDeploymentDescriptor.getOperatorState() |
Constructor and Description |
---|
TaskDeploymentDescriptor(org.apache.flink.api.common.JobID jobID,
String jobName,
JobVertexID vertexID,
ExecutionAttemptID executionId,
org.apache.flink.util.SerializedValue<org.apache.flink.api.common.ExecutionConfig> serializedExecutionConfig,
String taskName,
int indexInSubtaskGroup,
int numberOfSubtasks,
int attemptNumber,
org.apache.flink.configuration.Configuration jobConfiguration,
org.apache.flink.configuration.Configuration taskConfiguration,
String invokableClassName,
List<ResultPartitionDeploymentDescriptor> producedPartitions,
List<InputGateDeploymentDescriptor> inputGates,
List<BlobKey> requiredJarFiles,
List<URL> requiredClasspaths,
int targetSlotNumber,
org.apache.flink.util.SerializedValue<StateHandle<?>> operatorState)
Constructs a task deployment descriptor.
|
Modifier and Type | Method and Description |
---|---|
void |
Environment.acknowledgeCheckpoint(long checkpointId,
StateHandle<?> state)
Confirms that the invokable has successfully completed all steps it needed to
to for the checkpoint with the give checkpoint-ID.
|
Modifier and Type | Method and Description |
---|---|
void |
Execution.setInitialState(org.apache.flink.util.SerializedValue<StateHandle<?>> initialState,
Map<Integer,org.apache.flink.util.SerializedValue<StateHandle<?>>> initialKvState) |
void |
Execution.setInitialState(org.apache.flink.util.SerializedValue<StateHandle<?>> initialState,
Map<Integer,org.apache.flink.util.SerializedValue<StateHandle<?>>> initialKvState) |
Modifier and Type | Interface and Description |
---|---|
interface |
StatefulTask<T extends StateHandle<?>>
This interface must be implemented by any invokable that has recoverable state and participates
in checkpointing.
|
Modifier and Type | Method and Description |
---|---|
org.apache.flink.util.SerializedValue<StateHandle<?>> |
AcknowledgeCheckpoint.getState() |
Constructor and Description |
---|
AcknowledgeCheckpoint(org.apache.flink.api.common.JobID job,
ExecutionAttemptID taskExecutionId,
long checkpointId,
org.apache.flink.util.SerializedValue<StateHandle<?>> state,
long stateSize) |
Modifier and Type | Interface and Description |
---|---|
interface |
StreamStateHandle
A state handle that produces an input stream when resolved.
|
Modifier and Type | Class and Description |
---|---|
class |
AsynchronousStateHandle<T>
StateHandle that can asynchronously materialize the state that it represents. |
class |
LocalStateHandle<T extends Serializable>
A StateHandle that includes the operator states directly.
|
Modifier and Type | Method and Description |
---|---|
static <T extends StateHandle<?>> |
StateUtils.setOperatorState(StatefulTask<?> op,
StateHandle<?> state)
Utility method to define a common generic bound to be used for setting a
generic state handle on a generic state carrier.
|
Modifier and Type | Method and Description |
---|---|
abstract <S extends Serializable> |
AbstractStateBackend.checkpointStateSerializable(S state,
long checkpointID,
long timestamp)
Writes the given state into the checkpoint, and returns a handle that can retrieve the state back.
|
StateHandle<org.apache.flink.core.memory.DataInputView> |
AbstractStateBackend.CheckpointStateOutputView.closeAndGetHandle()
Closes the stream and gets a state handle that can create a DataInputView.
|
abstract StateHandle<T> |
AsynchronousStateHandle.materialize()
Materializes the state held by this
AsynchronousStateHandle . |
<T extends Serializable> |
StreamStateHandle.toSerializableHandle()
Converts this stream state handle into a state handle that de-serializes
the stream into an object using Java's serialization mechanism.
|
Modifier and Type | Method and Description |
---|---|
static <T extends StateHandle<?>> |
StateUtils.setOperatorState(StatefulTask<?> op,
StateHandle<?> state)
Utility method to define a common generic bound to be used for setting a
generic state handle on a generic state carrier.
|
Modifier and Type | Class and Description |
---|---|
class |
FileSerializableStateHandle<T extends Serializable>
A state handle that points to state stored in a file via Java Serialization.
|
class |
FileStreamStateHandle
A state handle that points to state in a file system, accessible as an input stream.
|
Modifier and Type | Method and Description |
---|---|
<S extends Serializable> |
FsStateBackend.checkpointStateSerializable(S state,
long checkpointID,
long timestamp) |
<T extends Serializable> |
FileStreamStateHandle.toSerializableHandle() |
Modifier and Type | Class and Description |
---|---|
class |
ByteStreamStateHandle
A state handle that contains stream state in a byte array.
|
class |
SerializedStateHandle<T extends Serializable>
A state handle that represents its state in serialized form as bytes.
|
Modifier and Type | Method and Description |
---|---|
<S extends Serializable> |
MemoryStateBackend.checkpointStateSerializable(S state,
long checkpointID,
long timestamp)
Serialized the given state into bytes using Java serialization and creates a state handle that
can re-create that state.
|
<T extends Serializable> |
ByteStreamStateHandle.toSerializableHandle() |
Modifier and Type | Method and Description |
---|---|
void |
RuntimeEnvironment.acknowledgeCheckpoint(long checkpointId,
StateHandle<?> state) |
Modifier and Type | Method and Description |
---|---|
StateHandle<T> |
ZooKeeperStateHandleStore.add(String pathInZooKeeper,
T state)
Creates a state handle and stores it in ZooKeeper with create mode
CreateMode.PERSISTENT . |
StateHandle<T> |
ZooKeeperStateHandleStore.add(String pathInZooKeeper,
T state,
org.apache.zookeeper.CreateMode createMode)
Creates a state handle and stores it in ZooKeeper.
|
StateHandle<T> |
ZooKeeperStateHandleStore.get(String pathInZooKeeper)
Gets a state handle from ZooKeeper.
|
StateHandle<T> |
StateStorageHelper.store(T state)
Stores the given state and returns a state handle to it.
|
Modifier and Type | Method and Description |
---|---|
List<org.apache.flink.api.java.tuple.Tuple2<StateHandle<T>,String>> |
ZooKeeperStateHandleStore.getAll()
Gets all available state handles from ZooKeeper.
|
List<org.apache.flink.api.java.tuple.Tuple2<StateHandle<T>,String>> |
ZooKeeperStateHandleStore.getAllSortedByName()
Gets all available state handles from ZooKeeper sorted by name (ascending).
|
Modifier and Type | Method and Description |
---|---|
StateHandle<T> |
FileSystemStateStorageHelper.store(T state) |
Copyright © 2014–2016 The Apache Software Foundation. All rights reserved.