You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@activemq.apache.org by de...@apache.org on 2010/06/09 12:31:50 UTC

svn commit: r952946 - in /activemq/trunk/activemq-core/src: main/java/org/apache/activemq/broker/region/ main/java/org/apache/activemq/broker/region/cursors/ test/java/org/apache/activemq/usecases/

Author: dejanb
Date: Wed Jun  9 10:31:49 2010
New Revision: 952946

URL: http://svn.apache.org/viewvc?rev=952946&view=rev
Log:
https://issues.apache.org/activemq/browse/AMQ-2663 - keepDurableSubsActive=false reactivation

Added:
    activemq/trunk/activemq-core/src/test/java/org/apache/activemq/usecases/DurableSubscriptionReactivationTest.java
Modified:
    activemq/trunk/activemq-core/src/main/java/org/apache/activemq/broker/region/DurableTopicSubscription.java
    activemq/trunk/activemq-core/src/main/java/org/apache/activemq/broker/region/cursors/TopicStorePrefetch.java

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/broker/region/DurableTopicSubscription.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/broker/region/DurableTopicSubscription.java?rev=952946&r1=952945&r2=952946&view=diff
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/broker/region/DurableTopicSubscription.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/broker/region/DurableTopicSubscription.java Wed Jun  9 10:31:49 2010
@@ -111,6 +111,7 @@ public class DurableTopicSubscription ex
                 for (Iterator<Destination> iter = destinations.values()
                         .iterator(); iter.hasNext();) {
                     Topic topic = (Topic) iter.next();
+                    add(context, topic);
                     topic.activate(context, this);
                 }
             }

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/broker/region/cursors/TopicStorePrefetch.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/broker/region/cursors/TopicStorePrefetch.java?rev=952946&r1=952945&r2=952946&view=diff
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/broker/region/cursors/TopicStorePrefetch.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/broker/region/cursors/TopicStorePrefetch.java Wed Jun  9 10:31:49 2010
@@ -28,7 +28,7 @@ import org.apache.commons.logging.Log;
 import org.apache.commons.logging.LogFactory;
 
 /**
- * perist pendingCount messages pendingCount message (messages awaiting disptach
+ * persist pendingCount messages pendingCount message (messages awaiting disptach
  * to a consumer) cursor
  * 
  * @version $Revision$

Added: activemq/trunk/activemq-core/src/test/java/org/apache/activemq/usecases/DurableSubscriptionReactivationTest.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/usecases/DurableSubscriptionReactivationTest.java?rev=952946&view=auto
==============================================================================
--- activemq/trunk/activemq-core/src/test/java/org/apache/activemq/usecases/DurableSubscriptionReactivationTest.java (added)
+++ activemq/trunk/activemq-core/src/test/java/org/apache/activemq/usecases/DurableSubscriptionReactivationTest.java Wed Jun  9 10:31:49 2010
@@ -0,0 +1,88 @@
+/**
+ * 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.usecases;
+
+import javax.jms.Connection;
+import javax.jms.Message;
+import javax.jms.MessageProducer;
+import javax.jms.Session;
+import javax.jms.Topic;
+import javax.jms.TopicSubscriber;
+
+import junit.framework.Test;
+
+import org.apache.activemq.EmbeddedBrokerTestSupport;
+import org.apache.activemq.broker.BrokerService;
+
+public class DurableSubscriptionReactivationTest extends EmbeddedBrokerTestSupport {
+
+    public boolean keepDurableSubsActive;
+    
+    public void initCombosForTestReactivateKeepaliveSubscription() {
+        addCombinationValues("keepDurableSubsActive", new Object[] { new Boolean(true), new Boolean(false) });
+    }
+    
+    public void testReactivateKeepaliveSubscription() throws Exception {
+
+        Connection connection = createConnection();
+        connection.setClientID("cliID");
+        connection.start();
+        Session session = connection.createSession(false, Session.AUTO_ACKNOWLEDGE);
+        TopicSubscriber subscriber = session.createDurableSubscriber((Topic) createDestination(), "subName");
+        subscriber.close();
+        connection.close();
+
+        connection = createConnection();
+        connection.start();
+        session = connection.createSession(false, Session.AUTO_ACKNOWLEDGE);
+        MessageProducer producer = session.createProducer(createDestination());
+        producer.send(session.createMessage());
+        connection.close();
+
+        connection = createConnection();
+        connection.setClientID("cliID");
+        connection.start();
+        session = connection.createSession(false, Session.AUTO_ACKNOWLEDGE);
+        subscriber = session.createDurableSubscriber((Topic) createDestination(), "subName");
+        Message message = subscriber.receive(1 * 1000);
+        subscriber.close();
+        connection.close();
+
+        assertNotNull("Message not received.", message);
+    }
+
+    protected void setUp() throws Exception {
+        useTopic = true;
+        super.setUp();
+    }
+
+    protected void tearDown() throws Exception {
+        super.tearDown();
+    }
+
+    @Override
+    protected BrokerService createBroker() throws Exception {
+        BrokerService answer = super.createBroker();
+        answer.setKeepDurableSubsActive(keepDurableSubsActive);
+        return answer;
+    }
+    
+    public static Test suite() {
+        return suite(DurableSubscriptionReactivationTest.class);
+      }
+}