Package | Description |
---|---|
org.apache.flink.api.common.state | |
org.apache.flink.contrib.streaming.state | |
org.apache.flink.queryablestate.client.state | |
org.apache.flink.runtime.state.heap |
This package contains the classes for key/value state backends that store the state
on the JVM heap as objects.
|
org.apache.flink.runtime.state.internal |
This package holds the classes of the internal state type hierarchy.
|
org.apache.flink.streaming.api.windowing.triggers | |
org.apache.flink.streaming.runtime.operators.windowing |
This package contains the operators that implement the various window operations
on data streams.
|
Modifier and Type | Interface and Description |
---|---|
interface |
AggregatingState<IN,OUT>
State interface for aggregating state, based on an
AggregateFunction . |
interface |
ListState<T>
State interface for partitioned list state in Operations. |
interface |
ReducingState<T>
State interface for reducing state. |
Modifier and Type | Class and Description |
---|---|
class |
RocksDBAggregatingState<K,N,T,ACC,R>
An
AggregatingState implementation that stores state in RocksDB. |
class |
RocksDBListState<K,N,V>
ListState implementation that stores state in RocksDB. |
class |
RocksDBReducingState<K,N,V>
ReducingState implementation that stores state in RocksDB. |
Modifier and Type | Class and Description |
---|---|
class |
ImmutableAggregatingState<IN,OUT>
A read-only
AggregatingState that does not allow for modifications. |
class |
ImmutableListState<V>
A read-only
ListState that does not allow for modifications. |
class |
ImmutableReducingState<V>
A read-only
ReducingState that does not allow for modifications. |
Modifier and Type | Class and Description |
---|---|
class |
AbstractHeapMergingState<K,N,IN,SV,OUT,S extends State>
Base class for
MergingState (InternalMergingState ) that is stored on the heap. |
class |
HeapAggregatingState<K,N,IN,ACC,OUT>
Heap-backed partitioned
AggregatingState that is
snapshotted into files. |
class |
HeapListState<K,N,V>
Heap-backed partitioned
ListState that is snapshotted into files. |
class |
HeapReducingState<K,N,V>
Heap-backed partitioned
ReducingState that is snapshotted into files. |
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 |
InternalListState<K,N,T>
The peer to the
ListState 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. |
Modifier and Type | Method and Description |
---|---|
<S extends MergingState<?,?>> |
Trigger.OnMergeContext.mergePartitionedState(StateDescriptor<S,?> stateDescriptor) |
Modifier and Type | Method and Description |
---|---|
<S extends MergingState<?,?>> |
WindowOperator.Context.mergePartitionedState(StateDescriptor<S,?> stateDescriptor) |
Copyright © 2014–2019 The Apache Software Foundation. All rights reserved.