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 2015/02/20 23:42:27 UTC

[1/2] activemq-6 git commit: Port a test from the HornetQ code-base.

Repository: activemq-6
Updated Branches:
  refs/heads/master 31a2036de -> 0d65983aa


Port a test from the HornetQ code-base.

A bug was recently discovered on a legacy HornetQ branch. ActiveMQ 6
doesn't suffer from the same problem, but the test is still valuable.
The HornetQ issue is described on
https://bugzilla.redhat.com/show_bug.cgi?id=1193085.


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

Branch: refs/heads/master
Commit: 0e537d08815a305d6bbacc1f7c614ab221548929
Parents: 31a2036
Author: jbertram <jb...@redhat.com>
Authored: Fri Feb 20 15:45:00 2015 -0600
Committer: jbertram <jb...@redhat.com>
Committed: Fri Feb 20 16:35:25 2015 -0600

----------------------------------------------------------------------
 .../byteman/tests/ClosingConnectionTest.java    | 192 +++++++++++++++++++
 1 file changed, 192 insertions(+)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/activemq-6/blob/0e537d08/tests/byteman-tests/src/test/java/org/apache/activemq/byteman/tests/ClosingConnectionTest.java
----------------------------------------------------------------------
diff --git a/tests/byteman-tests/src/test/java/org/apache/activemq/byteman/tests/ClosingConnectionTest.java b/tests/byteman-tests/src/test/java/org/apache/activemq/byteman/tests/ClosingConnectionTest.java
new file mode 100644
index 0000000..cd804e1
--- /dev/null
+++ b/tests/byteman-tests/src/test/java/org/apache/activemq/byteman/tests/ClosingConnectionTest.java
@@ -0,0 +1,192 @@
+/**
+ * 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.byteman.tests;
+
+import javax.management.MBeanServer;
+import javax.management.MBeanServerFactory;
+
+import org.apache.activemq.api.core.SimpleString;
+import org.apache.activemq.api.core.client.ClientMessage;
+import org.apache.activemq.api.core.client.ClientProducer;
+import org.apache.activemq.api.core.client.ClientSession;
+import org.apache.activemq.api.core.client.ClientSessionFactory;
+import org.apache.activemq.api.core.client.ServerLocator;
+import org.apache.activemq.api.core.management.ActiveMQServerControl;
+import org.apache.activemq.core.server.ActiveMQServer;
+import org.apache.activemq.core.server.JournalType;
+import org.apache.activemq.core.settings.impl.AddressSettings;
+import org.apache.activemq.tests.integration.IntegrationTestLogger;
+import org.apache.activemq.tests.integration.management.ManagementControlHelper;
+import org.apache.activemq.tests.util.ServiceTestBase;
+import org.jboss.byteman.contrib.bmunit.BMRule;
+import org.jboss.byteman.contrib.bmunit.BMRules;
+import org.jboss.byteman.contrib.bmunit.BMUnitRunner;
+import org.junit.Before;
+import org.junit.Test;
+import org.junit.runner.RunWith;
+
+@RunWith(BMUnitRunner.class)
+public class ClosingConnectionTest extends ServiceTestBase
+{
+   public static final SimpleString ADDRESS = new SimpleString("SimpleAddress");
+
+   private ServerLocator locator;
+
+   private ActiveMQServer server;
+
+   private static MBeanServer mBeanServer;
+
+   private static boolean readyToKill = false;
+
+   protected boolean isNetty()
+   {
+      return true;
+   }
+
+
+   @Override
+   @Before
+   public void setUp() throws Exception
+   {
+      super.setUp();
+      mBeanServer = MBeanServerFactory.createMBeanServer();
+      server = newActiveMQServer();
+      server.getConfiguration().setJournalType(JournalType.NIO);
+      server.getConfiguration().setJMXManagementEnabled(true);
+      server.start();
+      waitForServer(server);
+      locator = createFactory(isNetty());
+      readyToKill = false;
+   }
+
+   public static void killConnection() throws InterruptedException
+   {
+      if (readyToKill)
+      {
+         // We have to kill the connection in a new thread otherwise Netty won't interrupt the current thread
+         Thread closeConnectionThread = new Thread(new Runnable()
+         {
+            @Override
+            public void run()
+            {
+               try
+               {
+                  ActiveMQServerControl serverControl = ManagementControlHelper.createActiveMQServerControl(mBeanServer);
+                  serverControl.closeConnectionsForUser("guest");
+                  readyToKill = false;
+               }
+               catch (Exception e)
+               {
+                  e.printStackTrace();
+               }
+            }
+         });
+
+         closeConnectionThread.start();
+
+         try
+         {
+            /* We want to simulate a long-running remoting thread here. If closing the connection in the closeConnectionThread
+             * interrupts this thread then it will cause sleep() to throw and InterruptedException. Therefore we catch
+             * the InterruptedException and re-interrupt the current thread so the interrupt will be passed properly
+             * back to the caller. It's a bit of a hack, but I couldn't find any other way to simulate it.
+             */
+            Thread.sleep(1500);
+         }
+         catch (InterruptedException e)
+         {
+            Thread.currentThread().interrupt();
+         }
+      }
+   }
+
+   /*
+   * Test for https://bugzilla.redhat.com/show_bug.cgi?id=1193085
+   * */
+   @Test
+   @BMRules
+      (
+         rules =
+            {
+               @BMRule
+                  (
+                     name = "rule to kill connection",
+                     targetClass = "org.apache.activemq.core.journal.impl.NIOSequentialFile",
+                     targetMethod = "open(int, boolean)",
+                     targetLocation = "AT INVOKE java.nio.channels.FileChannel.size()",
+                     action = "org.apache.activemq.byteman.tests.ClosingConnectionTest.killConnection();"
+
+                  )
+            }
+      )
+   public void testKillConnection() throws Exception
+   {
+      locator.setBlockOnNonDurableSend(true);
+      locator.setBlockOnDurableSend(true);
+      locator.setBlockOnAcknowledge(true);
+
+      ClientSessionFactory sf = createSessionFactory(locator);
+      ClientSession session = sf.createSession("guest", null, false, true, true, false, 0);
+
+      session.createQueue(ADDRESS, ADDRESS, null, true);
+
+      ClientProducer producer = session.createProducer(ADDRESS);
+
+      ClientMessage message = session.createMessage(true);
+      message.getBodyBuffer().writeBytes(new byte[1024]);
+
+      for (int i = 0; i < 200; i++)
+      {
+         producer.send(message);
+      }
+
+      assertTrue(server.locateQueue(ADDRESS).getPageSubscription().getPagingStore().isPaging());
+
+      readyToKill = true;
+      try
+      {
+         for (int i = 0; i < 8; i++)
+         {
+            producer.send(message);
+         }
+         fail("Sending message here should result in failure.");
+      }
+      catch (Exception e)
+      {
+         IntegrationTestLogger.LOGGER.info("Caught exception: " + e.getMessage());
+      }
+
+      Thread.sleep(1000);
+
+      assertTrue(server.isStarted());
+
+      session.close();
+   }
+
+   private ActiveMQServer newActiveMQServer() throws Exception
+   {
+      ActiveMQServer server = createServer(true, createDefaultConfig(isNetty()), mBeanServer);
+
+      AddressSettings defaultSetting = new AddressSettings();
+      defaultSetting.setPageSizeBytes(10 * 1024);
+      defaultSetting.setMaxSizeBytes(20 * 1024);
+
+      server.getAddressSettingsRepository().addMatch("#", defaultSetting);
+
+      return server;
+   }
+}
\ No newline at end of file


[2/2] activemq-6 git commit: This closes #106 on back porting test

Posted by cl...@apache.org.
This closes #106 on back porting test


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

Branch: refs/heads/master
Commit: 0d65983aab3ff1c81e2abbab878815ec647802d3
Parents: 31a2036 0e537d0
Author: Clebert Suconic <cl...@apache.org>
Authored: Fri Feb 20 17:40:21 2015 -0500
Committer: Clebert Suconic <cl...@apache.org>
Committed: Fri Feb 20 17:40:21 2015 -0500

----------------------------------------------------------------------
 .../byteman/tests/ClosingConnectionTest.java    | 192 +++++++++++++++++++
 1 file changed, 192 insertions(+)
----------------------------------------------------------------------