如何使用 Avro 二进制编码器对 Kafka 消息进行编码/解码?

Posted

技术标签:

【中文标题】如何使用 Avro 二进制编码器对 Kafka 消息进行编码/解码?【英文标题】:How to encode/decode Kafka messages using Avro binary encoder? 【发布时间】:2012-01-08 01:22:59 【问题描述】:

我正在尝试使用 Avro 来读取/写入 Kafka 的消息。有没有人有使用 Avro 二进制编码器对将放入消息队列的数据进行编码/解码的示例?

我需要 Avro 部分而不是 Kafka 部分。或者,也许我应该看一个不同的解决方案?基本上,我试图找到一个关于空间的更有效的 JSON 解决方案。刚刚提到了 Avro,因为它可以比 JSON 更紧凑。

【问题讨论】:

【参考方案1】:

这是一个基本示例。我还没有尝试过多个分区/主题。

//示例生产者代码

import org.apache.avro.Schema;
import org.apache.avro.generic.GenericData;
import org.apache.avro.generic.GenericRecord;
import org.apache.avro.io.*;
import org.apache.avro.specific.SpecificDatumReader;
import org.apache.avro.specific.SpecificDatumWriter;
import org.apache.commons.codec.DecoderException;
import org.apache.commons.codec.binary.Hex;
import kafka.javaapi.producer.Producer;
import kafka.producer.KeyedMessage;
import kafka.producer.ProducerConfig;
import java.io.ByteArrayOutputStream;
import java.io.File;
import java.io.IOException;
import java.nio.charset.Charset;
import java.util.Properties;


public class ProducerTest 

    void producer(Schema schema) throws IOException 

        Properties props = new Properties();
        props.put("metadata.broker.list", "0:9092");
        props.put("serializer.class", "kafka.serializer.DefaultEncoder");
        props.put("request.required.acks", "1");
        ProducerConfig config = new ProducerConfig(props);
        Producer<String, byte[]> producer = new Producer<String, byte[]>(config);
        GenericRecord payload1 = new GenericData.Record(schema);
        //Step2 : Put data in that genericrecord object
        payload1.put("desc", "'testdata'");
        //payload1.put("name", "अasa");
        payload1.put("name", "dbevent1");
        payload1.put("id", 111);
        System.out.println("Original Message : "+ payload1);
        //Step3 : Serialize the object to a bytearray
        DatumWriter<GenericRecord>writer = new SpecificDatumWriter<GenericRecord>(schema);
        ByteArrayOutputStream out = new ByteArrayOutputStream();
        BinaryEncoder encoder = EncoderFactory.get().binaryEncoder(out, null);
        writer.write(payload1, encoder);
        encoder.flush();
        out.close();

        byte[] serializedBytes = out.toByteArray();
        System.out.println("Sending message in bytes : " + serializedBytes);
        //String serializedHex = Hex.encodeHexString(serializedBytes);
        //System.out.println("Serialized Hex String : " + serializedHex);
        KeyedMessage<String, byte[]> message = new KeyedMessage<String, byte[]>("page_views", serializedBytes);
        producer.send(message);
        producer.close();

    


    public static void main(String[] args) throws IOException, DecoderException 
        ProducerTest test = new ProducerTest();
        Schema schema = new Schema.Parser().parse(new File("src/test_schema.avsc"));
        test.producer(schema);
    

//示例消费者代码

第 1 部分:消费者组代码​​:因为您可以为多个分区/主题拥有多个消费者。

import kafka.consumer.ConsumerConfig;
import kafka.consumer.KafkaStream;
import kafka.javaapi.consumer.ConsumerConnector;

import java.util.HashMap;
import java.util.List;
import java.util.Map;
import java.util.Properties;
import java.util.concurrent.Executor;
import java.util.concurrent.ExecutorService;
import java.util.concurrent.Executors;
import java.util.concurrent.TimeUnit;

/**
 * Created by  on 9/1/15.
 */
