Renamed test into `AggregateWindowedTumblingSuppressedTest` -- MOVE
authorKai Moritz <kai@juplo.de>
Wed, 17 Jul 2024 09:49:39 +0000 (11:49 +0200)
committerKai Moritz <kai@juplo.de>
Wed, 17 Jul 2024 09:51:20 +0000 (11:51 +0200)
src/test/java/de/juplo/kafka/streams/aggregate/windowed/tumbling/AggregateWindowedTumblingSuppressedTest.java [new file with mode: 0644]
src/test/java/de/juplo/kafka/wordcount/counter/AggregationTopologyTest.java [deleted file]

diff --git a/src/test/java/de/juplo/kafka/streams/aggregate/windowed/tumbling/AggregateWindowedTumblingSuppressedTest.java b/src/test/java/de/juplo/kafka/streams/aggregate/windowed/tumbling/AggregateWindowedTumblingSuppressedTest.java
new file mode 100644 (file)
index 0000000..a650311
--- /dev/null
@@ -0,0 +1,176 @@
+package de.juplo.kafka.wordcount.counter;
+
+import lombok.extern.slf4j.Slf4j;
+import org.apache.kafka.common.serialization.Serdes;
+import org.apache.kafka.common.utils.Bytes;
+import org.apache.kafka.streams.*;
+import org.apache.kafka.streams.kstream.*;
+import org.apache.kafka.streams.kstream.internals.TimeWindow;
+import org.apache.kafka.streams.state.WindowStore;
+import org.apache.kafka.streams.test.TestRecord;
+import org.junit.jupiter.api.Test;
+
+import java.time.Duration;
+import java.time.Instant;
+import java.util.Properties;
+import java.util.regex.Matcher;
+import java.util.regex.Pattern;
+import java.util.stream.Stream;
+
+import static org.assertj.core.api.Assertions.assertThat;
+
+
+@Slf4j
+public class AggregationTopologyTest
+{
+  static final Duration WINDOW_SIZE = Duration.ofSeconds(10);
+  static final TimeWindows WINDOWS = TimeWindows.ofSizeWithNoGrace(WINDOW_SIZE);
+
+
+  @Test
+  public void test()
+  {
+    StreamsBuilder builder = new StreamsBuilder();
+
+    KStream<String, String> input = builder.stream(INPUT);
+
+    input
+        .groupByKey()
+        .windowedBy(WINDOWS)
+        .reduce(
+            (aggregate, value) -> aggregate + "-" + value,
+            Materialized.<String, String, WindowStore<Bytes, byte[]>>as("aggregated-store")
+                .withKeySerde(Serdes.String())
+                .withValueSerde(Serdes.String()))
+        .suppress(Suppressed.untilWindowCloses(Suppressed.BufferConfig.unbounded()))
+        .toStream((k,v) -> k.toString())
+        .to(OUTPUT);
+
+    Topology topology = builder.build();
+    log.info("Generated topology: {}", topology.describe());
+
+    Properties properties = new Properties();
+    properties.put(StreamsConfig.DEFAULT_KEY_SERDE_CLASS_CONFIG, Serdes.StringSerde.class);
+    properties.put(StreamsConfig.DEFAULT_VALUE_SERDE_CLASS_CONFIG, Serdes.StringSerde.class);
+
+    TopologyTestDriver testDriver = new TopologyTestDriver(topology, properties);
+
+    in = testDriver.createInputTopic(
+        INPUT,
+        Serdes.String().serializer(),
+        Serdes.String().serializer());
+    out = testDriver.createOutputTopic(
+        OUTPUT,
+        Serdes.String().deserializer(),
+        Serdes.String().deserializer());
+
+
+    sendAt("A", 63);
+    assertThatOutcomeIs();
+
+    sendAt("B", 64);
+    assertThatOutcomeIs();
+
+    sendAt("C", 65);
+    assertThatOutcomeIs();
+
+    sendAt("D", 66);
+    assertThatOutcomeIs();
+
+    sendAt("E", 69);
+    assertThatOutcomeIs();
+
+    sendAt("F", 70);
+    assertThatOutcomeIs(KeyValue.pair(windowFor(60), "A-B-C-D-E"));
+
+    sendAt("G", 74);
+    assertThatOutcomeIs();
+
+    sendAt("H", 75);
+    assertThatOutcomeIs();
+
+    sendAt("I", 100);
+    assertThatOutcomeIs(KeyValue.pair(windowFor(70), "F-G-H"));
+
+    sendAt("J", 120);
+    assertThatOutcomeIs(KeyValue.pair(windowFor(100), "I"));
+
+    sendAt("K", 140);
+    assertThatOutcomeIs(KeyValue.pair(windowFor(120), "J"));
+
+    sendAt("L", 160);
+    assertThatOutcomeIs(KeyValue.pair(windowFor(140), "K"));
+
+    // Never received, if no newer message is send
+    // KeyValue.pair(windowFor(160), "L")
+  }
+
+
+  static final String INPUT = "TEST-INPUT";
+  static final String OUTPUT = "TEST-OUTPUT";
+
+  static final String KEY = "foo";
+
+
+  TestInputTopic<String, String> in;
+  TestOutputTopic<String, String> out;
+
+
+  void sendAt(String value, int second)
+  {
+    TestRecord<String, String> record = new TestRecord<>(KEY, value, Instant.ofEpochSecond(second));
+    log.info(
+        "Sending  @ {}: {} = {}",
+        record.getRecordTime().toEpochMilli(),
+        record.key(),
+        record.value());
+    in.pipeInput(record);
+  }
+
+  void assertThatOutcomeIs(KeyValue<Windowed<String>, String>... expected)
+  {
+    assertThat(outcome()).containsExactly(expected);
+  }
+
+  Stream<KeyValue<Windowed<String>, String>> outcome()
+  {
+    return out
+        .readRecordsToList()
+        .stream()
+        .peek(record -> log.info(
+            "Received @ {}: {} = {}",
+            record.getRecordTime().toEpochMilli(),
+            record.key(),
+            record.value()))
+        .map(record -> KeyValue.pair(parse(record.key()), record.value()));
+  }
+
+
+  static final Pattern PATTERN = Pattern.compile("^\\[([^@]*)@(\\d+)/(\\d+)\\]$");
+
+  Windowed<String> parse(String serialized)
+  {
+    Matcher matcher = PATTERN.matcher(serialized);
+
+    if (!matcher.matches())
+    {
+      throw new IllegalArgumentException(serialized + "does not match " + PATTERN.pattern());
+    }
+
+    String key = matcher.group(1);
+    String start = matcher.group(2);
+    String end = matcher.group(3);
+
+    Window window = new TimeWindow(Long.parseLong(start), Long.parseLong(end));
+
+    return new Windowed<>(key, window);
+  }
+
+  Windowed<String> windowFor(int second)
+  {
+    Instant startTime = Instant.ofEpochSecond(second);
+    Instant endTime = startTime.plus(WINDOW_SIZE);
+    TimeWindow window = new TimeWindow(startTime.toEpochMilli(), endTime.toEpochMilli());
+    return new Windowed<>(KEY, window);
+  }
+}
diff --git a/src/test/java/de/juplo/kafka/wordcount/counter/AggregationTopologyTest.java b/src/test/java/de/juplo/kafka/wordcount/counter/AggregationTopologyTest.java
deleted file mode 100644 (file)
index a650311..0000000
+++ /dev/null
@@ -1,176 +0,0 @@
-package de.juplo.kafka.wordcount.counter;
-
-import lombok.extern.slf4j.Slf4j;
-import org.apache.kafka.common.serialization.Serdes;
-import org.apache.kafka.common.utils.Bytes;
-import org.apache.kafka.streams.*;
-import org.apache.kafka.streams.kstream.*;
-import org.apache.kafka.streams.kstream.internals.TimeWindow;
-import org.apache.kafka.streams.state.WindowStore;
-import org.apache.kafka.streams.test.TestRecord;
-import org.junit.jupiter.api.Test;
-
-import java.time.Duration;
-import java.time.Instant;
-import java.util.Properties;
-import java.util.regex.Matcher;
-import java.util.regex.Pattern;
-import java.util.stream.Stream;
-
-import static org.assertj.core.api.Assertions.assertThat;
-
-
-@Slf4j
-public class AggregationTopologyTest
-{
-  static final Duration WINDOW_SIZE = Duration.ofSeconds(10);
-  static final TimeWindows WINDOWS = TimeWindows.ofSizeWithNoGrace(WINDOW_SIZE);
-
-
-  @Test
-  public void test()
-  {
-    StreamsBuilder builder = new StreamsBuilder();
-
-    KStream<String, String> input = builder.stream(INPUT);
-
-    input
-        .groupByKey()
-        .windowedBy(WINDOWS)
-        .reduce(
-            (aggregate, value) -> aggregate + "-" + value,
-            Materialized.<String, String, WindowStore<Bytes, byte[]>>as("aggregated-store")
-                .withKeySerde(Serdes.String())
-                .withValueSerde(Serdes.String()))
-        .suppress(Suppressed.untilWindowCloses(Suppressed.BufferConfig.unbounded()))
-        .toStream((k,v) -> k.toString())
-        .to(OUTPUT);
-
-    Topology topology = builder.build();
-    log.info("Generated topology: {}", topology.describe());
-
-    Properties properties = new Properties();
-    properties.put(StreamsConfig.DEFAULT_KEY_SERDE_CLASS_CONFIG, Serdes.StringSerde.class);
-    properties.put(StreamsConfig.DEFAULT_VALUE_SERDE_CLASS_CONFIG, Serdes.StringSerde.class);
-
-    TopologyTestDriver testDriver = new TopologyTestDriver(topology, properties);
-
-    in = testDriver.createInputTopic(
-        INPUT,
-        Serdes.String().serializer(),
-        Serdes.String().serializer());
-    out = testDriver.createOutputTopic(
-        OUTPUT,
-        Serdes.String().deserializer(),
-        Serdes.String().deserializer());
-
-
-    sendAt("A", 63);
-    assertThatOutcomeIs();
-
-    sendAt("B", 64);
-    assertThatOutcomeIs();
-
-    sendAt("C", 65);
-    assertThatOutcomeIs();
-
-    sendAt("D", 66);
-    assertThatOutcomeIs();
-
-    sendAt("E", 69);
-    assertThatOutcomeIs();
-
-    sendAt("F", 70);
-    assertThatOutcomeIs(KeyValue.pair(windowFor(60), "A-B-C-D-E"));
-
-    sendAt("G", 74);
-    assertThatOutcomeIs();
-
-    sendAt("H", 75);
-    assertThatOutcomeIs();
-
-    sendAt("I", 100);
-    assertThatOutcomeIs(KeyValue.pair(windowFor(70), "F-G-H"));
-
-    sendAt("J", 120);
-    assertThatOutcomeIs(KeyValue.pair(windowFor(100), "I"));
-
-    sendAt("K", 140);
-    assertThatOutcomeIs(KeyValue.pair(windowFor(120), "J"));
-
-    sendAt("L", 160);
-    assertThatOutcomeIs(KeyValue.pair(windowFor(140), "K"));
-
-    // Never received, if no newer message is send
-    // KeyValue.pair(windowFor(160), "L")
-  }
-
-
-  static final String INPUT = "TEST-INPUT";
-  static final String OUTPUT = "TEST-OUTPUT";
-
-  static final String KEY = "foo";
-
-
-  TestInputTopic<String, String> in;
-  TestOutputTopic<String, String> out;
-
-
-  void sendAt(String value, int second)
-  {
-    TestRecord<String, String> record = new TestRecord<>(KEY, value, Instant.ofEpochSecond(second));
-    log.info(
-        "Sending  @ {}: {} = {}",
-        record.getRecordTime().toEpochMilli(),
-        record.key(),
-        record.value());
-    in.pipeInput(record);
-  }
-
-  void assertThatOutcomeIs(KeyValue<Windowed<String>, String>... expected)
-  {
-    assertThat(outcome()).containsExactly(expected);
-  }
-
-  Stream<KeyValue<Windowed<String>, String>> outcome()
-  {
-    return out
-        .readRecordsToList()
-        .stream()
-        .peek(record -> log.info(
-            "Received @ {}: {} = {}",
-            record.getRecordTime().toEpochMilli(),
-            record.key(),
-            record.value()))
-        .map(record -> KeyValue.pair(parse(record.key()), record.value()));
-  }
-
-
-  static final Pattern PATTERN = Pattern.compile("^\\[([^@]*)@(\\d+)/(\\d+)\\]$");
-
-  Windowed<String> parse(String serialized)
-  {
-    Matcher matcher = PATTERN.matcher(serialized);
-
-    if (!matcher.matches())
-    {
-      throw new IllegalArgumentException(serialized + "does not match " + PATTERN.pattern());
-    }
-
-    String key = matcher.group(1);
-    String start = matcher.group(2);
-    String end = matcher.group(3);
-
-    Window window = new TimeWindow(Long.parseLong(start), Long.parseLong(end));
-
-    return new Windowed<>(key, window);
-  }
-
-  Windowed<String> windowFor(int second)
-  {
-    Instant startTime = Instant.ofEpochSecond(second);
-    Instant endTime = startTime.plus(WINDOW_SIZE);
-    TimeWindow window = new TimeWindow(startTime.toEpochMilli(), endTime.toEpochMilli());
-    return new Windowed<>(KEY, window);
-  }
-}