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 2019/07/31 18:09:49 UTC

[activemq] 01/04: AMQ-3405 - rework fix to use original destination strategy which may be different from the default shared strategy. new test

This is an automated email from the ASF dual-hosted git repository.

cshannon pushed a commit to branch activemq-5.15.x
in repository https://gitbox.apache.org/repos/asf/activemq.git

commit 509c781669fa681eded9d11681e1cb92e5f5d553
Author: gtully <ga...@gmail.com>
AuthorDate: Thu Jun 7 11:38:42 2018 +0100

    AMQ-3405 - rework fix to use original destination strategy which may be different from the default shared strategy. new test
    
    (cherry picked from commit 1ebf1862795286505dc2ce2d36e91008029061a3)
---
 .../org/apache/activemq/broker/region/Queue.java   |   9 +-
 .../java/org/apache/activemq/jmx/DLQRetryTest.java | 202 +++++++++++++++++++++
 2 files changed, 209 insertions(+), 2 deletions(-)

diff --git a/activemq-broker/src/main/java/org/apache/activemq/broker/region/Queue.java b/activemq-broker/src/main/java/org/apache/activemq/broker/region/Queue.java
index 71bf5bb..d668c14 100644
--- a/activemq-broker/src/main/java/org/apache/activemq/broker/region/Queue.java
+++ b/activemq-broker/src/main/java/org/apache/activemq/broker/region/Queue.java
@@ -1478,8 +1478,13 @@ public class Queue extends BaseDestination implements Task, UsageListener, Index
             try {
                 messages.rollback(m.getMessageId());
                 if (isDLQ()) {
-                    DeadLetterStrategy strategy = getDeadLetterStrategy();
-                    strategy.rollback(m.getMessage());
+                    ActiveMQDestination originalDestination = m.getMessage().getOriginalDestination();
+                    if (originalDestination != null) {
+                        for (Destination destination : regionBroker.getDestinations(originalDestination)) {
+                            DeadLetterStrategy strategy = destination.getDeadLetterStrategy();
+                            strategy.rollback(m.getMessage());
+                        }
+                    }
                 }
             } finally {
                 messagesLock.writeLock().unlock();
diff --git a/activemq-unit-tests/src/test/java/org/apache/activemq/jmx/DLQRetryTest.java b/activemq-unit-tests/src/test/java/org/apache/activemq/jmx/DLQRetryTest.java
new file mode 100644
index 0000000..e2875fb
--- /dev/null
+++ b/activemq-unit-tests/src/test/java/org/apache/activemq/jmx/DLQRetryTest.java
@@ -0,0 +1,202 @@
+/**
+ * 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
+ * <p>
+ * http://www.apache.org/licenses/LICENSE-2.0
+ * <p>
+ * 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.jmx;
+
+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.Session;
+import javax.management.MBeanServer;
+import javax.management.MBeanServerInvocationHandler;
+import javax.management.MalformedObjectNameException;
+import javax.management.ObjectName;
+import java.util.ArrayList;
+import java.util.List;
+
+import org.apache.activemq.ActiveMQConnectionFactory;
+import org.apache.activemq.EmbeddedBrokerTestSupport;
+import org.apache.activemq.RedeliveryPolicy;
+import org.apache.activemq.broker.BrokerService;
+import org.apache.activemq.broker.jmx.QueueViewMBean;
+import org.apache.activemq.broker.region.policy.IndividualDeadLetterStrategy;
+import org.apache.activemq.broker.region.policy.PolicyEntry;
+import org.apache.activemq.broker.region.policy.PolicyMap;
+import org.apache.activemq.command.ActiveMQQueue;
+import org.apache.activemq.store.kahadb.KahaDBPersistenceAdapter;
+import org.slf4j.Logger;
+import org.slf4j.LoggerFactory;
+
+
+public class DLQRetryTest extends EmbeddedBrokerTestSupport {
+
+    private static final Logger LOG = LoggerFactory.getLogger(DLQRetryTest.class);
+
+    protected MBeanServer mbeanServer;
+    protected String domain = "org.apache.activemq";
+    protected String bindAddress;
+
+    protected Connection connection;
+
+    public void testDefaultDLQ() throws Exception {
+
+        // broker uses DLQ defined for this destination
+        String destinationName = "retry.test.default";
+
+        String objectNameStr = broker.getBrokerObjectName().toString();
+        objectNameStr += ",destinationType=Queue,destinationName=ActiveMQ.DLQ";
+
+        invokeRetryDLQ(destinationName, objectNameStr);
+    }
+
+
+    public void testIndividualDLQ() throws Exception {
+
+        // broker has an individual DLQ defined for this destination
+        String destinationName = "retry.test.individual";
+
+        String objectNameStr = broker.getBrokerObjectName().toString();
+        objectNameStr += ",destinationType=Queue,destinationName=DLQ." + destinationName;
+
+        invokeRetryDLQ(destinationName, objectNameStr);
+
+    }
+
+
+    private void invokeRetryDLQ(String destinationName, String mbeanName) throws Exception {
+        // Send some messages
+        connection = connectionFactory.createConnection();
+        try {
+
+            connection.start();
+            Session session = connection.createSession(false, Session.AUTO_ACKNOWLEDGE);
+            MessageProducer producer = session.createProducer(new ActiveMQQueue(destinationName));
+            Message message = session.createTextMessage("Message testing default DLQ");
+            producer.send(message);
+            producer.close();
+
+            //create a consumer to rollback
+            String mesageID = consumeRollbackMessage(destinationName);
+
+
+            ObjectName queueViewMBeanName = assertRegisteredObjectName(mbeanName);
+            final QueueViewMBean DLQProxy = (QueueViewMBean) MBeanServerInvocationHandler.newProxyInstance(mbeanServer, queueViewMBeanName, QueueViewMBean.class, true);
+
+            assertEquals("Check message is on DLQ", 1, DLQProxy.getQueueSize());
+
+            boolean moveSuccess = DLQProxy.retryMessage(mesageID);
+            assertEquals("moveSuccess", true, moveSuccess);
+
+            assertEquals("Check message is off DLQ (after retry invoked)", 0, DLQProxy.getQueueSize());
+
+            // do rollbacks again, so it gets placed in the DLQ again
+            String mesageID_secondAttempt = consumeRollbackMessage(destinationName);
+
+            assertEquals("Ensure messageID is the same for first and second attempt", mesageID, mesageID_secondAttempt);
+
+            // check the DLQ as the message
+            assertEquals("Check message is on DLQ for second time", 1, DLQProxy.getQueueSize());
+
+        } finally {
+
+            connection.close();
+
+        }
+    }
+
+    private String consumeRollbackMessage(String destination) throws JMSException {
+        Session consumerSession = connection.createSession(true, Session.AUTO_ACKNOWLEDGE);
+        MessageConsumer messageConsumer = consumerSession.createConsumer(new ActiveMQQueue(destination));
+
+        Message message = null;
+        String messageID = null;
+        do {
+            message = messageConsumer.receive(3000);
+            if (message != null) {
+                LOG.info("rolling back " + message.getJMSMessageID());
+                messageID = message.getJMSMessageID();
+                consumerSession.rollback();
+            }
+
+        } while (message != null);
+
+        messageConsumer.close();
+        return messageID;
+    }
+
+    protected ObjectName assertRegisteredObjectName(String name) throws MalformedObjectNameException, NullPointerException {
+        ObjectName objectName = new ObjectName(name);
+        if (mbeanServer.isRegistered(objectName)) {
+            LOG.info("Bean Registered: " + objectName);
+        } else {
+            fail("Could not find MBean!: " + objectName);
+        }
+        return objectName;
+    }
+
+    protected void setUp() throws Exception {
+        bindAddress = "tcp://localhost:0";
+        useTopic = false;
+        super.setUp();
+        mbeanServer = broker.getManagementContext().getMBeanServer();
+    }
+
+    protected void tearDown() throws Exception {
+        if (connection != null) {
+            connection.close();
+            connection = null;
+        }
+        super.tearDown();
+    }
+
+    protected BrokerService createBroker() throws Exception {
+        BrokerService answer = new BrokerService();
+        answer.setUseJmx(true);
+        answer.setEnableStatistics(true);
+        answer.addConnector(bindAddress);
+
+        PolicyMap policyMap = new PolicyMap();
+        List<PolicyEntry> entries = new ArrayList<PolicyEntry>();
+        PolicyEntry pe = new PolicyEntry();
+
+        IndividualDeadLetterStrategy individualDeadLetterStrategy = new IndividualDeadLetterStrategy();
+        individualDeadLetterStrategy.setQueuePrefix("DLQ.");
+        pe.setDeadLetterStrategy(individualDeadLetterStrategy);
+
+        pe.setQueue("retry.test.individual");
+        entries.add(pe);
+
+        policyMap.setPolicyEntries(entries);
+        answer.setDestinationPolicy(policyMap);
+
+        ((KahaDBPersistenceAdapter) answer.getPersistenceAdapter()).setConcurrentStoreAndDispatchQueues(false);
+        answer.deleteAllMessages();
+        return answer;
+    }
+
+    @Override
+    protected ConnectionFactory createConnectionFactory() throws Exception {
+        ActiveMQConnectionFactory activeMQConnectionFactory = new ActiveMQConnectionFactory(broker.getTransportConnectors().get(0).getPublishableConnectString());
+        RedeliveryPolicy redeliveryPolicy = new RedeliveryPolicy();
+        redeliveryPolicy.setMaximumRedeliveries(1);
+        activeMQConnectionFactory.setRedeliveryPolicy(redeliveryPolicy);
+        return activeMQConnectionFactory;
+    }
+
+}
\ No newline at end of file