Package | Description |
---|---|
org.apache.flink.api.common.functions | |
org.apache.flink.api.common.functions.util | |
org.apache.flink.api.common.state | |
org.apache.flink.contrib.streaming.state | |
org.apache.flink.queryablestate.client.state | |
org.apache.flink.runtime.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.operators | |
org.apache.flink.streaming.runtime.operators.windowing |
This package contains the operators that implement the various window operations
on data streams.
|
Modifier and Type | Method and Description |
---|---|
<UK,UV> MapState<UK,UV> |
RuntimeContext.getMapState(MapStateDescriptor<UK,UV> stateProperties)
Gets a handle to the system's key/value map state.
|
Modifier and Type | Method and Description |
---|---|
<UK,UV> MapState<UK,UV> |
AbstractRuntimeUDFContext.getMapState(MapStateDescriptor<UK,UV> stateProperties) |
Modifier and Type | Method and Description |
---|---|
MapState<UK,UV> |
MapStateDescriptor.bind(StateBinder stateBinder) |
<MK,MV> MapState<MK,MV> |
StateBinder.createMapState(MapStateDescriptor<MK,MV> stateDesc)
Creates and returns a new
MapState . |
<UK,UV> MapState<UK,UV> |
KeyedStateStore.getMapState(MapStateDescriptor<UK,UV> stateProperties)
Gets a handle to the system's key/value map state.
|
Modifier and Type | Class and Description |
---|---|
class |
RocksDBMapState<K,N,UK,UV>
MapState implementation that stores state in RocksDB. |
Modifier and Type | Class and Description |
---|---|
class |
ImmutableMapState<K,V>
A read-only
MapState that does not allow for modifications. |
Modifier and Type | Method and Description |
---|---|
<MK,MV> MapState<MK,MV> |
ImmutableStateBinder.createMapState(MapStateDescriptor<MK,MV> stateDesc) |
Modifier and Type | Method and Description |
---|---|
<UK,UV> MapState<UK,UV> |
DefaultKeyedStateStore.getMapState(MapStateDescriptor<UK,UV> stateProperties) |
Modifier and Type | Class and Description |
---|---|
class |
HeapMapState<K,N,UK,UV>
Heap-backed partitioned
MapState that is snapshotted into files. |
Modifier and Type | Interface and Description |
---|---|
interface |
InternalMapState<K,N,UK,UV>
The peer to the
MapState in the internal state type hierarchy. |
Modifier and Type | Method and Description |
---|---|
<UK,UV> MapState<UK,UV> |
StreamingRuntimeContext.getMapState(MapStateDescriptor<UK,UV> stateProperties) |
Modifier and Type | Method and Description |
---|---|
<UK,UV> MapState<UK,UV> |
WindowOperator.MergingWindowStateStore.getMapState(MapStateDescriptor<UK,UV> stateProperties) |
Copyright © 2014–2019 The Apache Software Foundation. All rights reserved.