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.functions.query | |
org.apache.flink.streaming.api.operators | |
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 | Method and Description |
---|---|
<T> ValueState<T> |
RuntimeContext.getState(ValueStateDescriptor<T> stateProperties)
Gets a handle to the system's key/value state.
|
Modifier and Type | Method and Description |
---|---|
<T> ValueState<T> |
AbstractRuntimeUDFContext.getState(ValueStateDescriptor<T> stateProperties) |
Modifier and Type | Method and Description |
---|---|
ValueState<T> |
ValueStateDescriptor.bind(StateBinder stateBinder) |
<T> ValueState<T> |
StateBinder.createValueState(ValueStateDescriptor<T> stateDesc)
Creates and returns a new
ValueState . |
<T> ValueState<T> |
KeyedStateStore.getState(ValueStateDescriptor<T> stateProperties)
Gets a handle to the system's key/value state.
|
Modifier and Type | Class and Description |
---|---|
class |
RocksDBValueState<K,N,V>
ValueState implementation that stores state in RocksDB. |
Modifier and Type | Class and Description |
---|---|
class |
ImmutableValueState<V>
A read-only
ValueState that does not allow for modifications. |
Modifier and Type | Method and Description |
---|---|
<T> ValueState<T> |
ImmutableStateBinder.createValueState(ValueStateDescriptor<T> stateDesc) |
Modifier and Type | Method and Description |
---|---|
<T> ValueState<T> |
DefaultKeyedStateStore.getState(ValueStateDescriptor<T> stateProperties) |
Modifier and Type | Class and Description |
---|---|
class |
HeapValueState<K,N,V>
Heap-backed partitioned
ValueState that is snapshotted into files. |
Modifier and Type | Interface and Description |
---|---|
interface |
InternalValueState<K,N,T>
The peer to the
ValueState in the internal state type hierarchy. |
Constructor and Description |
---|
QueryableValueStateOperator(String registrationName,
StateDescriptor<ValueState<IN>,IN> stateDescriptor) |
Modifier and Type | Method and Description |
---|---|
<T> ValueState<T> |
StreamingRuntimeContext.getState(ValueStateDescriptor<T> stateProperties) |
Modifier and Type | Method and Description |
---|---|
<S extends Serializable> |
Trigger.TriggerContext.getKeyValueState(String name,
Class<S> stateType,
S defaultState)
Deprecated.
|
<S extends Serializable> |
Trigger.TriggerContext.getKeyValueState(String name,
TypeInformation<S> stateType,
S defaultState)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
<S extends Serializable> |
WindowOperator.Context.getKeyValueState(String name,
Class<S> stateType,
S defaultState) |
<S extends Serializable> |
WindowOperator.Context.getKeyValueState(String name,
TypeInformation<S> stateType,
S defaultState) |
<T> ValueState<T> |
WindowOperator.MergingWindowStateStore.getState(ValueStateDescriptor<T> stateProperties) |
Copyright © 2014–2019 The Apache Software Foundation. All rights reserved.