You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@activemq.apache.org by ma...@apache.org on 2016/07/26 14:14:58 UTC

[1/2] activemq-artemis git commit: Spelling fixes

Repository: activemq-artemis
Updated Branches:
  refs/heads/master edcecccab -> 64e95b9b9


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/aed49b38
Tree: http://git-wip-us.apache.org/repos/asf/activemq-artemis/tree/aed49b38
Diff: http://git-wip-us.apache.org/repos/asf/activemq-artemis/diff/aed49b38

Branch: refs/heads/master
Commit: aed49b3894835bea0d5fd93785d61bdfca42040c
Parents: 110158b
Author: Ville Skytt� <vi...@iki.fi>
Authored: Tue Jul 26 14:24:45 2016 +0300
Committer: Ville Skytt� <vi...@iki.fi>
Committed: Tue Jul 26 14:24:45 2016 +0300

----------------------------------------------------------------------
 .../activemq/artemis/api/core/client/ActiveMQClient.java       | 2 +-
 .../apache/activemq/artemis/core/protocol/core/Channel.java    | 2 +-
 artemis-protocols/artemis-amqp-protocol/pom.xml                | 2 +-
 .../artemis/core/protocol/mqtt/MQTTSessionCallback.java        | 2 +-
 .../artemis/core/protocol/mqtt/MQTTSubscriptionManager.java    | 2 +-
 .../artemis/core/protocol/openwire/OpenWireConnection.java     | 2 +-
 .../core/protocol/openwire/OpenWireMessageConverter.java       | 4 ++--
 artemis-protocols/artemis-proton-plug/pom.xml                  | 2 +-
 .../activemq/artemis/ra/inflow/ActiveMQActivationSpec.java     | 2 +-
 .../org/apache/activemq/artemis/rest/queue/QueueConsumer.java  | 2 +-
 .../core/persistence/impl/journal/BatchingIDGenerator.java     | 2 +-
 .../core/persistence/impl/journal/JournalStorageManager.java   | 2 +-
 .../extensions/xa/recovery/ActiveMQXAResourceRecovery.java     | 2 +-
 .../src/test/java/org/apache/activemq/AutoFailTestSupport.java | 4 ++--
 .../test/java/org/apache/activemq/JmsAutoAckListenerTest.java  | 2 +-
 .../src/test/java/org/apache/activemq/JmsAutoAckTest.java      | 2 +-
 .../java/org/apache/activemq/JmsClientAckListenerTest.java     | 4 ++--
 .../test/java/org/apache/activemq/network/NetworkLoadTest.java | 6 +++---
 .../activemq/usecases/DurableSubscriptionTestSupport.java      | 2 +-
 .../ThreeBrokerTempDestDemandSubscriptionCleanupTest.java      | 4 ++--
 .../transport/amqp/client/util/UnmodifiableConnection.java     | 4 ++--
 .../artemis/tests/integration/client/CoreClientTest.java       | 2 +-
 .../tests/integration/client/MultipleProducersTest.java        | 4 ++--
 .../integration/jms/server/management/JMSQueueControlTest.java | 4 ++--
 .../artemis/tests/integration/openwire/amq/JmsAutoAckTest.java | 2 +-
 .../activemq/artemis/tests/integration/stomp/StompTest.java    | 2 +-
 .../activemq/artemis/jms/tests/tools/container/Server.java     | 6 +++---
 27 files changed, 38 insertions(+), 38 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/aed49b38/artemis-core-client/src/main/java/org/apache/activemq/artemis/api/core/client/ActiveMQClient.java
