Modifier and Type | Class and Description |
---|---|
class |
StateDescriptor<S extends State,T>
Base class for state descriptors.
|
Modifier and Type | Interface and Description |
---|---|
interface |
AggregatingState<IN,OUT>
State interface for aggregating state, based on an AggregateFunction . |
interface |
AppendingState<IN,OUT>
Base interface for partitioned state that supports adding elements and inspecting the current
state.
|
interface |
BroadcastState<K,V>
A type of state that can be created to store the state of a
BroadcastStream . |
interface |
FoldingState<T,ACC>
Deprecated.
will be removed in a future version in favor of
AggregatingState |
interface |
ListState<T>
State interface for partitioned list state in Operations. |
interface |
MapState<UK,UV>
State interface for partitioned key-value state. |
interface |
MergingState<IN,OUT>
Extension of
AppendingState that allows merging of state. |
interface |
ReadOnlyBroadcastState<K,V>
A read-only view of the
BroadcastState . |
interface |
ReducingState<T>
State interface for reducing state. |
interface |
ValueState<T>
State interface for partitioned single-value state. |
Modifier and Type | Class and Description |
---|---|
class |
AbstractRocksDBState<K,N,V>
Base class for
State implementations that store state in a RocksDB database. |
Modifier and Type | Method and Description |
---|---|
<N,SV,SEV,S extends State,IS extends S> |
RocksDBKeyedStateBackend.createInternalState(TypeSerializer<N> namespaceSerializer,
StateDescriptor<S,SV> stateDesc,
StateSnapshotTransformer.StateSnapshotTransformFactory<SEV> snapshotTransformFactory) |
Modifier and Type | Method and Description |
---|---|
<K,S extends State,V> |
QueryableStateClient.getKvState(JobID jobId,
String queryableStateName,
K key,
TypeHint<K> keyTypeHint,
StateDescriptor<S,V> stateDescriptor)
Returns a future holding the request result.
|
<K,S extends State,V> |
QueryableStateClient.getKvState(JobID jobId,
String queryableStateName,
K key,
TypeInformation<K> keyTypeInfo,
StateDescriptor<S,V> stateDescriptor)
Returns a future holding the request result.
|
Modifier and Type | Class and Description |
---|---|
class |
ImmutableAggregatingState<IN,OUT>
A read-only
AggregatingState that does not allow for modifications. |
class |
ImmutableFoldingState<IN,ACC>
Deprecated.
|
class |
ImmutableListState<V>
A read-only
ListState that does not allow for modifications. |
class |
ImmutableMapState<K,V>
A read-only
MapState that does not allow for modifications. |
class |
ImmutableReducingState<V>
A read-only
ReducingState that does not allow for modifications. |
class |
ImmutableValueState<V>
A read-only
ValueState that does not allow for modifications. |
Modifier and Type | Method and Description |
---|---|
static <ACC,S extends State> |
ImmutableFoldingState.createState(StateDescriptor<S,ACC> stateDescriptor,
byte[] serializedState)
Deprecated.
|
static <OUT,ACC,S extends State> |
ImmutableAggregatingState.createState(StateDescriptor<S,ACC> stateDescriptor,
byte[] serializedState) |
static <K,V,T,S extends State> |
ImmutableMapState.createState(StateDescriptor<S,T> stateDescriptor,
byte[] serializedState) |
static <V,T,S extends State> |
ImmutableListState.createState(StateDescriptor<S,T> stateDescriptor,
byte[] serializedState) |
static <V,S extends State> |
ImmutableReducingState.createState(StateDescriptor<S,V> stateDescriptor,
byte[] serializedState) |
static <V,S extends State> |
ImmutableValueState.createState(StateDescriptor<S,V> stateDescriptor,
byte[] serializedState) |
Modifier and Type | Interface and Description |
---|---|
interface |
KeyedStateFunction<K,S extends State>
A function to be applied to all keyed states.
|
Modifier and Type | Interface and Description |
---|---|
interface |
BackendWritableBroadcastState<K,V>
An interface with methods related to the interplay between the
Broadcast
State and the OperatorStateBackend . |
Modifier and Type | Class and Description |
---|---|
class |
HeapBroadcastState<K,V>
A
Broadcast State backed a heap-based Map . |
class |
PartitionableListState<S>
Implementation of operator list state.
|
Modifier and Type | Method and Description |
---|---|
<N,S extends State,T> |
KeyedStateBackend.applyToAllKeys(N namespace,
TypeSerializer<N> namespaceSerializer,
StateDescriptor<S,T> stateDescriptor,
KeyedStateFunction<K,S> function)
Applies the provided
KeyedStateFunction to the state with the provided StateDescriptor of all the currently active keys. |
<N,S extends State,T> |
AbstractKeyedStateBackend.applyToAllKeys(N namespace,
TypeSerializer<N> namespaceSerializer,
StateDescriptor<S,T> stateDescriptor,
KeyedStateFunction<K,S> function) |
default <N,SV,S extends State,IS extends S> |
KeyedStateFactory.createInternalState(TypeSerializer<N> namespaceSerializer,
StateDescriptor<S,SV> stateDesc)
Creates and returns a new
InternalKvState . |
<N,SV,SEV,S extends State,IS extends S> |
KeyedStateFactory.createInternalState(TypeSerializer<N> namespaceSerializer,
StateDescriptor<S,SV> stateDesc,
StateSnapshotTransformer.StateSnapshotTransformFactory<SEV> snapshotTransformFactory)
Creates and returns a new
InternalKvState . |
<N,S extends State,T> |
KeyedStateBackend.getOrCreateKeyedState(TypeSerializer<N> namespaceSerializer,
StateDescriptor<S,T> stateDescriptor)
Creates or retrieves a keyed state backed by this state backend.
|
<N,S extends State,V> |
AbstractKeyedStateBackend.getOrCreateKeyedState(TypeSerializer<N> namespaceSerializer,
StateDescriptor<S,V> stateDescriptor) |
<N,S extends State> |
KeyedStateBackend.getPartitionedState(N namespace,
TypeSerializer<N> namespaceSerializer,
StateDescriptor<S,?> stateDescriptor)
Creates or retrieves a partitioned state backed by this state backend.
|
<N,S extends State> |
AbstractKeyedStateBackend.getPartitionedState(N namespace,
TypeSerializer<N> namespaceSerializer,
StateDescriptor<S,?> stateDescriptor)
TODO: NOTE: This method does a lot of work caching / retrieving states just to update the
namespace.
|
protected <S extends State> |
DefaultKeyedStateStore.getPartitionedState(StateDescriptor<S,?> stateDescriptor) |
Modifier and Type | Class and Description |
---|---|
class |
AbstractHeapState<K,N,SV>
Base class for partitioned
State implementations that are backed by a regular heap hash
map. |
Modifier and Type | Method and Description |
---|---|
<N,S extends State,T> |
HeapKeyedStateBackend.applyToAllKeys(N namespace,
TypeSerializer<N> namespaceSerializer,
StateDescriptor<S,T> stateDescriptor,
KeyedStateFunction<K,S> function) |
<N,SV,SEV,S extends State,IS extends S> |
HeapKeyedStateBackend.createInternalState(TypeSerializer<N> namespaceSerializer,
StateDescriptor<S,SV> stateDesc,
StateSnapshotTransformer.StateSnapshotTransformFactory<SEV> snapshotTransformFactory) |
Modifier and Type | Interface and Description |
---|---|
interface |
InternalAggregatingState<K,N,IN,SV,OUT>
The peer to the
AggregatingState in the internal state type hierarchy. |
interface |
InternalAppendingState<K,N,IN,SV,OUT>
The peer to the
AppendingState in the internal state type hierarchy. |
interface |
InternalFoldingState<K,N,T,ACC>
Deprecated.
will be removed in a future version
|
interface |
InternalKvState<K,N,V>
The
InternalKvState is the root of the internal state type hierarchy, similar to the
State being the root of the public API state hierarchy. |
interface |
InternalListState<K,N,T>
The peer to the
ListState in the internal state type hierarchy. |
interface |
InternalMapState<K,N,UK,UV>
The peer to the
MapState in the internal state type hierarchy. |
interface |
InternalMergingState<K,N,IN,SV,OUT>
The peer to the
MergingState in the internal state type hierarchy. |
interface |
InternalReducingState<K,N,T>
The peer to the
ReducingState in the internal state type hierarchy. |
interface |
InternalValueState<K,N,T>
The peer to the
ValueState in the internal state type hierarchy. |
Modifier and Type | Class and Description |
---|---|
class |
TtlStateFactory<K,N,SV,TTLSV,S extends State,IS extends S>
This state factory wraps state objects, produced by backends, with TTL logic.
|
Modifier and Type | Method and Description |
---|---|
static <K,N,SV,TTLSV,S extends State,IS extends S> |
TtlStateFactory.createStateAndWrapWithTtlIfEnabled(TypeSerializer<N> namespaceSerializer,
StateDescriptor<S,SV> stateDesc,
KeyedStateBackend<K> stateBackend,
TtlTimeProvider timeProvider) |
Modifier and Type | Method and Description |
---|---|
abstract <VS,S extends State> |
KeyedBroadcastProcessFunction.Context.applyToKeyedState(StateDescriptor<S,VS> stateDescriptor,
KeyedStateFunction<KS,S> function)
Applies the provided
function to the state associated with the provided state descriptor . |
Modifier and Type | Method and Description |
---|---|
protected <N,S extends State,T> |
AbstractStreamOperator.getOrCreateKeyedState(TypeSerializer<N> namespaceSerializer,
StateDescriptor<S,T> stateDescriptor) |
protected <N,S extends State,T> |
AbstractStreamOperatorV2.getOrCreateKeyedState(TypeSerializer<N> namespaceSerializer,
StateDescriptor<S,T> stateDescriptor) |
<N,S extends State,T> |
StreamOperatorStateHandler.getOrCreateKeyedState(TypeSerializer<N> namespaceSerializer,
StateDescriptor<S,T> stateDescriptor) |
protected <S extends State,N> |
AbstractStreamOperator.getPartitionedState(N namespace,
TypeSerializer<N> namespaceSerializer,
StateDescriptor<S,?> stateDescriptor)
Creates a partitioned state handle, using the state backend configured for this task.
|
protected <S extends State,N> |
AbstractStreamOperatorV2.getPartitionedState(N namespace,
TypeSerializer<N> namespaceSerializer,
StateDescriptor<S,?> stateDescriptor)
Creates a partitioned state handle, using the state backend configured for this task.
|
protected <S extends State,N> |
StreamOperatorStateHandler.getPartitionedState(N namespace,
TypeSerializer<N> namespaceSerializer,
StateDescriptor<S,?> stateDescriptor)
Creates a partitioned state handle, using the state backend configured for this task.
|
protected <S extends State> |
AbstractStreamOperator.getPartitionedState(StateDescriptor<S,?> stateDescriptor)
Creates a partitioned state handle, using the state backend configured for this task.
|
protected <S extends State> |
AbstractStreamOperatorV2.getPartitionedState(StateDescriptor<S,?> stateDescriptor)
Creates a partitioned state handle, using the state backend configured for this task.
|
Modifier and Type | Class and Description |
---|---|
class |
SimpleVersionedListState<T>
|
Modifier and Type | Method and Description |
---|---|
<S extends State> |
Trigger.TriggerContext.getPartitionedState(StateDescriptor<S,?> stateDescriptor)
Retrieves a
State object that can be used to interact with fault-tolerant state
that is scoped to the window and key of the current trigger invocation. |
Modifier and Type | Method and Description |
---|---|
protected <S extends State> |
WindowOperator.PerWindowStateStore.getPartitionedState(StateDescriptor<S,?> stateDescriptor) |
<S extends State> |
WindowOperator.Context.getPartitionedState(StateDescriptor<S,?> stateDescriptor) |
Modifier and Type | Method and Description |
---|---|
State |
TtlStateVerifier.createState(FunctionInitializationContext context,
StateTtlConfig ttlConfig) |
Modifier and Type | Method and Description |
---|---|
GV |
TtlStateVerifier.get(State state) |
void |
TtlStateVerifier.update(State state,
Object update) |
Modifier and Type | Method and Description |
---|---|
protected void |
KeyedProcessFunctionWithCleanupState.cleanupState(State... states) |
Modifier and Type | Method and Description |
---|---|
<S extends State> |
InternalWindowProcessFunction.Context.getPartitionedState(StateDescriptor<S,?> stateDescriptor)
Creates a partitioned state handle, using the state backend configured for this task.
|
Modifier and Type | Method and Description |
---|---|
<S extends State> |
Trigger.TriggerContext.getPartitionedState(StateDescriptor<S,?> stateDescriptor)
Retrieves a
State object that can be used to interact with fault-tolerant state
that is scoped to the window and key of the current trigger invocation. |
Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.