Class InternalTimersSnapshot<K,N>
- java.lang.Object
-
- org.apache.flink.streaming.api.operators.InternalTimersSnapshot<K,N>
-
public class InternalTimersSnapshot<K,N> extends Object
A snapshot of internal timers, containing event and processing timers and the serializers to use to write / read them.
-
-
Constructor Summary
Constructors Constructor Description InternalTimersSnapshot()
Empty constructor used when restoring the timers.InternalTimersSnapshot(org.apache.flink.api.common.typeutils.TypeSerializer<K> keySerializer, org.apache.flink.api.common.typeutils.TypeSerializer<N> namespaceSerializer, Set<TimerHeapInternalTimer<K,N>> eventTimeTimers, Set<TimerHeapInternalTimer<K,N>> processingTimeTimers)
Constructor to use when snapshotting the timers.
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description boolean
equals(Object obj)
Set<TimerHeapInternalTimer<K,N>>
getEventTimeTimers()
org.apache.flink.api.common.typeutils.TypeSerializerSnapshot<K>
getKeySerializerSnapshot()
org.apache.flink.api.common.typeutils.TypeSerializerSnapshot<N>
getNamespaceSerializerSnapshot()
Set<TimerHeapInternalTimer<K,N>>
getProcessingTimeTimers()
int
hashCode()
void
setEventTimeTimers(Set<TimerHeapInternalTimer<K,N>> eventTimeTimers)
void
setKeySerializerSnapshot(org.apache.flink.api.common.typeutils.TypeSerializerSnapshot<K> keySerializerConfigSnapshot)
void
setNamespaceSerializerSnapshot(org.apache.flink.api.common.typeutils.TypeSerializerSnapshot<N> namespaceSerializerConfigSnapshot)
void
setProcessingTimeTimers(Set<TimerHeapInternalTimer<K,N>> processingTimeTimers)
-
-
-
Constructor Detail
-
InternalTimersSnapshot
public InternalTimersSnapshot()
Empty constructor used when restoring the timers.
-
InternalTimersSnapshot
public InternalTimersSnapshot(org.apache.flink.api.common.typeutils.TypeSerializer<K> keySerializer, org.apache.flink.api.common.typeutils.TypeSerializer<N> namespaceSerializer, @Nullable Set<TimerHeapInternalTimer<K,N>> eventTimeTimers, @Nullable Set<TimerHeapInternalTimer<K,N>> processingTimeTimers)
Constructor to use when snapshotting the timers.
-
-
Method Detail
-
getKeySerializerSnapshot
public org.apache.flink.api.common.typeutils.TypeSerializerSnapshot<K> getKeySerializerSnapshot()
-
setKeySerializerSnapshot
public void setKeySerializerSnapshot(org.apache.flink.api.common.typeutils.TypeSerializerSnapshot<K> keySerializerConfigSnapshot)
-
getNamespaceSerializerSnapshot
public org.apache.flink.api.common.typeutils.TypeSerializerSnapshot<N> getNamespaceSerializerSnapshot()
-
setNamespaceSerializerSnapshot
public void setNamespaceSerializerSnapshot(org.apache.flink.api.common.typeutils.TypeSerializerSnapshot<N> namespaceSerializerConfigSnapshot)
-
getEventTimeTimers
public Set<TimerHeapInternalTimer<K,N>> getEventTimeTimers()
-
setEventTimeTimers
public void setEventTimeTimers(Set<TimerHeapInternalTimer<K,N>> eventTimeTimers)
-
getProcessingTimeTimers
public Set<TimerHeapInternalTimer<K,N>> getProcessingTimeTimers()
-
setProcessingTimeTimers
public void setProcessingTimeTimers(Set<TimerHeapInternalTimer<K,N>> processingTimeTimers)
-
-