See: Description
Interface | Description |
---|---|
HeapPriorityQueueElement |
Interface for objects that can be managed by a
HeapPriorityQueue . |
InternalKeyContext<K> |
This interface is the current context of a keyed state.
|
KeyGroupPartitionedPriorityQueue.PartitionQueueSetFactory<T,PQS extends InternalPriorityQueue<T> & HeapPriorityQueueElement> |
Factory that produces the sub-queues that represent the partitions of a
KeyGroupPartitionedPriorityQueue . |
LevelIndexHeader |
Head level index for skip list.
|
Class | Description |
---|---|
AbstractHeapPriorityQueue<T extends HeapPriorityQueueElement> |
Abstract base class for heap (object array) based implementations of priority queues, with
support for fast deletes via
HeapPriorityQueueElement . |
AbstractHeapState<K,N,SV> |
Base class for partitioned
State implementations that are backed by a regular heap hash
map. |
CopyOnWriteSkipListStateMap<K,N,S> |
Implementation of state map which is based on skip list with copy-on-write support.
|
CopyOnWriteSkipListStateMapSnapshot<K,N,S> |
This class represents the snapshot of a
CopyOnWriteSkipListStateMap . |
CopyOnWriteStateMap<K,N,S> |
Implementation of Flink's in-memory state maps with copy-on-write support.
|
CopyOnWriteStateMap.StateMapEntry<K,N,S> |
One entry in the
CopyOnWriteStateMap . |
CopyOnWriteStateMapSnapshot<K,N,S> |
This class represents the snapshot of a
CopyOnWriteStateMap . |
CopyOnWriteStateTable<K,N,S> |
This implementation of
StateTable uses CopyOnWriteStateMap . |
CopyOnWriteStateTableSnapshot<K,N,S> |
This class represents the snapshot of a
CopyOnWriteStateTable and has a role in operator
state checkpointing. |
HeapKeyedStateBackend<K> |
A
AbstractKeyedStateBackend that keeps state on the Java Heap and will serialize state to
streams provided by a CheckpointStreamFactory upon checkpointing. |
HeapKeyedStateBackendBuilder<K> |
Builder class for
HeapKeyedStateBackend which handles all necessary initializations and
clean ups. |
HeapPriorityQueue<T extends HeapPriorityQueueElement> |
Basic heap-based priority queue for
HeapPriorityQueueElement objects. |
HeapPriorityQueueSet<T extends HeapPriorityQueueElement> |
A heap-based priority queue with set semantics, based on
HeapPriorityQueue . |
HeapPriorityQueueSetFactory |
Factory for
HeapPriorityQueueSet . |
HeapPriorityQueueSnapshotRestoreWrapper<T extends HeapPriorityQueueElement> |
This wrapper combines a HeapPriorityQueue with backend meta data.
|
HeapPriorityQueueStateSnapshot<T> |
This class represents the snapshot of an
HeapPriorityQueueSet . |
HeapRestoreOperation<K> |
Implementation of heap restore operation.
|
InternalKeyContextImpl<K> |
The default
InternalKeyContext implementation. |
KeyGroupPartitionedPriorityQueue<T,PQ extends InternalPriorityQueue<T> & HeapPriorityQueueElement> |
This implementation of
InternalPriorityQueue is internally partitioned into sub-queues
per key-group and essentially works as a heap-of-heaps. |
NestedMapsStateTable<K,N,S> |
This implementation of
StateTable uses NestedStateMap . |
NestedStateMap<K,N,S> | |
NestedStateMapSnapshot<K,N,S> |
This class represents the snapshot of a
NestedStateMap . |
OnHeapLevelIndexHeader |
Implementation of
LevelIndexHeader which stores index on heap. |
SkipListUtils |
Utilities for skip list.
|
StateMap<K,N,S> |
Base class for state maps.
|
StateMapSnapshot<K,N,S,T extends StateMap<K,N,S>> |
Base class for snapshots of a
StateMap . |
StateTable<K,N,S> |
Base class for state tables.
|
Enum | Description |
---|---|
NodeStatus |
Status of the node.
|
Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.