Package | Description |
---|---|
org.apache.flink.cep.nfa.sharedbuffer | |
org.apache.flink.runtime.state | |
org.apache.flink.state.api.functions | |
org.apache.flink.state.api.runtime | |
org.apache.flink.streaming.api.functions.windowing | |
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.runtime.operators.windowing.functions |
Constructor and Description |
---|
SharedBuffer(KeyedStateStore stateStore,
TypeSerializer<V> valueSerializer) |
SharedBuffer(KeyedStateStore stateStore,
TypeSerializer<V> valueSerializer,
SharedBufferCacheConfig cacheConfig) |
Modifier and Type | Class and Description |
---|---|
class |
DefaultKeyedStateStore
Default implementation of KeyedStateStore that currently forwards state registration to a
RuntimeContext . |
Modifier and Type | Method and Description |
---|---|
KeyedStateStore |
ManagedInitializationContext.getKeyedStateStore()
Returns an interface that allows for registering keyed state with the backend.
|
KeyedStateStore |
StateInitializationContextImpl.getKeyedStateStore() |
Constructor and Description |
---|
StateInitializationContextImpl(Long restoredCheckpointId,
OperatorStateStore operatorStateStore,
KeyedStateStore keyedStateStore,
Iterable<KeyGroupStatePartitionStreamProvider> rawKeyedStateInputs,
Iterable<StatePartitionStreamProvider> rawOperatorStateInputs) |
Modifier and Type | Method and Description |
---|---|
KeyedStateStore |
WindowReaderFunction.Context.globalState()
State accessor for per-key global state.
|
KeyedStateStore |
WindowReaderFunction.Context.windowState()
State accessor for per-key and per-window state.
|
Constructor and Description |
---|
SavepointRuntimeContext(RuntimeContext ctx,
KeyedStateStore keyedStateStore) |
Modifier and Type | Method and Description |
---|---|
KeyedStateStore |
InternalProcessApplyWindowContext.globalState() |
KeyedStateStore |
InternalProcessApplyAllWindowContext.globalState() |
abstract KeyedStateStore |
ProcessWindowFunction.Context.globalState()
State accessor for per-key global state.
|
abstract KeyedStateStore |
ProcessAllWindowFunction.Context.globalState()
State accessor for per-key global state.
|
KeyedStateStore |
InternalProcessApplyWindowContext.windowState() |
KeyedStateStore |
InternalProcessApplyAllWindowContext.windowState() |
abstract KeyedStateStore |
ProcessWindowFunction.Context.windowState()
State accessor for per-key and per-window state.
|
abstract KeyedStateStore |
ProcessAllWindowFunction.Context.windowState()
State accessor for per-key and per-window state.
|
Modifier and Type | Method and Description |
---|---|
KeyedStateStore |
AbstractStreamOperator.getKeyedStateStore() |
Modifier and Type | Method and Description |
---|---|
Optional<KeyedStateStore> |
StreamOperatorStateHandler.getKeyedStateStore() |
Optional<KeyedStateStore> |
AbstractStreamOperatorV2.getKeyedStateStore() |
Modifier and Type | Method and Description |
---|---|
void |
StreamingRuntimeContext.setKeyedStateStore(KeyedStateStore keyedStateStore) |
Constructor and Description |
---|
StreamingRuntimeContext(Environment env,
Map<String,Accumulator<?,?>> accumulators,
OperatorMetricGroup operatorMetricGroup,
OperatorID operatorID,
ProcessingTimeService processingTimeService,
KeyedStateStore keyedStateStore,
ExternalResourceInfoProvider externalResourceInfoProvider) |
Modifier and Type | Class and Description |
---|---|
class |
WindowOperator.AbstractPerWindowStateStore
Base class for per-window
KeyedStateStores . |
class |
WindowOperator.MergingWindowStateStore
Special
WindowOperator.AbstractPerWindowStateStore that doesn't allow access to per-window state. |
class |
WindowOperator.PerWindowStateStore
Regular per-window state store for use with
ProcessWindowFunction . |
Modifier and Type | Method and Description |
---|---|
KeyedStateStore |
WindowOperator.WindowContext.globalState() |
KeyedStateStore |
WindowOperator.WindowContext.windowState() |
Modifier and Type | Method and Description |
---|---|
KeyedStateStore |
InternalWindowFunction.InternalWindowContext.globalState() |
KeyedStateStore |
InternalProcessAllWindowContext.globalState() |
KeyedStateStore |
InternalProcessWindowContext.globalState() |
KeyedStateStore |
InternalWindowFunction.InternalWindowContext.windowState() |
KeyedStateStore |
InternalProcessAllWindowContext.windowState() |
KeyedStateStore |
InternalProcessWindowContext.windowState() |
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.