You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@activemq.apache.org by ta...@apache.org on 2018/04/30 21:53:27 UTC

[1/2] activemq-artemis git commit: ARTEMIS-1838 Fixing AMQP->Core Race on durable property

Repository: activemq-artemis
Updated Branches:
  refs/heads/master dd71f2f31 -> e2e5bdfec


ARTEMIS-1838 Fixing AMQP->Core Race on durable property


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

Branch: refs/heads/master
Commit: 384e1aa4d582d62a27f17acd24f10729b6f133a6
Parents: dd71f2f
Author: Clebert Suconic <cl...@apache.org>
Authored: Fri Apr 27 17:35:36 2018 -0400
Committer: Clebert Suconic <cl...@apache.org>
Committed: Mon Apr 30 17:30:22 2018 -0400

----------------------------------------------------------------------
 .../protocol/amqp/broker/AMQPMessage.java       |   5 +-
 tests/smoke-tests/pom.xml                       |  15 ++
 .../crossprotocol/MultiThreadConvertTest.java   | 169 +++++++++++++++++++
 3 files changed, 188 insertions(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/384e1aa4/artemis-protocols/artemis-amqp-protocol/src/main/java/org/apache/activemq/artemis/protocol/amqp/broker/AMQPMessage.java
----------------------------------------------------------------------
diff --git a/artemis-protocols/artemis-amqp-protocol/src/main/java/org/apache/activemq/artemis/protocol/amqp/broker/AMQPMessage.java b/artemis-protocols/artemis-amqp-protocol/src/main/java/org/apache/activemq/artemis/protocol/amqp/broker/AMQPMessage.java
index ba87ae6..5f7dbac 100644
--- a/artemis-protocols/artemis-amqp-protocol/src/main/java/org/apache/activemq/artemis/protocol/amqp/broker/AMQPMessage.java
+++ b/artemis-protocols/artemis-amqp-protocol/src/main/java/org/apache/activemq/artemis/protocol/amqp/broker/AMQPMessage.java
@@ -197,7 +197,7 @@ public class AMQPMessage extends RefCountMessage {
       return applicationProperties;
    }
 
-   private void parseHeaders() {
+   private synchronized void parseHeaders() {
       if (!parsedHeaders) {
          if (data == null) {
             initalizeObjects();
@@ -388,6 +388,7 @@ public class AMQPMessage extends RefCountMessage {
             _header = (Header) section;
             headerEnds = buffer.position();
             messagePaylodStart = headerEnds;
+            this.durable = _header.getDurable();
 
             if (_header.getTtl() != null) {
                this.expiration = System.currentTimeMillis() + _header.getTtl().intValue();
@@ -578,6 +579,8 @@ public class AMQPMessage extends RefCountMessage {
          return durable;
       }
 
+      parseHeaders();
+
       if (getHeader() != null && getHeader().getDurable() != null) {
          durable = getHeader().getDurable();
          return durable;

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/384e1aa4/tests/smoke-tests/pom.xml
----------------------------------------------------------------------
diff --git a/tests/smoke-tests/pom.xml b/tests/smoke-tests/pom.xml
index 9d5dff0..ca7ac19 100644
--- a/tests/smoke-tests/pom.xml
+++ b/tests/smoke-tests/pom.xml
@@ -178,6 +178,21 @@
                      <configuration>${basedir}/target/classes/servers/mqtt</configuration>
                   </configuration>
                </execution>
+               <execution>
+                  <phase>test-compile</phase>
+                  <id>create-standard</id>
+                  <goals>
+                     <goal>create</goal>
+                  </goals>
+                  <configuration>
+                     <!-- this makes it easier in certain envs -->
+                     <configuration>${basedir}/target/classes/servers/mqtt</configuration>
+                     <allowAnonymous>true</allowAnonymous>
+                     <user>admin</user>
+                     <password>admin</password>
+                     <instance>${basedir}/target/standard</instance>
+                  </configuration>
+               </execution>
 
             </executions>
             <dependencies>

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/384e1aa4/tests/smoke-tests/src/test/java/org/apache/activemq/artemis/tests/smoke/crossprotocol/MultiThreadConvertTest.java
----------------------------------------------------------------------
diff --git a/tests/smoke-tests/src/test/java/org/apache/activemq/artemis/tests/smoke/crossprotocol/MultiThreadConvertTest.java b/tests/smoke-tests/src/test/java/org/apache/activemq/artemis/tests/smoke/crossprotocol/MultiThreadConvertTest.java
new file mode 100644
index 0000000..32a5064
--- /dev/null
+++ b/tests/smoke-tests/src/test/java/org/apache/activemq/artemis/tests/smoke/crossprotocol/MultiThreadConvertTest.java
@@ -0,0 +1,169 @@
+/*
+ * 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.artemis.tests.smoke.crossprotocol;
+
+import javax.jms.Connection;
+import javax.jms.DeliveryMode;
+import javax.jms.IllegalStateException;
+import javax.jms.Message;
+import javax.jms.MessageConsumer;
+import javax.jms.MessageProducer;
+import javax.jms.Session;
+import javax.jms.TextMessage;
+import javax.jms.Topic;
+import java.util.HashMap;
+import java.util.UUID;
+import java.util.concurrent.CountDownLatch;
+import java.util.concurrent.ExecutorService;
+import java.util.concurrent.Executors;
+import java.util.concurrent.TimeUnit;
+import java.util.concurrent.atomic.AtomicBoolean;
+
+import org.apache.activemq.artemis.api.core.TransportConfiguration;
+import org.apache.activemq.artemis.core.remoting.impl.netty.TransportConstants;
+import org.apache.activemq.artemis.core.server.ActiveMQServer;
+import org.apache.activemq.artemis.jms.client.ActiveMQConnectionFactory;
+import org.apache.activemq.artemis.tests.smoke.common.SmokeTestBase;
+import org.apache.qpid.jms.JmsConnectionFactory;
+import org.junit.After;
+import org.junit.Before;
+import org.junit.Test;
+import org.slf4j.Logger;
+import org.slf4j.LoggerFactory;
+
+public class MultiThreadConvertTest extends SmokeTestBase {
+
+   private static final String SERVER_NAME_0 = "standard";
+
+   private static final Logger LOG = LoggerFactory.getLogger(MultiThreadConvertTest.class);
+
+   @Before
+   public void before() throws Exception {
+      cleanupData(SERVER_NAME_0);
+      disableCheckThread();
+      startServer(SERVER_NAME_0, 0, 30000);
+   }
+
+   protected TransportConfiguration addAcceptorConfiguration(ActiveMQServer server, int port) {
+      HashMap<String, Object> params = new HashMap<>();
+      params.put(TransportConstants.PORT_PROP_NAME, String.valueOf(port));
+      params.put(TransportConstants.PROTOCOLS_PROP_NAME, "AMQP");
+      HashMap<String, Object> amqpParams = new HashMap<>();
+
+      return new TransportConfiguration(NETTY_ACCEPTOR_FACTORY, params, "netty-amqp-acceptor", amqpParams);
+   }
+
+   public String getTopicName() {
+      return "test-topic-1";
+   }
+
+   @Override
+   @After
+   public void tearDown() throws Exception {
+      super.tearDown();
+   }
+
+   @Test(timeout = 60000)
+   public void testSendLotsOfDurableMessagesOnTopicWithManySubscribersPersistent() throws Exception {
+      doTestSendLotsOfDurableMessagesOnTopicWithManySubscribers(DeliveryMode.PERSISTENT);
+   }
+
+   @Test(timeout = 60000)
+   public void testSendLotsOfDurableMessagesOnTopicWithManySubscribersNonPersistent() throws Exception {
+      doTestSendLotsOfDurableMessagesOnTopicWithManySubscribers(DeliveryMode.NON_PERSISTENT);
+   }
+
+   private void doTestSendLotsOfDurableMessagesOnTopicWithManySubscribers(int durability) throws Exception {
+
+      final int MSG_COUNT = 400;
+      final int SUBSCRIBER_COUNT = 4;
+      final int DELIVERY_MODE = durability;
+
+      JmsConnectionFactory amqpFactory = new JmsConnectionFactory("amqp://127.0.0.1:5672");
+      ActiveMQConnectionFactory coreFactory = new ActiveMQConnectionFactory("tcp://127.0.0.1:61616");
+
+      Connection amqpConnection = amqpFactory.createConnection();
+      final ExecutorService executor = Executors.newFixedThreadPool(SUBSCRIBER_COUNT);
+
+      try {
+         final CountDownLatch subscribed = new CountDownLatch(SUBSCRIBER_COUNT);
+         final CountDownLatch done = new CountDownLatch(MSG_COUNT * SUBSCRIBER_COUNT);
+         final AtomicBoolean error = new AtomicBoolean(false);
+
+         for (int i = 0; i < SUBSCRIBER_COUNT; ++i) {
+            executor.execute(() -> {
+               Session coreSession = null;
+               Connection coreConnection = null;
+               try {
+                  coreConnection = coreFactory.createConnection();
+                  coreSession = coreConnection.createSession(false, Session.AUTO_ACKNOWLEDGE);
+                  Topic topic = coreSession.createTopic(getTopicName());
+                  MessageConsumer coreConsumer = coreSession.createConsumer(topic);
+
+                  subscribed.countDown(); // Signal ready
+
+                  coreConnection.start();
+
+                  for (int j = 0; j < MSG_COUNT; j++) {
+                     Message received = coreConsumer.receive(TimeUnit.SECONDS.toMillis(5));
+                     done.countDown();
+
+                     if (received.getJMSDeliveryMode() != DELIVERY_MODE) {
+                        throw new IllegalStateException("Message durability state is not corret.");
+                     }
+                  }
+
+               } catch (Throwable t) {
+                  LOG.error("Error during message consumption: ", t);
+                  error.set(true);
+               } finally {
+                  try {
+                     coreConnection.close();
+                  } catch (Throwable e) {
+                  }
+               }
+            });
+         }
+
+         assertTrue("Receivers didn't signal ready", subscribed.await(10, TimeUnit.SECONDS));
+
+         // Send using AMQP and receive using Core JMS client.
+         Session amqpSession = amqpConnection.createSession(false, Session.AUTO_ACKNOWLEDGE);
+         Topic topic = amqpSession.createTopic(getTopicName());
+         MessageProducer producer = amqpSession.createProducer(topic);
+         producer.setDeliveryMode(DELIVERY_MODE);
+
+         for (int i = 0; i < MSG_COUNT; i++) {
+            TextMessage message = amqpSession.createTextMessage("test");
+            message.setJMSCorrelationID(UUID.randomUUID().toString());
+            producer.send(message);
+         }
+
+         assertTrue("did not read all messages, waiting on: " + done.getCount(), done.await(30, TimeUnit.SECONDS));
+         assertFalse("should not be any errors on receive", error.get());
+      } finally {
+         try {
+            amqpConnection.close();
+         } catch (Exception e) {
+         }
+
+         executor.shutdown();
+         coreFactory.close();
+      }
+   }
+}


[2/2] activemq-artemis git commit: This closes #2053

Posted by ta...@apache.org.
This closes #2053


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

Branch: refs/heads/master
Commit: e2e5bdfeca1541cf674322fc6c467203aeac2e7b
Parents: dd71f2f 384e1aa
Author: Timothy Bish <ta...@gmail.com>
Authored: Mon Apr 30 17:53:04 2018 -0400
Committer: Timothy Bish <ta...@gmail.com>
Committed: Mon Apr 30 17:53:04 2018 -0400

----------------------------------------------------------------------
 .../protocol/amqp/broker/AMQPMessage.java       |   5 +-
 tests/smoke-tests/pom.xml                       |  15 ++
 .../crossprotocol/MultiThreadConvertTest.java   | 169 +++++++++++++++++++
 3 files changed, 188 insertions(+), 1 deletion(-)
----------------------------------------------------------------------