diff --git a/runners/flink/runner/src/main/java/org/apache/beam/runners/flink/translation/FlinkStreamingPipelineTranslator.java b/runners/flink/runner/src/main/java/org/apache/beam/runners/flink/translation/FlinkStreamingPipelineTranslator.java index 31b2bee63f72..64f3ca6b2c73 100644 --- a/runners/flink/runner/src/main/java/org/apache/beam/runners/flink/translation/FlinkStreamingPipelineTranslator.java +++ b/runners/flink/runner/src/main/java/org/apache/beam/runners/flink/translation/FlinkStreamingPipelineTranslator.java @@ -31,9 +31,7 @@ * This is a {@link FlinkPipelineTranslator} for streaming jobs. Its role is to translate the user-provided * {@link org.apache.beam.sdk.values.PCollection}-based job into a * {@link org.apache.flink.streaming.api.datastream.DataStream} one. - * - * This is based on {@link org.apache.beam.runners.dataflow.DataflowPipelineTranslator} - * */ + */ public class FlinkStreamingPipelineTranslator extends FlinkPipelineTranslator { private static final Logger LOG = LoggerFactory.getLogger(FlinkStreamingPipelineTranslator.class); diff --git a/runners/flink/runner/src/main/java/org/apache/beam/runners/flink/translation/wrappers/streaming/FlinkGroupAlsoByWindowWrapper.java b/runners/flink/runner/src/main/java/org/apache/beam/runners/flink/translation/wrappers/streaming/FlinkGroupAlsoByWindowWrapper.java index 9d2cad847a38..625a67e63ac1 100644 --- a/runners/flink/runner/src/main/java/org/apache/beam/runners/flink/translation/wrappers/streaming/FlinkGroupAlsoByWindowWrapper.java +++ b/runners/flink/runner/src/main/java/org/apache/beam/runners/flink/translation/wrappers/streaming/FlinkGroupAlsoByWindowWrapper.java @@ -83,19 +83,19 @@ * This class is the key class implementing all the windowing/triggering logic of Apache Beam. * To provide full compatibility and support for all the windowing/triggering combinations offered by * Beam, we opted for a strategy that uses the SDK's code for doing these operations. See the code in - * ({@link org.apache.beam.runners.core.GroupAlsoByWindowsDoFn}. - *

+ * ({@link org.apache.beam.sdk.util.GroupAlsoByWindowsDoFn}. + *

* In a nutshell, when the execution arrives to this operator, we expect to have a stream already * grouped by key. Each of the elements that enter here, registers a timer * (see {@link TimerInternals#setTimer(TimerInternals.TimerData)} in the * {@link FlinkGroupAlsoByWindowWrapper#activeTimers}. * This is essentially a timestamp indicating when to trigger the computation over the window this * element belongs to. - *

+ *

* When a watermark arrives, all the registered timers are checked to see which ones are ready to * fire (see {@link FlinkGroupAlsoByWindowWrapper#processWatermark(Watermark)}). These are deregistered from * the {@link FlinkGroupAlsoByWindowWrapper#activeTimers} - * list, and are fed into the {@link org.apache.beam.runners.core.GroupAlsoByWindowsDoFn} + * list, and are fed into the {@link org.apache.beam.sdk.util.GroupAlsoByWindowsDoFn} * for furhter processing. */ public class FlinkGroupAlsoByWindowWrapper @@ -134,7 +134,7 @@ public class FlinkGroupAlsoByWindowWrapper /** * Creates an DataStream where elements are grouped in windows based on the specified windowing strategy. * This method assumes that elements are already grouped by key. - *

+ *

* The difference with {@link #createForIterable(PipelineOptions, PCollection, KeyedStream)} * is that this method assumes that a combiner function is provided * (see {@link org.apache.beam.sdk.transforms.Combine.KeyedCombineFn}). @@ -177,7 +177,7 @@ public static DataStream>> create /** * Creates an DataStream where elements are grouped in windows based on the specified windowing strategy. * This method assumes that elements are already grouped by key. - *

+ *

* The difference with {@link #create(PipelineOptions, PCollection, KeyedStream, Combine.KeyedCombineFn, KvCoder)} * is that this method assumes no combiner function * (see {@link org.apache.beam.sdk.transforms.Combine.KeyedCombineFn}). @@ -253,8 +253,8 @@ public void open() throws Exception { } /** - * Create the adequate {@link org.apache.beam.runners.core.GroupAlsoByWindowsDoFn}, - * if not already created. + * Create the adequate {@link org.apache.beam.sdk.util.GroupAlsoByWindowsDoFn}, + * if not already created. * If a {@link org.apache.beam.sdk.transforms.Combine.KeyedCombineFn} was provided, then * a function with that combiner is created, so that elements are combined as they arrive. This is * done for speed and (in most of the cases) for reduction of the per-window state.