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 |
---|---|
<IN,ACC,OUT> |
RuntimeContext.getAggregatingState(AggregatingStateDescriptor<IN,ACC,OUT> stateProperties)
Gets a handle to the system's key/value aggregating state.
|
Modifier and Type | Method and Description |
---|---|
<IN,ACC,OUT> |
AbstractRuntimeUDFContext.getAggregatingState(AggregatingStateDescriptor<IN,ACC,OUT> stateProperties) |
Modifier and Type | Method and Description |
---|---|
AggregatingState<IN,OUT> |
AggregatingStateDescriptor.bind(StateBinder stateBinder) |
<IN,ACC,OUT> |
StateBinder.createAggregatingState(AggregatingStateDescriptor<IN,ACC,OUT> stateDesc)
Creates and returns a new
AggregatingState . |
<IN,ACC,OUT> |
KeyedStateStore.getAggregatingState(AggregatingStateDescriptor<IN,ACC,OUT> stateProperties)
Gets a handle to the system's key/value folding state.
|
Modifier and Type | Class and Description |
---|---|
class |
RocksDBAggregatingState<K,N,T,ACC,R>
An
AggregatingState 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. |
Modifier and Type | Method and Description |
---|---|
<IN,ACC,OUT> |
ImmutableStateBinder.createAggregatingState(AggregatingStateDescriptor<IN,ACC,OUT> stateDesc) |
Modifier and Type | Method and Description |
---|---|
<IN,ACC,OUT> |
DefaultKeyedStateStore.getAggregatingState(AggregatingStateDescriptor<IN,ACC,OUT> stateProperties) |
Modifier and Type | Class and Description |
---|---|
class |
HeapAggregatingState<K,N,IN,ACC,OUT>
Heap-backed partitioned
AggregatingState 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. |
Modifier and Type | Method and Description |
---|---|
<IN,ACC,OUT> |
StreamingRuntimeContext.getAggregatingState(AggregatingStateDescriptor<IN,ACC,OUT> stateProperties) |
Modifier and Type | Method and Description |
---|---|
<IN,ACC,OUT> |
WindowOperator.MergingWindowStateStore.getAggregatingState(AggregatingStateDescriptor<IN,ACC,OUT> stateProperties) |
Copyright © 2014–2019 The Apache Software Foundation. All rights reserved.