You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@activemq.apache.org by cl...@apache.org on 2018/08/09 23:39:01 UTC

activemq-artemis git commit: ARTEMIS-2013 Can't create durable subscriber to a composite topic

Repository: activemq-artemis
Updated Branches:
  refs/heads/2.6.x b9a85bdaa -> 3f3e0e692


ARTEMIS-2013 Can't create durable subscriber to a composite topic

An OpenWire client can use a compound destination name of the form
"a,b,c..." and consume from, or subscribe to, multiple destinations.
Such a compound destination only works for topics when the subscriber
is non-durable. Attempting to create a durable subscription on a
compound address will end up with an error.

The cause is when creating durable subs to multiple topics/addresses
the broker uses the same name to create internal queues, which
causes duplicate name conflict.

(cherry picked from commit e15f3901e4e449ff347ac004ac3c6034ca0e7a0b)


Project: http://git-wip-us.apache.org/repos/asf/activemq-artemis/repo
Commit: http://git-wip-us.apache.org/repos/asf/activemq-artemis/commit/3f3e0e69
Tree: http://git-wip-us.apache.org/repos/asf/activemq-artemis/tree/3f3e0e69
Diff: http://git-wip-us.apache.org/repos/asf/activemq-artemis/diff/3f3e0e69

Branch: refs/heads/2.6.x
Commit: 3f3e0e6929edb8a2200c5c8b9fbfd1b67d713fd2
Parents: b9a85bd
Author: Howard Gao <ho...@gmail.com>
Authored: Tue Aug 7 16:56:43 2018 +0800
Committer: Clebert Suconic <cl...@apache.org>
Committed: Thu Aug 9 19:38:56 2018 -0400

----------------------------------------------------------------------
 .../core/protocol/openwire/amq/AMQConsumer.java |  3 +
 .../openwire/CompositeDestinationTest.java      | 75 ++++++++++++++++++++
 2 files changed, 78 insertions(+)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/3f3e0e69/artemis-protocols/artemis-openwire-protocol/src/main/java/org/apache/activemq/artemis/core/protocol/openwire/amq/AMQConsumer.java
----------------------------------------------------------------------
diff --git a/artemis-protocols/artemis-openwire-protocol/src/main/java/org/apache/activemq/artemis/core/protocol/openwire/amq/AMQConsumer.java b/artemis-protocols/artemis-openwire-protocol/src/main/java/org/apache/activemq/artemis/core/protocol/openwire/amq/AMQConsumer.java
index 7e9881b..fae6ef7 100644
--- a/artemis-protocols/artemis-openwire-protocol/src/main/java/org/apache/activemq/artemis/core/protocol/openwire/amq/AMQConsumer.java
+++ b/artemis-protocols/artemis-openwire-protocol/src/main/java/org/apache/activemq/artemis/core/protocol/openwire/amq/AMQConsumer.java
@@ -186,6 +186,9 @@ public class AMQConsumer {
       addressInfo.setInternal(internalAddress);
       if (isDurable) {
          queueName = org.apache.activemq.artemis.jms.client.ActiveMQDestination.createQueueNameForSubscription(true, clientID, subscriptionName);
+         if (info.getDestination().isComposite()) {
+            queueName =  queueName.concat(physicalName);
+         }
          QueueQueryResult result = session.getCoreSession().executeQueueQuery(queueName);
          if (result.isExists()) {
             // Already exists

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/3f3e0e69/tests/integration-tests/src/test/java/org/apache/activemq/artemis/tests/integration/openwire/CompositeDestinationTest.java
----------------------------------------------------------------------
diff --git a/tests/integration-tests/src/test/java/org/apache/activemq/artemis/tests/integration/openwire/CompositeDestinationTest.java b/tests/integration-tests/src/test/java/org/apache/activemq/artemis/tests/integration/openwire/CompositeDestinationTest.java
new file mode 100644
index 0000000..dd26068
--- /dev/null
+++ b/tests/integration-tests/src/test/java/org/apache/activemq/artemis/tests/integration/openwire/CompositeDestinationTest.java
@@ -0,0 +1,75 @@
+/*
+ * 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.activemq.artemis.tests.integration.openwire;
+
+import org.apache.activemq.artemis.api.core.RoutingType;
+import org.apache.activemq.artemis.api.core.SimpleString;
+import org.apache.activemq.artemis.core.server.impl.AddressInfo;
+import org.junit.Before;
+import org.junit.Test;
+
+import javax.jms.Connection;
+import javax.jms.MessageProducer;
+import javax.jms.Session;
+import javax.jms.TextMessage;
+import javax.jms.Topic;
+import javax.jms.TopicSubscriber;
+
+public class CompositeDestinationTest extends BasicOpenWireTest {
+
+   @Override
+   @Before
+   public void setUp() throws Exception {
+      super.setUp();
+      AddressInfo addressInfo = new AddressInfo(new SimpleString("p.IN"), RoutingType.MULTICAST);
+      this.server.addAddressInfo(addressInfo);
+      addressInfo = new AddressInfo(new SimpleString("q.IN"), RoutingType.MULTICAST);
+      this.server.addAddressInfo(addressInfo);
+   }
+
+   @Test
+   public void testDurableSub() throws Exception {
+      Connection conn = factory.createConnection();
+      try {
+         conn.setClientID("my-client");
+         conn.start();
+
+         Session session = conn.createSession(false, Session.AUTO_ACKNOWLEDGE);
+         Topic topic = session.createTopic("p.IN,q.IN");
+
+         TopicSubscriber sub1 = session.createDurableSubscriber(topic, "durable1", null, false);
+
+         MessageProducer producer = session.createProducer(topic);
+
+         final int num = 10;
+
+         for (int i = 0; i < num; i++) {
+            producer.send(session.createTextMessage("msg" + i));
+         }
+
+         int count = 0;
+         TextMessage msg = (TextMessage) sub1.receive(2000);
+         while (msg != null) {
+            count++;
+            msg = (TextMessage) sub1.receive(2000);
+         }
+         assertEquals("Consumer should receive all messages from every topic", 2 * num, count);
+      } finally {
+         conn.close();
+      }
+   }
+}