Package | Description |
---|---|
org.apache.flink.api.common.functions | |
org.apache.flink.api.common.functions.util | |
org.apache.flink.api.common.state | |
org.apache.flink.queryablestate.client.state | |
org.apache.flink.runtime.state | |
org.apache.flink.runtime.state.internal |
This package holds the classes of the internal state type hierarchy.
|
org.apache.flink.state.api.runtime | |
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 |
---|---|
<T> ReducingState<T> |
RuntimeContext.getReducingState(ReducingStateDescriptor<T> stateProperties)
Gets a handle to the system's key/value reducing state.
|
Modifier and Type | Method and Description |
---|---|
<T> ReducingState<T> |
AbstractRuntimeUDFContext.getReducingState(ReducingStateDescriptor<T> stateProperties) |
Modifier and Type | Method and Description |
---|---|
<T> ReducingState<T> |
KeyedStateStore.getReducingState(ReducingStateDescriptor<T> stateProperties)
Gets a handle to the system's key/value reducing state.
|
Modifier and Type | Class and Description |
---|---|
class |
ImmutableReducingState<V>
A read-only
ReducingState that does not allow for modifications. |
Modifier and Type | Method and Description |
---|---|
<T> ReducingState<T> |
DefaultKeyedStateStore.getReducingState(ReducingStateDescriptor<T> stateProperties) |
Modifier and Type | Interface and Description |
---|---|
interface |
InternalReducingState<K,N,T>
The peer to the
ReducingState in the internal state type hierarchy. |
Modifier and Type | Method and Description |
---|---|
<T> ReducingState<T> |
SavepointRuntimeContext.getReducingState(ReducingStateDescriptor<T> stateProperties) |
Modifier and Type | Method and Description |
---|---|
<T> ReducingState<T> |
StreamingRuntimeContext.getReducingState(ReducingStateDescriptor<T> stateProperties) |
Modifier and Type | Method and Description |
---|---|
<T> ReducingState<T> |
WindowOperator.MergingWindowStateStore.getReducingState(ReducingStateDescriptor<T> stateProperties) |
Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.