Tags für Asciidoc hinzugefügt
[demos/kafka/training] / src / main / java / de / juplo / kafka / Application.java
index 9fcaa6e..b304fa9 100644 (file)
 package de.juplo.kafka;
 
 import lombok.extern.slf4j.Slf4j;
-import org.apache.kafka.clients.producer.KafkaProducer;
-import org.apache.kafka.clients.producer.ProducerRecord;
-import org.apache.kafka.common.serialization.StringSerializer;
-
-import java.util.Properties;
+import org.springframework.beans.factory.annotation.Autowired;
+import org.springframework.boot.ApplicationArguments;
+import org.springframework.boot.ApplicationRunner;
+import org.springframework.boot.SpringApplication;
+import org.springframework.boot.autoconfigure.SpringBootApplication;
+import org.springframework.kafka.core.KafkaTemplate;
+import org.springframework.kafka.support.SendResult;
+import org.springframework.util.concurrent.ListenableFuture;
 
 
 @Slf4j
-public class SimpleProducer
+@SpringBootApplication
+public class Application implements ApplicationRunner
 {
-  private final String id;
-  private final String topic;
-  private final KafkaProducer<String, String> producer;
-
-  private long produced = 0;
-  private volatile boolean running = true;
-  private volatile boolean done = false;
-
-  public SimpleProducer(String broker, String topic, String clientId)
-  {
-    Properties props = new Properties();
-    props.put("bootstrap.servers", broker);
-    props.put("client.id", clientId); // Nur zur Wiedererkennung
-    props.put("key.serializer", StringSerializer.class.getName());
-    props.put("value.serializer", StringSerializer.class.getName());
-
-    producer = new KafkaProducer<>(props);
-
-    this.topic = topic;
-    this.id = clientId;
-  }
+  @Autowired
+  KafkaTemplate<String, String> kafkaTemplate;
 
-  public void run()
+  @Override
+  public void run(ApplicationArguments args)
   {
-    long i = 0;
-
-    try
-    {
-      for (; running ; i++)
-      {
-        send(Long.toString(i%10), Long.toString(i));
-        Thread.sleep(500);
-      }
-    }
-    catch (InterruptedException e) {}
-    finally
+    for (int i = 0; i < 100; i++)
     {
-      log.info("{}: Closing the KafkaProducer", id);
-      producer.close();
-      log.info("{}: Produced {} messages in total, exiting!", id, produced);
-      done = true;
+      // tag::callback[]
+      ListenableFuture<SendResult<String, String>> listenableFuture =
+          kafkaTemplate.send("test", Long.toString(i%10), Long.toString(i));
+
+      listenableFuture.addCallback(
+          result -> log.info(
+              "Sent {}={} to partition={}, offset={}",
+              result.getProducerRecord().key(),
+              result.getProducerRecord().value(),
+              result.getRecordMetadata().partition(),
+              result.getRecordMetadata().offset()),
+          e -> log.error("ERROR sendig message", e));
+      // end::callback[]
     }
   }
 
-  void send(String key, String value)
+  public static void main(String[] args)
   {
-    final long time = System.currentTimeMillis();
-
-    final ProducerRecord<String, String> record = new ProducerRecord<>(
-        topic,  // Topic
-        key,    // Key
-        value   // Value
-    );
-
-    producer.send(record, (metadata, e) ->
-    {
-      long now = System.currentTimeMillis();
-      if (e == null)
-      {
-        // HANDLE SUCCESS
-        produced++;
-        log.debug(
-            "{} - Sent key={} message={} partition={}/{} timestamp={} latency={}ms",
-            id,
-            record.key(),
-            record.value(),
-            metadata.partition(),
-            metadata.offset(),
-            metadata.timestamp(),
-            now - time
-        );
-      }
-      else
-      {
-        // HANDLE ERROR
-        log.error(
-            "{} - ERROR key={} timestamp={} latency={}ms: {}",
-            id,
-            record.key(),
-            metadata == null ? -1 : metadata.timestamp(),
-            now - time,
-            e.toString()
-        );
-      }
-    });
-
-    long now = System.currentTimeMillis();
-    log.trace(
-        "{} - Queued #{} key={} latency={}ms",
-        id,
-        value,
-        record.key(),
-        now - time
-    );
-  }
-
-
-  public static void main(String[] args) throws Exception
-  {
-    String broker = ":9092";
-    String topic = "test";
-    String clientId = "DEV";
-
-    switch (args.length)
-    {
-      case 3:
-        clientId = args[2];
-      case 2:
-        topic = args[1];
-      case 1:
-        broker = args[0];
-    }
-
-    SimpleProducer instance = new SimpleProducer(broker, topic, clientId);
-
-    Runtime.getRuntime().addShutdownHook(new Thread(() ->
-    {
-      instance.running = false;
-      while (!instance.done)
-      {
-        log.info("Waiting for main-thread...");
-        try
-        {
-          Thread.sleep(1000);
-        }
-        catch (InterruptedException e) {}
-      }
-      log.info("Shutdown completed.");
-    }));
-
-    log.info(
-        "Running SimpleProducer: broker={}, topic={}, client-id={}",
-        broker,
-        topic,
-        clientId);
-    instance.run();
+    SpringApplication.run(Application.class, args);
   }
 }