NEU
[demos/kafka/chat] / src / main / java / de / juplo / kafka / chat / backend / persistence / kafka / KafkaChatHomeService.java
index 3ca5b7f..e23f08d 100644 (file)
@@ -20,23 +20,24 @@ import reactor.core.publisher.Mono;
 
 import java.time.*;
 import java.util.*;
-import java.util.concurrent.ExecutorService;
 import java.util.stream.IntStream;
 
 
 @Slf4j
 public class KafkaChatHomeService implements ChatHomeService, Runnable, ConsumerRebalanceListener
 {
-  private final ExecutorService executorService;
-  private final Consumer<String, MessageTo> consumer;
-  private final Producer<String, MessageTo> producer;
-  private final String topic;
+  private final String chatRoomsTopic;
+  private final Consumer<Integer, ChatRoomTo> chatRoomsConsumer;
+  private final Producer<Integer, ChatRoomTo> chatRoomsProducer;
+  private final String chatMessagesTopic;
+  private final Consumer<String, MessageTo> chatMessagesConsumer;
+  private final Producer<String, MessageTo> chatMessagesProducer;
   private final ZoneId zoneId;
   private final int numShards;
   private final boolean[] isShardOwned;
   private final long[] currentOffset;
   private final long[] nextOffset;
-  private final Map<UUID, ChatRoom>[] chatRoomMaps;
+  private final Map<UUID, ChatRoom>[] chatrooms;
   private final KafkaLikeShardingStrategy shardingStrategy;
 
   private boolean running;
@@ -44,24 +45,28 @@ public class KafkaChatHomeService implements ChatHomeService, Runnable, Consumer
 
 
   public KafkaChatHomeService(
-    ExecutorService executorService,
-    Consumer<String, MessageTo> consumer,
-    Producer<String, MessageTo> producer,
-    String topic,
+    String chatRoomsTopic,
+    Consumer<Integer, ChatRoomTo> chatRoomsConsumer,
+    Producer<Integer, ChatRoomTo> chatRoomsProducer,
+    String chatMessagesTopic,
+    Consumer<String, MessageTo> chatMessagesConsumer,
+    Producer<String, MessageTo> chatMessagesProducer,
     ZoneId zoneId,
     int numShards)
   {
     log.debug("Creating KafkaChatHomeService");
-    this.executorService = executorService;
-    this.consumer = consumer;
-    this.producer = producer;
-    this.topic = topic;
+    this.chatRoomsTopic = chatRoomsTopic;
+    this.chatRoomsConsumer = chatRoomsConsumer;
+    this.chatRoomsProducer = chatRoomsProducer;
+    this.chatMessagesTopic = chatMessagesTopic;
+    this.chatMessagesConsumer = chatMessagesConsumer;
+    this.chatMessagesProducer = chatMessagesProducer;
     this.zoneId = zoneId;
     this.numShards = numShards;
     this.isShardOwned = new boolean[numShards];
     this.currentOffset = new long[numShards];
     this.nextOffset = new long[numShards];
-    this.chatRoomMaps = new Map[numShards];
+    this.chatrooms = new Map[numShards];
     this.shardingStrategy = new KafkaLikeShardingStrategy(numShards);
   }
 
@@ -72,7 +77,7 @@ public class KafkaChatHomeService implements ChatHomeService, Runnable, Consumer
     log.info("Newly assigned partitions! Pausing normal operations...");
     loadInProgress = true;
 
-    consumer.endOffsets(partitions).forEach((topicPartition, currentOffset) ->
+    chatMessagesConsumer.endOffsets(partitions).forEach((topicPartition, currentOffset) ->
     {
       int partition = topicPartition.partition();
       isShardOwned[partition] =  true;
@@ -84,10 +89,10 @@ public class KafkaChatHomeService implements ChatHomeService, Runnable, Consumer
           nextOffset[partition],
           currentOffset);
 
-      consumer.seek(topicPartition, nextOffset[partition]);
+      chatMessagesConsumer.seek(topicPartition, nextOffset[partition]);
     });
 
-    consumer.resume(partitions);
+    chatMessagesConsumer.resume(partitions);
   }
 
   @Override
