You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@rocketmq.apache.org by do...@apache.org on 2021/12/06 12:27:54 UTC

[rocketmq] 01/02: Add decode encode test for topic queue manager

This is an automated email from the ASF dual-hosted git repository.

dongeforever pushed a commit to branch 5.0.0-alpha-static-topic
in repository https://gitbox.apache.org/repos/asf/rocketmq.git

commit 9cae8c1bf02afa5788435ea3360aeb241443515c
Author: dongeforever <do...@apache.org>
AuthorDate: Mon Dec 6 19:50:28 2021 +0800

    Add decode encode test for topic queue manager
---
 .../broker/topic/TopicQueueMappingManager.java     |   3 +
 .../broker/topic/TopicQueueMappingManagerTest.java | 112 +++++++++++++++++++++
 2 files changed, 115 insertions(+)

diff --git a/broker/src/main/java/org/apache/rocketmq/broker/topic/TopicQueueMappingManager.java b/broker/src/main/java/org/apache/rocketmq/broker/topic/TopicQueueMappingManager.java
index 9be442e..1c11fde 100644
--- a/broker/src/main/java/org/apache/rocketmq/broker/topic/TopicQueueMappingManager.java
+++ b/broker/src/main/java/org/apache/rocketmq/broker/topic/TopicQueueMappingManager.java
@@ -77,6 +77,7 @@ public class TopicQueueMappingManager extends ConfigManager {
         boolean updated = false;
         TopicQueueMappingDetail oldDetail = null;
         try {
+
             if (lock.tryLock(LOCK_TIMEOUT_MILLIS, TimeUnit.MILLISECONDS)) {
                 locked = true;
             } else {
@@ -85,6 +86,8 @@ public class TopicQueueMappingManager extends ConfigManager {
             if (newDetail == null) {
                 return;
             }
+            assert newDetail.getBname().equals(this.brokerController.getBrokerConfig().getBrokerName());
+
             newDetail.getHostedQueues().forEach((queueId, items) -> {
                 TopicQueueMappingUtils.checkLogicQueueMappingItemOffset(items);
             });
diff --git a/broker/src/test/java/org/apache/rocketmq/broker/topic/TopicQueueMappingManagerTest.java b/broker/src/test/java/org/apache/rocketmq/broker/topic/TopicQueueMappingManagerTest.java
new file mode 100644
index 0000000..3c3f488
--- /dev/null
+++ b/broker/src/test/java/org/apache/rocketmq/broker/topic/TopicQueueMappingManagerTest.java
@@ -0,0 +1,112 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+package org.apache.rocketmq.broker.topic;
+
+import org.apache.rocketmq.broker.BrokerController;
+import org.apache.rocketmq.common.BrokerConfig;
+import org.apache.rocketmq.common.statictopic.TopicQueueMappingDetail;
+import org.apache.rocketmq.common.statictopic.TopicQueueMappingUtils;
+import org.apache.rocketmq.common.statictopic.TopicRemappingDetailWrapper;
+import org.apache.rocketmq.store.config.MessageStoreConfig;
+import org.junit.Assert;
+import org.junit.Before;
+import org.junit.Test;
+import org.junit.runner.RunWith;
+import org.mockito.Mock;
+import org.mockito.junit.MockitoJUnitRunner;
+
+import java.nio.file.Files;
+import java.nio.file.Paths;
+import java.util.HashMap;
+import java.util.HashSet;
+import java.util.Map;
+import java.util.Set;
+import java.util.UUID;
+
+import static org.mockito.Mockito.when;
+
+@RunWith(MockitoJUnitRunner.class)
+public class TopicQueueMappingManagerTest {
+    @Mock
+    private BrokerController brokerController;
+    private static final String broker1Name = "broker1";
+
+    @Before
+    public void before() {
+        BrokerConfig brokerConfig = new BrokerConfig();
+        brokerConfig.setBrokerName(broker1Name);
+        when(brokerController.getBrokerConfig()).thenReturn(brokerConfig);
+
+        MessageStoreConfig messageStoreConfig = new MessageStoreConfig();
+        messageStoreConfig.setStorePathRootDir(System.getProperty("java.io.tmpdir"));
+        messageStoreConfig.setDeleteWhen("01;02;03;04;05;06;07;08;09;10;11;12;13;14;15;16;17;18;19;20;21;22;23;00");
+        when(brokerController.getMessageStoreConfig()).thenReturn(messageStoreConfig);
+    }
+
+
+    private void delete(TopicQueueMappingManager topicQueueMappingManager) throws Exception {
+        if (topicQueueMappingManager == null) {
+            return;
+        }
+        Files.deleteIfExists(Paths.get(topicQueueMappingManager.configFilePath()));
+        Files.deleteIfExists(Paths.get(topicQueueMappingManager.configFilePath() + ".bak"));
+
+
+    }
+
+    @Test
+    public void testEncodeDecode() throws Exception {
+        Map<String, TopicQueueMappingDetail> mappingDetailMap = new HashMap<>();
+        TopicQueueMappingManager topicQueueMappingManager = null;
+        Set<String> brokers = new HashSet<String>();
+        brokers.add(broker1Name);
+        {
+            for (int i = 0; i < 10; i++) {
+                String topic = UUID.randomUUID().toString();
+                int queueNum = 10;
+                TopicRemappingDetailWrapper topicRemappingDetailWrapper  = TopicQueueMappingUtils.createTopicConfigMapping(topic, queueNum, brokers, new HashMap<>());
+                Assert.assertEquals(1, topicRemappingDetailWrapper.getBrokerConfigMap().size());
+                TopicQueueMappingDetail topicQueueMappingDetail  = topicRemappingDetailWrapper.getBrokerConfigMap().values().iterator().next().getMappingDetail();
+                Assert.assertEquals(queueNum, topicQueueMappingDetail.getHostedQueues().size());
+                mappingDetailMap.put(topic, topicQueueMappingDetail);
+            }
+        }
+
+        {
+            topicQueueMappingManager = new TopicQueueMappingManager(brokerController);
+            Assert.assertTrue(topicQueueMappingManager.load());
+            Assert.assertEquals(0, topicQueueMappingManager.getTopicQueueMappingTable().size());
+            for (TopicQueueMappingDetail mappingDetail : mappingDetailMap.values()) {
+                for (int i = 0; i < 10; i++) {
+                    topicQueueMappingManager.updateTopicQueueMapping(mappingDetail, false);
+                }
+            }
+            topicQueueMappingManager.persist();
+        }
+
+        {
+            topicQueueMappingManager = new TopicQueueMappingManager(brokerController);
+            Assert.assertTrue(topicQueueMappingManager.load());
+            Assert.assertEquals(mappingDetailMap.size(), topicQueueMappingManager.getTopicQueueMappingTable().size());
+            for (TopicQueueMappingDetail topicQueueMappingDetail: topicQueueMappingManager.getTopicQueueMappingTable().values()) {
+                Assert.assertEquals(topicQueueMappingDetail, mappingDetailMap.get(topicQueueMappingDetail.getTopic()));
+            }
+        }
+        delete(topicQueueMappingManager);
+    }
+}
\ No newline at end of file