Package | Description |
---|---|
org.apache.flink.streaming.api.operators.source |
Modifier and Type | Class and Description |
---|---|
class |
BatchTimestampsAndWatermarks<T>
An implementation of
TimestampsAndWatermarks to be used during batch execution of a
program. |
class |
StreamingTimestampsAndWatermarks<T>
An implementation of timestamp extraction and watermark generation logic for streaming sources.
|
Modifier and Type | Method and Description |
---|---|
static <E> TimestampsAndWatermarks<E> |
TimestampsAndWatermarks.createBatchEventTimeLogic(WatermarkStrategy<E> watermarkStrategy,
MetricGroup metrics) |
static <E> TimestampsAndWatermarks<E> |
TimestampsAndWatermarks.createStreamingEventTimeLogic(WatermarkStrategy<E> watermarkStrategy,
MetricGroup metrics,
ProcessingTimeService timeService,
long periodicWatermarkIntervalMillis) |
Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.