Class InternalTimersSnapshotReaderWriters
- java.lang.Object
-
- org.apache.flink.streaming.api.operators.InternalTimersSnapshotReaderWriters
-
@Internal public class InternalTimersSnapshotReaderWriters extends Object
Readers and writers for different versions of theInternalTimersSnapshot
. Outdated formats are also kept here for documentation of history backlog.
-
-
Nested Class Summary
Nested Classes Modifier and Type Class Description static interface
InternalTimersSnapshotReaderWriters.InternalTimersSnapshotReader<K,N>
A reader for aInternalTimersSnapshot
.static interface
InternalTimersSnapshotReaderWriters.InternalTimersSnapshotWriter
A writer for aInternalTimersSnapshot
.static class
InternalTimersSnapshotReaderWriters.LegacyTimerSerializer<K,N>
ATypeSerializer
used to serialize/deserialize aTimerHeapInternalTimer
.
-
Field Summary
Fields Modifier and Type Field Description static int
NO_VERSION
-
Constructor Summary
Constructors Constructor Description InternalTimersSnapshotReaderWriters()
-
Method Summary
All Methods Static Methods Concrete Methods Modifier and Type Method Description static <K,N>
InternalTimersSnapshotReaderWriters.InternalTimersSnapshotReader<K,N>getReaderForVersion(int version, ClassLoader userCodeClassLoader)
static <K,N>
InternalTimersSnapshotReaderWriters.InternalTimersSnapshotWritergetWriterForVersion(int version, InternalTimersSnapshot<K,N> timersSnapshot, org.apache.flink.api.common.typeutils.TypeSerializer<K> keySerializer, org.apache.flink.api.common.typeutils.TypeSerializer<N> namespaceSerializer)
-
-
-
Field Detail
-
NO_VERSION
public static final int NO_VERSION
- See Also:
- Constant Field Values
-
-
Method Detail
-
getWriterForVersion
public static <K,N> InternalTimersSnapshotReaderWriters.InternalTimersSnapshotWriter getWriterForVersion(int version, InternalTimersSnapshot<K,N> timersSnapshot, org.apache.flink.api.common.typeutils.TypeSerializer<K> keySerializer, org.apache.flink.api.common.typeutils.TypeSerializer<N> namespaceSerializer)
-
getReaderForVersion
public static <K,N> InternalTimersSnapshotReaderWriters.InternalTimersSnapshotReader<K,N> getReaderForVersion(int version, ClassLoader userCodeClassLoader)
-
-