Package | Description |
---|---|
org.apache.flink.runtime.state | |
org.apache.flink.runtime.state.filesystem | |
org.apache.flink.runtime.state.memory |
Modifier and Type | Class and Description |
---|---|
class |
AbstractHeapState<K,N,SV,S extends org.apache.flink.api.common.state.State,SD extends org.apache.flink.api.common.state.StateDescriptor<S,?>,Backend extends AbstractStateBackend>
Base class for partitioned
ListState implementations that are backed by a regular
heap hash map. |
class |
AsynchronousKvStateSnapshot<K,N,S extends org.apache.flink.api.common.state.State,SD extends org.apache.flink.api.common.state.StateDescriptor<S,?>,Backend extends AbstractStateBackend>
KvStateSnapshot that asynchronously materializes the state that it represents. |
class |
GenericFoldingState<K,N,T,ACC,Backend extends AbstractStateBackend,W extends org.apache.flink.api.common.state.ValueState<ACC> & KvState<K,N,org.apache.flink.api.common.state.ValueState<ACC>,org.apache.flink.api.common.state.ValueStateDescriptor<ACC>,Backend>>
Generic implementation of
FoldingState based on a wrapped ValueState . |
class |
GenericListState<K,N,T,Backend extends AbstractStateBackend,W extends org.apache.flink.api.common.state.ValueState<ArrayList<T>> & KvState<K,N,org.apache.flink.api.common.state.ValueState<ArrayList<T>>,org.apache.flink.api.common.state.ValueStateDescriptor<ArrayList<T>>,Backend>>
Generic implementation of
ListState based on a wrapped ValueState . |
class |
GenericReducingState<K,N,T,Backend extends AbstractStateBackend,W extends org.apache.flink.api.common.state.ValueState<T> & KvState<K,N,org.apache.flink.api.common.state.ValueState<T>,org.apache.flink.api.common.state.ValueStateDescriptor<T>,Backend>>
Generic implementation of
ReducingState based on a wrapped ValueState . |
interface |
KvState<K,N,S extends org.apache.flink.api.common.state.State,SD extends org.apache.flink.api.common.state.StateDescriptor<S,?>,Backend extends AbstractStateBackend>
Key/Value state implementation for user-defined state.
|
interface |
KvStateSnapshot<K,N,S extends org.apache.flink.api.common.state.State,SD extends org.apache.flink.api.common.state.StateDescriptor<S,?>,Backend extends AbstractStateBackend>
This class represents a snapshot of the
KvState , taken for a checkpoint. |
interface |
StateBackendFactory<T extends AbstractStateBackend>
A factory to create a specific state backend.
|
Modifier and Type | Method and Description |
---|---|
AbstractStateBackend |
StateBackendFactory.createFromConfig(org.apache.flink.configuration.Configuration config)
Creates the state backend, optionally using the given configuration.
|
Modifier and Type | Class and Description |
---|---|
class |
FsStateBackend
The file state backend is a state backend that stores the state of streaming jobs in a file system.
|
Modifier and Type | Class and Description |
---|---|
class |
MemoryStateBackend
A
AbstractStateBackend that stores all its data and checkpoints in memory and has no
capabilities to spill to disk. |
Copyright © 2014–2016 The Apache Software Foundation. All rights reserved.