Package org.apache.flink.api.common.eventtime
-
Interface Summary Interface Description SerializableTimestampAssigner<T> ATimestampAssigner
that is alsoSerializable
.TimestampAssigner<T> ATimestampAssigner
assigns event time timestamps to elements.TimestampAssignerSupplier<T> A supplier forTimestampAssigners
.TimestampAssignerSupplier.Context Additional information available toTimestampAssignerSupplier.createTimestampAssigner(Context)
.WatermarkGenerator<T> TheWatermarkGenerator
generates watermarks either based on events or periodically (in a fixed interval).WatermarkGeneratorSupplier<T> A supplier forWatermarkGenerators
.WatermarkGeneratorSupplier.Context Additional information available toWatermarkGeneratorSupplier.createWatermarkGenerator(Context)
.WatermarkOutput An output for watermarks.WatermarkOutputMultiplexer.WatermarkUpdateListener A callback for propagating changes to split based watermarks.WatermarkStrategy<T> The WatermarkStrategy defines how to generateWatermark
s in the stream sources. -
Class Summary Class Description AscendingTimestampsWatermarks<T> A watermark generator that assumes monotonically ascending timestamps within the stream split and periodically generates watermarks based on that assumption.BoundedOutOfOrdernessWatermarks<T> A WatermarkGenerator for situations where records are out of order, but you can place an upper bound on how far the events are out of order.IndexedCombinedWatermarkStatus Represents combined value and status of a watermark for a set number of input partial watermarks.IngestionTimeAssigner<T> A timestamp assigner that assigns timestamps based on the machine's wall clock.NoWatermarksGenerator<E> An implementation of aWatermarkGenerator
that generates no Watermarks.RecordTimestampAssigner<E> ATimestampAssigner
that forwards the already-assigned timestamp.TimestampAssignerSupplier.SupplierFromSerializableTimestampAssigner<T> We need an actual class.Watermark Watermarks are the progress indicators in the data streams.WatermarkAlignmentParams Configuration parameters for watermark alignment.WatermarkOutputMultiplexer AWatermarkOutputMultiplexer
combines the watermark (and idleness) updates of multiple partitions/shards/splits into one combined watermark update and forwards it to an underlyingWatermarkOutput
.WatermarksWithIdleness<T> A WatermarkGenerator that adds idleness detection to another WatermarkGenerator.