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/07/09 16:41:17 UTC

[3/4] activemq-artemis git commit: Spelling fixes

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/b0a80ce1/examples/jms/client-side-failoverlistener/src/main/java/org/apache/activemq/artemis/jms/example/ClientSideFailoverListerExample.java
----------------------------------------------------------------------
diff --git a/examples/jms/client-side-failoverlistener/src/main/java/org/apache/activemq/artemis/jms/example/ClientSideFailoverListerExample.java b/examples/jms/client-side-failoverlistener/src/main/java/org/apache/activemq/artemis/jms/example/ClientSideFailoverListerExample.java
index 01f05dc..20c8808 100644
--- a/examples/jms/client-side-failoverlistener/src/main/java/org/apache/activemq/artemis/jms/example/ClientSideFailoverListerExample.java
+++ b/examples/jms/client-side-failoverlistener/src/main/java/org/apache/activemq/artemis/jms/example/ClientSideFailoverListerExample.java
@@ -34,7 +34,7 @@ import org.apache.activemq.artemis.jms.client.ActiveMQConnection;
  * This example demonstrates how you can listen on failover event on the client side
  *
  * In this example there are two nodes running in a cluster, both server will be running for start,
- * but after a while the first server will crash. This will trigger an fail oever event
+ * but after a while the first server will crash. This will trigger a fail-over event
  */
 public class ClientSideFailoverListerExample extends ActiveMQExample
 {

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/b0a80ce1/examples/jms/clustered-durable-subscription/readme.html
----------------------------------------------------------------------
diff --git a/examples/jms/clustered-durable-subscription/readme.html b/examples/jms/clustered-durable-subscription/readme.html
index 440d281..0d17214 100644
--- a/examples/jms/clustered-durable-subscription/readme.html
+++ b/examples/jms/clustered-durable-subscription/readme.html
@@ -172,7 +172,7 @@ under the License.
         We now consume those messages on *both* server 0 and server 1.
         Note that the messages have been load-balanced between the two nodes, with some
         messages on node 0 and others on node 1.
-        The "logical" subscription is distributed across the cluster an contains exactly one copy of all the messages sent.
+        The "logical" subscription is distributed across the cluster and contains exactly one copy of all the messages sent.
          </li>
         <pre class="prettyprint">
            <code>

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/b0a80ce1/examples/jms/clustered-durable-subscription/src/main/java/org/apache/activemq/artemis/jms/example/ClusteredDurableSubscriptionExample.java
----------------------------------------------------------------------
diff --git a/examples/jms/clustered-durable-subscription/src/main/java/org/apache/activemq/artemis/jms/example/ClusteredDurableSubscriptionExample.java b/examples/jms/clustered-durable-subscription/src/main/java/org/apache/activemq/artemis/jms/example/ClusteredDurableSubscriptionExample.java
index e297ff6..c5b3be4 100644
--- a/examples/jms/clustered-durable-subscription/src/main/java/org/apache/activemq/artemis/jms/example/ClusteredDurableSubscriptionExample.java
+++ b/examples/jms/clustered-durable-subscription/src/main/java/org/apache/activemq/artemis/jms/example/ClusteredDurableSubscriptionExample.java
@@ -133,7 +133,7 @@ public class ClusteredDurableSubscriptionExample extends ActiveMQExample
          // Step 14. We now consume those messages on *both* server 0 and server 1.
          // Note that the messages have been load-balanced between the two nodes, with some
          // messages on node 0 and others on node 1.
-         // The "logical" subscription is distributed across the cluster an contains exactly one copy of all the
+         // The "logical" subscription is distributed across the cluster and contains exactly one copy of all the
          // messages
 
          for (int i = 0; i < numMessages; i += 2)

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/b0a80ce1/examples/jms/embedded-simple/src/main/java/org/apache/activemq/artemis/jms/example/EmbeddedExample.java
----------------------------------------------------------------------
diff --git a/examples/jms/embedded-simple/src/main/java/org/apache/activemq/artemis/jms/example/EmbeddedExample.java b/examples/jms/embedded-simple/src/main/java/org/apache/activemq/artemis/jms/example/EmbeddedExample.java
index f42257f..8221873 100644
--- a/examples/jms/embedded-simple/src/main/java/org/apache/activemq/artemis/jms/example/EmbeddedExample.java
+++ b/examples/jms/embedded-simple/src/main/java/org/apache/activemq/artemis/jms/example/EmbeddedExample.java
@@ -36,7 +36,7 @@ import org.apache.activemq.artemis.spi.core.security.ActiveMQSecurityManagerImpl
 import org.apache.activemq.artemis.api.jms.JMSFactoryType;
 
 /**
- * This example demonstrates how to run a ActiveMQ Artemis embedded with JMS
+ * This example demonstrates how to run an ActiveMQ Artemis embedded with JMS
  */
 public class EmbeddedExample extends ActiveMQExample
 {

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/b0a80ce1/examples/jms/embedded/src/main/java/org/apache/activemq/artemis/jms/example/EmbeddedExample.java
----------------------------------------------------------------------
diff --git a/examples/jms/embedded/src/main/java/org/apache/activemq/artemis/jms/example/EmbeddedExample.java b/examples/jms/embedded/src/main/java/org/apache/activemq/artemis/jms/example/EmbeddedExample.java
index 255bf73..9300058 100644
--- a/examples/jms/embedded/src/main/java/org/apache/activemq/artemis/jms/example/EmbeddedExample.java
+++ b/examples/jms/embedded/src/main/java/org/apache/activemq/artemis/jms/example/EmbeddedExample.java
@@ -42,7 +42,7 @@ import org.apache.activemq.artemis.jms.server.config.impl.JMSQueueConfigurationI
 import org.apache.activemq.artemis.jms.server.embedded.EmbeddedJMS;
 
 /**
- * This example demonstrates how to run a ActiveMQ Artemis embedded with JMS
+ * This example demonstrates how to run an ActiveMQ Artemis embedded with JMS
  */
 public final class EmbeddedExample extends ActiveMQExample
 {

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/b0a80ce1/examples/jms/expiry/readme.html
----------------------------------------------------------------------
diff --git a/examples/jms/expiry/readme.html b/examples/jms/expiry/readme.html
index 24b3ff7..acbbe4b 100644
--- a/examples/jms/expiry/readme.html
+++ b/examples/jms/expiry/readme.html
@@ -27,11 +27,11 @@ under the License.
   <body onload="prettyPrint()">
      <h1>JMS Expiration Example</h1>
 
-     <p>This example shows you how to configure ActiveMQ Artemis so messages are expipired after a certain time..</p>
+     <p>This example shows you how to configure ActiveMQ Artemis so messages are expipired after a certain time.</p>
      <p>Messages can be retained in the messaging system for a limited period of time before being removed.
          JMS specification states that clients should not receive messages that have been expired (but it does not guarantee this will not happen).</p>
      <p>ActiveMQ Artemis can assign a <em>expiry address</em> to a given queue so that when messages are expired, they are removed from the queue and
-        routed to an this address. These "expired" messages can later be consumed for further inspection.
+        routed to this address. These "expired" messages can later be consumed for further inspection.
      <p>
          The example will send 1 message with a short <em>time-to-live</em> to a queue. We will wait for the message to expire and checks that the message
          is no longer in the queue it was sent to.

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/b0a80ce1/examples/jms/message-counters/readme.html
----------------------------------------------------------------------
diff --git a/examples/jms/message-counters/readme.html b/examples/jms/message-counters/readme.html
index 8a7f4c2..63b5d97 100644
--- a/examples/jms/message-counters/readme.html
+++ b/examples/jms/message-counters/readme.html
@@ -43,7 +43,7 @@ under the License.
      Queues are sampled every 10 seconds by default. For this example we will reduce it to 2 seconds by setting <code>message-counter-sample-period</code> to <code>2000</code>.<br />
      ActiveMQ Artemis holds in memory the message counters' history for a maximum number of days (10 by default). We can change the number of days the history is kept by setting
          the <code>message-counter-max-day-history</code> parameter.</p>
-     <p>The sample period and the max day history parameters have an small impact on the performance of ActiveMQ Artemis (the resources taken to sample a queue are not available to the system's
+     <p>The sample period and the max day history parameters have a small impact on the performance of ActiveMQ Artemis (the resources taken to sample a queue are not available to the system's
          normal use). You should set these parameters accordingly to the use and throughput of your messages.</p>
          
      <h2>Example step-by-step</h2>

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/b0a80ce1/examples/soak/normal/README
----------------------------------------------------------------------
diff --git a/examples/soak/normal/README b/examples/soak/normal/README
index 0a4dfe9..54ec245 100644
--- a/examples/soak/normal/README
+++ b/examples/soak/normal/README
@@ -22,7 +22,7 @@ system property (which defaults to server0). To run a 2nd server with a configur
 
    $ mvn verify -Pserver -Dserver.dir=server1
 
-server1 should contain a copy of configuration equivilent to that found under the server0 director with different
+server1 should contain a copy of configuration equivalent to that found under the server0 director with different
 settings.
 
 To run a server with the same configuration but on a different host.  Check out this source on the host machine and

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/b0a80ce1/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/JmsSessionRecoverTest.java
----------------------------------------------------------------------
diff --git a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/JmsSessionRecoverTest.java b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/JmsSessionRecoverTest.java
index a9e1b24..a6908a0 100644
--- a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/JmsSessionRecoverTest.java
+++ b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/JmsSessionRecoverTest.java
@@ -157,7 +157,7 @@ public class JmsSessionRecoverTest extends TestCase {
     }
 
     /**
-     * Test to make sure that a Async recover works.
+     * Test to make sure that an Async recover works.
      * 
      * @throws JMSException
      * @throws InterruptedException
@@ -226,7 +226,7 @@ public class JmsSessionRecoverTest extends TestCase {
     }
 
     /**
-     * Test to make sure that a Async recover works when using AUTO_ACKNOWLEDGE.
+     * Test to make sure that an Async recover works when using AUTO_ACKNOWLEDGE.
      * 
      * @throws JMSException
      * @throws InterruptedException

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/b0a80ce1/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/ProducerFlowControlSendFailTest.java
----------------------------------------------------------------------
diff --git a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/ProducerFlowControlSendFailTest.java b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/ProducerFlowControlSendFailTest.java
index c18eccd..12aa47d 100644
--- a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/ProducerFlowControlSendFailTest.java
+++ b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/ProducerFlowControlSendFailTest.java
@@ -58,17 +58,17 @@ public class ProducerFlowControlSendFailTest extends ProducerFlowControlTest {
     }
     
     @Override
-    public void test2ndPubisherWithStandardConnectionThatIsBlocked() throws Exception {
+    public void test2ndPublisherWithStandardConnectionThatIsBlocked() throws Exception {
         // with sendFailIfNoSpace set, there is no blocking of the connection
     }
     
     @Override
-    public void testAsyncPubisherRecoverAfterBlock() throws Exception {
+    public void testAsyncPublisherRecoverAfterBlock() throws Exception {
         // sendFail means no flowControllwindow as there is no producer ack, just an exception
     }
     
     @Override
-    public void testPubisherRecoverAfterBlock() throws Exception {
+    public void testPublisherRecoverAfterBlock() throws Exception {
         ActiveMQConnectionFactory factory = (ActiveMQConnectionFactory)createConnectionFactory();
         // with sendFail, there must be no flowControllwindow
         // sendFail is an alternative flow control mechanism that does not block
@@ -116,7 +116,7 @@ public class ProducerFlowControlSendFailTest extends ProducerFlowControlTest {
         keepGoing.set(false);
     }
 
-    public void testPubisherRecoverAfterBlockWithSyncSend() throws Exception {
+    public void testPublisherRecoverAfterBlockWithSyncSend() throws Exception {
         ActiveMQConnectionFactory factory = (ActiveMQConnectionFactory)createConnectionFactory();
         factory.setExceptionListener(null);
         factory.setUseAsyncSend(false);

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/b0a80ce1/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/ProducerFlowControlTest.java
----------------------------------------------------------------------
diff --git a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/ProducerFlowControlTest.java b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/ProducerFlowControlTest.java
index 70e15ec..a79e738 100644
--- a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/ProducerFlowControlTest.java
+++ b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/ProducerFlowControlTest.java
@@ -49,7 +49,7 @@ public class ProducerFlowControlTest extends JmsTestSupport {
     // used to test sendFailIfNoSpace on SystemUsage 
     protected final AtomicBoolean gotResourceException = new AtomicBoolean(false);
 
-    public void test2ndPubisherWithProducerWindowSendConnectionThatIsBlocked() throws Exception {
+    public void test2ndPublisherWithProducerWindowSendConnectionThatIsBlocked() throws Exception {
         ActiveMQConnectionFactory factory = (ActiveMQConnectionFactory)createConnectionFactory();
         factory.setProducerWindowSize(1024 * 64);
         connection = (ActiveMQConnection)factory.createConnection();
@@ -80,7 +80,7 @@ public class ProducerFlowControlTest extends JmsTestSupport {
         msg.acknowledge();
     }
 
-    public void testPubisherRecoverAfterBlock() throws Exception {
+    public void testPublisherRecoverAfterBlock() throws Exception {
         ActiveMQConnectionFactory factory = (ActiveMQConnectionFactory)createConnectionFactory();
         connection = (ActiveMQConnection)factory.createConnection();
         connections.add(connection);
@@ -125,7 +125,7 @@ public class ProducerFlowControlTest extends JmsTestSupport {
 		assertFalse("producer has resumed", done.get());
     }
 
-    public void testAsyncPubisherRecoverAfterBlock() throws Exception {
+    public void testAsyncPublisherRecoverAfterBlock() throws Exception {
         ActiveMQConnectionFactory factory = (ActiveMQConnectionFactory)createConnectionFactory();
         factory.setProducerWindowSize(1024 * 5);
         factory.setUseAsyncSend(true);
@@ -173,7 +173,7 @@ public class ProducerFlowControlTest extends JmsTestSupport {
         assertFalse("producer has resumed", done.get());
     }
 
-    public void test2ndPubisherWithSyncSendConnectionThatIsBlocked() throws Exception {
+    public void test2ndPublisherWithSyncSendConnectionThatIsBlocked() throws Exception {
         ActiveMQConnectionFactory factory = (ActiveMQConnectionFactory)createConnectionFactory();
         factory.setAlwaysSyncSend(true);
         connection = (ActiveMQConnection)factory.createConnection();
@@ -229,7 +229,7 @@ public class ProducerFlowControlTest extends JmsTestSupport {
         msg.acknowledge();
     }
 
-    public void test2ndPubisherWithStandardConnectionThatIsBlocked() throws Exception {
+    public void test2ndPublisherWithStandardConnectionThatIsBlocked() throws Exception {
         ConnectionFactory factory = createConnectionFactory();
         connection = (ActiveMQConnection)factory.createConnection();
         connections.add(connection);

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/b0a80ce1/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/TimeStampTest.java
----------------------------------------------------------------------
diff --git a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/TimeStampTest.java b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/TimeStampTest.java
index 2ec57b5..448bd3c 100644
--- a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/TimeStampTest.java
+++ b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/TimeStampTest.java
@@ -85,7 +85,7 @@ public class TimeStampTest extends TestCase {
                                                                                                             && receivedMessage.getJMSTimestamp() <= afterSend);
 
         // assert message timestamp is unchanged
-        assertEquals("JMS Message Timestamp of recieved message should be the same as the sent message\n        ", sentMessage.getJMSTimestamp(), receivedMessage.getJMSTimestamp());
+        assertEquals("JMS Message Timestamp of received message should be the same as the sent message\n        ", sentMessage.getJMSTimestamp(), receivedMessage.getJMSTimestamp());
 
         // Clean up
         producer.close();

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/b0a80ce1/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/broker/BrokerTest.java
----------------------------------------------------------------------
diff --git a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/broker/BrokerTest.java b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/broker/BrokerTest.java
index 2facb98..fc3438e 100644
--- a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/broker/BrokerTest.java
+++ b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/broker/BrokerTest.java
@@ -758,7 +758,7 @@ public class BrokerTest extends BrokerTestSupport {
 
     //
     // TODO: need to reimplement this since we don't fail when we send to a
-    // non-existant
+    // non-existent
     // destination. But if we can access the Region directly then we should be
     // able to
     // check that if the destination was removed.
@@ -843,7 +843,7 @@ public class BrokerTest extends BrokerTestSupport {
     // ActiveMQDestination.createDestination(connectionInfo1.getConnectionId()+":1",
     // destinationType);
     //            
-    // // Should not be able to send to a non-existant temp destination.
+    // // Should not be able to send to a non-existent temp destination.
     // try {
     // connection1.request(createMessage(producerInfo1, destination,
     // deliveryMode));

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/b0a80ce1/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/broker/RecoveryBrokerTest.java
----------------------------------------------------------------------
diff --git a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/broker/RecoveryBrokerTest.java b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/broker/RecoveryBrokerTest.java
index 491a585..e563063 100644
--- a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/broker/RecoveryBrokerTest.java
+++ b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/broker/RecoveryBrokerTest.java
@@ -358,7 +358,7 @@ public class RecoveryBrokerTest extends BrokerRestartTestSupport {
         assertNoMessagesLeft(connection);
     }
 
-    public void testQueuePersistentCommitedMessagesNotLostOnRestart() throws Exception {
+    public void testQueuePersistentCommittedMessagesNotLostOnRestart() throws Exception {
 
         ActiveMQDestination destination = new ActiveMQQueue("TEST");
 
@@ -406,7 +406,7 @@ public class RecoveryBrokerTest extends BrokerRestartTestSupport {
     }
     
 
-    public void testQueuePersistentCommitedAcksNotLostOnRestart() throws Exception {
+    public void testQueuePersistentCommittedAcksNotLostOnRestart() throws Exception {
 
         ActiveMQDestination destination = new ActiveMQQueue("TEST");
 

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/b0a80ce1/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/broker/XARecoveryBrokerTest.java
----------------------------------------------------------------------
diff --git a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/broker/XARecoveryBrokerTest.java b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/broker/XARecoveryBrokerTest.java
index 2c41673..6c25796 100644
--- a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/broker/XARecoveryBrokerTest.java
+++ b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/broker/XARecoveryBrokerTest.java
@@ -455,7 +455,7 @@ public class XARecoveryBrokerTest extends BrokerRestartTestSupport {
 
     }
 
-    public void testQueuePersistentCommitedMessagesNotLostOnRestart() throws Exception {
+    public void testQueuePersistentCommittedMessagesNotLostOnRestart() throws Exception {
 
         ActiveMQDestination destination = createDestination();
 
@@ -502,7 +502,7 @@ public class XARecoveryBrokerTest extends BrokerRestartTestSupport {
         assertNoMessagesLeft(connection);
     }
 
-    public void testQueuePersistentCommited2PhaseMessagesNotLostOnRestart() throws Exception {
+    public void testQueuePersistentCommitted2PhaseMessagesNotLostOnRestart() throws Exception {
 
         ActiveMQDestination destination = createDestination();
 
@@ -551,7 +551,7 @@ public class XARecoveryBrokerTest extends BrokerRestartTestSupport {
         assertNoMessagesLeft(connection);
     }
 
-    public void testQueuePersistentCommitedAcksNotLostOnRestart() throws Exception {
+    public void testQueuePersistentCommittedAcksNotLostOnRestart() throws Exception {
 
         ActiveMQDestination destination = createDestination();
 
@@ -691,8 +691,8 @@ public class XARecoveryBrokerTest extends BrokerRestartTestSupport {
         dataArrayResponse = (DataArrayResponse)connection.request(recoverInfo);
         assertEquals("there are no prepared tx", 0, dataArrayResponse.getData().length);
 
-        assertEquals("enqueue count does not see commited acks", 0, destinationView.getQueueSize());
-        assertEquals("enqueue count does not see commited acks", 4, destinationView.getDequeueCount());
+        assertEquals("enqueue count does not see committed acks", 0, destinationView.getQueueSize());
+        assertEquals("enqueue count does not see committed acks", 4, destinationView.getDequeueCount());
 
     }
 

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/b0a80ce1/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/broker/jmx/BrokerViewSlowStoreStartupTest.java
----------------------------------------------------------------------
diff --git a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/broker/jmx/BrokerViewSlowStoreStartupTest.java b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/broker/jmx/BrokerViewSlowStoreStartupTest.java
index 6910bed..cf1b767 100644
--- a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/broker/jmx/BrokerViewSlowStoreStartupTest.java
+++ b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/broker/jmx/BrokerViewSlowStoreStartupTest.java
@@ -278,13 +278,13 @@ public class BrokerViewSlowStoreStartupTest {
 
         try {
             view.removeConnector("tcp");
-            fail("Should have thrown an NoSuchElementException");
+            fail("Should have thrown a NoSuchElementException");
         } catch(NoSuchElementException e) {
         }
 
         try {
             view.removeNetworkConnector("tcp");
-            fail("Should have thrown an NoSuchElementException");
+            fail("Should have thrown a NoSuchElementException");
         } catch(NoSuchElementException e) {
         }
 

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/b0a80ce1/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/broker/jmx/MBeanTest.java
----------------------------------------------------------------------
diff --git a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/broker/jmx/MBeanTest.java b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/broker/jmx/MBeanTest.java
index e2b0c51..b679313 100644
--- a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/broker/jmx/MBeanTest.java
+++ b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/broker/jmx/MBeanTest.java
@@ -299,7 +299,7 @@ public class MBeanTest extends EmbeddedBrokerTestSupport {
         long queueSize = queue.getQueueSize();
         compdatalist = queue.browse();
         int actualCount = compdatalist.length;
-        echo("Orginal queue size is now " + queueSize);
+        echo("Original queue size is now " + queueSize);
         echo("Original browse queue size: " + actualCount);
 
         long dlqSize = dlq.getQueueSize();

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/b0a80ce1/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/broker/scheduler/JobSchedulerTest.java
----------------------------------------------------------------------
diff --git a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/broker/scheduler/JobSchedulerTest.java b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/broker/scheduler/JobSchedulerTest.java
index b84a782..bc0fab7 100644
--- a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/broker/scheduler/JobSchedulerTest.java
+++ b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/broker/scheduler/JobSchedulerTest.java
@@ -192,7 +192,7 @@ public class JobSchedulerTest {
         scheduler.addListener(new JobListener() {
             @Override
             public void scheduledJob(String id, ByteSequence job) {
-                LOG.info("Job exectued: {}", 11 - done.getCount());
+                LOG.info("Job executed: {}", 11 - done.getCount());
                 done.countDown();
             }
         });

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/b0a80ce1/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/broker/virtual/VirtualTopicDLQTest.java
----------------------------------------------------------------------
diff --git a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/broker/virtual/VirtualTopicDLQTest.java b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/broker/virtual/VirtualTopicDLQTest.java
index 7c853cf..f81ca71 100644
--- a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/broker/virtual/VirtualTopicDLQTest.java
+++ b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/broker/virtual/VirtualTopicDLQTest.java
@@ -374,7 +374,7 @@ public class VirtualTopicDLQTest extends TestCase {
 
         public synchronized void onException(JMSException ex) {
             ex.printStackTrace();
-            LOG.error("Consumer for destination, (" + destinationName + "), JMS Exception occured.  Shutting down client.");
+            LOG.error("Consumer for destination, (" + destinationName + "), JMS Exception occurred.  Shutting down client.");
         }
 
         public synchronized void setStop(boolean bStop) {

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/b0a80ce1/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/bugs/AMQ1853Test.java
----------------------------------------------------------------------
diff --git a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/bugs/AMQ1853Test.java b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/bugs/AMQ1853Test.java
index a3c3b1d..5169348 100644
--- a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/bugs/AMQ1853Test.java
+++ b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/bugs/AMQ1853Test.java
@@ -311,7 +311,7 @@ public class AMQ1853Test {
         }
 
         public synchronized void onException(JMSException ex) {
-            LOG.error("Consumer for destination, (" + destinationName + "), JMS Exception occured.  Shutting down client.");
+            LOG.error("Consumer for destination, (" + destinationName + "), JMS Exception occurred.  Shutting down client.");
         }
 
         public synchronized void setStop(boolean bStop) {

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/b0a80ce1/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/bugs/AMQ1917Test.java
----------------------------------------------------------------------
diff --git a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/bugs/AMQ1917Test.java b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/bugs/AMQ1917Test.java
index f896342..ad99707 100644
--- a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/bugs/AMQ1917Test.java
+++ b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/bugs/AMQ1917Test.java
@@ -83,7 +83,7 @@ public class AMQ1917Test extends TestCase {
             tpe.shutdown();
         }
 
-        public void testLoadedSendRecieveWithCorrelationId() throws Exception {
+        public void testLoadedSendReceiveWithCorrelationId() throws Exception {
 
             ActiveMQConnectionFactory connectionFactory = new org.apache.activemq.ActiveMQConnectionFactory();
             connectionFactory.setBrokerURL(connectionUri);

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/b0a80ce1/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/bugs/AMQ1936Test.java
----------------------------------------------------------------------
diff --git a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/bugs/AMQ1936Test.java b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/bugs/AMQ1936Test.java
index 2c86562..16cbcc0 100644
--- a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/bugs/AMQ1936Test.java
+++ b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/bugs/AMQ1936Test.java
@@ -45,7 +45,7 @@ import org.apache.activemq.util.Wait;
 import org.apache.log4j.Logger;
 
 /**
- * A AMQ1936Test
+ * AMQ1936Test
  *
  */
 public class AMQ1936Test extends TestCase {

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/b0a80ce1/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/bugs/AMQ2149Test.java
----------------------------------------------------------------------
diff --git a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/bugs/AMQ2149Test.java b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/bugs/AMQ2149Test.java
index f172a91..49903ef 100644
--- a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/bugs/AMQ2149Test.java
+++ b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/bugs/AMQ2149Test.java
@@ -340,7 +340,7 @@ public class AMQ2149Test {
         int batch = 200;
         long expectedSeq;
 
-        final TimerTask restartTask = schedualRestartTask(null, new Configurer() {
+        final TimerTask restartTask = scheduleRestartTask(null, new Configurer() {
             public void configure(BrokerService broker) throws Exception {
             }
         });
@@ -385,7 +385,7 @@ public class AMQ2149Test {
         });
 
         final Timer timer = new Timer();
-        schedualRestartTask(timer, new Configurer() {
+        scheduleRestartTask(timer, new Configurer() {
             public void configure(BrokerService broker) throws Exception {
             }
         });
@@ -408,7 +408,7 @@ public class AMQ2149Test {
         });
 
         final Timer timer = new Timer();
-        schedualRestartTask(timer, null);
+        scheduleRestartTask(timer, null);
 
         try {
             verifyOrderedMessageReceipt(ActiveMQDestination.TOPIC_TYPE);
@@ -441,7 +441,7 @@ public class AMQ2149Test {
         });
 
         final Timer timer = new Timer();
-        schedualRestartTask(timer, null);
+        scheduleRestartTask(timer, null);
 
         try {
             verifyOrderedMessageReceipt(destinationType, 1, true);
@@ -470,7 +470,7 @@ public class AMQ2149Test {
         }
     }
 
-    private TimerTask schedualRestartTask(final Timer timer, final Configurer configurer) {
+    private TimerTask scheduleRestartTask(final Timer timer, final Configurer configurer) {
         class RestartTask extends TimerTask {
             public void run() {
                 synchronized (brokerLock) {

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/b0a80ce1/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/bugs/AMQ2356Test.java
----------------------------------------------------------------------
diff --git a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/bugs/AMQ2356Test.java b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/bugs/AMQ2356Test.java
index 283dd92..fb6169d 100644
--- a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/bugs/AMQ2356Test.java
+++ b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/bugs/AMQ2356Test.java
@@ -37,7 +37,7 @@ import org.apache.activemq.command.ActiveMQQueue;
 import org.apache.activemq.store.kahadb.KahaDBStore;
 
 /*
- A AMQ2356Test
+ AMQ2356Test
  We have an environment where we have a very large number of destinations.
  In an effort to reduce the number of threads I have set the options
  -Dorg.apache.activemq.UseDedicatedTaskRunner=false

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/b0a80ce1/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/bugs/AMQ2832Test.java
----------------------------------------------------------------------
diff --git a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/bugs/AMQ2832Test.java b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/bugs/AMQ2832Test.java
index 22ad6ab..0bec264 100644
--- a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/bugs/AMQ2832Test.java
+++ b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/bugs/AMQ2832Test.java
@@ -101,7 +101,7 @@ public class AMQ2832Test {
         // ensure there are a bunch of data files but multiple entries in each
         adapter.setJournalMaxFileLength(1024 * 20);
 
-        // speed up the test case, checkpoint an cleanup early and often
+        // speed up the test case, checkpoint and cleanup early and often
         adapter.setCheckpointInterval(5000);
         adapter.setCleanupInterval(5000);
 

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/b0a80ce1/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/bugs/AMQ3014Test.java
----------------------------------------------------------------------
diff --git a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/bugs/AMQ3014Test.java b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/bugs/AMQ3014Test.java
index dcd5064..5f1c3e9 100644
--- a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/bugs/AMQ3014Test.java
+++ b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/bugs/AMQ3014Test.java
@@ -41,7 +41,7 @@ import org.junit.Test;
  * This test involves the creation of a local and remote broker, both of which
  * communicate over VM and TCP. The local broker establishes a bridge to the
  * remote broker for the purposes of verifying that broker info is only
- * transfered once the local broker's ID is known to the bridge support.
+ * transferred once the local broker's ID is known to the bridge support.
  */
 public class AMQ3014Test {
     // Change this URL to be an unused port.

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/b0a80ce1/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/bugs/AMQ3120Test.java
----------------------------------------------------------------------
diff --git a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/bugs/AMQ3120Test.java b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/bugs/AMQ3120Test.java
index bfff0fd..f61883b 100644
--- a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/bugs/AMQ3120Test.java
+++ b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/bugs/AMQ3120Test.java
@@ -74,7 +74,7 @@ public class AMQ3120Test {
         // ensure there are a bunch of data files but multiple entries in each
         adapter.setJournalMaxFileLength(1024 * 20);
 
-        // speed up the test case, checkpoint an cleanup early and often
+        // speed up the test case, checkpoint and cleanup early and often
         adapter.setCheckpointInterval(500);
         adapter.setCleanupInterval(500);
 

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/b0a80ce1/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/bugs/AMQ3674Test.java
----------------------------------------------------------------------
diff --git a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/bugs/AMQ3674Test.java b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/bugs/AMQ3674Test.java
index 47ab754..026bf11 100644
--- a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/bugs/AMQ3674Test.java
+++ b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/bugs/AMQ3674Test.java
@@ -73,7 +73,7 @@ public class AMQ3674Test {
             brokerView.destroyDurableSubscriber("subscriber1", "myTopic");
             fail("Expected Exception for Durable consumer is in use");
         } catch(Exception e) {
-            LOG.info("Recieved expected exception: " + e.getMessage());
+            LOG.info("Received expected exception: " + e.getMessage());
         }
 
         LOG.info("Current Durable Topic Subscriptions: " + brokerView.getDurableTopicSubscribers().length);

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/b0a80ce1/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/bugs/AMQ4062Test.java
----------------------------------------------------------------------
diff --git a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/bugs/AMQ4062Test.java b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/bugs/AMQ4062Test.java
index a567455..222efc7 100644
--- a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/bugs/AMQ4062Test.java
+++ b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/bugs/AMQ4062Test.java
@@ -130,7 +130,7 @@ public class AMQ4062Test {
     public void testDirableSubPrefetchRecovered() throws Exception{
 
         PrefetchConsumer consumer=new PrefetchConsumer(true, connectionUri);
-        consumer.recieve();
+        consumer.receive();
         durableSubscriptions=getDurableSubscriptions();
         ConsumerInfo info=getConsumerInfo(durableSubscriptions);
 
@@ -159,7 +159,7 @@ public class AMQ4062Test {
         //assertEquals(0, info.getPrefetchSize());
 
         consumer=new PrefetchConsumer(false, connectionUri);
-        consumer.recieve();
+        consumer.receive();
         consumer.a.countDown();
 
         info=null;
@@ -213,7 +213,7 @@ public class AMQ4062Test {
             this.uri = uri;
         }
 
-        public void recieve() throws Exception{
+        public void receive() throws Exception{
             ActiveMQConnectionFactory connectionFactory = new ActiveMQConnectionFactory(user, password, uri);
             connection = (ActiveMQConnection)connectionFactory.createConnection();
             connection.setClientID("3");

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/b0a80ce1/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/bugs/AMQ4323Test.java
----------------------------------------------------------------------
diff --git a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/bugs/AMQ4323Test.java b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/bugs/AMQ4323Test.java
index 8e6a96f..594e92f 100644
--- a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/bugs/AMQ4323Test.java
+++ b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/bugs/AMQ4323Test.java
@@ -78,7 +78,7 @@ public class AMQ4323Test {
         // ensure there are a bunch of data files but multiple entries in each
         adapter.setJournalMaxFileLength(1024 * 20);
 
-        // speed up the test case, checkpoint an cleanup early and often
+        // speed up the test case, checkpoint and cleanup early and often
         adapter.setCheckpointInterval(500);
         adapter.setCleanupInterval(500);
 

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/b0a80ce1/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/bugs/AMQ4504Test.java
----------------------------------------------------------------------
diff --git a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/bugs/AMQ4504Test.java b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/bugs/AMQ4504Test.java
index 64204bd..6041a89 100644
--- a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/bugs/AMQ4504Test.java
+++ b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/bugs/AMQ4504Test.java
@@ -73,7 +73,7 @@ public class AMQ4504Test {
         MessageConsumer consumer = connection.createSession(false, Session.AUTO_ACKNOWLEDGE).createConsumer(activeMQQueue);
         try {
             for (int i=0; i< numMessages * numDests; i++) {
-                assertNotNull("recieved:"  + i, consumer.receive(4000));
+                assertNotNull("received:"  + i, consumer.receive(4000));
             }
         } finally {
             connection.close();

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/b0a80ce1/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/bugs/MemoryUsageBlockResumeTest.java
----------------------------------------------------------------------
diff --git a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/bugs/MemoryUsageBlockResumeTest.java b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/bugs/MemoryUsageBlockResumeTest.java
index e8d5371..5ac2dc0 100644
--- a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/bugs/MemoryUsageBlockResumeTest.java
+++ b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/bugs/MemoryUsageBlockResumeTest.java
@@ -158,7 +158,7 @@ public class MemoryUsageBlockResumeTest extends TestSupport implements Thread.Un
 
         for (;count < 10; count++) {
             assertTrue((m = consumer.receive(messageReceiveTimeout)) != null);
-            LOG.info("Recieved Message (" + count + "):" + m + ", System Memory Usage " + broker.getSystemUsage().getMemoryUsage().getPercentUsage());
+            LOG.info("Received Message (" + count + "):" + m + ", System Memory Usage " + broker.getSystemUsage().getMemoryUsage().getPercentUsage());
             messagesConsumed.incrementAndGet();
         }
         consumer.close();
@@ -172,7 +172,7 @@ public class MemoryUsageBlockResumeTest extends TestSupport implements Thread.Un
         consumer = consumerSession.createConsumer(destination);
         for (count = 0;count < toSend*2; count++) {
             assertTrue((m = consumer.receive(messageReceiveTimeout)) != null);
-            LOG.info("Recieved Message (" + count + "):" + m + ", System Memory Usage " + broker.getSystemUsage().getMemoryUsage().getPercentUsage() );
+            LOG.info("Received Message (" + count + "):" + m + ", System Memory Usage " + broker.getSystemUsage().getMemoryUsage().getPercentUsage() );
             messagesConsumed.incrementAndGet();
         }
 

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/b0a80ce1/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/bugs/MemoryUsageCleanupTest.java
----------------------------------------------------------------------
diff --git a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/bugs/MemoryUsageCleanupTest.java b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/bugs/MemoryUsageCleanupTest.java
index e7feb90..017e070 100644
--- a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/bugs/MemoryUsageCleanupTest.java
+++ b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/bugs/MemoryUsageCleanupTest.java
@@ -113,7 +113,7 @@ public class MemoryUsageCleanupTest {
     public void testIt() throws Exception {
 
         final int startPercentage = broker.getAdminView().getMemoryPercentUsage();
-        LOG.info("MemoryUseage at test start = " + startPercentage);
+        LOG.info("MemoryUsage at test start = " + startPercentage);
 
         for (int i = 0; i < 2; i++) {
             LOG.info("Started the test iteration: " + i + " using queueName = " + queueName);
@@ -144,7 +144,7 @@ public class MemoryUsageCleanupTest {
             TimeUnit.SECONDS.sleep(2);
         }
 
-        LOG.info("MemoryUseage before awaiting temp store cleanup = " + broker.getAdminView().getMemoryPercentUsage());
+        LOG.info("MemoryUsage before awaiting temp store cleanup = " + broker.getAdminView().getMemoryPercentUsage());
 
         assertTrue("MemoryUsage should return to: " + startPercentage +
                    "% but was " + broker.getAdminView().getMemoryPercentUsage() + "%", Wait.waitFor(new Wait.Condition() {
@@ -156,7 +156,7 @@ public class MemoryUsageCleanupTest {
         }));
 
         int endPercentage = broker.getAdminView().getMemoryPercentUsage();
-        LOG.info("MemoryUseage at test end = " + endPercentage);
+        LOG.info("MemoryUsage at test end = " + endPercentage);
     }
 
     public void destroyQueue() {

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/b0a80ce1/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/bugs/OptimizeAcknowledgeWithExpiredMsgsTest.java
----------------------------------------------------------------------
diff --git a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/bugs/OptimizeAcknowledgeWithExpiredMsgsTest.java b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/bugs/OptimizeAcknowledgeWithExpiredMsgsTest.java
index 195ccbd..43f332b 100644
--- a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/bugs/OptimizeAcknowledgeWithExpiredMsgsTest.java
+++ b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/bugs/OptimizeAcknowledgeWithExpiredMsgsTest.java
@@ -306,7 +306,7 @@ public class OptimizeAcknowledgeWithExpiredMsgsTest {
         }
 
         public synchronized void onException(JMSException ex) {
-            LOG.error("JMS Exception occured.  Shutting down client.");
+            LOG.error("JMS Exception occurred.  Shutting down client.");
         }
     }
 }

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/b0a80ce1/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/bugs/TempStorageBlockedBrokerTest.java
----------------------------------------------------------------------
diff --git a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/bugs/TempStorageBlockedBrokerTest.java b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/bugs/TempStorageBlockedBrokerTest.java
index 066fb07..b78cd77 100644
--- a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/bugs/TempStorageBlockedBrokerTest.java
+++ b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/bugs/TempStorageBlockedBrokerTest.java
@@ -117,7 +117,7 @@ public class TempStorageBlockedBrokerTest extends TestSupport {
         while ((m = consumer.receive(messageReceiveTimeout)) != null) {
             count++;
             if (count != 0 && count%10 == 0) {
-                LOG.info("Recieved Message (" + count + "):" + m);
+                LOG.info("Received Message (" + count + "):" + m);
             }
             messagesConsumed.incrementAndGet();
             try {
@@ -132,7 +132,7 @@ public class TempStorageBlockedBrokerTest extends TestSupport {
         while ((m = consumer.receive(messageReceiveTimeout)) != null) {
             count++;
             if (count != 0 && count%100 == 0) {
-                LOG.info("Recieved Message (" + count + "):" + m);
+                LOG.info("Received Message (" + count + "):" + m);
             }
             messagesConsumed.incrementAndGet();
             try {

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/b0a80ce1/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/bugs/TempStoreDataCleanupTest.java
----------------------------------------------------------------------
diff --git a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/bugs/TempStoreDataCleanupTest.java b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/bugs/TempStoreDataCleanupTest.java
index 34df4a3..455f6ba 100644
--- a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/bugs/TempStoreDataCleanupTest.java
+++ b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/bugs/TempStoreDataCleanupTest.java
@@ -160,7 +160,7 @@ public class TempStoreDataCleanupTest {
         );
 
         int endPercentage = broker.getAdminView().getMemoryPercentUsage();
-        LOG.info("MemoryUseage at test end = " + endPercentage);
+        LOG.info("MemoryUsage at test end = " + endPercentage);
 
         assertEquals(startPercentage, endPercentage);
     }

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/b0a80ce1/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/network/CheckDuplicateMessagesOnDuplexTest.java
----------------------------------------------------------------------
diff --git a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/network/CheckDuplicateMessagesOnDuplexTest.java b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/network/CheckDuplicateMessagesOnDuplexTest.java
index 68681c6..e0b5cd5 100644
--- a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/network/CheckDuplicateMessagesOnDuplexTest.java
+++ b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/network/CheckDuplicateMessagesOnDuplexTest.java
@@ -177,7 +177,7 @@ public class CheckDuplicateMessagesOnDuplexTest {
         ManagementContext managementContext = new ManagementContext();
         managementContext.setCreateConnector(false);
         localBroker.setManagementContext(managementContext);
-        PersistenceAdapter persistenceAdapter = persistanceAdapterFactory("target/local");
+        PersistenceAdapter persistenceAdapter = persistenceAdapterFactory("target/local");
         localBroker.setPersistenceAdapter(persistenceAdapter);
         List<TransportConnector> transportConnectors = new ArrayList<TransportConnector>();
         DebugTransportFactory tf = new DebugTransportFactory();
@@ -197,7 +197,7 @@ public class CheckDuplicateMessagesOnDuplexTest {
         ManagementContext managementContext = new ManagementContext();
         managementContext.setCreateConnector(false);
         remoteBroker.setManagementContext(managementContext);
-        PersistenceAdapter persistenceAdapter = persistanceAdapterFactory("target/remote");
+        PersistenceAdapter persistenceAdapter = persistenceAdapterFactory("target/remote");
         remoteBroker.setPersistenceAdapter(persistenceAdapter);
         List<NetworkConnector> networkConnectors = new ArrayList<NetworkConnector>();
         DiscoveryNetworkConnector networkConnector = new DiscoveryNetworkConnector();
@@ -281,15 +281,15 @@ public class CheckDuplicateMessagesOnDuplexTest {
         remoteBroker.waitUntilStopped();
     }
 
-    private PersistenceAdapter persistanceAdapterFactory(String path) {
+    private PersistenceAdapter persistenceAdapterFactory(String path) {
         if (useLevelDB) {
-            return persistanceAdapterFactory_LevelDB(path);
+            return persistenceAdapterFactory_LevelDB(path);
         } else {
-            return persistanceAdapterFactory_KahaDB(path);
+            return persistenceAdapterFactory_KahaDB(path);
         }
     }
 
-    private PersistenceAdapter persistanceAdapterFactory_KahaDB(String path) {
+    private PersistenceAdapter persistenceAdapterFactory_KahaDB(String path) {
         KahaDBPersistenceAdapter kahaDBPersistenceAdapter = new KahaDBPersistenceAdapter();
         kahaDBPersistenceAdapter.setDirectory(new File(path));
         kahaDBPersistenceAdapter.setIgnoreMissingJournalfiles(true);
@@ -298,7 +298,7 @@ public class CheckDuplicateMessagesOnDuplexTest {
         return kahaDBPersistenceAdapter;
     }
 
-    private PersistenceAdapter persistanceAdapterFactory_LevelDB(String path) {
+    private PersistenceAdapter persistenceAdapterFactory_LevelDB(String path) {
         LevelDBPersistenceAdapter levelDBPersistenceAdapter = new LevelDBPersistenceAdapter();
         levelDBPersistenceAdapter.setDirectory(new File(path));
         return levelDBPersistenceAdapter;
@@ -353,4 +353,4 @@ public class CheckDuplicateMessagesOnDuplexTest {
             super.oneway(command);
         }
     }
-}
\ No newline at end of file
+}

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/b0a80ce1/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/network/NetworkFailoverTest.java
----------------------------------------------------------------------
diff --git a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/network/NetworkFailoverTest.java b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/network/NetworkFailoverTest.java
index b16dde0..b695b8c 100644
--- a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/network/NetworkFailoverTest.java
+++ b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/network/NetworkFailoverTest.java
@@ -116,7 +116,7 @@ public class NetworkFailoverTest extends TestCase {
             }
         });
 
-        // allow for consumer infos to perculate arround
+        // allow for consumer infos to perculate around
         Thread.sleep(2000);
         long done = System.currentTimeMillis() + (MESSAGE_COUNT * 6000);
         int i = 0;

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/b0a80ce1/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/network/NetworkLoadTest.java
----------------------------------------------------------------------
diff --git a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/network/NetworkLoadTest.java b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/network/NetworkLoadTest.java
index 31d2a07..17a0f23 100644
--- a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/network/NetworkLoadTest.java
+++ b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/network/NetworkLoadTest.java
@@ -57,7 +57,7 @@ import org.slf4j.LoggerFactory;
  * 
  * If the network bridges gets stuck at any point subsequent queues will not get messages.  This test 
  * samples the production and consumption stats every second and if the flow of messages
- * get stuck then this tast fails.  The test monitors the flow of messages for 1 min.
+ * get stuck then this test fails.  The test monitors the flow of messages for 1 min.
  *  
  * @author chirino
  */
@@ -319,7 +319,7 @@ public class NetworkLoadTest extends TestCase {
 
             // The test is just checking to make sure thaat the producer and consumer does not hang
             // due to the network hops take to route the message form the producer to the consumer.
-            assertTrue("Recieved some messages since last sample", r>0);
+            assertTrue("Received some messages since last sample", r>0);
             assertTrue("Produced some messages since last sample", p>0);
             
         }

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/b0a80ce1/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/network/SimpleNetworkTest.java
----------------------------------------------------------------------
diff --git a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/network/SimpleNetworkTest.java b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/network/SimpleNetworkTest.java
index 62385cb..17de21a 100644
--- a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/network/SimpleNetworkTest.java
+++ b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/network/SimpleNetworkTest.java
@@ -120,7 +120,7 @@ public class SimpleNetworkTest {
         });
 
         TopicRequestor requestor = new TopicRequestor((TopicSession)localSession, included);
-        // allow for consumer infos to perculate arround
+        // allow for consumer infos to perculate around
         Thread.sleep(5000);
         for (int i = 0; i < MESSAGE_COUNT; i++) {
             TextMessage msg = localSession.createTextMessage("test msg: " + i);
@@ -136,7 +136,7 @@ public class SimpleNetworkTest {
         MessageConsumer excludedConsumer = remoteSession.createConsumer(excluded);
         MessageProducer includedProducer = localSession.createProducer(included);
         MessageProducer excludedProducer = localSession.createProducer(excluded);
-        // allow for consumer infos to perculate arround
+        // allow for consumer infos to perculate around
         Thread.sleep(2000);
         Message test = localSession.createTextMessage("test");
         includedProducer.send(test);

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/b0a80ce1/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/transport/SoWriteTimeoutTest.java
----------------------------------------------------------------------
diff --git a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/transport/SoWriteTimeoutTest.java b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/transport/SoWriteTimeoutTest.java
index 6f05658..497da3a 100644
--- a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/transport/SoWriteTimeoutTest.java
+++ b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/transport/SoWriteTimeoutTest.java
@@ -85,7 +85,7 @@ public class SoWriteTimeoutTest extends JmsTestSupport {
         Session session = c.createSession(true, Session.SESSION_TRANSACTED);
         MessageConsumer consumer = session.createConsumer(dest);
         proxy.pause();
-        // writes should back up... writeTimeout will kick in a abort the connection
+        // writes should back up... writeTimeout will kick in and abort the connection
         TimeUnit.SECONDS.sleep(10);
         proxy.goOn();
         assertNotNull("can receive buffered messages", consumer.receive(500));
@@ -127,7 +127,7 @@ public class SoWriteTimeoutTest extends JmsTestSupport {
 
         proxy.pause();
 
-        // writes should back up... writeTimeout will kick in a abort the connection
+        // writes should back up... writeTimeout will kick in and abort the connection
         TimeUnit.SECONDS.sleep(1);
 
         // see the blocked threads

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/b0a80ce1/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/transport/failover/FailoverConsumerOutstandingCommitTest.java
----------------------------------------------------------------------
diff --git a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/transport/failover/FailoverConsumerOutstandingCommitTest.java b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/transport/failover/FailoverConsumerOutstandingCommitTest.java
index 9c08c81..c5d39d9 100644
--- a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/transport/failover/FailoverConsumerOutstandingCommitTest.java
+++ b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/transport/failover/FailoverConsumerOutstandingCommitTest.java
@@ -182,7 +182,7 @@ public class FailoverConsumerOutstandingCommitTest {
         broker.start();
 
         assertTrue("consumer added through failover", commitDoneLatch.await(20, TimeUnit.SECONDS));
-        assertTrue("another message was recieved after failover", messagesReceived.await(20, TimeUnit.SECONDS));
+        assertTrue("another message was received after failover", messagesReceived.await(20, TimeUnit.SECONDS));
 
         connection.close();
     }

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/b0a80ce1/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/transport/failover/FailoverTransactionTest.java
----------------------------------------------------------------------
diff --git a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/transport/failover/FailoverTransactionTest.java b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/transport/failover/FailoverTransactionTest.java
index 9b41713..4270eea 100644
--- a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/transport/failover/FailoverTransactionTest.java
+++ b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/transport/failover/FailoverTransactionTest.java
@@ -494,7 +494,7 @@ public class FailoverTransactionTest extends TestSupport {
             // duplicate checker not updated on canceled tasks, even it
             // it was, recovery of the audit would fail as the message is
             // not recorded in the store and the audit may not be up to date.
-            // So if duplicate messages are a absolute no no after restarts,
+            // So if duplicate messages are an absolute no no after restarts,
             // ConcurrentStoreAndDispatchQueues must be disabled
             ((KahaDBPersistenceAdapter) store).setConcurrentStoreAndDispatchQueues(false);
         }

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/b0a80ce1/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/transport/tcp/InactivityMonitorTest.java
----------------------------------------------------------------------
diff --git a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/transport/tcp/InactivityMonitorTest.java b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/transport/tcp/InactivityMonitorTest.java
index 919c5da..05acaf4 100644
--- a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/transport/tcp/InactivityMonitorTest.java
+++ b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/transport/tcp/InactivityMonitorTest.java
@@ -216,7 +216,7 @@ public class InactivityMonitorTest extends CombinationTestSupport implements Tra
     }
 
     /**
-     * Used to test when a operation blocks. This should not cause transport to
+     * Used to test when an operation blocks. This should not cause transport to
      * get disconnected.
      *
      * @throws Exception

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/b0a80ce1/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/transport/tcp/WireformatNegociationTest.java
----------------------------------------------------------------------
diff --git a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/transport/tcp/WireformatNegociationTest.java b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/transport/tcp/WireformatNegociationTest.java
index 70cfa0e..998c951 100644
--- a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/transport/tcp/WireformatNegociationTest.java
+++ b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/transport/tcp/WireformatNegociationTest.java
@@ -47,7 +47,7 @@ public class WireformatNegociationTest extends CombinationTestSupport {
     private final AtomicReference<Exception> asyncError = new AtomicReference<Exception>();
     private final AtomicBoolean ignoreAsycError = new AtomicBoolean();
 
-    private final CountDownLatch negociationCounter = new CountDownLatch(2);
+    private final CountDownLatch negotiationCounter = new CountDownLatch(2);
 
     protected void setUp() throws Exception {
         super.setUp();
@@ -63,7 +63,7 @@ public class WireformatNegociationTest extends CombinationTestSupport {
             public void onCommand(Object command) {
                 if (command instanceof WireFormatInfo) {
                     clientWF.set((WireFormatInfo)command);
-                    negociationCounter.countDown();
+                    negotiationCounter.countDown();
                 }
             }
 
@@ -71,7 +71,7 @@ public class WireformatNegociationTest extends CombinationTestSupport {
                 if (!ignoreAsycError.get()) {
                     LOG.info("Client transport error: ", error);
                     asyncError.set(error);
-                    negociationCounter.countDown();
+                    negotiationCounter.countDown();
                 }
             }
 
@@ -100,7 +100,7 @@ public class WireformatNegociationTest extends CombinationTestSupport {
                         public void onCommand(Object command) {
                             if (command instanceof WireFormatInfo) {
                                 serverWF.set((WireFormatInfo)command);
-                                negociationCounter.countDown();
+                                negotiationCounter.countDown();
                             }
                         }
 
@@ -108,7 +108,7 @@ public class WireformatNegociationTest extends CombinationTestSupport {
                             if (!ignoreAsycError.get()) {
                                 LOG.info("Server transport error: ", error);
                                 asyncError.set(error);
-                                negociationCounter.countDown();
+                                negotiationCounter.countDown();
                             }
                         }
 
@@ -157,7 +157,7 @@ public class WireformatNegociationTest extends CombinationTestSupport {
         startServer("tcp://localhost:61616?wireFormat.version=1");
         startClient("tcp://localhost:61616");
 
-        assertTrue("Connect timeout", negociationCounter.await(10, TimeUnit.SECONDS));
+        assertTrue("Connect timeout", negotiationCounter.await(10, TimeUnit.SECONDS));
         assertNull("Async error: " + asyncError, asyncError.get());
 
         assertNotNull(clientWF.get());
@@ -175,7 +175,7 @@ public class WireformatNegociationTest extends CombinationTestSupport {
         startServer("tcp://localhost:61616");
         startClient("tcp://localhost:61616?wireFormat.version=1");
 
-        assertTrue("Connect timeout", negociationCounter.await(10, TimeUnit.SECONDS));
+        assertTrue("Connect timeout", negotiationCounter.await(10, TimeUnit.SECONDS));
         assertNull("Async error: " + asyncError, asyncError.get());
 
         assertNotNull(clientWF.get());
@@ -193,7 +193,7 @@ public class WireformatNegociationTest extends CombinationTestSupport {
         startServer("tcp://localhost:61616");
         startClient("tcp://localhost:61616");
 
-        assertTrue("Connect timeout", negociationCounter.await(10, TimeUnit.SECONDS));
+        assertTrue("Connect timeout", negotiationCounter.await(10, TimeUnit.SECONDS));
         assertNull("Async error: " + asyncError, asyncError.get());
 
         assertNotNull(clientWF.get());
@@ -208,7 +208,7 @@ public class WireformatNegociationTest extends CombinationTestSupport {
         startServer("tcp://localhost:61616");
         startClient("tcp://localhost:61616?wireFormat.maxInactivityDurationInitalDelay=60000");
 
-        assertTrue("Connect timeout", negociationCounter.await(10, TimeUnit.SECONDS));
+        assertTrue("Connect timeout", negotiationCounter.await(10, TimeUnit.SECONDS));
         assertNull("Async error: " + asyncError, asyncError.get());
 
         assertNotNull(clientWF.get());
@@ -223,7 +223,7 @@ public class WireformatNegociationTest extends CombinationTestSupport {
         startServer("tcp://localhost:61616");
         startClient("tcp://localhost:61616?wireFormat.maxFrameSize=1048576");
 
-        assertTrue("Connect timeout", negociationCounter.await(10, TimeUnit.SECONDS));
+        assertTrue("Connect timeout", negotiationCounter.await(10, TimeUnit.SECONDS));
         assertNull("Async error: " + asyncError, asyncError.get());
 
         assertNotNull(clientWF.get());

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/b0a80ce1/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/transport/udp/UdpTestSupport.java
----------------------------------------------------------------------
diff --git a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/transport/udp/UdpTestSupport.java b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/transport/udp/UdpTestSupport.java
index 7defe95..02e19b7 100644
--- a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/transport/udp/UdpTestSupport.java
+++ b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/transport/udp/UdpTestSupport.java
@@ -110,7 +110,7 @@ public abstract class UdpTestSupport extends TestCase implements TransportListen
             producer.oneway(new ProducerInfo());
 
             Command received = assertCommandReceived();
-            assertTrue("Should have received a ActiveMQTextMessage but was: " + received, received instanceof ActiveMQTextMessage);
+            assertTrue("Should have received an ActiveMQTextMessage but was: " + received, received instanceof ActiveMQTextMessage);
             ActiveMQTextMessage actual = (ActiveMQTextMessage)received;
 
             assertEquals("getDestination", expected.getDestination(), actual.getDestination());

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/b0a80ce1/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/usecases/BrokerQueueNetworkWithDisconnectTest.java
----------------------------------------------------------------------
diff --git a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/usecases/BrokerQueueNetworkWithDisconnectTest.java b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/usecases/BrokerQueueNetworkWithDisconnectTest.java
index e32a1bc..5841b2b 100644
--- a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/usecases/BrokerQueueNetworkWithDisconnectTest.java
+++ b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/usecases/BrokerQueueNetworkWithDisconnectTest.java
@@ -82,7 +82,7 @@ public class BrokerQueueNetworkWithDisconnectTest extends JmsMultipleBrokersTest
         msgs.waitForMessagesToArrive(MESSAGE_COUNT);
 
         assertTrue("At least message " + MESSAGE_COUNT +
-                " must be recieved, duplicates are expected, count=" + msgs.getMessageCount(),
+                " must be received, duplicates are expected, count=" + msgs.getMessageCount(),
                 MESSAGE_COUNT <= msgs.getMessageCount());
     }
 

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/b0a80ce1/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/usecases/DurableSubDelayedUnsubscribeTest.java
----------------------------------------------------------------------
diff --git a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/usecases/DurableSubDelayedUnsubscribeTest.java b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/usecases/DurableSubDelayedUnsubscribeTest.java
index 438e264..aeda7c2 100644
--- a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/usecases/DurableSubDelayedUnsubscribeTest.java
+++ b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/usecases/DurableSubDelayedUnsubscribeTest.java
@@ -493,7 +493,7 @@ public class DurableSubDelayedUnsubscribeTest {
                     }
                 }
 
-                // 50% unsubscribe, 50% abondon subscription
+                // 50% unsubscribe, 50% abandon subscription
                 if (!ALLOW_SUBSCRIPTION_ABANDONMENT) {
                     unsubscribe();
                     ALLOW_SUBSCRIPTION_ABANDONMENT = true;

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/b0a80ce1/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/usecases/DurableSubscriptionTestSupport.java
----------------------------------------------------------------------
diff --git a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/usecases/DurableSubscriptionTestSupport.java b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/usecases/DurableSubscriptionTestSupport.java
index b610f8c..6e41949 100644
--- a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/usecases/DurableSubscriptionTestSupport.java
+++ b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/usecases/DurableSubscriptionTestSupport.java
@@ -417,7 +417,7 @@ public abstract class DurableSubscriptionTestSupport extends TestSupport {
         Session session = connection.createSession(false, Session.CLIENT_ACKNOWLEDGE);
         Topic topic = session.createTopic("topic-" + getName());
         MessageConsumer consumer = session.createDurableSubscriber(topic, "sub1");
-        // Drain any messages that may allready be in the sub
+        // Drain any messages that may already be in the sub
         while (consumer.receive(1000) != null) {
         }
 
@@ -443,7 +443,7 @@ public abstract class DurableSubscriptionTestSupport extends TestSupport {
         Session session = connection.createSession(false, Session.CLIENT_ACKNOWLEDGE);
         Topic topic = session.createTopic("topic-" + getName());
         MessageConsumer consumer = session.createDurableSubscriber(topic, "sub1");
-        // Drain any messages that may allready be in the sub
+        // Drain any messages that may already be in the sub
         while (consumer.receive(1000) != null) {
         }
 
@@ -473,7 +473,7 @@ public abstract class DurableSubscriptionTestSupport extends TestSupport {
         Session session = connection.createSession(false, ActiveMQSession.INDIVIDUAL_ACKNOWLEDGE);
         Topic topic = session.createTopic("topic-" + getName());
         MessageConsumer consumer = session.createDurableSubscriber(topic, "sub1");
-        // Drain any messages that may allready be in the sub
+        // Drain any messages that may already be in the sub
         while (consumer.receive(1000) != null) {
         }
         consumer.close();

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/b0a80ce1/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/usecases/MulticastDiscoveryOnFaultyNetworkTest.java
----------------------------------------------------------------------
diff --git a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/usecases/MulticastDiscoveryOnFaultyNetworkTest.java b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/usecases/MulticastDiscoveryOnFaultyNetworkTest.java
index e911d0c..6b61438 100644
--- a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/usecases/MulticastDiscoveryOnFaultyNetworkTest.java
+++ b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/usecases/MulticastDiscoveryOnFaultyNetworkTest.java
@@ -67,7 +67,7 @@ public class MulticastDiscoveryOnFaultyNetworkTest extends JmsMultipleBrokersTes
         msgs.waitForMessagesToArrive(MESSAGE_COUNT);
 
         assertTrue("At least message " + MESSAGE_COUNT + 
-                " must be recieved, duplicates are expected, count=" + msgs.getMessageCount(),
+                " must be received, duplicates are expected, count=" + msgs.getMessageCount(),
                 MESSAGE_COUNT <= msgs.getMessageCount());
     }
 

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/b0a80ce1/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/usecases/NoDuplicateOnTopicNetworkTest.java
----------------------------------------------------------------------
diff --git a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/usecases/NoDuplicateOnTopicNetworkTest.java b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/usecases/NoDuplicateOnTopicNetworkTest.java
index 6d28f34..046818a 100644
--- a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/usecases/NoDuplicateOnTopicNetworkTest.java
+++ b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/usecases/NoDuplicateOnTopicNetworkTest.java
@@ -267,10 +267,10 @@ public class NoDuplicateOnTopicNetworkTest extends CombinationTestSupport {
 
         private final List<String> receivedStrings = Collections.synchronizedList(new ArrayList<String>());
         private int numMessages = 10;
-        private CountDownLatch recievedLatch = new CountDownLatch(numMessages);
+        private CountDownLatch receivedLatch = new CountDownLatch(numMessages);
 
         public CountDownLatch getLatch() {
-            return recievedLatch;
+            return receivedLatch;
         }
         
         public List<String> getMessageStrings() {
@@ -324,7 +324,7 @@ public class NoDuplicateOnTopicNetworkTest extends CombinationTestSupport {
                     try {
                         LOG.debug("Received message [" + msg.getText() + "]");
                         receivedStrings.add(msg.getText());
-                        recievedLatch.countDown();
+                        receivedLatch.countDown();
                     } catch (JMSException e) {
                         fail("Unexpected :" + e);
                     }

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/b0a80ce1/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/usecases/ThreeBrokerTopicNetworkTest.java
----------------------------------------------------------------------
diff --git a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/usecases/ThreeBrokerTopicNetworkTest.java b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/usecases/ThreeBrokerTopicNetworkTest.java
index 99deb28..70d3563 100644
--- a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/usecases/ThreeBrokerTopicNetworkTest.java
+++ b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/usecases/ThreeBrokerTopicNetworkTest.java
@@ -105,7 +105,7 @@ public class ThreeBrokerTopicNetworkTest extends JmsMultipleBrokersTestSupport {
         MessageConsumer clientB = createConsumer("BrokerC", dest, "dummy > 30");
         MessageConsumer clientC = createConsumer("BrokerC", dest, "dummy = 34");
 
-        // let consumers propogate around the network
+        // let consumers propagate around the network
         Thread.sleep(2000);
         // Send messages
         // Send messages for broker A
@@ -229,7 +229,7 @@ public class ThreeBrokerTopicNetworkTest extends JmsMultipleBrokersTestSupport {
         MessageConsumer clientA = createConsumer("BrokerA", dest);
         MessageConsumer clientB = createConsumer("BrokerB", dest);
         MessageConsumer clientC = createConsumer("BrokerC", dest);
-        //let consumers propogate around the network
+        //let consumers propagate around the network
         Thread.sleep(2000);
 
         // Send messages
@@ -285,7 +285,7 @@ public class ThreeBrokerTopicNetworkTest extends JmsMultipleBrokersTestSupport {
         MessageConsumer clientA = createConsumer("BrokerA", dest);
         MessageConsumer clientB = createConsumer("BrokerB", dest);
         MessageConsumer clientC = createConsumer("BrokerC", dest);
-        //let consumers propogate around the network
+        //let consumers propagate around the network
         Thread.sleep(2000);
 
         // Send messages
@@ -328,7 +328,7 @@ public class ThreeBrokerTopicNetworkTest extends JmsMultipleBrokersTestSupport {
         MessageConsumer clientA = createDurableSubscriber("BrokerA", (Topic)dest, "clientA");
         MessageConsumer clientB = createDurableSubscriber("BrokerB", (Topic)dest, "clientB");
         MessageConsumer clientC = createDurableSubscriber("BrokerC", (Topic)dest, "clientC");
-        //let consumers propogate around the network
+        //let consumers propagate around the network
         Thread.sleep(2000);
 
         // Send messages
@@ -368,7 +368,7 @@ public class ThreeBrokerTopicNetworkTest extends JmsMultipleBrokersTestSupport {
         MessageConsumer clientB = createConsumer("BrokerB", dest);
         MessageConsumer clientC = createConsumer("BrokerC", dest);
 
-        //let consumers propogate around the network
+        //let consumers propagate around the network
         Thread.sleep(2000);
 
         // Send messages

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/b0a80ce1/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/usecases/TopicReplicationTest.java
----------------------------------------------------------------------
diff --git a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/usecases/TopicReplicationTest.java b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/usecases/TopicReplicationTest.java
index 354f8af..e01616e 100644
--- a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/usecases/TopicReplicationTest.java
+++ b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/usecases/TopicReplicationTest.java
@@ -46,7 +46,7 @@ public class TopicReplicationTest extends JmsMultipleBrokersTestSupport {
         MessageConsumer clientC = createConsumer("replication-broker4", dest);
         MessageConsumer clientD = createConsumer("replication-broker4", dest);
 
-        //let consumers propogate around the network
+        //let consumers propagate around the network
         Thread.sleep(2000);
 
         // Get message count

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/b0a80ce1/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/usecases/TwoBrokerVirtualTopicForwardingTest.java
----------------------------------------------------------------------
diff --git a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/usecases/TwoBrokerVirtualTopicForwardingTest.java b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/usecases/TwoBrokerVirtualTopicForwardingTest.java
index 0dc9e61..a53cc08 100644
--- a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/usecases/TwoBrokerVirtualTopicForwardingTest.java
+++ b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/usecases/TwoBrokerVirtualTopicForwardingTest.java
@@ -49,7 +49,7 @@ public class TwoBrokerVirtualTopicForwardingTest extends JmsMultipleBrokersTestS
         MessageConsumer clientB = createConsumer("BrokerB", createDestination("Consumer.B.VirtualTopic.tempTopic", false));
 
 
-        // give a sec to let advisories propogate
+        // give a sec to let advisories propagate
         Thread.sleep(500);
 
         ActiveMQQueue queueA = new ActiveMQQueue("Consumer.A.VirtualTopic.tempTopic");
@@ -91,7 +91,7 @@ public class TwoBrokerVirtualTopicForwardingTest extends JmsMultipleBrokersTestS
         MessageConsumer clientB = createConsumer("BrokerB", createDestination("Consumer.B.VirtualTopic.tempTopic", false));
 
 
-        // give a sec to let advisories propogate
+        // give a sec to let advisories propagate
         Thread.sleep(500);
 
         ActiveMQQueue queueA = new ActiveMQQueue("Consumer.A.VirtualTopic.tempTopic");
@@ -133,7 +133,7 @@ public class TwoBrokerVirtualTopicForwardingTest extends JmsMultipleBrokersTestS
         MessageConsumer clientC = createConsumer("BrokerB", createDestination("VirtualTopic.tempTopic", true));
 
 
-        // give a sec to let advisories propogate
+        // give a sec to let advisories propagate
         Thread.sleep(500);
 
         ActiveMQQueue queueA = new ActiveMQQueue("Consumer.A.VirtualTopic.tempTopic");

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/b0a80ce1/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/xbean/ManagementContextXBeanConfigTest.java
----------------------------------------------------------------------
diff --git a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/xbean/ManagementContextXBeanConfigTest.java b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/xbean/ManagementContextXBeanConfigTest.java
index 1936112..bd724a9 100644
--- a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/xbean/ManagementContextXBeanConfigTest.java
+++ b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/xbean/ManagementContextXBeanConfigTest.java
@@ -45,7 +45,7 @@ public class ManagementContextXBeanConfigTest extends TestCase {
     protected BrokerService brokerService;
     private static final transient Logger LOG = LoggerFactory.getLogger(ManagementContextXBeanConfigTest.class);
 
-    public void testManagmentContextConfiguredCorrectly() throws Exception {
+    public void testManagementContextConfiguredCorrectly() throws Exception {
         assertEquals(2011, brokerService.getManagementContext().getConnectorPort());
         assertEquals("test.domain", brokerService.getManagementContext().getJmxDomainName());
         // Make sure the broker is registered in the right jmx domain.

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/b0a80ce1/tests/integration-tests/src/test/java/org/apache/activemq/artemis/tests/integration/client/AutogroupIdTest.java
----------------------------------------------------------------------
diff --git a/tests/integration-tests/src/test/java/org/apache/activemq/artemis/tests/integration/client/AutogroupIdTest.java b/tests/integration-tests/src/test/java/org/apache/activemq/artemis/tests/integration/client/AutogroupIdTest.java
index 347fbdc..37ffcee 100644
--- a/tests/integration-tests/src/test/java/org/apache/activemq/artemis/tests/integration/client/AutogroupIdTest.java
+++ b/tests/integration-tests/src/test/java/org/apache/activemq/artemis/tests/integration/client/AutogroupIdTest.java
@@ -165,7 +165,7 @@ public class AutogroupIdTest extends ActiveMQTestBase
    }
 
    /*
-   * tests that even tho we have an grouping round robin distributor we don't pin the consumer as autogroup is false
+   * tests that even though we have a grouping round robin distributor we don't pin the consumer as autogroup is false
    * */
    @Test
    public void testGroupIdAutomaticallyNotSet() throws Exception

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/b0a80ce1/tests/integration-tests/src/test/java/org/apache/activemq/artemis/tests/integration/client/MessageExpirationTest.java
----------------------------------------------------------------------
diff --git a/tests/integration-tests/src/test/java/org/apache/activemq/artemis/tests/integration/client/MessageExpirationTest.java b/tests/integration-tests/src/test/java/org/apache/activemq/artemis/tests/integration/client/MessageExpirationTest.java
index e137d36..18d683f 100644
--- a/tests/integration-tests/src/test/java/org/apache/activemq/artemis/tests/integration/client/MessageExpirationTest.java
+++ b/tests/integration-tests/src/test/java/org/apache/activemq/artemis/tests/integration/client/MessageExpirationTest.java
@@ -107,7 +107,7 @@ public class MessageExpirationTest extends ActiveMQTestBase
       // stopping the consumer to cleanup the client's buffer
       session.stop();
 
-      // we recieve the message and then rollback...   then we wait some time > expiration, the message must be gone
+      // we receive the message and then rollback...   then we wait some time > expiration, the message must be gone
       session.rollback();
 
 

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/b0a80ce1/tests/integration-tests/src/test/java/org/apache/activemq/artemis/tests/integration/clientcrash/ClientCrashTest.java
----------------------------------------------------------------------
diff --git a/tests/integration-tests/src/test/java/org/apache/activemq/artemis/tests/integration/clientcrash/ClientCrashTest.java b/tests/integration-tests/src/test/java/org/apache/activemq/artemis/tests/integration/clientcrash/ClientCrashTest.java
index 8f73f65..575518b 100644
--- a/tests/integration-tests/src/test/java/org/apache/activemq/artemis/tests/integration/clientcrash/ClientCrashTest.java
+++ b/tests/integration-tests/src/test/java/org/apache/activemq/artemis/tests/integration/clientcrash/ClientCrashTest.java
@@ -33,7 +33,7 @@ import org.apache.activemq.artemis.core.settings.impl.AddressSettings;
 import org.apache.activemq.artemis.jms.client.ActiveMQTextMessage;
 
 /**
- * A test that makes sure that a ActiveMQ Artemis server cleans up the associated
+ * A test that makes sure that an ActiveMQ Artemis server cleans up the associated
  * resources when one of its client crashes.
  */
 public class ClientCrashTest extends ClientTestBase