----------------------------------------------------------------------
diff --git a/artemis-core-client/src/main/java/org/apache/activemq/artemis/api/core/client/ActiveMQClient.java b/artemis-core-client/src/main/java/org/apache/activemq/artemis/api/core/client/ActiveMQClient.java
index 1885d28..b6615be 100644
--- a/artemis-core-client/src/main/java/org/apache/activemq/artemis/api/core/client/ActiveMQClient.java
+++ b/artemis-core-client/src/main/java/org/apache/activemq/artemis/api/core/client/ActiveMQClient.java
@@ -269,7 +269,7 @@ public final class ActiveMQClient {
    }
 
    /**
-    * Allows programatically configuration of global thread pools properties.  This method will update the global
+    * Allows programmatical configuration of global thread pools properties.  This method will update the global
     * thread pool configuration based on the provided values notifying all globalThreadPoolListeners.
     *
     * Note: If global thread pools have already been created, they will not be updated with these new values.

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/aed49b38/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/Channel.java
----------------------------------------------------------------------
diff --git a/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/Channel.java b/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/Channel.java
index 4c59174..cf88d21 100644
--- a/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/Channel.java
+++ b/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/Channel.java
@@ -40,7 +40,7 @@ public interface Channel {
    long getID();
 
    /**
-    * This number increases every time the channel reconnects succesfully.
+    * This number increases every time the channel reconnects successfully.
     * This is used to guarantee the integrity of the channel on sequential commands such as large messages.
     * @return
     */

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/aed49b38/artemis-protocols/artemis-amqp-protocol/pom.xml
----------------------------------------------------------------------
diff --git a/artemis-protocols/artemis-amqp-protocol/pom.xml b/artemis-protocols/artemis-amqp-protocol/pom.xml
index a1fe6f6..a7033e9 100644
--- a/artemis-protocols/artemis-amqp-protocol/pom.xml
+++ b/artemis-protocols/artemis-amqp-protocol/pom.xml
@@ -30,7 +30,7 @@
    </properties>
 
    <dependencies>
-      <!-- JMS Client because of some Convertions that are done -->
+      <!-- JMS Client because of some conversions that are done -->
       <dependency>
          <groupId>org.apache.activemq</groupId>
          <artifactId>artemis-jms-client</artifactId>

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/aed49b38/artemis-protocols/artemis-mqtt-protocol/src/main/java/org/apache/activemq/artemis/core/protocol/mqtt/MQTTSessionCallback.java
----------------------------------------------------------------------
diff --git a/artemis-protocols/artemis-mqtt-protocol/src/main/java/org/apache/activemq/artemis/core/protocol/mqtt/MQTTSessionCallback.java b/artemis-protocols/artemis-mqtt-protocol/src/main/java/org/apache/activemq/artemis/core/protocol/mqtt/MQTTSessionCallback.java
index 57cb7fe..ea3fa0f 100644
--- a/artemis-protocols/artemis-mqtt-protocol/src/main/java/org/apache/activemq/artemis/core/protocol/mqtt/MQTTSessionCallback.java
+++ b/artemis-protocols/artemis-mqtt-protocol/src/main/java/org/apache/activemq/artemis/core/protocol/mqtt/MQTTSessionCallback.java
@@ -42,7 +42,7 @@ public class MQTTSessionCallback implements SessionCallback {
    }
 
    @Override
