@Internal public class TimerSerializerSnapshot<K,N> extends org.apache.flink.api.common.typeutils.CompositeTypeSerializerSnapshot<TimerHeapInternalTimer<K,N>,TimerSerializer<K,N>>
TimerSerializer
.Constructor and Description |
---|
TimerSerializerSnapshot() |
TimerSerializerSnapshot(TimerSerializer<K,N> timerSerializer) |
Modifier and Type | Method and Description |
---|---|
protected TimerSerializer<K,N> |
createOuterSerializerWithNestedSerializers(org.apache.flink.api.common.typeutils.TypeSerializer<?>[] nestedSerializers) |
protected int |
getCurrentOuterSnapshotVersion() |
protected org.apache.flink.api.common.typeutils.TypeSerializer<?>[] |
getNestedSerializers(TimerSerializer<K,N> outerSerializer) |
getCurrentVersion, getNestedSerializerSnapshots, isOuterSnapshotCompatible, readOuterSnapshot, readSnapshot, resolveOuterSchemaCompatibility, resolveSchemaCompatibility, restoreSerializer, writeOuterSnapshot, writeSnapshot
public TimerSerializerSnapshot()
public TimerSerializerSnapshot(TimerSerializer<K,N> timerSerializer)
protected int getCurrentOuterSnapshotVersion()
getCurrentOuterSnapshotVersion
in class org.apache.flink.api.common.typeutils.CompositeTypeSerializerSnapshot<TimerHeapInternalTimer<K,N>,TimerSerializer<K,N>>
protected TimerSerializer<K,N> createOuterSerializerWithNestedSerializers(org.apache.flink.api.common.typeutils.TypeSerializer<?>[] nestedSerializers)
createOuterSerializerWithNestedSerializers
in class org.apache.flink.api.common.typeutils.CompositeTypeSerializerSnapshot<TimerHeapInternalTimer<K,N>,TimerSerializer<K,N>>
protected org.apache.flink.api.common.typeutils.TypeSerializer<?>[] getNestedSerializers(TimerSerializer<K,N> outerSerializer)
getNestedSerializers
in class org.apache.flink.api.common.typeutils.CompositeTypeSerializerSnapshot<TimerHeapInternalTimer<K,N>,TimerSerializer<K,N>>
Copyright © 2014–2023 The Apache Software Foundation. All rights reserved.