public class ConsumerGroupExample 
   private final ConsumerConnector consumer;
   private final String topic;
   private ExecutorService executor;

   public ConsumerGroupExample(String a_zookeeper, String a_groupId, String a_topic)
      consumer = kafka.consumer.Consumer.createJavaConsumerConnector(
              createConsumerConfig(a_zookeeper, a_groupId));
      this.topic = a_topic;
   

   private static ConsumerConfig createConsumerConfig(String a_zookeeper, String a_groupId)
       Properties props = new Properties();
       props.put("zookeeper.connect", a_zookeeper);
       props.put("group.id", a_groupId);
       props.put("zookeeper.session.timeout.ms", "400");
       props.put("zookeeper.sync.time.ms", "200");
       props.put("auto.commit.interval.ms", "1000");

       return new ConsumerConfig(props);
   

    public void shutdown()
         if (consumer!=null) consumer.shutdown();
        if (executor!=null) executor.shutdown();
        System.out.println("Timed out waiting for consumer threads to shut down, exiting uncleanly");
        try
          if(!executor.awaitTermination(5000, TimeUnit.MILLISECONDS))

          
        catch(InterruptedException e)
            System.out.println("Interrupted");
        

    


    public void run(int a_numThreads)
        //Make a map of topic as key and no. of threads for that topic
        Map<String, Integer> topicCountMap = new HashMap<String, Integer>();
        topicCountMap.put(topic, new Integer(a_numThreads));
        //Create message streams for each topic
        Map<String, List<KafkaStream<byte[], byte[]>>> consumerMap = consumer.createMessageStreams(topicCountMap);
        List<KafkaStream<byte[], byte[]>> streams = consumerMap.get(topic);

        //initialize thread pool
        executor = Executors.newFixedThreadPool(a_numThreads);
        //start consuming from thread
        int threadNumber = 0;
        for (final KafkaStream stream : streams) 
            executor.submit(new ConsumerTest(stream, threadNumber));
            threadNumber++;
        
    
    public static void main(String[] args) 
        String zooKeeper = args[0];
        String groupId = args[1];
        String topic = args[2];
        int threads = Integer.parseInt(args[3]);

        ConsumerGroupExample example = new ConsumerGroupExample(zooKeeper, groupId, topic);
        example.run(threads);

        try 
            Thread.sleep(10000);
         catch (InterruptedException ie) 

        
        example.shutdown();
    



第 2 部分:实际消费消息的个人消费者。

import kafka.consumer.ConsumerIterator;
import kafka.consumer.KafkaStream;
import kafka.message.MessageAndMetadata;
import org.apache.avro.Schema;
import org.apache.avro.generic.GenericRecord;
import org.apache.avro.generic.IndexedRecord;
import org.apache.avro.io.DatumReader;
import org.apache.avro.io.Decoder;
import org.apache.avro.io.DecoderFactory;
import org.apache.avro.specific.SpecificDatumReader;
import org.apache.commons.codec.binary.Hex;

import java.io.File;
import java.io.IOException;

public class ConsumerTest implements Runnable

    private KafkaStream m_stream;
    private int m_threadNumber;

    public ConsumerTest(KafkaStream a_stream, int a_threadNumber) 
        m_threadNumber = a_threadNumber;
        m_stream = a_stream;
    

    public void run()
        ConsumerIterator<byte[], byte[]>it = m_stream.iterator();
        while(it.hasNext())
        
            try 
                //System.out.println("Encoded Message received : " + message_received);
                //byte[] input = Hex.decodeHex(it.next().message().toString().toCharArray());
                //System.out.println("Deserializied Byte array : " + input);
                byte[] received_message = it.next().message();
                System.out.println(received_message);
                Schema schema = null;
                schema = new Schema.Parser().parse(new File("src/test_schema.avsc"));
                DatumReader<GenericRecord> reader = new SpecificDatumReader<GenericRecord>(schema);
                Decoder decoder = DecoderFactory.get().binaryDecoder(received_message, null);
                GenericRecord payload2 = null;
                payload2 = reader.read(null, decoder);
                System.out.println("Message received : " + payload2);
            catch (Exception e) 
                e.printStackTrace();
                System.out.println(e);
            
        

    



测试 AVRO 架构:


    "namespace": "xyz.test",
     "type": "record",
     "name": "payload",
     "fields":[
         
            "name": "name", "type": "string"
         ,
         
            "name": "id",  "type": ["int", "null"]
         ,
         
            "name": "desc", "type": ["string", "null"]
         
     ]

