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.
|
org.apache.flink.streaming.tests.artificialstate.builder |
Modifier and Type | Method and Description |
---|---|
<T> ListState<T> |
RuntimeContext.getListState(ListStateDescriptor<T> stateProperties)
Gets a handle to the system's key/value list state.
|
Modifier and Type | Method and Description |
---|---|
<T> ListState<T> |
AbstractRuntimeUDFContext.getListState(ListStateDescriptor<T> stateProperties) |
Modifier and Type | Method and Description |
---|---|
<S> ListState<S> |
OperatorStateStore.getListState(ListStateDescriptor<S> stateDescriptor)
Creates (or restores) a list state.
|
<T> ListState<T> |
KeyedStateStore.getListState(ListStateDescriptor<T> stateProperties)
Gets a handle to the system's key/value list state.
|
<S> ListState<S> |
OperatorStateStore.getOperatorState(ListStateDescriptor<S> stateDescriptor)
Deprecated.
since 1.3.0. This was deprecated as part of a refinement to the function names.
Please use
OperatorStateStore.getListState(ListStateDescriptor) instead. |
<S> ListState<S> |
OperatorStateStore.getUnionListState(ListStateDescriptor<S> stateDescriptor)
Creates (or restores) a list state.
|
Modifier and Type | Method and Description |
---|---|
<S> ListState<S> |
DefaultOperatorStateBackend.getListState(ListStateDescriptor<S> stateDescriptor) |
<T> ListState<T> |
DefaultKeyedStateStore.getListState(ListStateDescriptor<T> stateProperties) |
<S> ListState<S> |
DefaultOperatorStateBackend.getOperatorState(ListStateDescriptor<S> stateDescriptor)
Deprecated.
This was deprecated as part of a refinement to the function names.
Please use
DefaultOperatorStateBackend.getListState(ListStateDescriptor) instead. |
<S> ListState<S> |
DefaultOperatorStateBackend.getUnionListState(ListStateDescriptor<S> stateDescriptor) |
Modifier and Type | Method and Description |
---|---|
<T> ListState<T> |
StreamingRuntimeContext.getListState(ListStateDescriptor<T> stateProperties) |
Modifier and Type | Method and Description |
---|---|
<T> ListState<T> |
WindowOperator.MergingWindowStateStore.getListState(ListStateDescriptor<T> stateProperties) |
Constructor and Description |
---|
ArtificialListStateBuilder(String stateName,
JoinFunction<IN,Iterable<STATE>,List<STATE>> keyedStateGenerator,
JoinFunction<IN,Iterable<STATE>,List<STATE>> operatorStateGenerator,
ListStateDescriptor<STATE> listStateDescriptor) |
Copyright © 2014–2020 The Apache Software Foundation. All rights reserved.