You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@activemq.apache.org by ja...@apache.org on 2011/10/05 19:15:19 UTC

svn commit: r1179328 - in /activemq/trunk: activemq-camel/src/test/java/org/apache/activemq/camel/component/JmsSimpleRequestReplyTest.java activemq-core/src/main/java/org/apache/activemq/ActiveMQConnection.java

Author: janstey
Date: Wed Oct  5 17:15:19 2011
New Revision: 1179328

URL: http://svn.apache.org/viewvc?rev=1179328&view=rev
Log:
AMQ-3457 - check the connection id to make sure we don't delete someone else's temp dest

Reviewed by gtully


Added:
    activemq/trunk/activemq-camel/src/test/java/org/apache/activemq/camel/component/JmsSimpleRequestReplyTest.java
Modified:
    activemq/trunk/activemq-core/src/main/java/org/apache/activemq/ActiveMQConnection.java

Added: activemq/trunk/activemq-camel/src/test/java/org/apache/activemq/camel/component/JmsSimpleRequestReplyTest.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-camel/src/test/java/org/apache/activemq/camel/component/JmsSimpleRequestReplyTest.java?rev=1179328&view=auto
==============================================================================
--- activemq/trunk/activemq-camel/src/test/java/org/apache/activemq/camel/component/JmsSimpleRequestReplyTest.java (added)
+++ activemq/trunk/activemq-camel/src/test/java/org/apache/activemq/camel/component/JmsSimpleRequestReplyTest.java Wed Oct  5 17:15:19 2011
@@ -0,0 +1,83 @@
+/**
+ * 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.camel.component;
+
+import javax.jms.ConnectionFactory;
+
+import org.apache.activemq.ActiveMQConnectionFactory;
+import org.apache.activemq.pool.PooledConnectionFactory;
+import org.apache.camel.CamelContext;
+import org.apache.camel.Exchange;
+import org.apache.camel.ExchangePattern;
+import org.apache.camel.Processor;
+import org.apache.camel.builder.RouteBuilder;
+import org.apache.camel.component.mock.MockEndpoint;
+import org.apache.camel.test.junit4.CamelTestSupport;
+import org.junit.Test;
+import static org.apache.camel.component.jms.JmsComponent.jmsComponentAutoAcknowledge;
+
+/**
+ * A simple request / reply test
+ */
+public class JmsSimpleRequestReplyTest extends CamelTestSupport {
+
+    protected String componentName = "activemq";
+
+    @Test
+    public void testRequestReply2Messages() throws Exception {
+        MockEndpoint result = getMockEndpoint("mock:result");
+        result.expectedMessageCount(1);
+
+        template.requestBody("activemq:queue:hello", "Hello World");
+        
+        result.assertIsSatisfied();
+    }
+
+    protected CamelContext createCamelContext() throws Exception {
+        CamelContext camelContext = super.createCamelContext();
+
+        ConnectionFactory connectionFactory = createConnectionFactory(null);
+        camelContext.addComponent("activemq", jmsComponentAutoAcknowledge(connectionFactory));
+
+        return camelContext;
+    }
+
+    public static ConnectionFactory createConnectionFactory(String options) {
+        String url = "vm://test-broker?broker.persistent=false&broker.useJmx=false";
+        if (options != null) {
+            url = url + "&" + options;
+        }
+        ActiveMQConnectionFactory connectionFactory = new ActiveMQConnectionFactory(url);
+        // use a pooled connection factory
+        PooledConnectionFactory pooled = new PooledConnectionFactory(connectionFactory);
+        pooled.setMaxConnections(8);
+        return pooled;
+    }
+    
+    protected RouteBuilder createRouteBuilder() throws Exception {
+        return new RouteBuilder() {
+            public void configure() throws Exception {
+                from("activemq:queue:hello").process(new Processor() {
+                    public void process(Exchange exchange) throws Exception {
+                        exchange.getIn().setBody("Bye World");
+                        assertNotNull(exchange.getIn().getHeader("JMSReplyTo"));
+                    }
+                }).to("mock:result");
+            }
+        };
+    }
+}
\ No newline at end of file

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/ActiveMQConnection.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/ActiveMQConnection.java?rev=1179328&r1=1179327&r2=1179328&view=diff
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/ActiveMQConnection.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/ActiveMQConnection.java Wed Oct  5 17:15:19 2011
@@ -2425,7 +2425,13 @@ public class ActiveMQConnection implemen
         while(entries.hasNext()) {
             ConcurrentHashMap.Entry<ActiveMQTempDestination, ActiveMQTempDestination> entry = entries.next();
             try {
-                this.deleteTempDestination(entry.getValue());
+                // Only delete this temp destination if it was created from this connection. The connection used
+                // for the advisory consumer may also have a reference to this temp destination. 
+                ActiveMQTempDestination dest = entry.getValue();                             
+                String thisConnectionId = (info.getConnectionId() == null) ? "" : info.getConnectionId().toString();
+                if (dest.getConnectionId() != null && dest.getConnectionId().equals(thisConnectionId)) {
+                    this.deleteTempDestination(entry.getValue());
+                }
             } catch (Exception ex) {
                 // the temp dest is in use so it can not be deleted.
                 // it is ok to leave it to connection tear down phase