需要注意的重要事项是:

    您需要标准的 kafka 和 avro jar 来开箱即用地运行此代码。

    很重要 props.put("serializer.class", "kafka.serializer.DefaultEncoder"); 如果您将字节数组作为消息发送,Dont use stringEncoder as that wont 工作。

    您可以将 byte[] 转换为十六进制字符串并将其发送,然后在消费者上将十六进制字符串重新转换为 byte[],然后再转换为原始消息。

    按照此处所述运行 zookeeper 和代理:- http://kafka.apache.org/documentation.html#quickstart 并创建一个名为“page_views”或任何您想要的主题。

    运行 ProducerTest.java,然后运行 ​​ConsumerGroupExample.java,查看正在生成和使用的 avro 数据。

【讨论】:

感谢您的帮助!!我试过了,但在消费者代码中,我的 it.hasNext() 函数返回 false,因此控件永远不会进入 while 循环。知道我做错了什么吗?【参考方案2】:

我终于记得问了Kafka邮件列表,得到了以下答案,效果很好。

是的,您可以将消息作为字节数组发送。如果你看构造函数 Message 类的,你会看到 -

def this(bytes: Array[Byte])

现在,看看 Producer send() API -

def send(producerData: ProducerData[K,V]*)

您可以将 V 设置为 Message 类型,将 K 设置为您想要的密钥。 如果您不关心使用密钥进行分区,请将其设置为 Message 也可以输入。

谢谢, 尼哈

【讨论】:

【参考方案3】:

如果要从 Avro 消息中获取字节数组(kafka 部分已经回答),请使用二进制编码器:

    GenericDatumWriter<GenericRecord> writer = new GenericDatumWriter<GenericRecord>(schema); 
    ByteArrayOutputStream os = new ByteArrayOutputStream(); 
    try 
        Encoder e = EncoderFactory.get().binaryEncoder(os, null); 
        writer.write(record, e); 
        e.flush(); 
        byte[] byteData = os.toByteArray(); 
     finally 
        os.close(); 
    

【讨论】:

你能把这个 byteData 发送到 KafkaBroker 并从控制台消费者那里读取吗? Producer 密钥序列化程序应该是什么? 响应中提到,kafka 部分记录在其他响应中——***.com/a/8348264/5266 和***.com/a/32341917/5266【参考方案4】:

更新答案。

Kafka 有一个带有 Maven(SBT 格式)坐标的 Avro 序列化器/反序列化器:

  "io.confluent" % "kafka-avro-serializer" % "3.0.0"

您将 KafkaAvroSerializer 的实例传递给 KafkaProducer 构造函数。

然后您可以创建 Avro GenericRecord 实例,并将它们用作您可以使用 KafkaProducer 发送的 Kafka ProducerRecord 实例中的值。

在 Kafka 消费者端,您使用 KafkaAvroDeserializer 和 KafkaConsumer。

【讨论】:

你能提供一个简短但完整的例子吗? 这只适用于添加了 Confluent 自己的 Maven 存储库,因为它们不会将工件发布到 maven Central:packages.confluent.io/maven【参考方案5】:

您也可以简单地考虑压缩数据,而不是 Avro;使用 gzip(良好的压缩,更高的 cpu)或 LZF 或 Snappy(快得多,压缩慢一点)。

或者还有Smile binary JSON,Jackson 在 Java 中支持(带有 this extension):它是紧凑的二进制格式,比 Avro 更易于使用:

ObjectMapper mapper = new ObjectMapper(new SmileFactory());
byte[] serialized = mapper.writeValueAsBytes(pojo);
// or back
SomeType pojo = mapper.readValue(serialized, SomeType.class);

与 JSON 基本相同的代码,除了传递不同的格式工厂。 从数据大小来看,Smile 还是 Avro 更紧凑取决于用例的细节;但两者都比 JSON 更紧凑。

这样做的好处是,使用相同的代码,仅使用 POJO 即可快速处理 JSON 和 Smile。与 Avro 相比,Avro 要么需要代码生成,要么需要大量手动代码来打包和解包 GenericRecords。

【讨论】:

以上是关于如何使用 Avro 二进制编码器对 Kafka 消息进行编码/解码?的主要内容,如果未能解决你的问题,请参考以下文章

在Kafka中使用Avro编码消息:Producter篇

具有解码器问题的 Kafka Avro Consumer

Kafka中使用Avro编码解码消息

Kafka:ZK+Kafka+Spark Streaming集群环境搭建(十三)定义一个avro schema使用comsumer发送avro字符流,producer接受avro字符流并解析(示例代码

在火花结构化流中反序列化 kafka avro 主题的 int 编码无效

无法读取 Kafka 主题 avro 消息