java - 使用 Kafka Streams 按 ID 和时间连接日志 - 无法刷新状态存储

标签 java apache-kafka apache-kafka-streams

我想使用 Kafka Streams 在一个时间窗口内按 ID 连接日志。

目前,我可以成功统计具有相同 ID(注释代码)的日志数量。

但是,当我用 .aggregate 替换 .count 方法时,我遇到以下错误:

"Failed to flush state store time-windowed-aggregation-stream-store"
Caused by: java.lang.ClassCastException: org.apache.kafka.streams.kstream.Windowed cannot be cast to java.lang.String

我是新手,无法找出此错误的原因,我认为使用 .withValueSerde(Serdes.String()) 应该可以防止这种情况发生。

在我的代码下面:

package myapps;

import java.time.Duration;
import java.util.Properties;
import java.util.concurrent.CountDownLatch;
import org.apache.kafka.common.serialization.Serdes;
import org.apache.kafka.common.utils.Bytes;
import org.apache.kafka.streams.KafkaStreams;
import org.apache.kafka.streams.StreamsBuilder;
import org.apache.kafka.streams.StreamsConfig;
import org.apache.kafka.streams.Topology;
import org.apache.kafka.streams.kstream.*;
import org.apache.kafka.streams.kstream.KStream;
import org.apache.kafka.streams.kstream.Suppressed.*;
import org.apache.kafka.streams.state.WindowStore;

public class MyCode {

    public static void main(String[] args) throws Exception {
        Properties props = new Properties();
        props.put(StreamsConfig.APPLICATION_ID_CONFIG, "streams-mycode");
        props.put(StreamsConfig.BOOTSTRAP_SERVERS_CONFIG, "localhost:9092");
        props.put(StreamsConfig.DEFAULT_KEY_SERDE_CLASS_CONFIG, Serdes.String().getClass());
        props.put(StreamsConfig.DEFAULT_VALUE_SERDE_CLASS_CONFIG, Serdes.String().getClass());

        final StreamsBuilder builder = new StreamsBuilder();

        KStream<String, String> source = builder.stream("streams-plaintext-input");
        KStream<String, String> changedKeyStream = source.selectKey((k, v)
         -> v.substring(v.indexOf("mid="),v.indexOf("mid=")+8));

        /* // Working code for count
        changedKeyStream
        .groupByKey()
        .windowedBy(TimeWindows.of(Duration.ofSeconds(3))
        .grace(Duration.ofSeconds(2)))
        .count(Materialized.with(Serdes.String(), Serdes.Long())) // could be replaced with an aggregator (reducer?) ? 
        .suppress(Suppressed.untilWindowCloses(BufferConfig.unbounded()))
        .toStream()
        .print(Printed.toSysOut());
        */

        changedKeyStream
        .groupByKey()
        .windowedBy(TimeWindows.of(Duration.ofSeconds(3)))

        .aggregate(
        String::new, (String k, String v, String Result) -> { return Result+"\n"+v; },
        Materialized.<String, String, WindowStore<Bytes, byte[]>>as("time-windowed-aggregated-stream-store") /* state store name */
        .withValueSerde(Serdes.String())) /* serde for aggregate value */
        .suppress(Suppressed.untilWindowCloses(BufferConfig.unbounded()))
        .toStream()
        .print(Printed.toSysOut());

        changedKeyStream.to("streams-mycode-output", Produced.with(Serdes.String(), Serdes.String()));

        final Topology topology = builder.build();
        final KafkaStreams streams = new KafkaStreams(topology, props);
        final CountDownLatch latch = new CountDownLatch(1);

        // attach shutdown handler to catch control-c
        Runtime.getRuntime().addShutdownHook(new Thread("streams-shutdown-hook") {
            @Override
            public void run() {
                streams.close();
                latch.countDown();
            }
        });

        // launch until control+c
        try {
            streams.start();
            latch.await();
        } catch (Throwable e) {
            System.out.print("Something went wrong!"); 
            System.exit(1);
        }
        System.exit(0);
    }
}

预先感谢您的帮助。

最佳答案

有两个选项可以修复它:

  1. org.apache.kafka.streams.kstream.Grouped 传递给 KStream::groupByKey
  2. 将 org.apache.kafka.common.serialization.Serde 设置为 Materialized - Materialized::withKeySerde(...)

示例代码如下:

广告 1。

changedKeyStream
  .groupByKey(Grouped.with(Serdes.String(), Serdes.String()))
  .windowedBy(TimeWindows.of(Duration.ofSeconds(3)))

广告 2。

changedKeyStream
  .groupByKey()
  .windowedBy(TimeWindows.of(Duration.ofSeconds(3)))
  .aggregate(
    String::new, (String k, String v, String Result) -> { return Result+"_"+v; },
    Materialized.<String, String, WindowStore<Bytes, byte[]>>as("time-windowed-aggregated-stream-store") /* state store name */
      .withValueSerde(Serdes.String())
      .withKeySerde(Serdes.String())
   )

关于java - 使用 Kafka Streams 按 ID 和时间连接日志 - 无法刷新状态存储,我们在Stack Overflow上找到一个类似的问题: https://stackoverflow.com/questions/58611221/

相关文章:

java - 'exactly once' 是否仅适用于流(主题 1 -> 应用程序 -> 主题 2)?

java - 卡夫卡输出流

java - 使用 kafka-streams 有条件地对 json 输入流进行排序

apache-kafka - KSQL查询和表存储

java - 为什么 Kafka KTable 缺少条目?

java - Kafka 流 API 示例 KStream 无法解析为类型

java - 我正在努力在我的应用程序上设置 "Keep me on Logged in"状态。我该怎么做呢?

java - 使用HashMap创建动态函数调用

java - split ("\\W") 和 split ("[^\\w' ]"有什么区别

java - 在java中生成自定义文本文件