Package | Description |
---|---|
org.apache.flink.api.common.functions | |
org.apache.flink.api.common.functions.util | |
org.apache.flink.api.common.state | |
org.apache.flink.cep.nfa.sharedbuffer | |
org.apache.flink.datastream.api.context | |
org.apache.flink.datastream.impl.context | |
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.functions.query | |
org.apache.flink.streaming.api.operators | |
org.apache.flink.streaming.api.windowing.triggers | |
org.apache.flink.streaming.runtime.operators.windowing |
This package contains the operators that implement the various window operations on data streams.
|
org.apache.flink.table.runtime.dataview | |
org.apache.flink.table.runtime.functions | |
org.apache.flink.table.runtime.operators.deduplicate |
Modifier and Type | Method and Description |
---|---|
<T> ValueState<T> |
RuntimeContext.getState(ValueStateDescriptor<T> stateProperties)
Gets a handle to the system's key/value state.
|
Modifier and Type | Method and Description |
---|---|
<T> ValueState<T> |
AbstractRuntimeUDFContext.getState(ValueStateDescriptor<T> stateProperties) |
Modifier and Type | Method and Description |
---|---|
<T> ValueState<T> |
KeyedStateStore.getState(ValueStateDescriptor<T> stateProperties)
Gets a handle to the system's key/value state.
|
Modifier and Type | Method and Description |
---|---|
void |
SharedBuffer.migrateOldState(KeyedStateBackend<?> stateBackend,
ValueState<NFAState> computationStates) |
Modifier and Type | Method and Description |
---|---|
<T> Optional<ValueState<T>> |
StateManager.getState(ValueStateDeclaration<T> stateDeclaration)
Get the specific value state.
|
Modifier and Type | Method and Description |
---|---|
<T> Optional<ValueState<T>> |
DefaultStateManager.getState(ValueStateDeclaration<T> stateDeclaration) |
Modifier and Type | Class and Description |
---|---|
class |
ImmutableValueState<V>
A read-only
ValueState that does not allow for modifications. |
Modifier and Type | Method and Description |
---|---|
<T> ValueState<T> |
DefaultKeyedStateStore.getState(ValueStateDescriptor<T> stateProperties) |
Modifier and Type | Interface and Description |
---|---|
interface |
InternalValueState<K,N,T>
The peer to the
ValueState in the internal state type hierarchy. |
Modifier and Type | Method and Description |
---|---|
<T> ValueState<T> |
SavepointRuntimeContext.getState(ValueStateDescriptor<T> stateProperties) |
Constructor and Description |
---|
QueryableValueStateOperator(String registrationName,
StateDescriptor<ValueState<IN>,IN> stateDescriptor) |
Modifier and Type | Method and Description |
---|---|
<T> ValueState<T> |
StreamingRuntimeContext.getState(ValueStateDescriptor<T> stateProperties) |
Modifier and Type | Method and Description |
---|---|
<S extends Serializable> |
Trigger.TriggerContext.getKeyValueState(String name,
Class<S> stateType,
S defaultState)
Deprecated.
|
<S extends Serializable> |
Trigger.TriggerContext.getKeyValueState(String name,
TypeInformation<S> stateType,
S defaultState)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
<S extends Serializable> |
WindowOperator.Context.getKeyValueState(String name,
Class<S> stateType,
S defaultState) |
<S extends Serializable> |
WindowOperator.Context.getKeyValueState(String name,
TypeInformation<S> stateType,
S defaultState) |
<T> ValueState<T> |
WindowOperator.MergingWindowStateStore.getState(ValueStateDescriptor<T> stateProperties) |
Modifier and Type | Method and Description |
---|---|
protected ValueState<EV> |
StateMapView.KeyedStateMapViewWithKeysNullable.getNullState() |
protected ValueState<EV> |
StateMapView.NamespacedStateMapViewWithKeysNullable.getNullState() |
Constructor and Description |
---|
KeyedStateMapViewWithKeysNullable(MapState<EK,EV> mapState,
ValueState<EV> nullState) |
Modifier and Type | Method and Description |
---|---|
default void |
CleanupState.registerProcessingCleanupTimer(ValueState<Long> cleanupTimeState,
long currentTime,
long minRetentionTime,
long maxRetentionTime,
TimerService timerService) |
Modifier and Type | Method and Description |
---|---|
static void |
RowTimeDeduplicateFunction.deduplicateOnRowTime(ValueState<RowData> state,
RowData currentRow,
Collector<RowData> out,
boolean generateUpdateBefore,
boolean generateInsert,
int rowtimeIndex,
boolean keepLastRow)
Processes element to deduplicate on keys with row time semantic, sends current element if it
is last or first row, retracts previous element if needed.
|
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.