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.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 |
---|---|
<IN,ACC,OUT> |
KeyedStateStore.getAggregatingState(AggregatingStateDescriptor<IN,ACC,OUT> stateProperties)
Gets a handle to the system's key/value folding state.
|
Modifier and Type | Method and Description |
---|---|
<IN,ACC,OUT> |
DefaultKeyedStateStore.getAggregatingState(AggregatingStateDescriptor<IN,ACC,OUT> stateProperties) |
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–2020 The Apache Software Foundation. All rights reserved.