Class and Description |
---|
StateInitializationContext
This interface provides a context in which operators can initialize by registering to managed state (i.e.
|
VoidNamespace
Singleton placeholder class for state without a namespace.
|
Class and Description |
---|
AbstractKeyedStateBackend
Base implementation of KeyedStateBackend.
|
AbstractStateBackend
An abstract base implementation of the
StateBackend interface. |
CheckpointListener
This interface must be implemented by functions/operations that want to receive
a commit notification once a checkpoint has been completely acknowledged by all
participants.
|
CheckpointStreamFactory |
KeyedStateBackend
A keyed state backend provides methods for managing keyed state.
|
KeyedStateHandle
Base for the handles of the checkpointed states in keyed streams.
|
KeyGroupRange
This class defines a range of key-group indexes.
|
OperatorStateBackend
Interface that combines both, the user facing
OperatorStateStore interface and the system interface
Snapshotable |
Snapshotable
Interface for operators that can perform snapshots of their state.
|
StateBackend
A State Backend defines how the state of a streaming application is stored and
checkpointed.
|
StateBackendFactory
A factory to create a specific state backend.
|
Class and Description |
---|
ChainedStateHandle
Handle to state handles for the operators in an operator chain.
|
CompositeStateHandle
Base of all snapshots that are taken by
StateBackend s and some other
components in tasks. |
KeyedStateHandle
Base for the handles of the checkpointed states in keyed streams.
|
KeyGroupRange
This class defines a range of key-group indexes.
|
OperatorStateHandle
State handle for partitionable operator state.
|
SharedStateRegistry
This registry manages state that is shared across (incremental) checkpoints, and is responsible
for deleting shared state that is no longer used in any valid checkpoint.
|
SharedStateRegistryFactory
Simple factory to produce
SharedStateRegistry objects. |
StateObject
Base of all handles that represent checkpointed state in some form.
|
StreamStateHandle
A
StateObject that represents state that was written to a stream. |
Class and Description |
---|
KeyedStateHandle
Base for the handles of the checkpointed states in keyed streams.
|
OperatorStateHandle
State handle for partitionable operator state.
|
StreamStateHandle
A
StateObject that represents state that was written to a stream. |
Class and Description |
---|
StateBackend
A State Backend defines how the state of a streaming application is stored and
checkpointed.
|
Class and Description |
---|
StateBackend
A State Backend defines how the state of a streaming application is stored and
checkpointed.
|
Class and Description |
---|
KeyGroupRange
This class defines a range of key-group indexes.
|
Class and Description |
---|
KeyGroupRange
This class defines a range of key-group indexes.
|
Class and Description |
---|
AbstractKeyedStateBackend
Base implementation of KeyedStateBackend.
|
ChainedStateHandle
Handle to state handles for the operators in an operator chain.
|
CheckpointListener
This interface must be implemented by functions/operations that want to receive
a commit notification once a checkpoint has been completely acknowledged by all
participants.
|
CheckpointStreamFactory |
CheckpointStreamFactory.CheckpointStateOutputStream
A dedicated output stream that produces a
StreamStateHandle when closed. |
CompositeStateHandle
Base of all snapshots that are taken by
StateBackend s and some other
components in tasks. |
DoneFuture
A
Future that is always done and will just yield the object that was given at creation
time. |
FunctionInitializationContext
This interface provides a context in which user functions can initialize by registering to managed state (i.e.
|
FunctionSnapshotContext
This interface provides a context in which user functions that use managed state (i.e.
|
KeyedBackendStateMetaInfoSnapshotReaderWriters.KeyedBackendStateMetaInfoReader |
KeyedBackendStateMetaInfoSnapshotReaderWriters.KeyedBackendStateMetaInfoWriter |
KeyedStateBackend
A keyed state backend provides methods for managing keyed state.
|
KeyedStateCheckpointOutputStream
Checkpoint output stream that allows to write raw keyed state in a partitioned way, split into key-groups.
|
KeyedStateHandle
Base for the handles of the checkpointed states in keyed streams.
|
KeyGroupRange
This class defines a range of key-group indexes.
|
KeyGroupRangeOffsets
This class combines a key-group range with offsets that correspond to the key-groups in the range.
|
KeyGroupsList
This interface offers ordered random read access to multiple key group ids.
|
KeyGroupsStateHandle
A handle to the partitioned stream operator state after it has been checkpointed.
|
KeyGroupStatePartitionStreamProvider
This class provides access to an input stream that contains state data for one key group and the key group id.
|
ManagedInitializationContext
This interface provides a context in which operators can initialize by registering to managed state (i.e.
|
ManagedSnapshotContext
This interface provides a context in which operators that use managed state (i.e.
|
NonClosingCheckpointOutputStream
Abstract class to implement custom checkpoint output streams which should not be closable for user code.
|
OperatorBackendStateMetaInfoSnapshotReaderWriters.AbstractOperatorBackendStateMetaInfoReader |
OperatorBackendStateMetaInfoSnapshotReaderWriters.AbstractOperatorBackendStateMetaInfoWriter |
OperatorBackendStateMetaInfoSnapshotReaderWriters.OperatorBackendStateMetaInfoReader |
OperatorBackendStateMetaInfoSnapshotReaderWriters.OperatorBackendStateMetaInfoWriter |
OperatorStateBackend
Interface that combines both, the user facing
OperatorStateStore interface and the system interface
Snapshotable |
OperatorStateCheckpointOutputStream
Checkpoint output stream that allows to write raw operator state in a partitioned way.
|
OperatorStateHandle
State handle for partitionable operator state.
|
OperatorStateHandle.Mode
The modes that determine how an
OperatorStateHandle is assigned to tasks during restore. |
OperatorStateHandle.StateMetaInfo |
RegisteredKeyedBackendStateMetaInfo.Snapshot
A consistent snapshot of a
RegisteredKeyedBackendStateMetaInfo . |
RegisteredOperatorBackendStateMetaInfo.Snapshot
A consistent snapshot of a
RegisteredOperatorBackendStateMetaInfo . |
RetrievableStateHandle
Handle to state that can be read back again via
RetrievableStateHandle.retrieveState() . |
SharedStateRegistry
This registry manages state that is shared across (incremental) checkpoints, and is responsible
for deleting shared state that is no longer used in any valid checkpoint.
|
SharedStateRegistry.Result
The result of an attempt to (un)/reference state
|
SharedStateRegistryFactory
Simple factory to produce
SharedStateRegistry objects. |
SharedStateRegistryKey
This class represents a key that uniquely identifies (on a logical level) state handles for
registration in the
SharedStateRegistry . |
Snapshotable
Interface for operators that can perform snapshots of their state.
|
StateBackend
A State Backend defines how the state of a streaming application is stored and
checkpointed.
|
StateHandleID
Unique ID that allows for logical comparison between state handles.
|
StateInitializationContext
This interface provides a context in which operators can initialize by registering to managed state (i.e.
|
StateObject
Base of all handles that represent checkpointed state in some form.
|
StatePartitionStreamProvider
This class provides access to input streams that contain data of one state partition of a partitionable state.
|
StateSnapshotContext
This interface provides a context in which operators that use managed (i.e.
|
StreamCompressionDecorator
Implementations of this interface decorate streams with a compression scheme.
|
StreamStateHandle
A
StateObject that represents state that was written to a stream. |
VoidNamespace
Singleton placeholder class for state without a namespace.
|
VoidNamespaceSerializer
Serializer for
VoidNamespace . |
VoidNamespaceTypeInfo |
Class and Description |
---|
AbstractKeyedStateBackend
Base implementation of KeyedStateBackend.
|
AbstractStateBackend
An abstract base implementation of the
StateBackend interface. |
CheckpointStreamFactory |
CheckpointStreamFactory.CheckpointStateOutputStream
A dedicated output stream that produces a
StreamStateHandle when closed. |
KeyGroupRange
This class defines a range of key-group indexes.
|
OperatorStateBackend
Interface that combines both, the user facing
OperatorStateStore interface and the system interface
Snapshotable |
StateBackend
A State Backend defines how the state of a streaming application is stored and
checkpointed.
|
StateBackendFactory
A factory to create a specific state backend.
|
StateObject
Base of all handles that represent checkpointed state in some form.
|
StreamStateHandle
A
StateObject that represents state that was written to a stream. |
Class and Description |
---|
AbstractKeyedStateBackend
Base implementation of KeyedStateBackend.
|
CheckpointListener
This interface must be implemented by functions/operations that want to receive
a commit notification once a checkpoint has been completely acknowledged by all
participants.
|
CheckpointStreamFactory |
KeyedStateBackend
A keyed state backend provides methods for managing keyed state.
|
KeyedStateHandle
Base for the handles of the checkpointed states in keyed streams.
|
KeyGroupRange
This class defines a range of key-group indexes.
|
RegisteredKeyedBackendStateMetaInfo
Compound meta information for a registered state in a keyed state backend.
|
Snapshotable
Interface for operators that can perform snapshots of their state.
|
StateTransformationFunction
Interface for a binary function that is used for push-down of state transformation into state backends.
|
Class and Description |
---|
AbstractKeyedStateBackend
Base implementation of KeyedStateBackend.
|
AbstractStateBackend
An abstract base implementation of the
StateBackend interface. |
CheckpointStreamFactory |
CheckpointStreamFactory.CheckpointStateOutputStream
A dedicated output stream that produces a
StreamStateHandle when closed. |
KeyGroupRange
This class defines a range of key-group indexes.
|
OperatorStateBackend
Interface that combines both, the user facing
OperatorStateStore interface and the system interface
Snapshotable |
StateBackend
A State Backend defines how the state of a streaming application is stored and
checkpointed.
|
StateObject
Base of all handles that represent checkpointed state in some form.
|
StreamStateHandle
A
StateObject that represents state that was written to a stream. |
Class and Description |
---|
KeyGroupRange
This class defines a range of key-group indexes.
|
Class and Description |
---|
KeyGroupRange
This class defines a range of key-group indexes.
|
Class and Description |
---|
RetrievableStateHandle
Handle to state that can be read back again via
RetrievableStateHandle.retrieveState() . |
Class and Description |
---|
RetrievableStateHandle
Handle to state that can be read back again via
RetrievableStateHandle.retrieveState() . |
Class and Description |
---|
VoidNamespace
Singleton placeholder class for state without a namespace.
|
Class and Description |
---|
FunctionInitializationContext
This interface provides a context in which user functions can initialize by registering to managed state (i.e.
|
FunctionSnapshotContext
This interface provides a context in which user functions that use managed state (i.e.
|
Class and Description |
---|
AbstractStateBackend
An abstract base implementation of the
StateBackend interface. |
Class and Description |
---|
CheckpointListener
This interface must be implemented by functions/operations that want to receive
a commit notification once a checkpoint has been completely acknowledged by all
participants.
|
FunctionInitializationContext
This interface provides a context in which user functions can initialize by registering to managed state (i.e.
|
FunctionSnapshotContext
This interface provides a context in which user functions that use managed state (i.e.
|
Class and Description |
---|
CheckpointListener
This interface must be implemented by functions/operations that want to receive
a commit notification once a checkpoint has been completely acknowledged by all
participants.
|
FunctionInitializationContext
This interface provides a context in which user functions can initialize by registering to managed state (i.e.
|
FunctionSnapshotContext
This interface provides a context in which user functions that use managed state (i.e.
|
StateInitializationContext
This interface provides a context in which operators can initialize by registering to managed state (i.e.
|
StateSnapshotContext
This interface provides a context in which operators that use managed (i.e.
|
Class and Description |
---|
AbstractStateBackend
An abstract base implementation of the
StateBackend interface. |
Class and Description |
---|
KeyedStateBackend
A keyed state backend provides methods for managing keyed state.
|
KeyedStateHandle
Base for the handles of the checkpointed states in keyed streams.
|
KeyGroupsList
This interface offers ordered random read access to multiple key group ids.
|
OperatorStateBackend
Interface that combines both, the user facing
OperatorStateStore interface and the system interface
Snapshotable |
OperatorStateHandle
State handle for partitionable operator state.
|
StateInitializationContext
This interface provides a context in which operators can initialize by registering to managed state (i.e.
|
StateSnapshotContext
This interface provides a context in which operators that use managed (i.e.
|
VoidNamespace
Singleton placeholder class for state without a namespace.
|
Class and Description |
---|
StateInitializationContext
This interface provides a context in which operators can initialize by registering to managed state (i.e.
|
StateSnapshotContext
This interface provides a context in which operators that use managed (i.e.
|
Class and Description |
---|
VoidNamespace
Singleton placeholder class for state without a namespace.
|
Class and Description |
---|
FunctionInitializationContext
This interface provides a context in which user functions can initialize by registering to managed state (i.e.
|
FunctionSnapshotContext
This interface provides a context in which user functions that use managed state (i.e.
|
Class and Description |
---|
FunctionInitializationContext
This interface provides a context in which user functions can initialize by registering to managed state (i.e.
|
FunctionSnapshotContext
This interface provides a context in which user functions that use managed state (i.e.
|
Class and Description |
---|
CheckpointListener
This interface must be implemented by functions/operations that want to receive
a commit notification once a checkpoint has been completely acknowledged by all
participants.
|
FunctionInitializationContext
This interface provides a context in which user functions can initialize by registering to managed state (i.e.
|
FunctionSnapshotContext
This interface provides a context in which user functions that use managed state (i.e.
|
Class and Description |
---|
CheckpointListener
This interface must be implemented by functions/operations that want to receive
a commit notification once a checkpoint has been completely acknowledged by all
participants.
|
FunctionInitializationContext
This interface provides a context in which user functions can initialize by registering to managed state (i.e.
|
FunctionSnapshotContext
This interface provides a context in which user functions that use managed state (i.e.
|
Class and Description |
---|
CheckpointListener
This interface must be implemented by functions/operations that want to receive
a commit notification once a checkpoint has been completely acknowledged by all
participants.
|
FunctionInitializationContext
This interface provides a context in which user functions can initialize by registering to managed state (i.e.
|
FunctionSnapshotContext
This interface provides a context in which user functions that use managed state (i.e.
|
Class and Description |
---|
CheckpointListener
This interface must be implemented by functions/operations that want to receive
a commit notification once a checkpoint has been completely acknowledged by all
participants.
|
Class and Description |
---|
StateInitializationContext
This interface provides a context in which operators can initialize by registering to managed state (i.e.
|
StateSnapshotContext
This interface provides a context in which operators that use managed (i.e.
|
Class and Description |
---|
AbstractKeyedStateBackend
Base implementation of KeyedStateBackend.
|
CheckpointStreamFactory |
KeyedStateHandle
Base for the handles of the checkpointed states in keyed streams.
|
KeyGroupRange
This class defines a range of key-group indexes.
|
OperatorStateBackend
Interface that combines both, the user facing
OperatorStateStore interface and the system interface
Snapshotable |
OperatorStateHandle
State handle for partitionable operator state.
|
Class and Description |
---|
OperatorStateBackend
Interface that combines both, the user facing
OperatorStateStore interface and the system interface
Snapshotable |
StateInitializationContext
This interface provides a context in which operators can initialize by registering to managed state (i.e.
|
StateSnapshotContext
This interface provides a context in which operators that use managed (i.e.
|
Copyright © 2014–2018 The Apache Software Foundation. All rights reserved.