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 2016/08/25 18:22:50 UTC

[8/8] activemq-artemis git commit: Spelling fixes

Spelling fixes


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

Branch: refs/heads/master
Commit: e1728f07976c870f5c6bf55d4b8afd363b7e3edc
Parents: 8c6e044
Author: Ville Skytt� <vi...@iki.fi>
Authored: Thu Aug 25 12:53:30 2016 +0300
Committer: Clebert Suconic <cl...@apache.org>
Committed: Thu Aug 25 14:22:32 2016 -0400

----------------------------------------------------------------------
 .../spi/core/protocol/RemotingConnection.java   |  2 +-
 .../artemis/util/CompressionUtilTest.java       | 32 ++++++++++----------
 .../apache/activemq/artemis/dto/XmlUtil.java    |  2 +-
 ...che_activemq_artemis_jlibaio_LibaioContext.c |  2 +-
 .../proton/converter/jms/ServerDestination.java |  2 +-
 .../protocol/openwire/OpenWireConnection.java   |  2 +-
 .../artemis/rest/queue/PostMessageNoDups.java   |  4 +--
 .../artemis/core/server/impl/QueueImpl.java     |  3 +-
 .../impl/SharedNothingLiveActivation.java       |  2 +-
 .../spi/core/protocol/ProtocolManager.java      |  2 +-
 docs/hacking-guide/en/ide.md                    |  4 +--
 docs/user-manual/en/aerogear-integration.md     |  2 +-
 docs/user-manual/en/vertx-integration.md        |  2 +-
 .../jms/example/HAPolicyAutoBackupExample.java  |  2 +-
 .../activemq/artemis/jms/example/PerfBase.java  |  2 +-
 .../artemis/jms/soak/example/SoakBase.java      |  2 +-
 .../aerogear/ActiveMQAeroGearLogger.java        |  2 +-
 pom.xml                                         |  2 +-
 .../activemq/EmbeddedBrokerTestSupport.java     |  2 +-
 .../org/apache/activemq/OptimizedAckTest.java   |  2 +-
 .../activemq/security/SecurityJMXTest.java      |  2 +-
 .../failover/FailoverTransactionTest.java       |  2 +-
 .../NonBlockingConsumerRedeliveryTest.java      |  6 ++--
 .../usecases/StartAndStopBrokerTest.java        |  2 +-
 .../jms/tests/tools/container/Server.java       |  2 +-
 .../conform/connection/TopicConnectionTest.java |  2 +-
 26 files changed, 45 insertions(+), 46 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/e1728f07/artemis-core-client/src/main/java/org/apache/activemq/artemis/spi/core/protocol/RemotingConnection.java
----------------------------------------------------------------------
diff --git a/artemis-core-client/src/main/java/org/apache/activemq/artemis/spi/core/protocol/RemotingConnection.java b/artemis-core-client/src/main/java/org/apache/activemq/artemis/spi/core/protocol/RemotingConnection.java
index 0f16db7..0f5abf3 100644
--- a/artemis-core-client/src/main/java/org/apache/activemq/artemis/spi/core/protocol/RemotingConnection.java
+++ b/artemis-core-client/src/main/java/org/apache/activemq/artemis/spi/core/protocol/RemotingConnection.java
@@ -105,7 +105,7 @@ public interface RemotingConnection extends BufferHandler {
    /**
     * set the failure listeners.
     * <p>
-    * These will be called in the event of the connection being closed. Any previosuly added listeners will be removed.
+    * These will be called in the event of the connection being closed. Any previously added listeners will be removed.
     *
     * @param listeners the listeners to add.
     */

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/e1728f07/artemis-core-client/src/test/java/org/apache/activemq/artemis/util/CompressionUtilTest.java
----------------------------------------------------------------------
diff --git a/artemis-core-client/src/test/java/org/apache/activemq/artemis/util/CompressionUtilTest.java b/artemis-core-client/src/test/java/org/apache/activemq/artemis/util/CompressionUtilTest.java
index 71e2ce0..e864822 100644
--- a/artemis-core-client/src/test/java/org/apache/activemq/artemis/util/CompressionUtilTest.java
+++ b/artemis-core-client/src/test/java/org/apache/activemq/artemis/util/CompressionUtilTest.java
@@ -60,10 +60,10 @@ public class CompressionUtilTest extends Assert {
       }
 
       byte[] output = new byte[30];
-      Deflater compresser = new Deflater();
-      compresser.setInput(input);
-      compresser.finish();
-      int compressedDataLength = compresser.deflate(output);
+      Deflater compressor = new Deflater();
+      compressor.setInput(input);
+      compressor.finish();
+      int compressedDataLength = compressor.deflate(output);
 
       compareByteArray(allCompressed, output, compressedDataLength);
    }