@@ -112,7 +117,7 @@ public class KafkaChatHomeService implements ChatHomeService, Runnable, Consumer
   @Override
   public void run()
   {
-    consumer.subscribe(List.of(topic));
+    chatMessagesConsumer.subscribe(List.of(chatMessagesTopic));
 
     running = true;
 
@@ -120,7 +125,7 @@ public class KafkaChatHomeService implements ChatHomeService, Runnable, Consumer
     {
       try
       {
-        ConsumerRecords<String, MessageTo> records = consumer.poll(Duration.ofMinutes(5));
+        ConsumerRecords<String, MessageTo> records = chatMessagesConsumer.poll(Duration.ofMinutes(5));
         log.info("Fetched {} messages", records.count());
 
         if (loadInProgress)
@@ -167,7 +172,7 @@ public class KafkaChatHomeService implements ChatHomeService, Runnable, Consumer
 
       Message message = new Message(key, record.offset(), timestamp, messageTo.getText());
 
-      ChatRoom chatRoom = chatRoomMaps[record.partition()].get(chatRoomId);
+      ChatRoom chatRoom = chatrooms[record.partition()].get(chatRoomId);
       KafkaChatRoomService kafkaChatRoomService =
           (KafkaChatRoomService) chatRoom.getChatRoomService();
 
@@ -189,10 +194,10 @@ public class KafkaChatHomeService implements ChatHomeService, Runnable, Consumer
 
   void pauseAllOwnedPartions()
   {
-    consumer.pause(IntStream
+    chatMessagesConsumer.pause(IntStream
         .range(0, numShards)
         .filter(shard -> isShardOwned[shard])
-        .mapToObj(shard -> new TopicPartition(topic, shard))
+        .mapToObj(shard -> new TopicPartition(chatMessagesTopic, shard))
         .toList());
   }
 
@@ -203,7 +208,7 @@ public class KafkaChatHomeService implements ChatHomeService, Runnable, Consumer
       String text)
   {
     int shard = this.shardingStrategy.selectShard(chatRoomId);
-    TopicPartition tp = new TopicPartition(topic, shard);
+    TopicPartition tp = new TopicPartition(chatMessagesTopic, shard);
     ZonedDateTime zdt = ZonedDateTime.of(timestamp, zoneId);
     return Mono.create(sink ->
     {
@@ -215,7 +220,7 @@ public class KafkaChatHomeService implements ChatHomeService, Runnable, Consumer
               chatRoomId.toString(),
               MessageTo.of(key.getUsername(), key.getMessageId(), text));
 
-      producer.send(record, ((metadata, exception) ->
+      chatMessagesProducer.send(record, ((metadata, exception) ->
       {
         if (metadata != null)
         {
@@ -241,6 +246,14 @@ public class KafkaChatHomeService implements ChatHomeService, Runnable, Consumer
   }
 
 
+  public void putChatRoom(ChatRoom chatRoom)
+  {
+
+    ProducerRecord<Integer, ChatRoomTo> record = new ProducerRecord<>(chatRoom.getShard(), );
+    // TODO: Nachricht senden!
+    chatrooms[chatRoom.getShard()].put(chatRoom.getId(), chatRoom);
+  }
+
   @Override
   public Mono<ChatRoom> getChatRoom(int shard, UUID id)
   {
@@ -250,7 +263,7 @@ public class KafkaChatHomeService implements ChatHomeService, Runnable, Consumer
     }
     else
     {
-      return Mono.justOrEmpty(chatRoomMaps[shard].get(id));
+      return Mono.justOrEmpty(chatrooms[shard].get(id));
     }
   }
 
@@ -263,7 +276,7 @@ public class KafkaChatHomeService implements ChatHomeService, Runnable, Consumer
     }
     else
     {
-      return Flux.fromStream(chatRoomMaps[shard].values().stream());
+      return Flux.fromStream(chatrooms[shard].values().stream());
     }
   }
 }