You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@activemq.apache.org by cs...@apache.org on 2016/06/06 13:17:55 UTC

activemq git commit: A fix for AMQ-6310

Repository: activemq
Updated Branches:
  refs/heads/activemq-5.13.x ceeb1f68a -> 539d6b747


A fix for AMQ-6310

Checking for leading wildcard in the prefix for a virtualtopic,
modifying the behavior of shouldDispatch in the VirtualTopicInterceptor.

(cherry picked from commit 6bf5987921f6fdb6844652bb77e2fc14b002ccf2)


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

Branch: refs/heads/activemq-5.13.x
Commit: 539d6b747a96e2fb848a7a9d3d5329893fe5d360
Parents: ceeb1f6
Author: Jonathan Malek <jo...@jonathanmalek.me>
Authored: Sat Jun 4 16:51:27 2016 -0700
Committer: Christopher L. Shannon (cshannon) <ch...@gmail.com>
Committed: Mon Jun 6 13:17:25 2016 +0000

----------------------------------------------------------------------
 .../region/virtual/VirtualTopicInterceptor.java |   2 +-
 ...TopicInterceptorWithLeadingWildcardTest.java | 114 +++++++++++++++++++
 2 files changed, 115 insertions(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/activemq/blob/539d6b74/activemq-broker/src/main/java/org/apache/activemq/broker/region/virtual/VirtualTopicInterceptor.java
----------------------------------------------------------------------
diff --git a/activemq-broker/src/main/java/org/apache/activemq/broker/region/virtual/VirtualTopicInterceptor.java b/activemq-broker/src/main/java/org/apache/activemq/broker/region/virtual/VirtualTopicInterceptor.java
index 65d3efc..c0f5f5d 100644
--- a/activemq-broker/src/main/java/org/apache/activemq/broker/region/virtual/VirtualTopicInterceptor.java
+++ b/activemq-broker/src/main/java/org/apache/activemq/broker/region/virtual/VirtualTopicInterceptor.java
@@ -150,7 +150,7 @@ public class VirtualTopicInterceptor extends DestinationFilter {
 
     protected boolean shouldDispatch(Broker broker, Message message, Destination dest) throws IOException {
     	//if can't find .* in the prefix, default back to old logic and return true
-    	return prefix.contains(".*") ? dest.getName().startsWith(prefix.substring(0, prefix.indexOf(".*"))) : true;
+    	return prefix.contains(".*") && !prefix.startsWith("*") ? dest.getName().startsWith(prefix.substring(0, prefix.indexOf(".*"))) : true;
     }
 
     protected ActiveMQDestination getQueueConsumersWildcard(ActiveMQDestination original) {

http://git-wip-us.apache.org/repos/asf/activemq/blob/539d6b74/activemq-unit-tests/src/test/java/org/apache/activemq/broker/virtual/CustomVirtualTopicInterceptorWithLeadingWildcardTest.java
----------------------------------------------------------------------
diff --git a/activemq-unit-tests/src/test/java/org/apache/activemq/broker/virtual/CustomVirtualTopicInterceptorWithLeadingWildcardTest.java b/activemq-unit-tests/src/test/java/org/apache/activemq/broker/virtual/CustomVirtualTopicInterceptorWithLeadingWildcardTest.java
new file mode 100644
index 0000000..53cd443
--- /dev/null
+++ b/activemq-unit-tests/src/test/java/org/apache/activemq/broker/virtual/CustomVirtualTopicInterceptorWithLeadingWildcardTest.java
@@ -0,0 +1,114 @@
+/**
+ * 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.broker.virtual;
+
+import javax.jms.Connection;
+import javax.jms.JMSException;
+import javax.jms.MessageConsumer;
+import javax.jms.MessageProducer;
+import javax.jms.Session;
+
+import org.apache.activemq.EmbeddedBrokerTestSupport;
+import org.apache.activemq.broker.BrokerService;
+import org.apache.activemq.broker.region.DestinationInterceptor;
+import org.apache.activemq.broker.region.virtual.VirtualDestination;
+import org.apache.activemq.broker.region.virtual.VirtualDestinationInterceptor;
+import org.apache.activemq.broker.region.virtual.VirtualTopic;
+import org.apache.activemq.command.ActiveMQDestination;
+import org.apache.activemq.command.ActiveMQQueue;
+import org.apache.activemq.command.ActiveMQTopic;
+import org.slf4j.Logger;
+import org.slf4j.LoggerFactory;
+/**
+ * Test for ticket AMQ-6310, leading wildcards no longer match after AMQ-6058
+ */
+public class CustomVirtualTopicInterceptorWithLeadingWildcardTest extends EmbeddedBrokerTestSupport{
+
+	private static final Logger LOG = LoggerFactory.getLogger(CustomVirtualTopicInterceptorWithLeadingWildcardTest.class);
+	protected int total = 10;
+	protected Connection connection;	
+	
+    protected ActiveMQDestination getConsumer1Destination() {
+        return new ActiveMQQueue("q1.a.virtualtopic.topic");
+    }
+
+    protected ActiveMQDestination getConsumer2Destination() {
+        return new ActiveMQQueue("q2.a.virtualtopic.topic");
+    }     
+    
+    protected ActiveMQDestination getProducerDestination() {
+        return new ActiveMQTopic("virtualtopic.topic");
+    }    
+    
+    public void testVirtualTopicRouting() throws Exception {
+    	if (connection == null) {
+            connection = createConnection();
+        }
+        connection.start();
+        
+        LOG.info("validate no other messages on queues");        
+        try {
+            Session session = connection.createSession(false, Session.AUTO_ACKNOWLEDGE);
+
+            ActiveMQDestination destination1 = getConsumer1Destination();
+            ActiveMQDestination destination2 = getConsumer2Destination();
+
+            MessageConsumer c1 = session.createConsumer(destination1, null);
+            MessageConsumer c2 = session.createConsumer(destination2, null);
+
+            LOG.info("send one simple message that should go to both consumers");
+            MessageProducer producer = session.createProducer(getProducerDestination());
+            assertNotNull(producer);
+
+            producer.send(session.createTextMessage("Last Message"));
+            //check that c1 received the message as it should
+            assertNotNull(c1.receive(3000));
+            //check that c2 received the message as well - this breaks pre-patch,
+            //when VirtualTopicInterceptor.shouldDispatch only returned true if the prefix
+            //did not have ".*", or the destination name started with the first part of the
+            //prefix (i.e. in the case of "*.*.", the destination name would have had
+            //to be "*").
+            assertNotNull(c2.receive(3000));
+            
+        } catch (JMSException e) {
+            e.printStackTrace();
+            fail("unexpected ex while waiting for last messages: " + e);
+        }
+    }
+    
+    protected void tearDown() throws Exception {
+        if (connection != null) {
+            connection.close();
+        }
+        super.tearDown();
+    }
+    
+    //setup the broker and virtual topic to test custom Virtual topic name 
+    //and a multilevel prefix
+    protected BrokerService createBroker() throws Exception {
+        BrokerService broker = new BrokerService();
+        broker.setPersistent(false);
+
+        VirtualTopic virtualTopic = new VirtualTopic();
+        virtualTopic.setName("virtualtopic.>");
+        virtualTopic.setPrefix("*.*.");
+        VirtualDestinationInterceptor interceptor = new VirtualDestinationInterceptor();
+        interceptor.setVirtualDestinations(new VirtualDestination[]{virtualTopic});        
+        broker.setDestinationInterceptors(new DestinationInterceptor[]{interceptor});
+        return broker;
+    }
+}