@@ -97,10 +97,10 @@ public class CompressionUtilTest extends Assert {
       }
 
       byte[] output = new byte[30];
-      Deflater compresser = new Deflater();
-      compresser.setInput(input);
-      compresser.finish();
-      int compressedDataLength = compresser.deflate(output);
+      Deflater compressor = new Deflater();
+      compressor.setInput(input);
+      compressor.finish();
+      int compressedDataLength = compressor.deflate(output);
 
       compareByteArray(allCompressed, output, compressedDataLength);
    }
@@ -110,10 +110,10 @@ public class CompressionUtilTest extends Assert {
       String inputString = "blahblahblah??blahblahblahblahblah??blablahblah??blablahblah??bla";
       byte[] input = inputString.getBytes(StandardCharsets.UTF_8);
       byte[] output = new byte[30];
-      Deflater compresser = new Deflater();
-      compresser.setInput(input);
-      compresser.finish();
-      int compressedDataLength = compresser.deflate(output);
+      Deflater compressor = new Deflater();
+      compressor.setInput(input);
+      compressor.finish();
+      int compressedDataLength = compressor.deflate(output);
 
       byte[] zipBytes = new byte[compressedDataLength];
 
@@ -146,10 +146,10 @@ public class CompressionUtilTest extends Assert {
       String inputString = "blahblahblah??blahblahblahblahblah??blablahblah??blablahblah??bla";
       byte[] input = inputString.getBytes(StandardCharsets.UTF_8);
       byte[] output = new byte[30];
-      Deflater compresser = new Deflater();
-      compresser.setInput(input);
-      compresser.finish();
-      int compressedDataLength = compresser.deflate(output);
+      Deflater compressor = new Deflater();
+      compressor.setInput(input);
+      compressor.finish();
+      int compressedDataLength = compressor.deflate(output);
 
       byte[] zipBytes = new byte[compressedDataLength];
 

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/e1728f07/artemis-dto/src/main/java/org/apache/activemq/artemis/dto/XmlUtil.java
----------------------------------------------------------------------
diff --git a/artemis-dto/src/main/java/org/apache/activemq/artemis/dto/XmlUtil.java b/artemis-dto/src/main/java/org/apache/activemq/artemis/dto/XmlUtil.java
index f474453..fa0ff9a 100644
--- a/artemis-dto/src/main/java/org/apache/activemq/artemis/dto/XmlUtil.java
+++ b/artemis-dto/src/main/java/org/apache/activemq/artemis/dto/XmlUtil.java
@@ -79,7 +79,7 @@ public class XmlUtil {
       return decode(clazz, configuration, null, null);
    }
 
-   /** We offer parameters for artemisInstance and artemisHoms as they could be coming from the CLI or Maven Plugin */
+   /** We offer parameters for artemisInstance and artemisHome as they could be coming from the CLI or Maven Plugin */
    public static <T> T decode(Class<T> clazz, File configuration, String artemisHome, String artemisInstance) throws Exception {
       JAXBContext jaxbContext = JAXBContext.newInstance("org.apache.activemq.artemis.dto");
 

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/e1728f07/artemis-native/src/main/c/org_apache_activemq_artemis_jlibaio_LibaioContext.c
----------------------------------------------------------------------
diff --git a/artemis-native/src/main/c/org_apache_activemq_artemis_jlibaio_LibaioContext.c b/artemis-native/src/main/c/org_apache_activemq_artemis_jlibaio_LibaioContext.c
index 860d192..74545fc 100644
--- a/artemis-native/src/main/c/org_apache_activemq_artemis_jlibaio_LibaioContext.c
+++ b/artemis-native/src/main/c/org_apache_activemq_artemis_jlibaio_LibaioContext.c
@@ -48,7 +48,7 @@ struct io_control {
 
     pthread_mutex_t pollLock;
 
-    // a resuable pool of iocb
+    // a reusable pool of iocb
     struct iocb ** iocb;
     int queueSize;
     int iocbPut;

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/e1728f07/artemis-protocols/artemis-amqp-protocol/src/main/java/org/apache/activemq/artemis/core/protocol/proton/converter/jms/ServerDestination.java
----------------------------------------------------------------------
diff --git a/artemis-protocols/artemis-amqp-protocol/src/main/java/org/apache/activemq/artemis/core/protocol/proton/converter/jms/ServerDestination.java b/artemis-protocols/artemis-amqp-protocol/src/main/java/org/apache/activemq/artemis/core/protocol/proton/converter/jms/ServerDestination.java
index ab26264..0a8bb29 100644
--- a/artemis-protocols/artemis-amqp-protocol/src/main/java/org/apache/activemq/artemis/core/protocol/proton/converter/jms/ServerDestination.java
+++ b/artemis-protocols/artemis-amqp-protocol/src/main/java/org/apache/activemq/artemis/core/protocol/proton/converter/jms/ServerDestination.java
@@ -22,7 +22,7 @@ import javax.jms.JMSException;
 import javax.jms.Queue;
 
 /**
- * This is just here to avoid all the client checks we ned with valid JMS destinations, protocol convertors don't need to
+ * This is just here to avoid all the client checks we need with valid JMS destinations, protocol convertors don't need to
  * adhere to the jms. semantics.
  */
 public class ServerDestination extends ActiveMQDestination implements Queue {

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/e1728f07/artemis-protocols/artemis-openwire-protocol/src/main/java/org/apache/activemq/artemis/core/protocol/openwire/OpenWireConnection.java
----------------------------------------------------------------------
diff --git a/artemis-protocols/artemis-openwire-protocol/src/main/java/org/apache/activemq/artemis/core/protocol/openwire/OpenWireConnection.java b/artemis-protocols/artemis-openwire-protocol/src/main/java/org/apache/activemq/artemis/core/protocol/openwire/OpenWireConnection.java
index 7c52b27..8f53bdb 100644
--- a/artemis-protocols/artemis-openwire-protocol/src/main/java/org/apache/activemq/artemis/core/protocol/openwire/OpenWireConnection.java
+++ b/artemis-protocols/artemis-openwire-protocol/src/main/java/org/apache/activemq/artemis/core/protocol/openwire/OpenWireConnection.java
@@ -477,7 +477,7 @@ public class OpenWireConnection extends AbstractRemotingConnection implements Se
             if (context.isReconnect() || (context.isNetworkConnection())) {
                // once implemented ARTEMIS-194, we need to set the storedSequenceID here somehow
                // We have different semantics on Artemis Journal, but we could adapt something for this
-               // TBD during the implemetnation of ARTEMIS-194
+               // TBD during the implementation of ARTEMIS-194
                result.setLastStoredSequenceId(0);
             }
             SessionState ss = state.getSessionState(id.getParentId());

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/e1728f07/artemis-rest/src/main/java/org/apache/activemq/artemis/rest/queue/PostMessageNoDups.java
----------------------------------------------------------------------
diff --git a/artemis-rest/src/main/java/org/apache/activemq/artemis/rest/queue/PostMessageNoDups.java b/artemis-rest/src/main/java/org/apache/activemq/artemis/rest/queue/PostMessageNoDups.java
index b2b34e2..9c3a88d 100644
--- a/artemis-rest/src/main/java/org/apache/activemq/artemis/rest/queue/PostMessageNoDups.java
+++ b/artemis-rest/src/main/java/org/apache/activemq/artemis/rest/queue/PostMessageNoDups.java
@@ -24,7 +24,7 @@ import javax.ws.rs.core.Response;
 import javax.ws.rs.core.UriInfo;
 
 /**
- * implements reliable "create", "create-next" pattern defined by REST-* Messaging specificaiton
+ * implements reliable "create", "create-next" pattern defined by REST-* Messaging specification
  */
 public class PostMessageNoDups extends PostMessage {
 
@@ -37,4 +37,4 @@ public class PostMessageNoDups extends PostMessage {
       res.location(uriInfo.getAbsolutePathBuilder().path(id).build());
       return res.build();
    }
-}
\ No newline at end of file
+}

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/e1728f07/artemis-server/src/main/java/org/apache/activemq/artemis/core/server/impl/QueueImpl.java
----------------------------------------------------------------------
diff --git a/artemis-server/src/main/java/org/apache/activemq/artemis/core/server/impl/QueueImpl.java b/artemis-server/src/main/java/org/apache/activemq/artemis/core/server/impl/QueueImpl.java
index dfcba27..1514748 100644
--- a/artemis-server/src/main/java/org/apache/activemq/artemis/core/server/impl/QueueImpl.java
+++ b/artemis-server/src/main/java/org/apache/activemq/artemis/core/server/impl/QueueImpl.java
@@ -615,7 +615,7 @@ public class QueueImpl implements Queue {
       }
 
       if (logger.isTraceEnabled()) {
-         logger.trace("Force delivery deliverying async");
+         logger.trace("Force delivery delivering async");
       }
 
       deliverAsync();
@@ -3045,4 +3045,3 @@ public class QueueImpl implements Queue {
       }
    }
 }
-

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/e1728f07/artemis-server/src/main/java/org/apache/activemq/artemis/core/server/impl/SharedNothingLiveActivation.java
----------------------------------------------------------------------
diff --git a/artemis-server/src/main/java/org/apache/activemq/artemis/core/server/impl/SharedNothingLiveActivation.java b/artemis-server/src/main/java/org/apache/activemq/artemis/core/server/impl/SharedNothingLiveActivation.java
index f17bcc5..938f5dd 100644
--- a/artemis-server/src/main/java/org/apache/activemq/artemis/core/server/impl/SharedNothingLiveActivation.java
+++ b/artemis-server/src/main/java/org/apache/activemq/artemis/core/server/impl/SharedNothingLiveActivation.java
@@ -304,7 +304,7 @@ public class SharedNothingLiveActivation extends LiveActivation {
       NodeManager nodeManagerInUse = activeMQServer.getNodeManager();
 
       if (nodeManagerInUse != null) {
-         //todo does this actually make any difference, we only set a different flag in the lock file which replication doesnt use
+         //todo does this actually make any difference, we only set a different flag in the lock file which replication doesn't use
          if (permanently) {
             nodeManagerInUse.crashLiveServer();
          }

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/e1728f07/artemis-server/src/main/java/org/apache/activemq/artemis/spi/core/protocol/ProtocolManager.java
----------------------------------------------------------------------
diff --git a/artemis-server/src/main/java/org/apache/activemq/artemis/spi/core/protocol/ProtocolManager.java b/artemis-server/src/main/java/org/apache/activemq/artemis/spi/core/protocol/ProtocolManager.java
index 62befaf..3d5be39 100644
--- a/artemis-server/src/main/java/org/apache/activemq/artemis/spi/core/protocol/ProtocolManager.java
+++ b/artemis-server/src/main/java/org/apache/activemq/artemis/spi/core/protocol/ProtocolManager.java
@@ -56,7 +56,7 @@ public interface ProtocolManager<P extends BaseInterceptor> {
    MessageConverter getConverter();
 
    /** If this protocols accepts connectoins without an initial handshake.
-    *  If true this protocol will be the failback case no other conenctions are made.
+    *  If true this protocol will be the failback case no other connections are made.
     *  New designed protocols should always require a handshake. This is only useful for legacy protocols. */
    boolean acceptsNoHandshake();
 

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/e1728f07/docs/hacking-guide/en/ide.md
----------------------------------------------------------------------
diff --git a/docs/hacking-guide/en/ide.md b/docs/hacking-guide/en/ide.md
index 8853780..c96ccef 100644
--- a/docs/hacking-guide/en/ide.md
+++ b/docs/hacking-guide/en/ide.md
@@ -49,7 +49,7 @@ imported properly.  To (re)import the "tests" Maven profile in an existing proje
 * Open the Maven Projects Tool Window: View -> Tool Windows -> Maven Projects
 * Select the "profiles" drop down
 * Unselect then reselect the checkbox next to "tests".
-* Click on the "Reimport all maven projects" button in the top left hand corner of the window. (It looks like a ciruclar
+* Click on the "Reimport all maven projects" button in the top left hand corner of the window. (It looks like a circular
 blue arrow.
 * Wait for IDEA to reload and try running a JUnit test again.  The option to run should now be present.
 
@@ -94,4 +94,4 @@ Importing all ActiveMQ Artemis subprojects will create _too many_ projects in Ec
 and _Project Explorer_ views. One way to address that is to use
 [Eclipse's Working Sets](http://help.eclipse.org/juno/index.jsp?topic=%2Forg.eclipse.platform.doc.user%2Fconcepts%2Fcworkset.htm)
 feature. A good introduction to it can be found at a
-[Dzone article on Eclipse Working Sets](http://eclipse.dzone.com/articles/categorise-projects-package).
\ No newline at end of file
+[Dzone article on Eclipse Working Sets](http://eclipse.dzone.com/articles/categorise-projects-package).

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/e1728f07/docs/user-manual/en/aerogear-integration.md
----------------------------------------------------------------------
diff --git a/docs/user-manual/en/aerogear-integration.md b/docs/user-manual/en/aerogear-integration.md
index 2a83f4d..0dbafb2 100644
--- a/docs/user-manual/en/aerogear-integration.md
+++ b/docs/user-manual/en/aerogear-integration.md
@@ -35,7 +35,7 @@ Shown are the required params for the connector service and are:
 
 -   `master-secret`. The secret of your mobile application in AeroGear.
 
-As well as these required paramaters there are the following optional
+As well as these required parameters there are the following optional
 parameters
 
 -   `ttl`. The time to live for the message once AeroGear receives it.

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/e1728f07/docs/user-manual/en/vertx-integration.md
----------------------------------------------------------------------
diff --git a/docs/user-manual/en/vertx-integration.md b/docs/user-manual/en/vertx-integration.md
index 9c52a0f..f823f11 100644
--- a/docs/user-manual/en/vertx-integration.md
+++ b/docs/user-manual/en/vertx-integration.md
@@ -64,7 +64,7 @@ Shown are the required params for the connector service:
 
 -   `queue`. The name of the Apache ActiveMQ Artemis queue to fetch message from.
 
-As well as these required paramaters there are the following optional
+As well as these required parameters there are the following optional
 parameters
 
 -   `host`. The host name on which the vertx target container is

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/e1728f07/examples/features/ha/ha-policy-autobackup/src/main/java/org/apache/activemq/artemis/jms/example/HAPolicyAutoBackupExample.java
----------------------------------------------------------------------
diff --git a/examples/features/ha/ha-policy-autobackup/src/main/java/org/apache/activemq/artemis/jms/example/HAPolicyAutoBackupExample.java b/examples/features/ha/ha-policy-autobackup/src/main/java/org/apache/activemq/artemis/jms/example/HAPolicyAutoBackupExample.java
index 0401617..d2b8d95 100644
--- a/examples/features/ha/ha-policy-autobackup/src/main/java/org/apache/activemq/artemis/jms/example/HAPolicyAutoBackupExample.java
+++ b/examples/features/ha/ha-policy-autobackup/src/main/java/org/apache/activemq/artemis/jms/example/HAPolicyAutoBackupExample.java
@@ -103,7 +103,7 @@ public class HAPolicyAutoBackupExample {
             System.out.println("Got message: " + message0.getText() + " from node 0");
          }
 
-         // Step 14.close the consumer so it doesnt get any messages
+         // Step 14.close the consumer so it doesn't get any messages
          consumer1.close();
 
          // Step 15.now kill server1, messages will be scaled down to server0

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/e1728f07/examples/features/perf/perf/src/main/java/org/apache/activemq/artemis/jms/example/PerfBase.java
----------------------------------------------------------------------
diff --git a/examples/features/perf/perf/src/main/java/org/apache/activemq/artemis/jms/example/PerfBase.java b/examples/features/perf/perf/src/main/java/org/apache/activemq/artemis/jms/example/PerfBase.java
index 0b3e741..ad92b08 100644
--- a/examples/features/perf/perf/src/main/java/org/apache/activemq/artemis/jms/example/PerfBase.java
+++ b/examples/features/perf/perf/src/main/java/org/apache/activemq/artemis/jms/example/PerfBase.java
@@ -88,7 +88,7 @@ public abstract class PerfBase {
       boolean drainQueue = Boolean.valueOf(props.getProperty("drain-queue"));
       String destinationName = props.getProperty("destination-name");
       int throttleRate = Integer.valueOf(props.getProperty("throttle-rate"));
-      boolean dupsOK = Boolean.valueOf(props.getProperty("dups-ok-acknowlege"));
+      boolean dupsOK = Boolean.valueOf(props.getProperty("dups-ok-acknowledge"));
       boolean disableMessageID = Boolean.valueOf(props.getProperty("disable-message-id"));
       boolean disableTimestamp = Boolean.valueOf(props.getProperty("disable-message-timestamp"));
       String clientLibrary = props.getProperty("client-library", "core");

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/e1728f07/examples/features/perf/soak/src/main/java/org/apache/activemq/artemis/jms/soak/example/SoakBase.java
----------------------------------------------------------------------
diff --git a/examples/features/perf/soak/src/main/java/org/apache/activemq/artemis/jms/soak/example/SoakBase.java b/examples/features/perf/soak/src/main/java/org/apache/activemq/artemis/jms/soak/example/SoakBase.java
index 3b0b105..bd17b38 100644
--- a/examples/features/perf/soak/src/main/java/org/apache/activemq/artemis/jms/soak/example/SoakBase.java
+++ b/examples/features/perf/soak/src/main/java/org/apache/activemq/artemis/jms/soak/example/SoakBase.java
@@ -69,7 +69,7 @@ public class SoakBase {
       String destinationLookup = props.getProperty("destination-lookup");
       String connectionFactoryLookup = props.getProperty("connection-factory-lookup");
       int throttleRate = Integer.valueOf(props.getProperty("throttle-rate"));
-      boolean dupsOK = Boolean.valueOf(props.getProperty("dups-ok-acknowlege"));
+      boolean dupsOK = Boolean.valueOf(props.getProperty("dups-ok-acknowledge"));
       boolean disableMessageID = Boolean.valueOf(props.getProperty("disable-message-id"));
       boolean disableTimestamp = Boolean.valueOf(props.getProperty("disable-message-timestamp"));
 

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/e1728f07/integration/activemq-aerogear-integration/src/main/java/org/apache/activemq/artemis/integration/aerogear/ActiveMQAeroGearLogger.java
----------------------------------------------------------------------
diff --git a/integration/activemq-aerogear-integration/src/main/java/org/apache/activemq/artemis/integration/aerogear/ActiveMQAeroGearLogger.java b/integration/activemq-aerogear-integration/src/main/java/org/apache/activemq/artemis/integration/aerogear/ActiveMQAeroGearLogger.java
index c8e7c57..66c000e 100644
--- a/integration/activemq-aerogear-integration/src/main/java/org/apache/activemq/artemis/integration/aerogear/ActiveMQAeroGearLogger.java
+++ b/integration/activemq-aerogear-integration/src/main/java/org/apache/activemq/artemis/integration/aerogear/ActiveMQAeroGearLogger.java
@@ -57,7 +57,7 @@ public interface ActiveMQAeroGearLogger extends BasicLogger {
    void reply404();
 
    @LogMessage(level = Logger.Level.WARN)
-   @Message(id = 232005, value = "removing aerogear connector as unexpected respone {0} returned", format = Message.Format.MESSAGE_FORMAT)
+   @Message(id = 232005, value = "removing aerogear connector as unexpected response {0} returned", format = Message.Format.MESSAGE_FORMAT)
    void replyUnknown(int status);
 
    @LogMessage(level = Logger.Level.WARN)

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/e1728f07/pom.xml
----------------------------------------------------------------------
diff --git a/pom.xml b/pom.xml
index 7781431..26dfb39 100644
--- a/pom.xml
+++ b/pom.xml
@@ -198,7 +198,7 @@
 
    <dependencyManagement>
       <dependencies>
-         <!-- ## Test Dependenices ## Note: Junit is required in certain module tests.  We should control versions from here. -->
+         <!-- ## Test Dependencies ## Note: Junit is required in certain module tests.  We should control versions from here. -->
          <dependency>
             <groupId>junit</groupId>
             <artifactId>junit</artifactId>

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/e1728f07/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/EmbeddedBrokerTestSupport.java
----------------------------------------------------------------------
diff --git a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/EmbeddedBrokerTestSupport.java b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/EmbeddedBrokerTestSupport.java
index 49ef298..9096c06 100644
--- a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/EmbeddedBrokerTestSupport.java
+++ b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/EmbeddedBrokerTestSupport.java
@@ -128,7 +128,7 @@ public abstract class EmbeddedBrokerTestSupport extends CombinationTestSupport {
    /**
     * Factory method to create a new {@link Destination}
     *
-    * @return newly created Destinaiton
+    * @return newly created Destination
     */
    protected ActiveMQDestination createDestination() {
       return createDestination(getDestinationString());

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/e1728f07/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/OptimizedAckTest.java
----------------------------------------------------------------------
diff --git a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/OptimizedAckTest.java b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/OptimizedAckTest.java
index 8da4cf7..fb44c71 100644
--- a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/OptimizedAckTest.java
+++ b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/OptimizedAckTest.java
@@ -69,7 +69,7 @@ public class OptimizedAckTest extends TestSupport {
       Binding binding = broker.getServer().getPostOffice().getBinding(new SimpleString("jms.queue.test"));
 
       final QueueImpl coreQueue = (QueueImpl) binding.getBindable();
-      assertTrue("deliverying count is 10", Wait.waitFor(new Wait.Condition() {
+      assertTrue("delivering count is 10", Wait.waitFor(new Wait.Condition() {
          @Override
          public boolean isSatisified() throws Exception {
             return 10 == coreQueue.getDeliveringCount();

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/e1728f07/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/security/SecurityJMXTest.java
----------------------------------------------------------------------
diff --git a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/security/SecurityJMXTest.java b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/security/SecurityJMXTest.java
index eb7fc04..ab85bb4 100644
--- a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/security/SecurityJMXTest.java
+++ b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/security/SecurityJMXTest.java
@@ -85,7 +85,7 @@ public class SecurityJMXTest extends TestCase {
       Connection c = new ActiveMQConnectionFactory("vm://localhost").createConnection("system", "manager");
       c.start();
 
-      // browser consumer will force expriation check on addConsumer
+      // browser consumer will force expiration check on addConsumer
       QueueBrowser browser = c.createSession(false, Session.AUTO_ACKNOWLEDGE).createBrowser(new ActiveMQQueue("TEST.Q"));
       assertTrue("no message in the q", !browser.getEnumeration().hasMoreElements());
 

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/e1728f07/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 1557854..44f2f43 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
@@ -875,7 +875,7 @@ public class FailoverTransactionTest extends OpenwireArtemisBaseTest {
 
          try {
             consumerSession.commit();
-            Assert.fail("expected transaciton rolledback ex");
+            Assert.fail("expected transaction rolledback ex");
          }
          catch (TransactionRolledBackException expected) {
          }

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/e1728f07/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/usecases/NonBlockingConsumerRedeliveryTest.java
----------------------------------------------------------------------
diff --git a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/usecases/NonBlockingConsumerRedeliveryTest.java b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/usecases/NonBlockingConsumerRedeliveryTest.java
index f29680f..00e9c2b 100644
--- a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/usecases/NonBlockingConsumerRedeliveryTest.java
+++ b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/usecases/NonBlockingConsumerRedeliveryTest.java
@@ -312,7 +312,7 @@ public class NonBlockingConsumerRedeliveryTest {
                   count = 0;
                }
                catch (JMSException e) {
-                  LOG.warn("Caught an unexcepted exception: " + e.getMessage());
+                  LOG.warn("Caught an unexpected exception: " + e.getMessage());
                }
             }
             else {
@@ -321,7 +321,7 @@ public class NonBlockingConsumerRedeliveryTest {
                   session.commit();
                }
                catch (JMSException e) {
-                  LOG.warn("Caught an unexcepted exception: " + e.getMessage());
+                  LOG.warn("Caught an unexpected exception: " + e.getMessage());
                }
             }
          }
@@ -388,7 +388,7 @@ public class NonBlockingConsumerRedeliveryTest {
                session.rollback();
             }
             catch (JMSException e) {
-               LOG.warn("Caught an unexcepted exception: " + e.getMessage());
+               LOG.warn("Caught an unexpected exception: " + e.getMessage());
             }
          }
       });

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/e1728f07/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/usecases/StartAndStopBrokerTest.java
----------------------------------------------------------------------
diff --git a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/usecases/StartAndStopBrokerTest.java b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/usecases/StartAndStopBrokerTest.java
index eb20e10..2776548 100644
--- a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/usecases/StartAndStopBrokerTest.java
+++ b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/usecases/StartAndStopBrokerTest.java
@@ -36,7 +36,7 @@ public class StartAndStopBrokerTest extends TestCase {
       // have persistence messages as a default
       System.setProperty("activemq.persistenceAdapter", "org.apache.activemq.store.vm.VMPersistenceAdapter");
 
-      // configuration of container and all protocolls
+      // configuration of container and all protocols
       BrokerService broker = createBroker();
 
       // start a client

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/e1728f07/tests/jms-tests/src/test/java/org/apache/activemq/artemis/jms/tests/tools/container/Server.java
----------------------------------------------------------------------
diff --git a/tests/jms-tests/src/test/java/org/apache/activemq/artemis/jms/tests/tools/container/Server.java b/tests/jms-tests/src/test/java/org/apache/activemq/artemis/jms/tests/tools/container/Server.java
index 55b717f..1180726 100644
--- a/tests/jms-tests/src/test/java/org/apache/activemq/artemis/jms/tests/tools/container/Server.java
+++ b/tests/jms-tests/src/test/java/org/apache/activemq/artemis/jms/tests/tools/container/Server.java
@@ -53,7 +53,7 @@ public interface Server extends Remote {
    void kill() throws Exception;
 
    /**
-    * When kill is called you are actually schedulling the server to be killed in few milliseconds.
+    * When kill is called you are actually scheduling the server to be killed in few milliseconds.
     * There are certain cases where we need to assure the server was really killed.
     * For that we have this simple ping we can use to verify if the server still alive or not.
     */

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/e1728f07/tests/joram-tests/src/test/java/org/objectweb/jtests/jms/conform/connection/TopicConnectionTest.java
----------------------------------------------------------------------
diff --git a/tests/joram-tests/src/test/java/org/objectweb/jtests/jms/conform/connection/TopicConnectionTest.java b/tests/joram-tests/src/test/java/org/objectweb/jtests/jms/conform/connection/TopicConnectionTest.java
index 129e6f9..2d8200f 100644
--- a/tests/joram-tests/src/test/java/org/objectweb/jtests/jms/conform/connection/TopicConnectionTest.java
+++ b/tests/joram-tests/src/test/java/org/objectweb/jtests/jms/conform/connection/TopicConnectionTest.java
@@ -26,7 +26,7 @@ import org.objectweb.jtests.jms.framework.PubSubTestCase;
 /**
  * Test topic-specific connection features.
  *
- * Test setting of client ID which is relevant only for Durable Subscribtion
+ * Test setting of client ID which is relevant only for Durable Subscription
  */
 
 public class TopicConnectionTest extends PubSubTestCase {