NG
[demos/kafka/chat] / src / main / java / de / juplo / kafka / chat / backend / persistence / kafka / ChatRoomChannel.java
index 0c553e6..1c6ae91 100644 (file)
@@ -1,59 +1,37 @@
 package de.juplo.kafka.chat.backend.persistence.kafka;
 
 import de.juplo.kafka.chat.backend.domain.*;
-import de.juplo.kafka.chat.backend.persistence.KafkaLikeShardingStrategy;
+import lombok.RequiredArgsConstructor;
 import lombok.extern.slf4j.Slf4j;
 import org.apache.kafka.clients.consumer.Consumer;
-import org.apache.kafka.clients.consumer.ConsumerRebalanceListener;
 import org.apache.kafka.clients.consumer.ConsumerRecord;
 import org.apache.kafka.clients.consumer.ConsumerRecords;
 import org.apache.kafka.clients.producer.Producer;
 import org.apache.kafka.clients.producer.ProducerRecord;
 import org.apache.kafka.common.TopicPartition;
-import org.apache.kafka.common.errors.RecordDeserializationException;
 import org.apache.kafka.common.errors.WakeupException;
 import reactor.core.publisher.Flux;
 import reactor.core.publisher.Mono;
 
 import java.time.*;
-import java.util.Collection;
+import java.util.HashMap;
 import java.util.List;
 import java.util.Map;
 import java.util.UUID;
 import java.util.stream.IntStream;
 
 
+@RequiredArgsConstructor
 @Slf4j
 public class ChatRoomChannel implements Runnable
 {
   private final String topic;
-  private final Consumer<Integer, ChatRoomTo> consumer;
-  private final Producer<Integer, ChatRoomTo> producer;
-  private final ShardingStrategy shardingStrategy;
-  private final ChatMessageChannel chatMessageChannel;
+  private final Consumer<String, AbstractTo> consumer;
+  private final Map<UUID, ChatRoomInfo> chatrooms = new HashMap<>();
 
   private boolean running;
 
 
-  public ChatRoomChannel(
-    String topic,
-    Consumer<Integer, ChatRoomTo> consumer,
-    Producer<Integer, ChatRoomTo> producer,
-    int numShards,
-    ChatMessageChannel chatMessageChannel)
-  {
-    log.debug(
-        "Creating ChatRoomChannel for topic {} with sharding for {} partitions",
-        topic,
-        numShards);
-    this.topic = topic;
-    this.consumer = consumer;
-    this.producer = producer;
-    this.shardingStrategy = new KafkaLikeShardingStrategy(numShards);
-    this.chatMessageChannel = chatMessageChannel;
-  }
-
-
   @Override
   public void run()
   {
@@ -65,54 +43,45 @@ public class ChatRoomChannel implements Runnable
     {
       try
       {
-        ConsumerRecords<String, MessageTo> records = consumer.poll(Duration.ofMinutes(5));
+        ConsumerRecords<String, AbstractTo> records = consumer.poll(Duration.ofMinutes(5));
         log.info("Fetched {} messages", records.count());
 
+        for (ConsumerRecord<String, AbstractTo> record : records)
+        {
+          switch (record.value().getType())
+          {
+            case CHATROOM_INFO:
+              createChatRoom((ChatRoomInfoTo) record.value());
+              break;
+
+            default:
+              log.debug(
+                  "Ignoring message for key {} with offset {}: {}",
+                  record.key(),
+                  record.offset(),
+                  record.value());
+          }
+        }
       }
       catch (WakeupException e)
       {
-      }
-      catch (RecordDeserializationException e)
-      {
+        log.info("Received WakeupException, exiting!");
+        running = false;
       }
     }
+
+    log.info("Exiting normally");
   }
 
 
-  Mono<ChatRoomInfo> sendCreateChatRoomRequest(
-      UUID chatRoomId,
-      String name)
+  void createChatRoom(ChatRoomInfoTo chatRoomInfoTo)
   {
-    int shard = this.shardingStrategy.selectShard(chatRoomId);
-    ChatRoomTo chatRoomTo = ChatRoomTo.of(chatRoomId, name, shard);
-    return Mono.create(sink ->
-    {
-      ProducerRecord<Integer, ChatRoomTo> record =
-          new ProducerRecord<>(
-              topic,
-              shard,
-              chatRoomTo);
+    ChatRoomInfo chatRoomInfo = chatRoomInfoTo.toChatRoomInfo();
+    chatrooms.put(chatRoomInfo.getId(), chatRoomInfo);
+  }
 
-      producer.send(record, ((metadata, exception) ->
-      {
-        if (metadata != null)
-        {
-          log.info("Successfully send chreate-request {}", chatRoomTo);
-          sink.success(chatRoomTo.toChatRoomInfo());
-        }
-        else
-        {
-          // On send-failure
-          log.error(
-              "Could not create-request for chat-room={}, key={}, timestamp={}, text={}: {}",
-              chatRoomId,
-              key,
-              timestamp,
-              text,
-              exception);
-          sink.error(exception);
-        }
-      }));
-    });
+  Flux<ChatRoomInfo> getChatRooms()
+  {
+    return Flux.fromIterable(chatrooms.values());
   }
 }