You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@activemq.apache.org by ra...@apache.org on 2008/09/22 20:15:35 UTC

svn commit: r697921 - in /activemq/trunk/activemq-core/src: main/java/org/apache/activemq/broker/region/Queue.java main/java/org/apache/activemq/broker/region/cursors/AbstractStoreCursor.java test/java/org/apache/activemq/broker/region/QueuePurgeTest.java

Author: rajdavies
Date: Mon Sep 22 11:15:34 2008
New Revision: 697921

URL: http://svn.apache.org/viewvc?rev=697921&view=rev
Log:
Fix for https://issues.apache.org/activemq/browse/AMQ-1940

Added:
    activemq/trunk/activemq-core/src/test/java/org/apache/activemq/broker/region/QueuePurgeTest.java   (with props)
Modified:
    activemq/trunk/activemq-core/src/main/java/org/apache/activemq/broker/region/Queue.java
    activemq/trunk/activemq-core/src/main/java/org/apache/activemq/broker/region/cursors/AbstractStoreCursor.java

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/broker/region/Queue.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/broker/region/Queue.java?rev=697921&r1=697920&r2=697921&view=diff
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/broker/region/Queue.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/broker/region/Queue.java Mon Sep 22 11:15:34 2008
@@ -724,6 +724,8 @@
             }
         } while (!pagedInMessages.isEmpty() || this.destinationStatistics.getMessages().getCount() > 0);
         gc();
+        this.destinationStatistics.getMessages().setCount(0);
+        getMessages().clear();
     }
 
     /**
@@ -1205,18 +1207,24 @@
     private void doDispatch(List<QueueMessageReference> list) throws Exception {
         dispatchLock.lock();
         try {
-            synchronized(pagedInPendingDispatch) {
-                if(!pagedInPendingDispatch.isEmpty()) {
-                    // Try to first dispatch anything that had not been dispatched before.
+            synchronized (pagedInPendingDispatch) {
+                if (!pagedInPendingDispatch.isEmpty()) {
+                    // Try to first dispatch anything that had not been
+                    // dispatched before.
                     pagedInPendingDispatch = doActualDispatch(pagedInPendingDispatch);
                 }
-                // and now see if we can dispatch the new stuff.. and append to the pending 
+                // and now see if we can dispatch the new stuff.. and append to
+                // the pending
                 // list anything that does not actually get dispatched.
                 if (list != null && !list.isEmpty()) {
                     if (pagedInPendingDispatch.isEmpty()) {
                         pagedInPendingDispatch.addAll(doActualDispatch(list));
                     } else {
-                        pagedInPendingDispatch.addAll(list);
+                        for (QueueMessageReference qmr : list) {
+                            if (!pagedInPendingDispatch.contains(qmr)) {
+                                pagedInPendingDispatch.add(qmr);
+                            }
+                        }
                     }
                 }
             }
@@ -1226,7 +1234,8 @@
     }
     
     /**
-     * @return list of messages that could get dispatched to consumers if they were not full.
+     * @return list of messages that could get dispatched to consumers if they
+     *         were not full.
      */
     private List<QueueMessageReference> doActualDispatch(List<QueueMessageReference> list) throws Exception {
         List<QueueMessageReference> rc = new ArrayList<QueueMessageReference>(list.size());

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/broker/region/cursors/AbstractStoreCursor.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/broker/region/cursors/AbstractStoreCursor.java?rev=697921&r1=697920&r2=697921&view=diff
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/broker/region/cursors/AbstractStoreCursor.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/broker/region/cursors/AbstractStoreCursor.java Mon Sep 22 11:15:34 2008
@@ -194,6 +194,7 @@
         batchList.clear();
         batchResetNeeded = true;
         this.cacheEnabled=false;
+        size=0;
     }
     
     protected final synchronized void fillBatch() {

Added: activemq/trunk/activemq-core/src/test/java/org/apache/activemq/broker/region/QueuePurgeTest.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/broker/region/QueuePurgeTest.java?rev=697921&view=auto
==============================================================================
--- activemq/trunk/activemq-core/src/test/java/org/apache/activemq/broker/region/QueuePurgeTest.java (added)
+++ activemq/trunk/activemq-core/src/test/java/org/apache/activemq/broker/region/QueuePurgeTest.java Mon Sep 22 11:15:34 2008
@@ -0,0 +1,104 @@
+/**
+ * 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.region;
+
+import javax.jms.Connection;
+import javax.jms.ConnectionFactory;
+import javax.jms.JMSException;
+import javax.jms.Message;
+import javax.jms.MessageConsumer;
+import javax.jms.MessageProducer;
+import javax.jms.Queue;
+import javax.jms.Session;
+import javax.jms.TextMessage;
+import javax.management.MBeanServerInvocationHandler;
+import javax.management.MalformedObjectNameException;
+import javax.management.ObjectName;
+import junit.framework.TestCase;
+import org.apache.activemq.ActiveMQConnectionFactory;
+import org.apache.activemq.broker.BrokerService;
+import org.apache.activemq.broker.jmx.QueueViewMBean;
+
+public class QueuePurgeTest extends TestCase {
+    BrokerService broker;
+    ConnectionFactory factory;
+    Connection connection;
+    Session session;
+    Queue queue;
+    MessageConsumer consumer;
+
+    protected void setUp() throws Exception {
+        broker = new BrokerService();
+        broker.setUseJmx(true);
+        broker.setPersistent(false);
+        broker.addConnector("tcp://localhost:0");
+        broker.start();
+        factory = new ActiveMQConnectionFactory("vm://localhost");
+        connection = factory.createConnection();
+        connection.start();
+    }
+
+    protected void tearDown() throws Exception {
+        consumer.close();
+        session.close();
+        connection.stop();
+        connection.close();
+        broker.stop();
+    }
+
+    public void testPurgeQueueWithActiveConsumer() throws Exception {
+        createProducerAndSendMessages();
+        QueueViewMBean proxy = getProxyToQueueViewMBean();
+        createConsumer();
+        proxy.purge();
+        assertEquals("Queue size is not zero, it's " + proxy.getQueueSize(), 0,
+                proxy.getQueueSize());
+    }
+
+    private QueueViewMBean getProxyToQueueViewMBean()
+            throws MalformedObjectNameException, JMSException {
+        ObjectName queueViewMBeanName = new ObjectName("org.apache.activemq"
+                + ":Type=Queue,Destination=" + queue.getQueueName()
+                + ",BrokerName=localhost");
+        QueueViewMBean proxy = (QueueViewMBean) MBeanServerInvocationHandler
+                .newProxyInstance(broker.getManagementContext()
+                        .getMBeanServer(), queueViewMBeanName,
+                        QueueViewMBean.class, true);
+        return proxy;
+    }
+
+    private void createProducerAndSendMessages() throws Exception {
+        session = connection.createSession(false, Session.CLIENT_ACKNOWLEDGE);
+        queue = session.createQueue("test1");
+        MessageProducer producer = session.createProducer(queue);
+        for (int i = 0; i < 10000; i++) {
+            TextMessage message = session.createTextMessage("message " + i);
+            producer.send(message);
+        }
+        producer.close();
+    }
+
+    private void createConsumer() throws Exception {
+        consumer = session.createConsumer(queue);
+        // wait for buffer fill out
+        Thread.sleep(5 * 1000);
+        for (int i = 0; i < 100; ++i) {
+            Message message = consumer.receive();
+            message.acknowledge();
+        }
+    }
+}

Propchange: activemq/trunk/activemq-core/src/test/java/org/apache/activemq/broker/region/QueuePurgeTest.java
------------------------------------------------------------------------------
    svn:eol-style = native