Package | Description |
---|---|
org.apache.flink.runtime.state | |
org.apache.flink.streaming.api.operators |
Constructor and Description |
---|
DefaultOperatorStateBackend(ExecutionConfig executionConfig,
CloseableRegistry closeStreamOnCancelRegistry,
Map<String,PartitionableListState<?>> registeredOperatorStates,
Map<String,BackendWritableBroadcastState<?,?>> registeredBroadcastStates,
Map<String,PartitionableListState<?>> accessedStatesByName,
Map<String,BackendWritableBroadcastState<?,?>> accessedBroadcastStatesByName,
SnapshotStrategyRunner<OperatorStateHandle,?> snapshotStrategyRunner) |
Modifier and Type | Method and Description |
---|---|
static SnapshotStrategyRunner<KeyedStateHandle,? extends FullSnapshotResources<?>> |
StreamOperatorStateHandler.prepareCanonicalSavepoint(CheckpointableKeyedStateBackend<?> keyedStateBackend,
CloseableRegistry closeableRegistry) |
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.