Package | Description |
---|---|
org.apache.flink.api.common.functions | |
org.apache.flink.api.common.functions.util | |
org.apache.flink.api.common.state | |
org.apache.flink.runtime.state | |
org.apache.flink.streaming.api.datastream | |
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 | Method and Description |
---|---|
<T> ReducingState<T> |
DefaultKeyedStateStore.getReducingState(ReducingStateDescriptor<T> stateProperties) |
Modifier and Type | Method and Description |
---|---|
QueryableStateStream<KEY,T> |
KeyedStream.asQueryableState(String queryableStateName,
ReducingStateDescriptor<T> stateDescriptor)
Publishes the keyed stream as a queryable ReducingState instance.
|
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–2020 The Apache Software Foundation. All rights reserved.