You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@activemq.apache.org by jb...@apache.org on 2020/02/22 06:53:19 UTC

[activemq] 06/08: Fix some typos

This is an automated email from the ASF dual-hosted git repository.

jbonofre pushed a commit to branch activemq-5.15.x
in repository https://gitbox.apache.org/repos/asf/activemq.git

commit d05fe8ebdbec2652050624b0a1a30fe67419da57
Author: Daniel Trebbien <dt...@gmail.com>
AuthorDate: Fri Jul 28 19:23:27 2017 -0700

    Fix some typos
    
    (cherry picked from commit 7b528ecee77f02426e3f2b16cd49ccfaeb221f95)
---
 .../org/apache/activemq/broker/BrokerService.java  |  2 +-
 .../cursors/StoreDurableSubscriberCursor.java      |  2 +-
 .../broker/region/cursors/TopicStorePrefetch.java  |  2 +-
 .../apache/activemq/JmsTransactionTestSupport.java | 34 +++++++++++-----------
 .../apache/activemq/ActiveMQMessageConsumer.java   |  2 +-
 .../apache/activemq/jndi/JNDIReferenceFactory.java |  2 +-
 .../java/org/apache/activemq/util/IdGenerator.java |  2 +-
 .../apache/activemq/jms/pool/PooledConnection.java |  2 +-
 8 files changed, 24 insertions(+), 24 deletions(-)

