web-dev-qa-db-ja.com

Avroバイナリエンコーダーを使用してメッセージをエンコード/デコードする方法Kafka?

Kafkaとの間で読み書きされるメッセージにAvroを使用しようとしています。 Avroバイナリエンコーダーを使用して、メッセージキューに置かれるデータをエンコード/デコードする例はありますか?

Kafkaの部分よりもAvroの部分が必要です。または、別のソリューションを検討する必要がありますか?基本的に、スペースに関してJSONのより効率的なソリューションを見つけようとしています。 AvroはJSONよりもコンパクトになる可能性があるため、先ほど言及しました。

27
blockcipher

私はついにKafka=メーリングリストに尋ねることを思い出し、次の回答を得ました。これは完璧に機能しました。

はい、メッセージをバイト配列として送信できます。 Messageクラスのコンストラクターを見ると、次のように表示されます-

def this(bytes:Array [Byte])

Producer send()APIを見てみましょう-

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

VをMessageタイプ、Kをキーにしたいものに設定できます。キーを使用してパーティションを作成する必要がない場合は、それをメッセージタイプにも設定します。

ありがとう、ネハ

11
blockcipher

これは基本的な例です。複数のパーティション/トピックで試したことはありません。

//サンプルプロデューサーコード

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"]
         }
     ]
}

注意すべき重要な点は次のとおりです。

  1. このコードをそのまま実行するには、標準のkafkaおよびavro jarが必要です。

  2. 非常に重要ですprops.put( "serializer.class"、 "kafka.serializer.DefaultEncoder");ドンt use stringEncoder as that wontは、バイト配列をメッセージとして送信する場合に機能します。

  3. Byte []を16進文字列に変換して送信し、コンシューマで16進文字列をbyte []に​​再変換してから元のメッセージに再変換できます。

  4. ここで説明されているように、zookeeperとブローカーを実行します。- http://kafka.Apache.org/documentation.html#quickstart と呼ばれるトピックを作成します。

  5. ProducerTest.Javaを実行してからConsumerGroupExample.Javaを実行し、生成および消費されるavroデータを確認します。

19
ramu

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(); 
    }
9
Will Sargent

更新された回答。

Kafkaには、Maven(SBT形式)座標を備えたAvroシリアライザー/デシリアライザーがあります。

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

KafkaAvroSerializerのインスタンスをKafkaProducerコンストラクターに渡します。

次に、Avro GenericRecordインスタンスを作成し、それらをKafkaProducerで送信できるKafka ProducerRecordインスタンス内の値として使用できます。

Kafka=コンシューマー側では、KafkaAvroDeserializerとKafkaConsumerを使用します。

3
clay

Avroの代わりに、単にデータの圧縮を検討することもできます。 gzip(良好な圧縮、高いCPU)またはLZFまたはSnappy(非常に高速、少し遅い圧縮)のいずれか。

または、代わりに Smile binary JSON があり、JavaでJacksonがサポートしています( この拡張子 ):コンパクトなバイナリ形式であり、 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よりもコンパクトです。

利点は、これがJSONとSmileの両方で、POJOだけを使用して同じコードで高速に動作することです。コード生成、またはGenericRecordsのパックとアンパックに大量の手動コードを必要とするAvroと比較して。

2
StaxMan