Package | Description |
---|---|
org.apache.flink.contrib.streaming.state | |
org.apache.flink.runtime.query | |
org.apache.flink.runtime.state.heap |
This package contains the classes for key/value state backends that store the state on the JVM
heap as objects.
|
org.apache.flink.runtime.state.internal |
This package holds the classes of the internal state type hierarchy.
|
org.apache.flink.table.runtime.dataview | |
org.apache.flink.table.runtime.operators.window |
Class and Description |
---|
InternalKvState
The
InternalKvState is the root of the internal state type hierarchy, similar to the
State being the root of the public API state hierarchy. |
InternalKvState.StateIncrementalVisitor
The state entry visitor which supports remove and update of the last returned entries.
|
Class and Description |
---|
InternalKvState
The
InternalKvState is the root of the internal state type hierarchy, similar to the
State being the root of the public API state hierarchy. |
Class and Description |
---|
InternalKvState
The
InternalKvState is the root of the internal state type hierarchy, similar to the
State being the root of the public API state hierarchy. |
InternalKvState.StateIncrementalVisitor
The state entry visitor which supports remove and update of the last returned entries.
|
Class and Description |
---|
InternalAppendingState
The peer to the
AppendingState in the internal state type hierarchy. |
InternalKvState
The
InternalKvState is the root of the internal state type hierarchy, similar to the
State being the root of the public API state hierarchy. |
InternalKvState.StateIncrementalVisitor
The state entry visitor which supports remove and update of the last returned entries.
|
InternalMergingState
The peer to the
MergingState in the internal state type hierarchy. |
Class and Description |
---|
InternalListState
The peer to the
ListState in the internal state type hierarchy. |
InternalMapState
The peer to the
MapState in the internal state type hierarchy. |
InternalValueState
The peer to the
ValueState in the internal state type hierarchy. |
Class and Description |
---|
InternalValueState
The peer to the
ValueState in the internal state type hierarchy. |
Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.