-   public int sendMessage(MessageReference referece, ServerMessage message, ServerConsumer consumer, int deliveryCount) {
+   public int sendMessage(MessageReference reference, ServerMessage message, ServerConsumer consumer, int deliveryCount) {
       try {
          session.getMqttPublishManager().sendMessage(message, consumer, deliveryCount);
       }

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/aed49b38/artemis-protocols/artemis-mqtt-protocol/src/main/java/org/apache/activemq/artemis/core/protocol/mqtt/MQTTSubscriptionManager.java
----------------------------------------------------------------------
diff --git a/artemis-protocols/artemis-mqtt-protocol/src/main/java/org/apache/activemq/artemis/core/protocol/mqtt/MQTTSubscriptionManager.java b/artemis-protocols/artemis-mqtt-protocol/src/main/java/org/apache/activemq/artemis/core/protocol/mqtt/MQTTSubscriptionManager.java
index cbe64a6..ea6eb4a 100644
--- a/artemis-protocols/artemis-mqtt-protocol/src/main/java/org/apache/activemq/artemis/core/protocol/mqtt/MQTTSubscriptionManager.java
+++ b/artemis-protocols/artemis-mqtt-protocol/src/main/java/org/apache/activemq/artemis/core/protocol/mqtt/MQTTSubscriptionManager.java
@@ -38,7 +38,7 @@ public class MQTTSubscriptionManager {
 
    private MQTTLogger log = MQTTLogger.LOGGER;
 
-   // We filter out Artemis managment messages and notifications
+   // We filter out Artemis management messages and notifications
    private SimpleString managementFilter;
 
    public MQTTSubscriptionManager(MQTTSession session) {

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/aed49b38/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 fad17af..fe05c9e 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
@@ -845,7 +845,7 @@ public class OpenWireConnection extends AbstractRemotingConnection implements Se
 
    CommandProcessor commandProcessorInstance = new CommandProcessor();
 
-   // This will listen for commands throught the protocolmanager
+   // This will listen for commands through the protocolmanager
    public class CommandProcessor implements CommandVisitor {
 
       public AMQConnectionContext getContext() {

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/aed49b38/artemis-protocols/artemis-openwire-protocol/src/main/java/org/apache/activemq/artemis/core/protocol/openwire/OpenWireMessageConverter.java
----------------------------------------------------------------------
diff --git a/artemis-protocols/artemis-openwire-protocol/src/main/java/org/apache/activemq/artemis/core/protocol/openwire/OpenWireMessageConverter.java b/artemis-protocols/artemis-openwire-protocol/src/main/java/org/apache/activemq/artemis/core/protocol/openwire/OpenWireMessageConverter.java
index 121560f..b5689f5 100644
--- a/artemis-protocols/artemis-openwire-protocol/src/main/java/org/apache/activemq/artemis/core/protocol/openwire/OpenWireMessageConverter.java
+++ b/artemis-protocols/artemis-openwire-protocol/src/main/java/org/apache/activemq/artemis/core/protocol/openwire/OpenWireMessageConverter.java
@@ -448,7 +448,7 @@ public class OpenWireMessageConverter implements MessageConverter {
       return md;
    }
 
-   private static ActiveMQMessage toAMQMessage(MessageReference refernce, ServerMessage coreMessage, WireFormat marshaller, ActiveMQDestination actualDestination) throws IOException {
+   private static ActiveMQMessage toAMQMessage(MessageReference reference, ServerMessage coreMessage, WireFormat marshaller, ActiveMQDestination actualDestination) throws IOException {
       ActiveMQMessage amqMsg = null;
       byte coreType = coreMessage.getType();
       switch (coreType) {
@@ -748,7 +748,7 @@ public class OpenWireMessageConverter implements MessageConverter {
          amqMsg.setMarshalledProperties(new ByteSequence(marshalledBytes));
       }
 
-      amqMsg.setRedeliveryCounter(refernce.getDeliveryCount() - 1);
+      amqMsg.setRedeliveryCounter(reference.getDeliveryCount() - 1);
 
       byte[] replyToBytes = (byte[]) coreMessage.getObjectProperty(AMQ_MSG_REPLY_TO);
       if (replyToBytes != null) {

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/aed49b38/artemis-protocols/artemis-proton-plug/pom.xml
----------------------------------------------------------------------
diff --git a/artemis-protocols/artemis-proton-plug/pom.xml b/artemis-protocols/artemis-proton-plug/pom.xml
index c140f60..684b3ce 100644
--- a/artemis-protocols/artemis-proton-plug/pom.xml
+++ b/artemis-protocols/artemis-proton-plug/pom.xml
@@ -30,7 +30,7 @@
    </properties>
 
    <dependencies>
-      <!-- JMS Client because of some Convertions that are done -->
+      <!-- JMS Client because of some conversions that are done -->
       <dependency>
          <groupId>org.apache.activemq</groupId>
          <artifactId>artemis-jms-client</artifactId>

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/aed49b38/artemis-ra/src/main/java/org/apache/activemq/artemis/ra/inflow/ActiveMQActivationSpec.java
----------------------------------------------------------------------
diff --git a/artemis-ra/src/main/java/org/apache/activemq/artemis/ra/inflow/ActiveMQActivationSpec.java b/artemis-ra/src/main/java/org/apache/activemq/artemis/ra/inflow/ActiveMQActivationSpec.java
index 7a8e8c4..61dc37a 100644
--- a/artemis-ra/src/main/java/org/apache/activemq/artemis/ra/inflow/ActiveMQActivationSpec.java
+++ b/artemis-ra/src/main/java/org/apache/activemq/artemis/ra/inflow/ActiveMQActivationSpec.java
@@ -792,7 +792,7 @@ public class ActiveMQActivationSpec extends ConnectionFactoryProperties implemen
       return buffer.toString();
    }
 
-   // here for backwards compatibilty
+   // here for backwards compatibility
    public void setUseDLQ(final boolean b) {
    }
 

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/aed49b38/artemis-rest/src/main/java/org/apache/activemq/artemis/rest/queue/QueueConsumer.java
----------------------------------------------------------------------
diff --git a/artemis-rest/src/main/java/org/apache/activemq/artemis/rest/queue/QueueConsumer.java b/artemis-rest/src/main/java/org/apache/activemq/artemis/rest/queue/QueueConsumer.java
index 9ebc209..96a1ae9 100644
--- a/artemis-rest/src/main/java/org/apache/activemq/artemis/rest/queue/QueueConsumer.java
+++ b/artemis-rest/src/main/java/org/apache/activemq/artemis/rest/queue/QueueConsumer.java
@@ -39,7 +39,7 @@ import org.apache.activemq.artemis.rest.util.LinkStrategy;
 import org.apache.activemq.artemis.utils.SelectorTranslator;
 
 /**
- * Auto-acknowleged consumer
+ * Auto-acknowledged consumer
  */
 public class QueueConsumer {
 

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/aed49b38/artemis-server/src/main/java/org/apache/activemq/artemis/core/persistence/impl/journal/BatchingIDGenerator.java
----------------------------------------------------------------------
diff --git a/artemis-server/src/main/java/org/apache/activemq/artemis/core/persistence/impl/journal/BatchingIDGenerator.java b/artemis-server/src/main/java/org/apache/activemq/artemis/core/persistence/impl/journal/BatchingIDGenerator.java
index a3e9640..cdcb4fa 100644
--- a/artemis-server/src/main/java/org/apache/activemq/artemis/core/persistence/impl/journal/BatchingIDGenerator.java
+++ b/artemis-server/src/main/java/org/apache/activemq/artemis/core/persistence/impl/journal/BatchingIDGenerator.java
@@ -124,7 +124,7 @@ public final class BatchingIDGenerator implements IDGenerator {
 
          if (!storageManager.isStarted()) {
             // This could happen after the server is stopped
-            // while notifications are being sent and ID gerated.
+            // while notifications are being sent and ID generated.
             // If the ID is intended to the journal you would know soon enough
             // so we just ignore this for now
             logger.debug("The journalStorageManager is not loaded. " + "This is probably ok as long as it's a notification being sent after shutdown");

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/aed49b38/artemis-server/src/main/java/org/apache/activemq/artemis/core/persistence/impl/journal/JournalStorageManager.java
----------------------------------------------------------------------
diff --git a/artemis-server/src/main/java/org/apache/activemq/artemis/core/persistence/impl/journal/JournalStorageManager.java b/artemis-server/src/main/java/org/apache/activemq/artemis/core/persistence/impl/journal/JournalStorageManager.java
index 157306e..b50e117 100644
--- a/artemis-server/src/main/java/org/apache/activemq/artemis/core/persistence/impl/journal/JournalStorageManager.java
+++ b/artemis-server/src/main/java/org/apache/activemq/artemis/core/persistence/impl/journal/JournalStorageManager.java
@@ -192,7 +192,7 @@ public class JournalStorageManager extends AbstractJournalStorageManager {
       latch.await(30, TimeUnit.SECONDS);
 
       // We cache the variable as the replicator could be changed between here and the time we call stop
-      // since sendLiveIsStoping my issue a close back from the channel
+      // since sendLiveIsStopping may issue a close back from the channel
       // and we want to ensure a stop here just in case
       ReplicationManager replicatorInUse = replicator;
       if (replicatorInUse != null) {

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/aed49b38/artemis-service-extensions/src/main/java/org/apache/activemq/artemis/service/extensions/xa/recovery/ActiveMQXAResourceRecovery.java
----------------------------------------------------------------------
diff --git a/artemis-service-extensions/src/main/java/org/apache/activemq/artemis/service/extensions/xa/recovery/ActiveMQXAResourceRecovery.java b/artemis-service-extensions/src/main/java/org/apache/activemq/artemis/service/extensions/xa/recovery/ActiveMQXAResourceRecovery.java
index f22f295..b80795c 100644
--- a/artemis-service-extensions/src/main/java/org/apache/activemq/artemis/service/extensions/xa/recovery/ActiveMQXAResourceRecovery.java
+++ b/artemis-service-extensions/src/main/java/org/apache/activemq/artemis/service/extensions/xa/recovery/ActiveMQXAResourceRecovery.java
@@ -62,7 +62,7 @@ public class ActiveMQXAResourceRecovery {
 
    public boolean initialise(final String config) {
       if (ActiveMQXARecoveryLogger.LOGGER.isTraceEnabled()) {
-         ActiveMQXARecoveryLogger.LOGGER.trace(this + " intialise: " + config);
+         ActiveMQXARecoveryLogger.LOGGER.trace(this + " initialise: " + config);
       }
 
       String[] configs = config.split(";");

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/aed49b38/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/AutoFailTestSupport.java
----------------------------------------------------------------------
diff --git a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/AutoFailTestSupport.java b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/AutoFailTestSupport.java
index 519536d..4a2ccc9 100644
--- a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/AutoFailTestSupport.java
+++ b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/AutoFailTestSupport.java
@@ -74,12 +74,12 @@ public abstract class AutoFailTestSupport extends TestCase {
             @Override
             public void run() {
                 try {
-                    // Wait for test to finish succesfully
+                    // Wait for test to finish successfully
                     Thread.sleep(getMaxTestTime());
                 } catch (InterruptedException e) {
                     // This usually means the test was successful
                 } finally {
-                    // Check if the test was able to tear down succesfully,
+                    // Check if the test was able to tear down successfully,
                     // which usually means, it has finished its run.
                     if (!isTestSuccess.get()) {
                         LOG.error("Test case has exceeded the maximum allotted time to run of: " + getMaxTestTime() + " ms.");

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/aed49b38/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/JmsAutoAckListenerTest.java
----------------------------------------------------------------------
diff --git a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/JmsAutoAckListenerTest.java b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/JmsAutoAckListenerTest.java
index 5900560..0b5ea63 100644
--- a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/JmsAutoAckListenerTest.java
+++ b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/JmsAutoAckListenerTest.java
@@ -50,7 +50,7 @@ public class JmsAutoAckListenerTest extends TestSupport implements MessageListen
    }
 
    /**
-    * Tests if acknowleged messages are being consumed.
+    * Tests if acknowledged messages are being consumed.
     *
     * @throws javax.jms.JMSException
     */

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/aed49b38/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/JmsAutoAckTest.java
----------------------------------------------------------------------
diff --git a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/JmsAutoAckTest.java b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/JmsAutoAckTest.java
index 39e73fe..c2b00e9 100644
--- a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/JmsAutoAckTest.java
+++ b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/JmsAutoAckTest.java
@@ -50,7 +50,7 @@ public class JmsAutoAckTest extends TestSupport {
    }
 
    /**
-    * Tests if acknowleged messages are being consumed.
+    * Tests if acknowledged messages are being consumed.
     *
     * @throws javax.jms.JMSException
     */

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/aed49b38/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/JmsClientAckListenerTest.java
----------------------------------------------------------------------
diff --git a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/JmsClientAckListenerTest.java b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/JmsClientAckListenerTest.java
index 9142cf8..a707a96 100644
--- a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/JmsClientAckListenerTest.java
+++ b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/JmsClientAckListenerTest.java
@@ -51,7 +51,7 @@ public class JmsClientAckListenerTest extends TestSupport implements MessageList
    }
 
    /**
-    * Tests if acknowleged messages are being consumed.
+    * Tests if acknowledged messages are being consumed.
     *
     * @throws javax.jms.JMSException
     */
@@ -82,7 +82,7 @@ public class JmsClientAckListenerTest extends TestSupport implements MessageList
    }
 
    /**
-    * Tests if unacknowleged messages are being redelivered when the consumer
+    * Tests if unacknowledged messages are being redelivered when the consumer
     * connects again.
     *
     * @throws javax.jms.JMSException

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/aed49b38/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 335a63c..5471218 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
@@ -139,7 +139,7 @@ public class NetworkLoadTest extends TestCase {
 
       forwardingClients = new ForwardingClient[BROKER_COUNT - 1];
       for (int i = 0; i < forwardingClients.length; i++) {
-         LOG.info("Starting fowarding client " + i);
+         LOG.info("Starting forwarding client " + i);
          forwardingClients[i] = new ForwardingClient(i, i + 1);
          forwardingClients[i].start();
       }
@@ -148,11 +148,11 @@ public class NetworkLoadTest extends TestCase {
    @Override
    protected void tearDown() throws Exception {
       for (int i = 0; i < forwardingClients.length; i++) {
-         LOG.info("Stoping fowarding client " + i);
+         LOG.info("Stopping forwarding client " + i);
          forwardingClients[i].close();
       }
       for (int i = 0; i < brokers.length; i++) {
-         LOG.info("Stoping broker " + i);
+         LOG.info("Stopping broker " + i);
          brokers[i].stop();
       }
    }

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/aed49b38/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 040aa85..567ced0 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
@@ -448,7 +448,7 @@ public abstract class DurableSubscriptionTestSupport extends TestSupport {
       }
 
       // See if the durable sub works in a new connection.
-      // The embeded broker shutsdown when his connections are closed.
+      // The embedded broker shuts down when its connections are closed.
       // So we open the new connection before the old one is closed.
       connection.close();
       connection = createConnection();

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/aed49b38/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/usecases/ThreeBrokerTempDestDemandSubscriptionCleanupTest.java
----------------------------------------------------------------------
diff --git a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/usecases/ThreeBrokerTempDestDemandSubscriptionCleanupTest.java b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/usecases/ThreeBrokerTempDestDemandSubscriptionCleanupTest.java
index 41a0aed..7b34799 100644
--- a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/usecases/ThreeBrokerTempDestDemandSubscriptionCleanupTest.java
+++ b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/usecases/ThreeBrokerTempDestDemandSubscriptionCleanupTest.java
@@ -102,7 +102,7 @@ public class ThreeBrokerTempDestDemandSubscriptionCleanupTest extends JmsMultipl
                   assertNotNull("We should have gotten a response, but didn't for iter: " + i, response);
                   assertEquals("We got the wrong response from the echo service", "Iteration: " + i, response.getText());
 
-                  // so we close the consumer so that an actual RemoveInfo command gets propogated through the
+                  // so we close the consumer so that an actual RemoveInfo command gets propagated through the
                   // network
                   responseConsumer.close();
                   conn.close();
@@ -263,4 +263,4 @@ public class ThreeBrokerTempDestDemandSubscriptionCleanupTest extends JmsMultipl
       connector.setDuplex(true);
       return connector;
    }
-}
\ No newline at end of file
+}

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/aed49b38/tests/artemis-test-support/src/main/java/org/apache/activemq/transport/amqp/client/util/UnmodifiableConnection.java
----------------------------------------------------------------------
diff --git a/tests/artemis-test-support/src/main/java/org/apache/activemq/transport/amqp/client/util/UnmodifiableConnection.java b/tests/artemis-test-support/src/main/java/org/apache/activemq/transport/amqp/client/util/UnmodifiableConnection.java
index 32003a4..5e2ef15 100644
--- a/tests/artemis-test-support/src/main/java/org/apache/activemq/transport/amqp/client/util/UnmodifiableConnection.java
+++ b/tests/artemis-test-support/src/main/java/org/apache/activemq/transport/amqp/client/util/UnmodifiableConnection.java
@@ -100,13 +100,13 @@ public class UnmodifiableConnection implements Connection {
 
    @Override
    public Link linkHead(EnumSet<EndpointState> local, EnumSet<EndpointState> remote) {
-      // TODO - If implemented this method should return an unmodifiable link isntance.
+      // TODO - If implemented this method should return an unmodifiable link instance.
       return null;
    }
 
    @Override
    public Delivery getWorkHead() {
-      // TODO - If implemented this method should return an unmodifiable delivery isntance.
+      // TODO - If implemented this method should return an unmodifiable delivery instance.
       return null;
    }
 

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/aed49b38/tests/integration-tests/src/test/java/org/apache/activemq/artemis/tests/integration/client/CoreClientTest.java
----------------------------------------------------------------------
diff --git a/tests/integration-tests/src/test/java/org/apache/activemq/artemis/tests/integration/client/CoreClientTest.java b/tests/integration-tests/src/test/java/org/apache/activemq/artemis/tests/integration/client/CoreClientTest.java
index 86bc765..a907ad2 100644
--- a/tests/integration-tests/src/test/java/org/apache/activemq/artemis/tests/integration/client/CoreClientTest.java
+++ b/tests/integration-tests/src/test/java/org/apache/activemq/artemis/tests/integration/client/CoreClientTest.java
@@ -117,7 +117,7 @@ public class CoreClientTest extends ActiveMQTestBase {
 
          // One way around the setting destination problem is as follows -
          // Remove destination as an attribute from client producer.
-         // The destination always has to be set explicity before sending a message
+         // The destination always has to be set explicitly before sending a message
 
          message.setAddress(QUEUE);
 

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/aed49b38/tests/integration-tests/src/test/java/org/apache/activemq/artemis/tests/integration/client/MultipleProducersTest.java
----------------------------------------------------------------------
diff --git a/tests/integration-tests/src/test/java/org/apache/activemq/artemis/tests/integration/client/MultipleProducersTest.java b/tests/integration-tests/src/test/java/org/apache/activemq/artemis/tests/integration/client/MultipleProducersTest.java
index 4aedc98..a98ff74 100644
--- a/tests/integration-tests/src/test/java/org/apache/activemq/artemis/tests/integration/client/MultipleProducersTest.java
+++ b/tests/integration-tests/src/test/java/org/apache/activemq/artemis/tests/integration/client/MultipleProducersTest.java
@@ -120,7 +120,7 @@ public class MultipleProducersTest extends JMSTestBase {
       }
 
       // send 5 message to queueTwo
-      // there shoudl be 5 messages on queueTwo
+      // there should be 5 messages on queueTwo
       for (int i = 0; i < 5; i++) {
          sendMessage(queueTwo, session);
       }
@@ -137,7 +137,7 @@ public class MultipleProducersTest extends JMSTestBase {
          sendMessage(queueOne, session);
       }
 
-      // at the end of the test there shoudl be 5 message on queueOne and 5 messages on queueTwo
+      // at the end of the test there should be 5 message on queueOne and 5 messages on queueTwo
 
       session.close();
 

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/aed49b38/tests/integration-tests/src/test/java/org/apache/activemq/artemis/tests/integration/jms/server/management/JMSQueueControlTest.java
----------------------------------------------------------------------
diff --git a/tests/integration-tests/src/test/java/org/apache/activemq/artemis/tests/integration/jms/server/management/JMSQueueControlTest.java b/tests/integration-tests/src/test/java/org/apache/activemq/artemis/tests/integration/jms/server/management/JMSQueueControlTest.java
index 406dc8f..e312a2a 100644
--- a/tests/integration-tests/src/test/java/org/apache/activemq/artemis/tests/integration/jms/server/management/JMSQueueControlTest.java
+++ b/tests/integration-tests/src/test/java/org/apache/activemq/artemis/tests/integration/jms/server/management/JMSQueueControlTest.java
@@ -1517,7 +1517,7 @@ public class JMSQueueControlTest extends ManagementTestBase {
 
    @Test
    public void testMoveMessageToUnknownQueue() throws Exception {
-      String unknwonQueue = RandomUtil.randomString();
+      String unknownQueue = RandomUtil.randomString();
 
       String[] messageIDs = JMSUtil.sendMessages(queue, 1);
 
@@ -1525,7 +1525,7 @@ public class JMSQueueControlTest extends ManagementTestBase {
       Assert.assertEquals(1, getMessageCount(queueControl));
 
       try {
-         queueControl.moveMessage(messageIDs[0], unknwonQueue);
+         queueControl.moveMessage(messageIDs[0], unknownQueue);
          Assert.fail();
       }
       catch (Exception e) {

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/aed49b38/tests/integration-tests/src/test/java/org/apache/activemq/artemis/tests/integration/openwire/amq/JmsAutoAckTest.java
----------------------------------------------------------------------
diff --git a/tests/integration-tests/src/test/java/org/apache/activemq/artemis/tests/integration/openwire/amq/JmsAutoAckTest.java b/tests/integration-tests/src/test/java/org/apache/activemq/artemis/tests/integration/openwire/amq/JmsAutoAckTest.java
index 5644244..d937d11 100644
--- a/tests/integration-tests/src/test/java/org/apache/activemq/artemis/tests/integration/openwire/amq/JmsAutoAckTest.java
+++ b/tests/integration-tests/src/test/java/org/apache/activemq/artemis/tests/integration/openwire/amq/JmsAutoAckTest.java
@@ -32,7 +32,7 @@ import org.junit.Test;
 public class JmsAutoAckTest extends BasicOpenWireTest {
 
    /**
-    * Tests if acknowleged messages are being consumed.
+    * Tests if acknowledged messages are being consumed.
     *
     * @throws javax.jms.JMSException
     */

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/aed49b38/tests/integration-tests/src/test/java/org/apache/activemq/artemis/tests/integration/stomp/StompTest.java
----------------------------------------------------------------------
diff --git a/tests/integration-tests/src/test/java/org/apache/activemq/artemis/tests/integration/stomp/StompTest.java b/tests/integration-tests/src/test/java/org/apache/activemq/artemis/tests/integration/stomp/StompTest.java
index 67293be..1c4adc5 100644
--- a/tests/integration-tests/src/test/java/org/apache/activemq/artemis/tests/integration/stomp/StompTest.java
+++ b/tests/integration-tests/src/test/java/org/apache/activemq/artemis/tests/integration/stomp/StompTest.java
@@ -191,7 +191,7 @@ public class StompTest extends StompTestBase {
       frame = "SEND\n" + "destination:" + address + "\n\n" + stompPayload + Stomp.NULL;
       sendFrame(frame);
 
-      // Recieve MQTT Message
+      // Receive MQTT Message
       byte[] mqttPayload = clientProvider.receive(10000);
       clientProvider.disconnect();
 

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/aed49b38/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 a006365..55b717f 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
@@ -103,7 +103,7 @@ public interface Server extends Remote {
    // int downCacheSize, boolean manageConfirmations) throws Exception;
    //
    // /**
-   // * Creates a topic programatically.
+   // * Creates a topic programmatically.
    // */
    // void deployTopicProgrammatically(String name, String jndiName) throws Exception;
    //
@@ -119,7 +119,7 @@ public interface Server extends Remote {
    // int downCacheSize, boolean manageConfirmations) throws Exception;
    //
    // /**
-   // * Creates a queue programatically.
+   // * Creates a queue programmatically.
    // */
    // void deployQueueProgrammatically(String name, String jndiName) throws Exception;
 
@@ -130,7 +130,7 @@ public interface Server extends Remote {
    // void undeployDestination(boolean isQueue, String name) throws Exception;
 
    /**
-    * Destroys a programatically created destination.
+    * Destroys a programmatically created destination.
     */
    // boolean undeployDestinationProgrammatically(boolean isQueue, String name) throws Exception;
    void deployConnectionFactory(String clientId,


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

Posted by ma...@apache.org.
This closes #665


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

Branch: refs/heads/master
Commit: 64e95b9b9192f058fc3cb1053a03879ef2a3d8c6
Parents: edceccc aed49b3
Author: Martyn Taylor <mt...@redhat.com>
Authored: Tue Jul 26 15:14:40 2016 +0100
Committer: Martyn Taylor <mt...@redhat.com>
Committed: Tue Jul 26 15:14:40 2016 +0100

----------------------------------------------------------------------
 .../activemq/artemis/api/core/client/ActiveMQClient.java       | 2 +-
 .../apache/activemq/artemis/core/protocol/core/Channel.java    | 2 +-
 artemis-protocols/artemis-amqp-protocol/pom.xml                | 2 +-
 .../artemis/core/protocol/mqtt/MQTTSessionCallback.java        | 2 +-
 .../artemis/core/protocol/mqtt/MQTTSubscriptionManager.java    | 2 +-
 .../artemis/core/protocol/openwire/OpenWireConnection.java     | 2 +-
 .../core/protocol/openwire/OpenWireMessageConverter.java       | 4 ++--
 artemis-protocols/artemis-proton-plug/pom.xml                  | 2 +-
 .../activemq/artemis/ra/inflow/ActiveMQActivationSpec.java     | 2 +-
 .../org/apache/activemq/artemis/rest/queue/QueueConsumer.java  | 2 +-
 .../core/persistence/impl/journal/BatchingIDGenerator.java     | 2 +-
 .../core/persistence/impl/journal/JournalStorageManager.java   | 2 +-
 .../extensions/xa/recovery/ActiveMQXAResourceRecovery.java     | 2 +-
 .../src/test/java/org/apache/activemq/AutoFailTestSupport.java | 4 ++--
 .../test/java/org/apache/activemq/JmsAutoAckListenerTest.java  | 2 +-
 .../src/test/java/org/apache/activemq/JmsAutoAckTest.java      | 2 +-
 .../java/org/apache/activemq/JmsClientAckListenerTest.java     | 4 ++--
 .../test/java/org/apache/activemq/network/NetworkLoadTest.java | 6 +++---
 .../activemq/usecases/DurableSubscriptionTestSupport.java      | 2 +-
 .../ThreeBrokerTempDestDemandSubscriptionCleanupTest.java      | 4 ++--
 .../transport/amqp/client/util/UnmodifiableConnection.java     | 4 ++--
 .../artemis/tests/integration/client/CoreClientTest.java       | 2 +-
 .../tests/integration/client/MultipleProducersTest.java        | 4 ++--
 .../integration/jms/server/management/JMSQueueControlTest.java | 4 ++--
 .../artemis/tests/integration/openwire/amq/JmsAutoAckTest.java | 2 +-
 .../activemq/artemis/tests/integration/stomp/StompTest.java    | 2 +-
 .../activemq/artemis/jms/tests/tools/container/Server.java     | 6 +++---
 27 files changed, 38 insertions(+), 38 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/64e95b9b/artemis-protocols/artemis-mqtt-protocol/src/main/java/org/apache/activemq/artemis/core/protocol/mqtt/MQTTSubscriptionManager.java
----------------------------------------------------------------------