diff --git a/activemq-broker/src/main/java/org/apache/activemq/broker/BrokerService.java b/activemq-broker/src/main/java/org/apache/activemq/broker/BrokerService.java
index 40547d5..b4cdcac 100644
--- a/activemq-broker/src/main/java/org/apache/activemq/broker/BrokerService.java
+++ b/activemq-broker/src/main/java/org/apache/activemq/broker/BrokerService.java
@@ -2163,7 +2163,7 @@ public class BrokerService implements Service {
     /**
      * Schedules a periodic task based on schedulePeriodForDiskLimitCheck to
      * update store and temporary store limits if the amount of available space
-     * plus current store size is less than the existin configured limit
+     * plus current store size is less than the existing configured limit
      */
     protected void scheduleDiskUsageLimitsCheck() throws IOException {
         if (schedulePeriodForDiskUsageCheck > 0 &&
diff --git a/activemq-broker/src/main/java/org/apache/activemq/broker/region/cursors/StoreDurableSubscriberCursor.java b/activemq-broker/src/main/java/org/apache/activemq/broker/region/cursors/StoreDurableSubscriberCursor.java
index 7864556..807f26a 100644
--- a/activemq-broker/src/main/java/org/apache/activemq/broker/region/cursors/StoreDurableSubscriberCursor.java
+++ b/activemq-broker/src/main/java/org/apache/activemq/broker/region/cursors/StoreDurableSubscriberCursor.java
@@ -199,7 +199,7 @@ public class StoreDurableSubscriberCursor extends AbstractPendingMessageCursor {
                     if (prioritizedMessages && immediatePriorityDispatch && tsp.isPaging()) {
                         if (msg.getPriority() > tsp.getLastRecoveredPriority()) {
                             tsp.recoverMessage(node.getMessage(), true);
-                            LOG.trace("cached high priority ({} message: {}, current paged batch priority: {}, cache size: {}", new Object[]{ msg.getPriority(), msg.getMessageId(), tsp.getLastRecoveredPriority(), tsp.batchList.size()});
+                            LOG.trace("cached high priority ({}) message: {}, current paged batch priority: {}, cache size: {}", new Object[]{ msg.getPriority(), msg.getMessageId(), tsp.getLastRecoveredPriority(), tsp.batchList.size()});
                         }
                     }
                 }
diff --git a/activemq-broker/src/main/java/org/apache/activemq/broker/region/cursors/TopicStorePrefetch.java b/activemq-broker/src/main/java/org/apache/activemq/broker/region/cursors/TopicStorePrefetch.java
index 71bb4eb..a97b1e8 100644
--- a/activemq-broker/src/main/java/org/apache/activemq/broker/region/cursors/TopicStorePrefetch.java
+++ b/activemq-broker/src/main/java/org/apache/activemq/broker/region/cursors/TopicStorePrefetch.java
@@ -28,7 +28,7 @@ import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
 /**
- * persist pendingCount messages pendingCount message (messages awaiting disptach
+ * persist pendingCount messages pendingCount message (messages awaiting dispatch
  * to a consumer) cursor
  *
  *
diff --git a/activemq-broker/src/test/java/org/apache/activemq/JmsTransactionTestSupport.java b/activemq-broker/src/test/java/org/apache/activemq/JmsTransactionTestSupport.java
index 539a1e0..e5bdbdf 100644
--- a/activemq-broker/src/test/java/org/apache/activemq/JmsTransactionTestSupport.java
+++ b/activemq-broker/src/test/java/org/apache/activemq/JmsTransactionTestSupport.java
@@ -162,7 +162,7 @@ public abstract class JmsTransactionTestSupport extends TestSupport implements M
 
         TextMessage message = session.createTextMessage("Batch Message");
         for (int j = 0; j < batchCount; j++) {
-            LOG.info("Producing bacth " + j + " of " + batchSize + " messages");
+            LOG.info("Producing batch " + j + " of " + batchSize + " messages");
 
             beginTx();
             for (int i = 0; i < batchSize; i++) {
@@ -170,7 +170,7 @@ public abstract class JmsTransactionTestSupport extends TestSupport implements M
             }
             messageSent();
             commitTx();
-            LOG.info("Consuming bacth " + j + " of " + batchSize + " messages");
+            LOG.info("Consuming batch " + j + " of " + batchSize + " messages");
 
             beginTx();
             for (int i = 0; i < batchSize; i++) {
@@ -187,7 +187,7 @@ public abstract class JmsTransactionTestSupport extends TestSupport implements M
     }
 
     /**
-     * Sends a batch of messages and validates that the rollbacked message was
+     * Sends a batch of messages and validates that the rolled-back message was
      * not consumed.
      *
      * @throws Exception
@@ -200,7 +200,7 @@ public abstract class JmsTransactionTestSupport extends TestSupport implements M
         producer.send(outbound[0]);
         commitTx();
 
-        // sends a message that gets rollbacked
+        // sends a message that gets rolled-back
         beginTx();
         producer.send(session.createTextMessage("I'm going to get rolled back."));
         rollbackTx();
@@ -224,7 +224,7 @@ public abstract class JmsTransactionTestSupport extends TestSupport implements M
         messages.add(message);
         LOG.info("Received: " + message);
 
-        // validates that the rollbacked was not consumed
+        // validates that the rolled-back was not consumed
         commitTx();
         Message inbound[] = new Message[messages.size()];
         messages.toArray(inbound);
@@ -253,7 +253,7 @@ public abstract class JmsTransactionTestSupport extends TestSupport implements M
         messages.add(message);
         LOG.info("Received: " + message);
 
-        // validates that the rollbacked was not consumed
+        // validates that the rolled-back was not consumed
         commitTx();
         Message inbound[] = new Message[messages.size()];
         messages.toArray(inbound);
@@ -275,7 +275,7 @@ public abstract class JmsTransactionTestSupport extends TestSupport implements M
         producer.send(outbound[0]);
         commitTx();
 
-        // sends a message that gets rollbacked
+        // sends a message that gets rolled-back
         beginTx();
         producer.send(session.createTextMessage("I'm going to get rolled back."));
         consumer.close();
@@ -300,7 +300,7 @@ public abstract class JmsTransactionTestSupport extends TestSupport implements M
         messages.add(message);
         LOG.info("Received: " + message);
 
-        // validates that the rollbacked was not consumed
+        // validates that the rolled-back was not consumed
         commitTx();
         Message inbound[] = new Message[messages.size()];
         messages.toArray(inbound);
@@ -321,7 +321,7 @@ public abstract class JmsTransactionTestSupport extends TestSupport implements M
         producer.send(outbound[0]);
         commitTx();
 
-        // sends a message that gets rollbacked
+        // sends a message that gets rolled-back
         beginTx();
         producer.send(session.createTextMessage("I'm going to get rolled back."));
         consumer.close();
@@ -348,7 +348,7 @@ public abstract class JmsTransactionTestSupport extends TestSupport implements M
         messages.add(message);
         LOG.info("Received: " + message);
 
-        // validates that the rollbacked was not consumed
+        // validates that the rolled-back was not consumed
         commitTx();
         Message inbound[] = new Message[messages.size()];
         messages.toArray(inbound);
@@ -356,7 +356,7 @@ public abstract class JmsTransactionTestSupport extends TestSupport implements M
     }
 
     /**
-     * Sends a batch of messages and validates that the rollbacked message was
+     * Sends a batch of messages and validates that the rolled-back message was
      * redelivered.
      *
      * @throws Exception
@@ -407,7 +407,7 @@ public abstract class JmsTransactionTestSupport extends TestSupport implements M
     }
 
     /**
-     * Sends a batch of messages and validates that the rollbacked message was
+     * Sends a batch of messages and validates that the rolled-back message was
      * redelivered.
      *
      * @throws Exception
@@ -461,7 +461,7 @@ public abstract class JmsTransactionTestSupport extends TestSupport implements M
     }
 
     /**
-     * Sends a batch of messages and validates that the rollbacked message was
+     * Sends a batch of messages and validates that the rolled-back message was
      * not consumed.
      *
      * @throws Exception
@@ -487,12 +487,12 @@ public abstract class JmsTransactionTestSupport extends TestSupport implements M
             LOG.info("Received: " + message);
         }
 
-        // validates that the rollbacked was not consumed
+        // validates that the rolled-back was not consumed
         commitTx();
     }
 
     /**
-     * Perform the test that validates if the rollbacked message was redelivered
+     * Perform the test that validates if the rolled-back message was redelivered
      * multiple times.
      *
      * @throws Exception
@@ -504,7 +504,7 @@ public abstract class JmsTransactionTestSupport extends TestSupport implements M
     }
 
     /**
-     * Sends a batch of messages and validates that the rollbacked message was
+     * Sends a batch of messages and validates that the rolled-back message was
      * not consumed. This test differs by setting the message prefetch to one.
      *
      * @throws Exception
@@ -515,7 +515,7 @@ public abstract class JmsTransactionTestSupport extends TestSupport implements M
     }
 
     /**
-     * Sends a batch of messages and and validates that the rollbacked message
+     * Sends a batch of messages and and validates that the rolled-back message
      * was redelivered. This test differs by setting the message prefetch to
      * one.
      *
diff --git a/activemq-client/src/main/java/org/apache/activemq/ActiveMQMessageConsumer.java b/activemq-client/src/main/java/org/apache/activemq/ActiveMQMessageConsumer.java
index 5c7015b..6e927f0 100644
--- a/activemq-client/src/main/java/org/apache/activemq/ActiveMQMessageConsumer.java
+++ b/activemq-client/src/main/java/org/apache/activemq/ActiveMQMessageConsumer.java
@@ -806,7 +806,7 @@ public class ActiveMQMessageConsumer implements MessageAvailableConsumer, StatsC
                         try {
                             session.sendAck(ackToSend,true);
                         } catch (JMSException e) {
-                            LOG.error(getConsumerId() + " failed to delivered acknowledgements", e);
+                            LOG.error(getConsumerId() + " failed to deliver acknowledgements", e);
                         } finally {
                             deliveryingAcknowledgements.set(false);
                         }
diff --git a/activemq-client/src/main/java/org/apache/activemq/jndi/JNDIReferenceFactory.java b/activemq-client/src/main/java/org/apache/activemq/jndi/JNDIReferenceFactory.java
index 9d7c11e..1619a8e 100644
--- a/activemq-client/src/main/java/org/apache/activemq/jndi/JNDIReferenceFactory.java
+++ b/activemq-client/src/main/java/org/apache/activemq/jndi/JNDIReferenceFactory.java
@@ -40,7 +40,7 @@ public class JNDIReferenceFactory implements ObjectFactory {
 
     /**
      * This will be called by a JNDIprovider when a Reference is retrieved from
-     * a JNDI store - and generates the orignal instance
+     * a JNDI store - and generates the original instance
      * 
      * @param object the Reference object
      * @param name the JNDI name
diff --git a/activemq-client/src/main/java/org/apache/activemq/util/IdGenerator.java b/activemq-client/src/main/java/org/apache/activemq/util/IdGenerator.java
index 0b29416..09a5658 100644
--- a/activemq-client/src/main/java/org/apache/activemq/util/IdGenerator.java
+++ b/activemq-client/src/main/java/org/apache/activemq/util/IdGenerator.java
@@ -184,7 +184,7 @@ public class IdGenerator {
     /**
      * From a generated id - return the seed (i.e. minus the count)
      *
-     * @param id the generated identifer
+     * @param id the generated identifier
      * @return the seed
      */
     public static String getSeedFromId(String id) {
diff --git a/activemq-jms-pool/src/main/java/org/apache/activemq/jms/pool/PooledConnection.java b/activemq-jms-pool/src/main/java/org/apache/activemq/jms/pool/PooledConnection.java
index 111e730..2b57039 100644
--- a/activemq-jms-pool/src/main/java/org/apache/activemq/jms/pool/PooledConnection.java
+++ b/activemq-jms-pool/src/main/java/org/apache/activemq/jms/pool/PooledConnection.java
@@ -256,7 +256,7 @@ public class PooledConnection implements TopicConnection, QueueConnection, Poole
             try {
                 session.close();
             } catch (JMSException ex) {
-                LOG.info("failed to close laoned Session \"" + session + "\" on closing pooled connection: " + ex.getMessage());
+                LOG.info("failed to close loaned Session \"" + session + "\" on closing pooled connection: " + ex.getMessage());
             }
         }
         loanedSessions.clear();