You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@activemq.apache.org by cl...@apache.org on 2017/12/20 21:00:45 UTC

[1/2] activemq-artemis git commit: NO-JIRA Add openwire temp queue cluster test

Repository: activemq-artemis
Updated Branches:
  refs/heads/master 72c1470ea -> b61be4dc4


NO-JIRA Add openwire temp queue cluster test

The test makes sure temp queue from openwire
works in a clustered environment.


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

Branch: refs/heads/master
Commit: 3dd6d8a263ee40620fd076a19546ca79440ef744
Parents: 72c1470
Author: Howard Gao <ho...@gmail.com>
Authored: Mon Dec 18 18:08:58 2017 +0800
Committer: Clebert Suconic <cl...@apache.org>
Committed: Wed Dec 20 16:00:37 2017 -0500

----------------------------------------------------------------------
 .../cluster/OpenWireJMSClusteredTestBase.java   |  59 +++++++
 .../cluster/TemporaryQueueClusterTest.java      | 155 +++++++++++++++++++
 2 files changed, 214 insertions(+)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/3dd6d8a2/tests/integration-tests/src/test/java/org/apache/activemq/artemis/tests/integration/openwire/cluster/OpenWireJMSClusteredTestBase.java
----------------------------------------------------------------------
diff --git a/tests/integration-tests/src/test/java/org/apache/activemq/artemis/tests/integration/openwire/cluster/OpenWireJMSClusteredTestBase.java b/tests/integration-tests/src/test/java/org/apache/activemq/artemis/tests/integration/openwire/cluster/OpenWireJMSClusteredTestBase.java
new file mode 100644
index 0000000..66aca80
--- /dev/null
+++ b/tests/integration-tests/src/test/java/org/apache/activemq/artemis/tests/integration/openwire/cluster/OpenWireJMSClusteredTestBase.java
@@ -0,0 +1,59 @@
+/*
+ * 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.integration.openwire.cluster;
+
+import org.apache.activemq.ActiveMQConnectionFactory;
+import org.apache.activemq.artemis.core.server.cluster.impl.MessageLoadBalancingType;
+import org.apache.activemq.artemis.tests.integration.cluster.distribution.ClusterTestBase;
+import org.junit.Before;
+
+public class OpenWireJMSClusteredTestBase extends ClusterTestBase {
+
+   protected ActiveMQConnectionFactory openWireCf1;
+
+   protected ActiveMQConnectionFactory openWireCf2;
+
+   @Override
+   @Before
+   public void setUp() throws Exception {
+      super.setUp();
+
+      setupServer(0, true, true);
+      setupServer(1, true, true);
+
+      setupClusterConnection("cluster0", "", MessageLoadBalancingType.ON_DEMAND, 1, true, 0, 1);
+      setupClusterConnection("cluster1", "", MessageLoadBalancingType.ON_DEMAND, 1, true, 1, 0);
+
+      startServers(0, 1);
+
+      waitForTopology(servers[0], 2);
+      waitForTopology(servers[1], 2);
+
+      setupSessionFactory(0, true);
+      setupSessionFactory(1, true);
+
+      String uri1 = getServerUri(0);
+      String uri2 = getServerUri(1);
+      openWireCf1 = new ActiveMQConnectionFactory(uri1);
+      openWireCf2 = new ActiveMQConnectionFactory(uri2);
+   }
+
+   @Override
+   protected boolean isResolveProtocols() {
+      return true;
+   }
+}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/3dd6d8a2/tests/integration-tests/src/test/java/org/apache/activemq/artemis/tests/integration/openwire/cluster/TemporaryQueueClusterTest.java
----------------------------------------------------------------------
diff --git a/tests/integration-tests/src/test/java/org/apache/activemq/artemis/tests/integration/openwire/cluster/TemporaryQueueClusterTest.java b/tests/integration-tests/src/test/java/org/apache/activemq/artemis/tests/integration/openwire/cluster/TemporaryQueueClusterTest.java
new file mode 100644
index 0000000..1d5fd00
--- /dev/null
+++ b/tests/integration-tests/src/test/java/org/apache/activemq/artemis/tests/integration/openwire/cluster/TemporaryQueueClusterTest.java
@@ -0,0 +1,155 @@
+/*
+ * 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.integration.openwire.cluster;
+
+import org.apache.activemq.artemis.api.core.RoutingType;
+import org.junit.Before;
+import org.junit.Test;
+
+import javax.jms.Connection;
+import javax.jms.MessageConsumer;
+import javax.jms.MessageProducer;
+import javax.jms.Queue;
+import javax.jms.Session;
+import javax.jms.TextMessage;
+
+public class TemporaryQueueClusterTest extends OpenWireJMSClusteredTestBase {
+
+   public static final String QUEUE_NAME = "target";
+
+   @Override
+   @Before
+   public void setUp() throws Exception {
+      super.setUp();
+
+      createAddressInfo(0, QUEUE_NAME, RoutingType.ANYCAST, -1, false);
+      createAddressInfo(1, QUEUE_NAME, RoutingType.ANYCAST, -1, false);
+      createQueue(0, QUEUE_NAME, QUEUE_NAME, null, true, null, null, RoutingType.ANYCAST);
+      createQueue(1, QUEUE_NAME, QUEUE_NAME, null, true, null, null, RoutingType.ANYCAST);
+
+      waitForBindings(0, QUEUE_NAME, 1, 0, true);
+      waitForBindings(0, QUEUE_NAME, 1, 0, false);
+      waitForBindings(1, QUEUE_NAME, 1, 0, true);
+      waitForBindings(1, QUEUE_NAME, 1, 0, false);
+   }
+
+   @Test
+   public void testClusteredQueue() throws Exception {
+
+      System.out.println("creating connections");
+      Connection conn1 = openWireCf1.createConnection();
+      Connection conn2 = openWireCf2.createConnection();
+
+      conn1.start();
+      conn2.start();
+
+      try {
+         Session session1 = conn1.createSession(false, Session.AUTO_ACKNOWLEDGE);
+         Queue targetQueue1 = session1.createQueue(QUEUE_NAME);
+
+         Session session2 = conn2.createSession(false, Session.AUTO_ACKNOWLEDGE);
+         Queue targetQueue2 = session2.createQueue(QUEUE_NAME);
+
+         MessageProducer prod1 = session1.createProducer(targetQueue1);
+         MessageConsumer cons2 = session2.createConsumer(targetQueue2);
+
+         TextMessage msg = session1.createTextMessage("hello");
+
+         prod1.send(msg);
+
+         TextMessage msgReceived = (TextMessage) cons2.receive(5000);
+
+         assertNotNull(msgReceived);
+         assertEquals(msgReceived.getText(), msg.getText());
+
+      } finally {
+         conn1.close();
+         conn2.close();
+      }
+   }
+
+   @Test
+   public void testTemporaryQueue() throws Exception {
+
+      Connection conn1 = openWireCf1.createConnection();
+      Connection conn2 = openWireCf2.createConnection();
+
+      conn1.start();
+      conn2.start();
+
+      try {
+         Session session1 = conn1.createSession(false, Session.AUTO_ACKNOWLEDGE);
+         Queue targetQueue1 = session1.createQueue(QUEUE_NAME);
+         Queue tempQueue = session1.createTemporaryQueue();
+         System.out.println("temp queue is " + tempQueue.getQueueName());
+         Session session2 = conn2.createSession(false, Session.AUTO_ACKNOWLEDGE);
+         Queue targetQueue2 = session2.createQueue(QUEUE_NAME);
+
+         waitForBindings(0, QUEUE_NAME, 1, 0, true);
+         waitForBindings(0, tempQueue.getQueueName(), 1, 0, true);
+         waitForBindings(0, QUEUE_NAME, 1, 0, false);
+
+         waitForBindings(1, QUEUE_NAME, 1, 0, true);
+         waitForBindings(1, QUEUE_NAME, 1, 0, false);
+         waitForBindings(1, tempQueue.getQueueName(), 1, 0, false);
+
+         MessageProducer prod1 = session1.createProducer(targetQueue1);
+         MessageConsumer cons2 = session2.createConsumer(targetQueue2);
+         MessageConsumer tempCons1 = session1.createConsumer(tempQueue);
+
+         waitForBindings(0, tempQueue.getQueueName(), 1, 1, true);
+         waitForBindings(1, QUEUE_NAME, 1, 1, true);
+
+         for (int i = 0; i < 10; i++) {
+            TextMessage message = session1.createTextMessage("" + i);
+            message.setJMSReplyTo(tempQueue);
+            prod1.send(message);
+         }
+
+         for (int i = 0; i < 10; i++) {
+            if (i % 2 == 0) {
+               TextMessage received = (TextMessage) cons2.receive(5000);
+               System.out.println(received.getText());
+               System.out.println("check temp queue on server #2");
+               MessageProducer tempProducer = session2.createProducer(received.getJMSReplyTo());
+               tempProducer.send(session2.createTextMessage(">>> " + received.getText()));
+               tempProducer.close();
+            }
+         }
+
+         for (int i = 0; i < 10; i++) {
+            if (i % 2 == 0) {
+               TextMessage received = (TextMessage) tempCons1.receive(5000);
+               assertNotNull(received);
+               System.out.println(received.getText());
+            }
+         }
+      } finally {
+         conn1.close();
+         conn2.close();
+      }
+   }
+
+   // Package protected ---------------------------------------------
+
+   // Protected -----------------------------------------------------
+
+   // Private -------------------------------------------------------
+
+   // Inner classes -------------------------------------------------
+
+}


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

Posted by cl...@apache.org.
This closes #1724


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

Branch: refs/heads/master
Commit: b61be4dc4f01ecd36687bf3d90881ed5a5b1cc65
Parents: 72c1470 3dd6d8a
Author: Clebert Suconic <cl...@apache.org>
Authored: Wed Dec 20 16:00:38 2017 -0500
Committer: Clebert Suconic <cl...@apache.org>
Committed: Wed Dec 20 16:00:38 2017 -0500

----------------------------------------------------------------------
 .../cluster/OpenWireJMSClusteredTestBase.java   |  59 +++++++
 .../cluster/TemporaryQueueClusterTest.java      | 155 +++++++++++++++++++
 2 files changed, 214 insertions(+)
----------------------------------------------------------------------