NO-JIRA Fixing typos in log messages, test names and comments

Related to ARTEMIS-387 (fowardingAddress)
This commit is contained in:
Jiri Danek 2017-02-19 13:07:37 +01:00 committed by Clebert Suconic
parent e43add02d7
commit a7a0535afa
51 changed files with 94 additions and 97 deletions

View File

@ -54,7 +54,7 @@ public interface ActiveMQBuffer extends DataInput {
/**
* Sets the {@code readerIndex} of this buffer.
*
* @param readerIndex The reader's index The reader infex
* @param readerIndex The reader's index
* @throws IndexOutOfBoundsException if the specified {@code readerIndex} is
* less than {@code 0} or
* greater than {@code this.writerIndex}

View File

@ -162,7 +162,7 @@ public abstract class ActiveMQScheduledComponent implements ActiveMQComponent, R
return future != null;
}
// this will restart the schedulped component upon changes
// this will restart the scheduled component upon changes
private void restartIfNeeded() {
if (isStarted()) {
stop();

View File

@ -25,7 +25,7 @@ import java.util.Random;
* <li>Java classes can only product time stamps with maximum resolution of one
* millisecond (at least before JDK 1.5). To compensate, an additional counter
* is used, so that more than one UUID can be generated between java clock
* updates. Counter may be used to generate up to 10000 UUIDs for each distrinct
* updates. Counter may be used to generate up to 10000 UUIDs for each distinct
* java clock value.
* <li>Due to even lower clock resolution on some platforms (older Windows
* versions use 55 msec resolution), timestamp value can also advanced ahead of

View File

@ -255,10 +255,10 @@ public class URISupport {
/**
* Given a composite URI, parse the individual URI elements contained within that URI and return
* a CompsoteData instance that contains the parsed URI values.
* a CompositeData instance that contains the parsed URI values.
*
* @param uri The target URI that should be parsed.
* @return a new CompsiteData instance representing the parsed composite URI.
* @return a new CompositeData instance representing the parsed composite URI.
* @throws java.net.URISyntaxException
*/
public static CompositeData parseComposite(URI uri) throws URISyntaxException {
@ -277,7 +277,7 @@ public class URISupport {
* Examine a URI and determine if it is a Composite type or not.
*
* @param uri The URI that is to be examined.
* @return true if the given URI is a Compsote type.
* @return true if the given URI is a Composite type.
*/
public static boolean isCompositeURI(URI uri) {
String ssp = stripPrefix(uri.getRawSchemeSpecificPart().trim(), "//").trim();
@ -333,7 +333,7 @@ public class URISupport {
* for logging as the ssp should have already been extracted from it and passed here.
*
* @param uri The original source URI whose ssp is parsed into the composite data.
* @param rc The CompsositeData instance that will be populated from the given ssp.
* @param rc The CompositeData instance that will be populated from the given ssp.
* @param ssp The scheme specific part from the original string that is a composite or one or more URIs.
* @throws java.net.URISyntaxException
*/
@ -524,10 +524,10 @@ public class URISupport {
}
/**
* Examine the supplied string and ensure that all parends appear as matching pairs.
* Examine the supplied string and ensure that all parens appear as matching pairs.
*
* @param str The target string to examine.
* @return true if the target string has valid parend pairings.
* @return true if the target string has valid paren pairings.
*/
public static boolean checkParenthesis(String str) {
boolean result = true;

View File

@ -71,12 +71,12 @@ public class URIParserTest {
}
/**
* Even thought there's no host Poperty on FruitBase.. this should still work fine without throwing any exceptions
* Even thought there's no host Property on FruitBase.. this should still work fine without throwing any exceptions
*
* @throws Throwable
*/
@Test
public void testSchemaNoHosPropertyt() throws Throwable {
public void testSchemaNoHosProperty() throws Throwable {
FruitParser parser = new FruitParser();
FruitBase fruit = parser.newObject(new URI("base://some:guy@fair-market:3030?color=green&fluentName=something"), null);
Assert.assertEquals("base", fruit.getName());
@ -85,7 +85,7 @@ public class URIParserTest {
}
/**
* Even thought there's no host Poperty on FruitBase.. this should still work fine without throwing any exceptions
* Even thought there's no host Property on FruitBase.. this should still work fine without throwing any exceptions
*
* @throws Throwable
*/

View File

@ -310,7 +310,7 @@ public final class ActiveMQDefaultConfiguration {
// Producer flow control
private static int DEFAULT_BRIDGE_PRODUCER_WINDOW_SIZE = -1;
// Upon reconnection this configures the number of time the same node on the topology will be retried before reseting the server locator and using the initial connectors
// Upon reconnection this configures the number of time the same node on the topology will be retried before resetting the server locator and using the initial connectors
private static int DEFAULT_BRIDGE_CONNECT_SAME_NODE = 10;
// The period (in milliseconds) used to check if the cluster connection has failed to receive pings from another server

View File

@ -213,7 +213,7 @@ public interface ActiveMQServerControl {
/**
* Returns whether the bindings directory is created on this server startup.
*/
@Attribute(desc = "whether the bindings directory is created on this server startu")
@Attribute(desc = "whether the bindings directory is created on this server startup")
boolean isCreateBindingsDir();
/**
@ -999,7 +999,7 @@ public interface ActiveMQServerControl {
void createBridge(@Parameter(name = "name", desc = "Name of the bridge") String name,
@Parameter(name = "queueName", desc = "Name of the source queue") String queueName,
@Parameter(name = "forwardingAddress", desc = "Forwarding address") String forwardingAddress,
@Parameter(name = "filterString", desc = "Filter of the brdige") String filterString,
@Parameter(name = "filterString", desc = "Filter of the bridge") String filterString,
@Parameter(name = "transformerClassName", desc = "Class name of the bridge transformer") String transformerClassName,
@Parameter(name = "retryInterval", desc = "Connection retry interval") long retryInterval,
@Parameter(name = "retryIntervalMultiplier", desc = "Connection retry interval multiplier") double retryIntervalMultiplier,
@ -1019,7 +1019,7 @@ public interface ActiveMQServerControl {
void createBridge(@Parameter(name = "name", desc = "Name of the bridge") String name,
@Parameter(name = "queueName", desc = "Name of the source queue") String queueName,
@Parameter(name = "forwardingAddress", desc = "Forwarding address") String forwardingAddress,
@Parameter(name = "filterString", desc = "Filter of the brdige") String filterString,
@Parameter(name = "filterString", desc = "Filter of the bridge") String filterString,
@Parameter(name = "transformerClassName", desc = "Class name of the bridge transformer") String transformerClassName,
@Parameter(name = "retryInterval", desc = "Connection retry interval") long retryInterval,
@Parameter(name = "retryIntervalMultiplier", desc = "Connection retry interval multiplier") double retryIntervalMultiplier,

View File

@ -190,7 +190,7 @@ public interface ActiveMQClientMessageBundle {
@Message(id = 119047, value = "nodes have different node names")
IllegalArgumentException nodeHaveDifferentNames();
@Message(id = 119048, value = "nodes hava a different number of attributes")
@Message(id = 119048, value = "nodes have a different number of attributes")
IllegalArgumentException nodeHaveDifferentAttNumber();
@Message(id = 119049, value = "attribute {0}={1} does not match", format = Message.Format.MESSAGE_FORMAT)
@ -199,7 +199,7 @@ public interface ActiveMQClientMessageBundle {
@Message(id = 119050, value = "one node has children and the other does not")
IllegalArgumentException oneNodeHasChildren();
@Message(id = 119051, value = "nodes hava a different number of children")
@Message(id = 119051, value = "nodes have a different number of children")
IllegalArgumentException nodeHasDifferentChildNumber();
@Message(id = 119052, value = "Element {0} requires a valid Boolean value, but ''{1}'' cannot be parsed as a Boolean", format = Message.Format.MESSAGE_FORMAT)

View File

@ -271,7 +271,7 @@ public final class ChannelImpl implements Channel {
packet.setChannelID(id);
if (logger.isTraceEnabled()) {
logger.trace("Sending packet nonblocking " + packet + " on channeID=" + id);
logger.trace("Sending packet nonblocking " + packet + " on channelID=" + id);
}
ActiveMQBuffer buffer = packet.encode(connection);

View File

@ -86,7 +86,7 @@ public class TimeAndCounterIDGenerator implements IDGenerator {
// This will only happen if a computer can generate more than ID_MASK ids (16 million IDs per 16
// milliseconds)
// If this wrapping code starts to happen, it needs revision
throw new IllegalStateException("The IDGenerator is being overlaped, and it needs revision as the system generated more than " + TimeAndCounterIDGenerator.ID_MASK +
throw new IllegalStateException("The IDGenerator is being overlapped, and it needs revision as the system generated more than " + TimeAndCounterIDGenerator.ID_MASK +
" ids per 16 milliseconds which exceeded the IDgenerator limit");
}

View File

@ -233,7 +233,7 @@ public final class ActiveMQMessageConsumer implements QueueReceiver, TopicSubscr
throw ioob;
}
// We Do the ack after doBeforeRecive, as in the case of large messages, this may fail so we don't want messages redelivered
// We Do the ack after doBeforeReceive, as in the case of large messages, this may fail so we don't want messages redelivered
// https://issues.jboss.org/browse/JBPAPP-6110
if (session.getAcknowledgeMode() == ActiveMQJMSConstants.INDIVIDUAL_ACKNOWLEDGE) {
jmsMsg.setIndividualAcknowledge();

View File

@ -205,7 +205,7 @@ public class TimedBuffer {
if (bufferLimit == 0 || buffer.writerIndex() + sizeChecked > bufferLimit) {
// Either there is not enough space left in the buffer for the sized record
// Or a flush has just been performed and we need to re-calcualate bufferLimit
// Or a flush has just been performed and we need to re-calculate bufferLimit
flush();

View File

@ -143,7 +143,7 @@ public interface ActiveMQJournalLogger extends BasicLogger {
void compactReadError(JournalFile file);
@LogMessage(level = Logger.Level.WARN)
@Message(id = 142012, value = "Couldn't find tx={0} to merge after compacting",
@Message(id = 142012, value = "Couldn''t find tx={0} to merge after compacting",
format = Message.Format.MESSAGE_FORMAT)
void compactMergeError(Long id);
@ -173,7 +173,7 @@ public interface ActiveMQJournalLogger extends BasicLogger {
void couldNotStopJournalExecutor();
@LogMessage(level = Logger.Level.WARN)
@Message(id = 142018, value = "Temporary files were left unnatended after a crash on journal directory, deleting invalid files now",
@Message(id = 142018, value = "Temporary files were left unattended after a crash on journal directory, deleting invalid files now",
format = Message.Format.MESSAGE_FORMAT)
void tempFilesLeftOpen();

View File

@ -65,7 +65,7 @@ public class CallbackOrderTest {
ArrayList<AIOSequentialFileFactory.AIOSequentialCallback> list = new ArrayList<>();
// We will repeat the teset a few times, increasing N
// We will repeat the test a few times, increasing N
// to increase possibility of issues due to reuse of callbacks
for (int n = 1; n < 100; n++) {
System.out.println("n = " + n);

View File

@ -20,7 +20,7 @@ package org.apache.activemq.artemis.jlibaio.util;
import org.apache.activemq.artemis.jlibaio.SubmitInfo;
/**
* this is an utility class where you can reuse Callbackk objects for your LibaioContext usage.
* this is an utility class where you can reuse Callback objects for your LibaioContext usage.
*/
public class CallbackCache<Callback extends SubmitInfo> {

View File

@ -309,7 +309,7 @@ public class AMQPConnectionContext extends ProtonInitializable {
initialise();
/*
* This can be null which is in effect an empty map, also we really dont need to check this for in bound connections
* This can be null which is in effect an empty map, also we really don't need to check this for in bound connections
* but its here in case we add support for outbound connections.
* */
if (connection.getRemoteProperties() == null || !connection.getRemoteProperties().containsKey(CONNECTION_OPEN_FAILED)) {

View File

@ -88,7 +88,7 @@ public class AmqpSupport {
}
/**
* Search for a particular filter using a set of known indentification values
* Search for a particular filter using a set of known identification values
* in the Map of filters.
*
* @param filters The filters map that should be searched.

View File

@ -177,7 +177,7 @@ public class StompSession implements SessionCallback {
final long consumerID = consumer.getID();
// this will be called after the delivery is complete
// we can't call sesison.ack within the delivery
// we can't call session.ack within the delivery
// as it could dead lock.
afterDeliveryTasks.offer(new PendingTask() {
@Override

View File

@ -37,7 +37,7 @@ import org.apache.activemq.artemis.ra.ConnectionFactoryProperties;
/**
* The activation spec
* These properties are set on the MDB ActivactionProperties
* These properties are set on the MDB ActivationProperties
*/
public class ActiveMQActivationSpec extends ConnectionFactoryProperties implements ActivationSpec, Serializable {

View File

@ -342,7 +342,7 @@ public class ActiveMQMessageHandler implements MessageHandler, FailoverEventList
tx.setRollbackOnly();
}
} catch (Exception e1) {
ActiveMQRALogger.LOGGER.warn("unnable to clear the transaction", e1);
ActiveMQRALogger.LOGGER.warn("unable to clear the transaction", e1);
}
}

View File

@ -333,7 +333,7 @@ public abstract class ComparisonExpression extends BinaryExpression implements B
/**
* Validates that the expression can be used in {@code ==} or {@code <>} expression. Cannot
* not be NULL TRUE or FALSE litterals.
* not be NULL TRUE or FALSE literals.
*
* @param expr
*/

View File

@ -371,7 +371,7 @@ public interface ActiveMQMessageBundle {
@Message(id = 119114, value = "Replication synchronization process timed out after waiting {0} milliseconds", format = Message.Format.MESSAGE_FORMAT)
IllegalStateException replicationSynchronizationTimeout(long timeout);
@Message(id = 119115, value = "Colocated Policy hasn't different type live and backup", format = Message.Format.MESSAGE_FORMAT)
@Message(id = 119115, value = "Colocated Policy hasn''t different type live and backup", format = Message.Format.MESSAGE_FORMAT)
ActiveMQIllegalStateException liveBackupMismatch();
@Message(id = 119116, value = "Netty Acceptor unavailable", format = Message.Format.MESSAGE_FORMAT)

View File

@ -195,7 +195,7 @@ public interface ActiveMQServerLogger extends BasicLogger {
@LogMessage(level = Logger.Level.INFO)
@Message(
id = 221026,
value = "Bridge {0} connected to fowardingAddress={1}. {2} does not have any bindings. Messages will be ignored until a binding is created.",
value = "Bridge {0} connected to forwardingAddress={1}. {2} does not have any bindings. Messages will be ignored until a binding is created.",
format = Message.Format.MESSAGE_FORMAT)
void bridgeNoBindings(SimpleString name, SimpleString forwardingAddress, SimpleString address);
@ -621,7 +621,7 @@ public interface ActiveMQServerLogger extends BasicLogger {
void stompTXAckNorSupported();
@LogMessage(level = Logger.Level.WARN)
@Message(id = 222071, value = "Interrupted while waiting for stomp heart beate to die", format = Message.Format.MESSAGE_FORMAT)
@Message(id = 222071, value = "Interrupted while waiting for stomp heartbeat to die", format = Message.Format.MESSAGE_FORMAT)
void errorOnStompHeartBeat(@Cause InterruptedException e);
@LogMessage(level = Logger.Level.WARN)
@ -1125,7 +1125,7 @@ public interface ActiveMQServerLogger extends BasicLogger {
@LogMessage(level = Logger.Level.WARN)
@Message(id = 222187,
value = "Failed to activate replicata",
value = "Failed to activate replicated backup",
format = Message.Format.MESSAGE_FORMAT)
void activateReplicatedBackupFailed(@Cause Throwable e);
@ -1171,7 +1171,7 @@ public interface ActiveMQServerLogger extends BasicLogger {
@LogMessage(level = Logger.Level.WARN)
@Message(id = 222195,
value = "Large message {0} wasn't found when dealing with add pending large message",
value = "Large message {0} wasn''t found when dealing with add pending large message",
format = Message.Format.MESSAGE_FORMAT)
void largeMessageNotFound(long id);
@ -1385,7 +1385,7 @@ public interface ActiveMQServerLogger extends BasicLogger {
void errorWritingToInvmConnector(@Cause Exception e, Runnable runnable);
@LogMessage(level = Logger.Level.ERROR)
@Message(id = 224028, value = "Failed to stop accepto {0}r", format = Message.Format.MESSAGE_FORMAT)
@Message(id = 224028, value = "Failed to stop acceptor {0}", format = Message.Format.MESSAGE_FORMAT)
void errorStoppingAcceptor(String name);
@LogMessage(level = Logger.Level.ERROR)

View File

@ -83,8 +83,8 @@ public class BackupManager implements ActiveMQComponent {
for (ClusterConnectionConfiguration config : configuration.getClusterConfigurations()) {
deployBackupConnector(config);
}
//start each connector and if we are backup and shared store announce ourselves. NB with replication we dont do this
//as we wait for replication to start and be notififed by the replication manager.
//start each connector and if we are backup and shared store announce ourselves. NB with replication we don't do this
//as we wait for replication to start and be notified by the replication manager.
for (BackupConnector conn : backupConnectors) {
conn.start();
if (server.getHAPolicy().isBackup() && server.getHAPolicy().isSharedStore()) {

View File

@ -501,7 +501,7 @@ public class BridgeImpl implements Bridge, SessionFailureListener, SendAcknowled
/* Hook for processing message before forwarding */
protected ServerMessage beforeForward(final ServerMessage message) {
if (useDuplicateDetection) {
// We keep our own DuplicateID for the Bridge, so bouncing back and forths will work fine
// We keep our own DuplicateID for the Bridge, so bouncing back and forth will work fine
byte[] bytes = getDuplicateBytes(nodeUUID, message.getMessageID());
message.putBytesProperty(MessageImpl.HDR_BRIDGE_DUPLICATE_ID, bytes);

View File

@ -51,8 +51,8 @@ public abstract class Activation implements Runnable {
}
/*
* allow the activation t ooverride this if it needs to tidy up after freezing the connection. its a different method as
* its called outside of the lock that the previous method is.
* allow the activation to override this if it needs to tidy up after freezing the connection. it's a different method as
* it's called outside of the lock that the previous method is.
* */
public void postConnectionFreeze() {
}

View File

@ -45,9 +45,9 @@
<xsd:element name="internal-naming-prefix" type="xsd:string" maxOccurs="1" minOccurs="0">
<xsd:annotation>
<xsd:documentation>
Artemis uses internal queues and addresses for implmenting certain behaviours. These queues and addresses
Artemis uses internal queues and addresses for implementing certain behaviours. These queues and addresses
will be prefixed by default with "$.activemq.internal" to avoid naming clashes with user namespacing.
This can be overriden by setting this value to a valid Artemis address.
This can be overridden by setting this value to a valid Artemis address.
</xsd:documentation>
</xsd:annotation>
</xsd:element>
@ -1290,7 +1290,7 @@
<xsd:annotation>
<xsd:documentation>
Upon reconnection this configures the number of time the same node on the topology will be retried
before reseting the server locator and using the initial connectors
before resetting the server locator and using the initial connectors
</xsd:documentation>
</xsd:annotation>
</xsd:element>
@ -1670,7 +1670,7 @@
<xsd:element name="file-store" type="fileStoreType" minOccurs="0" maxOccurs="1">
<xsd:annotation>
<xsd:documentation>
Use a file based store for peristing journal, paging and large messages
Use a file based store for persisting journal, paging and large messages
</xsd:documentation>
</xsd:annotation>
</xsd:element>
@ -1828,7 +1828,7 @@
<xsd:annotation>
<xsd:documentation>
the connectors that shouldn't have their ports offset, typically remote connectors or the
connector used in the cluster connection if scalinmg down
connector used in the cluster connection if scaling down
</xsd:documentation>
</xsd:annotation>
<xsd:complexType>
@ -2379,7 +2379,7 @@
<xsd:element name="redelivery-delay-multiplier" type="xsd:double" maxOccurs="1" minOccurs="0">
<xsd:annotation>
<xsd:documentation>
multipler to apply to the "redelivery-delay"
multiplier to apply to the "redelivery-delay"
</xsd:documentation>
</xsd:annotation>
</xsd:element>

View File

@ -31,7 +31,7 @@ public class UserPrincipalTest extends Assert {
try {
new UserPrincipal(null);
fail("Should have thrown IllegalArgumentException");
} catch (IllegalArgumentException ingore) {
} catch (IllegalArgumentException ignore) {
}
}

View File

@ -242,7 +242,7 @@ public class ActiveMQXAResourceWrapper implements XAResource, SessionFailureList
}
if (result == null) {
// we should always throw a retry for certain methods comit etc, if not the tx is marked as a heuristic and
// we should always throw a retry for certain methods commit etc, if not the tx is marked as a heuristic and
// all chaos is let loose
if (retry) {
XAException xae = new XAException("Connection unavailable for xa recovery");

View File

@ -37,9 +37,9 @@
<xsd:element name="internal-naming-prefix" type="xsd:string" maxOccurs="1" minOccurs="0">
<xsd:annotation>
<xsd:documentation>
Artemis uses internal queues and addresses for implmenting certain behaviours. These queues and addresses
Artemis uses internal queues and addresses for implementing certain behaviours. These queues and addresses
will be prefixed by default with "$.activemq.internal" to avoid naming clashes with user namespacing.
This can be overriden by setting this value to a valid Artemis address.
This can be overridden by setting this value to a valid Artemis address.
</xsd:documentation>
</xsd:annotation>
</xsd:element>
@ -1216,7 +1216,7 @@
<xsd:annotation>
<xsd:documentation>
Upon reconnection this configures the number of time the same node on the topology will be retried
before reseting the server locator and using the initial connectors
before resetting the server locator and using the initial connectors
</xsd:documentation>
</xsd:annotation>
</xsd:element>
@ -1602,7 +1602,7 @@
<xsd:element name="file-store" type="fileStoreType" minOccurs="0" maxOccurs="1">
<xsd:annotation>
<xsd:documentation>
Use a file based store for peristing journal, paging and large messages
Use a file based store for persisting journal, paging and large messages
</xsd:documentation>
</xsd:annotation>
</xsd:element>
@ -1753,7 +1753,7 @@
<xsd:annotation>
<xsd:documentation>
the connectors that shouldn't have their ports offset, typically remote connectors or the
connector used in the cluster connection if scalinmg down
connector used in the cluster connection if scaling down
</xsd:documentation>
</xsd:annotation>
<xsd:complexType>
@ -2274,7 +2274,7 @@
<xsd:element name="redelivery-delay-multiplier" type="xsd:double" maxOccurs="1" minOccurs="0">
<xsd:annotation>
<xsd:documentation>
multipler to apply to the "redelivery-delay"
multiplier to apply to the "redelivery-delay"
</xsd:documentation>
</xsd:annotation>
</xsd:element>

View File

@ -56,7 +56,7 @@ public class ActiveMQConnectionFactoryTest extends CombinationTestSupport {
@Override
public void tearDown() throws Exception {
// Try our best to close any previously opend connection.
// Try our best to close any previously opened connection.
try {
connection.close();
} catch (Throwable ignore) {
@ -107,7 +107,7 @@ public class ActiveMQConnectionFactoryTest extends CombinationTestSupport {
}
//we don't support in-vm connector (will we?)
public void testCreateVMConnectionWithEmbdeddBroker() throws URISyntaxException, JMSException {
public void testCreateVMConnectionWithEmbeddedBroker() throws URISyntaxException, JMSException {
ActiveMQConnectionFactory cf = new ActiveMQConnectionFactory("vm://myBroker2?broker.persistent=false");
// Make sure the broker is not created until the connection is
// instantiated.

View File

@ -500,7 +500,7 @@ public class ActiveMQXAConnectionFactoryTest extends CombinationTestSupport {
if (connection.getConnectionId().equals(clientId)) {
try {
connection.processPrepareTransaction(new TransactionInfo(connectionId, new XATransactionId(tid), TransactionInfo.PREPARE));
fail("did not get expected excepton on missing transaction, it must be still there in error!");
fail("did not get expected exception on missing transaction, it must be still there in error!");
} catch (IllegalStateException expectedOnNoTransaction) {
}
}

View File

@ -69,7 +69,7 @@ public class TransactionContextTest {
@Override
public void afterCommit() throws Exception {
fail("exepcted rollback exception");
fail("expected rollback exception");
}
@Override
@ -87,7 +87,7 @@ public class TransactionContextTest {
@Override
public void afterCommit() throws Exception {
fail("exepcted rollback exception");
fail("expected rollback exception");
}
@Override
@ -99,7 +99,7 @@ public class TransactionContextTest {
try {
underTest.commit();
fail("exepcted rollback exception");
fail("expected rollback exception");
} catch (TransactionRolledBackException expected) {
}
@ -122,7 +122,7 @@ public class TransactionContextTest {
@Override
public void afterCommit() throws Exception {
fail("exepcted rollback exception");
fail("expected rollback exception");
}
@Override

View File

@ -204,7 +204,7 @@ public class AdvisoryBrokerTest extends BrokerTestSupport {
connection2.send(sessionInfo2);
connection2.send(producerInfo2);
// We should get an advisory of the new produver.
// We should get an advisory of the new producer.
Message m1 = receiveMessage(connection1);
assertNotNull(m1);
assertNotNull(m1.getDataStructure());

View File

@ -136,7 +136,7 @@ public class AbortSlowAckConsumer0Test extends AbortSlowConsumer0Test {
Message message = consumer.receive(5000);
assertNotNull(message);
// Consumer needs to be closed before the reeive call.
// Consumer needs to be closed before the receive call.
TimeUnit.SECONDS.sleep(15);
try {
@ -165,7 +165,7 @@ public class AbortSlowAckConsumer0Test extends AbortSlowConsumer0Test {
assertNotNull(message);
message.acknowledge();
// Consumer needs to be closed before the reeive call.
// Consumer needs to be closed before the receive call.
TimeUnit.SECONDS.sleep(15);
try {

View File

@ -211,7 +211,7 @@ public class AbortSlowConsumer0Test extends AbortSlowConsumerBase {
assertTrue("Consumer gone from broker view", Wait.waitFor(new Wait.Condition() {
@Override
public boolean isSatisified() throws Exception {
LOG.info("DestView {} comsumerCount {}", destView, destView.getConsumerCount());
LOG.info("DestView {} consumerCount {}", destView, destView.getConsumerCount());
return 0 == destView.getConsumerCount();
}
}));

View File

@ -188,7 +188,7 @@ public class TimeStampingBrokerPluginTest extends TestCase {
consumer.close();
consumer = session.createConsumer(session.createQueue("DLQ." + queue));
// Get mesage from DLQ
// Get message from DLQ
receivedMessage = consumer.receive(1000);
// assert we got the same message ID we sent

View File

@ -155,7 +155,7 @@ public class TwoBrokerFailoverClusterTest extends OpenwireArtemisBaseTest {
double count = clientConnectionCounts.get(key);
double percentage = count / total;
System.out.println(count + " of " + total + " connections for " + key + " = " + percentage);
Assert.assertTrue("Connections distribution expected to be >= than " + minimumPercentage + ". Actuall distribution was " + percentage + " for connection " + key, percentage >= minimumPercentage);
Assert.assertTrue("Connections distribution expected to be >= than " + minimumPercentage + ". Actual distribution was " + percentage + " for connection " + key, percentage >= minimumPercentage);
}
}

View File

@ -519,7 +519,7 @@ public class ThreeBrokerQueueNetworkTest extends JmsMultipleBrokersTestSupport {
// Setup destination
final Destination dest = createDestination("TEST.FOO", false);
// delay the advisory messages so that one can percolate fully (cyclicly) before the other
// delay the advisory messages so that one can percolate fully (cyclically) before the other
BrokerItem brokerB = brokers.get("BrokerA");
brokerB.broker.setPlugins(new BrokerPlugin[]{new BrokerPlugin() {

View File

@ -176,7 +176,7 @@ public class AmqpSession extends AmqpAbstractResource<Session> {
/**
* Create a sender instance using the given Target
*
* @param target the caller created and configured Traget used to create the sender link.
* @param target the caller created and configured Target used to create the sender link.
* @return a newly created sender that is ready for use.
* @throws Exception if an error occurs while creating the receiver.
*/
@ -187,7 +187,7 @@ public class AmqpSession extends AmqpAbstractResource<Session> {
/**
* Create a sender instance using the given Target
*
* @param target the caller created and configured Traget used to create the sender link.
* @param target the caller created and configured Target used to create the sender link.
* @param senderId the sender ID to assign to the newly created Sender.
* @return a newly created sender that is ready for use.
* @throws Exception if an error occurs while creating the receiver.
@ -199,7 +199,7 @@ public class AmqpSession extends AmqpAbstractResource<Session> {
/**
* Create a sender instance using the given Target
*
* @param target the caller created and configured Traget used to create the sender link.
* @param target the caller created and configured Target used to create the sender link.
* @param senderId the sender ID to assign to the newly created Sender.
* @param desiredCapabilities the capabilities that the caller wants the remote to support.
* @param offeredCapabilities the capabilities that the caller wants the advertise support for.

View File

@ -120,7 +120,7 @@ public class AmqpTransactionCoordinator extends AmqpAbstractResource<Sender> {
public void declare(AmqpTransactionId txId, AsyncResult request) throws Exception {
if (txId.getRemoteTxId() != null) {
throw new IllegalStateException("Declar called while a TX is still Active.");
throw new IllegalStateException("Declare called while a TX is still Active.");
}
if (isClosed()) {

View File

@ -753,7 +753,7 @@ public class AmqpSendReceiveTest extends AmqpClientTestSupport {
LOG.info("*** Attempting to read remaining messages with both receivers");
int splitCredit = (MSG_COUNT - 4) / 2;
LOG.info("**** Receiver #1 granting creadit[{}] for its block of messages", splitCredit);
LOG.info("**** Receiver #1 granting credit[{}] for its block of messages", splitCredit);
receiver1.flow(splitCredit);
for (int i = 0; i < splitCredit; i++) {
AmqpMessage message = receiver1.receive(10, TimeUnit.SECONDS);
@ -762,7 +762,7 @@ public class AmqpSendReceiveTest extends AmqpClientTestSupport {
message.accept();
}
LOG.info("**** Receiver #2 granting creadit[{}] for its block of messages", splitCredit);
LOG.info("**** Receiver #2 granting credit[{}] for its block of messages", splitCredit);
receiver2.flow(splitCredit);
for (int i = 0; i < splitCredit; i++) {
AmqpMessage message = receiver2.receive(10, TimeUnit.SECONDS);

View File

@ -36,7 +36,7 @@ import org.junit.Before;
import org.junit.Test;
/**
* The delete queue was reseting some fields on the Queue what would eventually turn a NPE.
* The delete queue was resetting some fields on the Queue what would eventually turn a NPE.
* this test would eventually fail without the fix but it was a rare event as in most of the time
* the NPE happened during depaging what let the server to recover itself on the next depage.
* To verify a fix on this test against the previous version of QueueImpl look for NPEs on System.err

View File

@ -358,7 +358,7 @@ public class SlowConsumerTest extends ActiveMQTestBase {
/**
* This test creates 3 consumers on one queue. A producer sends
* messages at a rate of 2 mesages per second. Each consumer
* messages at a rate of 2 messages per second. Each consumer
* consumes messages at rate of 1 message per second. The slow
* consumer threshold is 1 message per second.
* Based on the above settings, at least one of the consumers

View File

@ -39,7 +39,7 @@ public class TransactionDurabilityTest extends ActiveMQTestBase {
* Ref R1 gets consumed and acknowledged by transacted session S1, this decrements the ref count and causes an acknowledge record to be written to storage,
* transactionally, but it's not committed yet.
* Ref R2 then gets consumed and acknowledged by non transacted session S2, this causes a delete record to be written to storage.
* R1 then rolls back, and the server is restarted - unfortunatelt since the delete record was written R1 is not ready to be consumed again.
* R1 then rolls back, and the server is restarted - unfortunately since the delete record was written R1 is not ready to be consumed again.
*
* It's therefore crucial the messages aren't deleted from storage until AFTER any ack records are committed to storage.
*

View File

@ -253,7 +253,7 @@ public class ClusteredMessageCounterTest extends ClusterTestBase {
}
}
//Peroidically receive a number of messages
//Periodically receive a number of messages
private class PeriodicalReceiver extends TimerTask {
private int batchSize;
private int serverID;

View File

@ -54,7 +54,7 @@ public class TransactionContextTest extends BasicOpenWireTest {
@Override
public void afterCommit() throws Exception {
fail("exepcted rollback exception");
fail("expected rollback exception");
}
@Override
@ -72,7 +72,7 @@ public class TransactionContextTest extends BasicOpenWireTest {
@Override
public void afterCommit() throws Exception {
fail("exepcted rollback exception");
fail("expected rollback exception");
}
@Override
@ -84,7 +84,7 @@ public class TransactionContextTest extends BasicOpenWireTest {
try {
underTest.commit();
fail("exepcted rollback exception");
fail("expected rollback exception");
} catch (TransactionRolledBackException expected) {
}
@ -106,7 +106,7 @@ public class TransactionContextTest extends BasicOpenWireTest {
@Override
public void afterCommit() throws Exception {
fail("exepcted rollback exception");
fail("expected rollback exception");
}
@Override

View File

@ -65,7 +65,7 @@ public class ActiveMQClusteredTest extends ActiveMQRAClusteredTestBase {
DummyMessageEndpoint endpoint = new DummyMessageEndpoint(latch);
DummyMessageEndpointFactory endpointFactory = new DummyMessageEndpointFactory(endpoint, false);
qResourceAdapter.endpointActivation(endpointFactory, spec);
//make sure thet activation didn't start, i.e. no MDB consumers
//make sure that activation didn't start, i.e. no MDB consumers
assertEquals(((Queue) server.getPostOffice().getBinding(MDBQUEUEPREFIXEDSIMPLE).getBindable()).getConsumerCount(), 0);
qResourceAdapter.endpointDeactivation(endpointFactory, spec);
@ -194,7 +194,7 @@ public class ActiveMQClusteredTest extends ActiveMQRAClusteredTestBase {
spec.setSetupAttempts(5);
spec.setSetupInterval(200);
spec.setReconnectAttempts(reconnectAttempts);
spec.setHA(true); // if this isn't true then the toplogy listener won't get nodeDown notifications
spec.setHA(true); // if this isn't true then the topology listener won't get nodeDown notifications
spec.setCallTimeout(500L); // if this isn't set then it may take a long time for tearDown to occur on the MDB connection
qResourceAdapter.setConnectorClassName(INVM_CONNECTOR_FACTORY);
CountDownLatch latch = new CountDownLatch(1);

View File

@ -181,7 +181,7 @@ public abstract class RestMessageContext implements Closeable {
message = EntityUtils.toString(entity);
} else {
// drop message
System.err.println("Mesage too large, drop it " + len);
System.err.println("Message too large, drop it " + len);
}
Header header = response.getFirstHeader(KEY_MSG_CONSUMER);

View File

@ -715,7 +715,7 @@ public class TransactedSessionTest extends JMSTestCase {
}
/**
* Test IllegateStateException is thrown if commit is called on a non-transacted session
* Test IllegalStateException is thrown if commit is called on a non-transacted session
*/
@Test
public void testCommitIllegalState() throws Exception {
@ -916,12 +916,9 @@ public class TransactedSessionTest extends JMSTestCase {
}
}
/*
* Test IllegateStateException is thrown if rollback is
* called on a non-transacted session
*
/**
* Test IllegalStateException is thrown if rollback is called on a non-transacted session
*/
@Test
public void testRollbackIllegalState() throws Exception {
Connection conn = createConnection();

View File

@ -254,7 +254,7 @@ public class ActiveMQResourceAdapterConfigTest extends ActiveMQTestBase {
" <config-property-value></config-property-value>\n" +
" </config-property>\n" +
" <config-property>\n" +
" <description>max number of threads for scheduled threrad pool</description>\n" +
" <description>max number of threads for scheduled thread pool</description>\n" +
" <config-property-name>ScheduledThreadPoolMaxSize</config-property-name>\n" +
" <config-property-type>int</config-property-type>\n" +
" <config-property-value></config-property-value>\n" +
@ -392,13 +392,13 @@ public class ActiveMQResourceAdapterConfigTest extends ActiveMQTestBase {
" <config-property-value></config-property-value>" +
" </config-property>" +
" <config-property>" +
" <description>List of package/class names against which matching objects are permitted to be deserilized</description>" +
" <description>List of package/class names against which matching objects are permitted to be deserialized</description>" +
" <config-property-name>DeserializationWhiteList</config-property-name>" +
" <config-property-type>java.lang.String</config-property-type>" +
" <config-property-value></config-property-value>" +
" </config-property>" +
" <config-property>" +
" <description>List of package/classe names against which matching objects are forbidden to be deserialized</description>" +
" <description>List of package/class names against which matching objects are forbidden to be deserialized</description>" +
" <config-property-name>DeserializationBlackList</config-property-name>" +
" <config-property-type>java.lang.String</config-property-type>" +
" <config-property-value></config-property-value>" +