Return-Path: X-Original-To: apmail-qpid-commits-archive@www.apache.org Delivered-To: apmail-qpid-commits-archive@www.apache.org Received: from mail.apache.org (hermes.apache.org [140.211.11.3]) by minotaur.apache.org (Postfix) with SMTP id CE4641029A for ; Thu, 23 Jan 2014 23:38:25 +0000 (UTC) Received: (qmail 29856 invoked by uid 500); 23 Jan 2014 23:38:21 -0000 Delivered-To: apmail-qpid-commits-archive@qpid.apache.org Received: (qmail 29827 invoked by uid 500); 23 Jan 2014 23:38:21 -0000 Mailing-List: contact commits-help@qpid.apache.org; run by ezmlm Precedence: bulk List-Help: List-Unsubscribe: List-Post: List-Id: Reply-To: dev@qpid.apache.org Delivered-To: mailing list commits@qpid.apache.org Received: (qmail 29819 invoked by uid 99); 23 Jan 2014 23:38:20 -0000 Received: from athena.apache.org (HELO athena.apache.org) (140.211.11.136) by apache.org (qpsmtpd/0.29) with ESMTP; Thu, 23 Jan 2014 23:38:20 +0000 X-ASF-Spam-Status: No, hits=-2000.0 required=5.0 tests=ALL_TRUSTED X-Spam-Check-By: apache.org Received: from [140.211.11.4] (HELO eris.apache.org) (140.211.11.4) by apache.org (qpsmtpd/0.29) with ESMTP; Thu, 23 Jan 2014 23:38:17 +0000 Received: from eris.apache.org (localhost [127.0.0.1]) by eris.apache.org (Postfix) with ESMTP id 2A29D23889FD; Thu, 23 Jan 2014 23:37:57 +0000 (UTC) Content-Type: text/plain; charset="utf-8" MIME-Version: 1.0 Content-Transfer-Encoding: 7bit Subject: svn commit: r1560853 [3/3] - in /qpid/trunk/qpid/java: broker-core/src/main/java/org/apache/log4j/ broker-core/src/main/java/org/apache/qpid/server/ broker-core/src/main/java/org/apache/qpid/server/configuration/ broker-core/src/main/java/org/apache/qp... Date: Thu, 23 Jan 2014 23:37:51 -0000 To: commits@qpid.apache.org From: rgodfrey@apache.org X-Mailer: svnmailer-1.0.9 Message-Id: <20140123233757.2A29D23889FD@eris.apache.org> X-Virus-Checked: Checked by ClamAV on apache.org Modified: qpid/trunk/qpid/java/broker-plugins/access-control/src/test/java/org/apache/qpid/server/security/access/firewall/HostnameFirewallRuleTest.java URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/broker-plugins/access-control/src/test/java/org/apache/qpid/server/security/access/firewall/HostnameFirewallRuleTest.java?rev=1560853&r1=1560852&r2=1560853&view=diff ============================================================================== --- qpid/trunk/qpid/java/broker-plugins/access-control/src/test/java/org/apache/qpid/server/security/access/firewall/HostnameFirewallRuleTest.java (original) +++ qpid/trunk/qpid/java/broker-plugins/access-control/src/test/java/org/apache/qpid/server/security/access/firewall/HostnameFirewallRuleTest.java Thu Jan 23 23:37:48 2014 @@ -51,7 +51,7 @@ public class HostnameFirewallRuleTest ex assertTrue(_HostnameFirewallRule.matches(addressWithMatchingHostname)); } - public void testSingleHostnameWilcard() throws Exception + public void testSingleHostnameWildcard() throws Exception { String hostnameInRule = ".*FOO.*"; InetAddress addressWithMatchingHostname = mock(InetAddress.class); Modified: qpid/trunk/qpid/java/broker-plugins/access-control/src/test/java/org/apache/qpid/server/security/access/plugins/DefaultAccessControlTest.java URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/broker-plugins/access-control/src/test/java/org/apache/qpid/server/security/access/plugins/DefaultAccessControlTest.java?rev=1560853&r1=1560852&r2=1560853&view=diff ============================================================================== --- qpid/trunk/qpid/java/broker-plugins/access-control/src/test/java/org/apache/qpid/server/security/access/plugins/DefaultAccessControlTest.java (original) +++ qpid/trunk/qpid/java/broker-plugins/access-control/src/test/java/org/apache/qpid/server/security/access/plugins/DefaultAccessControlTest.java Thu Jan 23 23:37:48 2014 @@ -329,7 +329,7 @@ public class DefaultAccessControlTest ex /** * Tests that granting of access method rights with mask allows matching operations to be performed on the specified component */ - public void testAuthoriseAccessMethodWhenMatchingAcessOperationsAllowedOnSpecifiedComponent() throws ConfigurationException + public void testAuthoriseAccessMethodWhenMatchingAccessOperationsAllowedOnSpecifiedComponent() throws ConfigurationException { final RuleSet rs = new RuleSet(); Modified: qpid/trunk/qpid/java/broker-plugins/amqp-0-10-protocol/src/main/java/org/apache/qpid/server/protocol/v0_10/ServerSession.java URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/broker-plugins/amqp-0-10-protocol/src/main/java/org/apache/qpid/server/protocol/v0_10/ServerSession.java?rev=1560853&r1=1560852&r2=1560853&view=diff ============================================================================== --- qpid/trunk/qpid/java/broker-plugins/amqp-0-10-protocol/src/main/java/org/apache/qpid/server/protocol/v0_10/ServerSession.java (original) +++ qpid/trunk/qpid/java/broker-plugins/amqp-0-10-protocol/src/main/java/org/apache/qpid/server/protocol/v0_10/ServerSession.java Thu Jan 23 23:37:48 2014 @@ -89,7 +89,7 @@ public class ServerSession extends Sessi { private static final Logger _logger = LoggerFactory.getLogger(ServerSession.class); - private static final String NULL_DESTINTATION = UUID.randomUUID().toString(); + private static final String NULL_DESTINATION = UUID.randomUUID().toString(); private static final int PRODUCER_CREDIT_TOPUP_THRESHOLD = 1 << 30; private static final int UNFINISHED_COMMAND_QUEUE_THRESHOLD = 500; @@ -421,12 +421,12 @@ public class ServerSession extends Sessi public void register(String destination, Subscription_0_10 sub) { - _subscriptions.put(destination == null ? NULL_DESTINTATION : destination, sub); + _subscriptions.put(destination == null ? NULL_DESTINATION : destination, sub); } public Subscription_0_10 getSubscription(String destination) { - return _subscriptions.get(destination == null ? NULL_DESTINTATION : destination); + return _subscriptions.get(destination == null ? NULL_DESTINATION : destination); } public void unregister(Subscription_0_10 sub) Modified: qpid/trunk/qpid/java/broker-plugins/amqp-0-10-protocol/src/main/java/org/apache/qpid/server/protocol/v0_10/ServerSessionDelegate.java URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/broker-plugins/amqp-0-10-protocol/src/main/java/org/apache/qpid/server/protocol/v0_10/ServerSessionDelegate.java?rev=1560853&r1=1560852&r2=1560853&view=diff ============================================================================== --- qpid/trunk/qpid/java/broker-plugins/amqp-0-10-protocol/src/main/java/org/apache/qpid/server/protocol/v0_10/ServerSessionDelegate.java (original) +++ qpid/trunk/qpid/java/broker-plugins/amqp-0-10-protocol/src/main/java/org/apache/qpid/server/protocol/v0_10/ServerSessionDelegate.java Thu Jan 23 23:37:48 2014 @@ -968,7 +968,7 @@ public class ServerSessionDelegate exten } else { - //TODO - here because of non-compiant python tests + //TODO - here because of non-compliant python tests // should raise exception ILLEGAL_ARGUMENT "binding-key not set" if (!method.hasBindingKey()) { Modified: qpid/trunk/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/AMQChannel.java URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/AMQChannel.java?rev=1560853&r1=1560852&r2=1560853&view=diff ============================================================================== --- qpid/trunk/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/AMQChannel.java (original) +++ qpid/trunk/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/AMQChannel.java Thu Jan 23 23:37:48 2014 @@ -393,7 +393,7 @@ public class AMQChannel implements AMQSe * * Pre-requisite: the current message is judged to have no destination queues. * - * @throws AMQConnectionException if the message is mandatoryclose-on-no-route + * @throws AMQConnectionException if the message is mandatory close-on-no-route * @see AMQProtocolSession#isCloseWhenNoRoute() */ private void handleUnroutableMessage(AMQMessage message) throws AMQConnectionException @@ -969,7 +969,7 @@ public class AMQChannel implements AMQSe // perform an Async delivery for each of the subscriptions in this // Channel. The alternative would be to ensure that the subscription // had received the change in suspension state. That way the logic - // behind decieding to start an async delivery was located with the + // behind deciding to start an async delivery was located with the // Subscription. if (wasSuspended) { Modified: qpid/trunk/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/AMQProtocolEngine.java URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/AMQProtocolEngine.java?rev=1560853&r1=1560852&r2=1560853&view=diff ============================================================================== --- qpid/trunk/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/AMQProtocolEngine.java (original) +++ qpid/trunk/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/AMQProtocolEngine.java Thu Jan 23 23:37:48 2014 @@ -387,7 +387,7 @@ public class AMQProtocolEngine implement AMQChannel amqChannel = _channelMap.get(channelId); if(amqChannel != null) { - // The _receivedLock is already aquired in the caller + // The _receivedLock is already acquired in the caller // It is safe to add channel _channelsForCurrentMessage.add(amqChannel); } @@ -477,7 +477,7 @@ public class AMQProtocolEngine implement (_codecFactory.getDecoder()).setExpectProtocolInitiation(false); try { - // Log incomming protocol negotiation request + // Log incoming protocol negotiation request _actor.message(ConnectionMessages.OPEN(null, pi.getProtocolMajor() + "-" + pi.getProtocolMinor(), null, null, false, true, false, false)); ProtocolVersion pv = pi.checkVersion(); // Fails if not correct @@ -608,7 +608,7 @@ public class AMQProtocolEngine implement { if (_logger.isDebugEnabled()) { - _logger.debug("ChannelException occured on non-existent channel:" + e.getMessage()); + _logger.debug("ChannelException occurred on non-existent channel:" + e.getMessage()); } if (_logger.isInfoEnabled()) @@ -851,14 +851,14 @@ public class AMQProtocolEngine implement public void closeChannelOk(int channelId) { - // todo QPID-847 - This is called from two lcoations ChannelCloseHandler and ChannelCloseOkHandler. - // When it is the CC_OK_Handler then it makes sence to remove the channel else we will leak memory. + // todo QPID-847 - This is called from two locations ChannelCloseHandler and ChannelCloseOkHandler. + // When it is the CC_OK_Handler then it makes sense to remove the channel else we will leak memory. // We do it from the Close Handler as we are sending the OK back to the client. // While this is AMQP spec compliant. The Java client in the event of an IllegalArgumentException // will send a close-ok.. Where we should call removeChannel. // However, due to the poor exception handling on the client. The client-user will be notified of the // InvalidArgument and if they then decide to close the session/connection then the there will be time - // for that to occur i.e. a new close method be sent before the exeption handling can mark the session closed. + // for that to occur i.e. a new close method be sent before the exception handling can mark the session closed. _closingChannelsList.remove(channelId); } Modified: qpid/trunk/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/AMQProtocolSession.java URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/AMQProtocolSession.java?rev=1560853&r1=1560852&r2=1560853&view=diff ============================================================================== --- qpid/trunk/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/AMQProtocolSession.java (original) +++ qpid/trunk/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/AMQProtocolSession.java Thu Jan 23 23:37:48 2014 @@ -123,7 +123,7 @@ public interface AMQProtocolSession exte void closeChannel(int channelId, AMQConstant cause, String message) throws AMQException; /** - * Markes the specific channel as closed. This will release the lock for that channel id so a new channel can be + * Marks the specific channel as closed. This will release the lock for that channel id so a new channel can be * created on that id. * * @param channelId id of the channel to close Modified: qpid/trunk/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/ExtractResendAndRequeue.java URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/ExtractResendAndRequeue.java?rev=1560853&r1=1560852&r2=1560853&view=diff ============================================================================== --- qpid/trunk/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/ExtractResendAndRequeue.java (original) +++ qpid/trunk/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/ExtractResendAndRequeue.java Thu Jan 23 23:37:48 2014 @@ -37,20 +37,20 @@ public class ExtractResendAndRequeue imp private final Map _msgToRequeue; private final Map _msgToResend; - private final boolean _requeueIfUnabletoResend; + private final boolean _requeueIfUnableToResend; private final UnacknowledgedMessageMap _unacknowledgedMessageMap; private final MessageStore _transactionLog; public ExtractResendAndRequeue(UnacknowledgedMessageMap unacknowledgedMessageMap, Map msgToRequeue, Map msgToResend, - boolean requeueIfUnabletoResend, + boolean requeueIfUnableToResend, MessageStore txnLog) { _unacknowledgedMessageMap = unacknowledgedMessageMap; _msgToRequeue = msgToRequeue; _msgToResend = msgToResend; - _requeueIfUnabletoResend = requeueIfUnabletoResend; + _requeueIfUnableToResend = requeueIfUnableToResend; _transactionLog = txnLog; } @@ -78,7 +78,7 @@ public class ExtractResendAndRequeue imp // cannot resend, so re-queue. if (!message.isQueueDeleted()) { - if (_requeueIfUnabletoResend) + if (_requeueIfUnableToResend) { _msgToRequeue.put(deliveryTag, message); } Modified: qpid/trunk/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/SubscriptionImpl.java URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/SubscriptionImpl.java?rev=1560853&r1=1560852&r2=1560853&view=diff ============================================================================== --- qpid/trunk/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/SubscriptionImpl.java (original) +++ qpid/trunk/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/SubscriptionImpl.java Thu Jan 23 23:37:48 2014 @@ -58,7 +58,7 @@ import java.util.concurrent.locks.Lock; import java.util.concurrent.locks.ReentrantLock; /** - * Encapsulation of a supscription to a queue.

Ties together the protocol session of a subscriber, the consumer tag + * Encapsulation of a subscription to a queue.

Ties together the protocol session of a subscriber, the consumer tag * that was given out by the broker and the channel id.

*/ public abstract class SubscriptionImpl implements Subscription, FlowCreditManager.FlowCreditManagerListener Modified: qpid/trunk/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/UnexpectedMethodException.java URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/UnexpectedMethodException.java?rev=1560853&r1=1560852&r2=1560853&view=diff ============================================================================== --- qpid/trunk/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/UnexpectedMethodException.java (original) +++ qpid/trunk/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/UnexpectedMethodException.java Thu Jan 23 23:37:48 2014 @@ -31,6 +31,6 @@ public class UnexpectedMethodException e public UnexpectedMethodException(AMQMethodBody body) { - super("Unexpected method recevied: " + body.getClass().getName()); + super("Unexpected method received: " + body.getClass().getName()); } } Modified: qpid/trunk/qpid/java/broker-plugins/amqp-0-8-protocol/src/test/java/org/apache/qpid/server/protocol/v0_8/AckTest.java URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/broker-plugins/amqp-0-8-protocol/src/test/java/org/apache/qpid/server/protocol/v0_8/AckTest.java?rev=1560853&r1=1560852&r2=1560853&view=diff ============================================================================== --- qpid/trunk/qpid/java/broker-plugins/amqp-0-8-protocol/src/test/java/org/apache/qpid/server/protocol/v0_8/AckTest.java (original) +++ qpid/trunk/qpid/java/broker-plugins/amqp-0-8-protocol/src/test/java/org/apache/qpid/server/protocol/v0_8/AckTest.java Thu Jan 23 23:37:48 2014 @@ -182,7 +182,7 @@ public class AckTest extends QpidTestCas final int msgCount = 10; publishMessages(msgCount, true); UnacknowledgedMessageMap map = _channel.getUnacknowledgedMessageMap(); - assertEquals("Unextpected size for unacknowledge message map",msgCount,map.size()); + assertEquals("Unexpected size for unacknowledged message map",msgCount,map.size()); Set deliveryTagSet = map.getDeliveryTags(); int i = 1; @@ -333,93 +333,6 @@ public class AckTest extends QpidTestCas } - -/* - public void testPrefetchHighLow() throws AMQException - { - int lowMark = 5; - int highMark = 10; - - _subscription = SubscriptionFactoryImpl.INSTANCE.createSubscription(5, _protocolSession, DEFAULT_CONSUMER_TAG, true,null,false, new LimitlessCreditManager()); - _channel.setPrefetchLowMarkCount(lowMark); - _channel.setPrefetchHighMarkCount(highMark); - - assertTrue(_channel.getPrefetchLowMarkCount() == lowMark); - assertTrue(_channel.getPrefetchHighMarkCount() == highMark); - - publishMessages(highMark); - - // at this point we should have sent out only highMark messages - // which have not bee received so will be queued up in the channel - // which should be suspended - assertTrue(_subscription.isSuspended()); - UnacknowledgedMessageMap map = _channel.getUnacknowledgedMessageMap(); - assertTrue(map.size() == highMark); - - //acknowledge messages so we are just above lowMark - _channel.acknowledgeMessage(lowMark - 1, true); - - //we should still be suspended - assertTrue(_subscription.isSuspended()); - assertTrue(map.size() == lowMark + 1); - - //acknowledge one more message - _channel.acknowledgeMessage(lowMark, true); - - //and suspension should be lifted - assertTrue(!_subscription.isSuspended()); - - //pubilsh more msgs so we are just below the limit - publishMessages(lowMark - 1); - - //we should not be suspended - assertTrue(!_subscription.isSuspended()); - - //acknowledge all messages - _channel.acknowledgeMessage(0, true); - try - { - Thread.sleep(3000); - } - catch (InterruptedException e) - { - _log.error("Error: " + e, e); - } - //map will be empty - assertTrue(map.size() == 0); - } - -*/ -/* - public void testPrefetch() throws AMQException - { - _subscription = SubscriptionFactoryImpl.INSTANCE.createSubscription(5, _protocolSession, DEFAULT_CONSUMER_TAG, true,null,false, new LimitlessCreditManager()); - _channel.setMessageCredit(5); - - assertTrue(_channel.getPrefetchCount() == 5); - - final int msgCount = 5; - publishMessages(msgCount); - - // at this point we should have sent out only 5 messages with a further 5 queued - // up in the channel which should now be suspended - assertTrue(_subscription.isSuspended()); - UnacknowledgedMessageMap map = _channel.getUnacknowledgedMessageMap(); - assertTrue(map.size() == 5); - _channel.acknowledgeMessage(5, true); - assertTrue(!_subscription.isSuspended()); - try - { - Thread.sleep(3000); - } - catch (InterruptedException e) - { - _log.error("Error: " + e, e); - } - assertTrue(map.size() == 0); - } - -*/ public static junit.framework.Test suite() { return new junit.framework.TestSuite(AckTest.class); Modified: qpid/trunk/qpid/java/broker-plugins/amqp-0-8-protocol/src/test/java/org/apache/qpid/server/protocol/v0_8/AcknowledgeTest.java URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/broker-plugins/amqp-0-8-protocol/src/test/java/org/apache/qpid/server/protocol/v0_8/AcknowledgeTest.java?rev=1560853&r1=1560852&r2=1560853&view=diff ============================================================================== --- qpid/trunk/qpid/java/broker-plugins/amqp-0-8-protocol/src/test/java/org/apache/qpid/server/protocol/v0_8/AcknowledgeTest.java (original) +++ qpid/trunk/qpid/java/broker-plugins/amqp-0-8-protocol/src/test/java/org/apache/qpid/server/protocol/v0_8/AcknowledgeTest.java Thu Jan 23 23:37:48 2014 @@ -117,12 +117,12 @@ public class AcknowledgeTest extends Qpi runMessageAck(10, 1, 0, true, 0); } - protected void runMessageAck(int sendMessageCount, long firstDeliveryTag, long acknowledgeDeliveryTag, boolean acknowldegeMultiple, int remainingUnackedMessages) throws AMQException + protected void runMessageAck(int sendMessageCount, long firstDeliveryTag, long acknowledgeDeliveryTag, boolean acknowledgeMultiple, int remainingUnackedMessages) throws AMQException { //Check store is empty checkStoreContents(0); - //Send required messsages to the queue + //Send required messages to the queue BrokerTestHelper_0_8.publishMessages(getChannel(), sendMessageCount, _queueName, @@ -147,7 +147,7 @@ public class AcknowledgeTest extends Qpi //Wait for the messages to be delivered getSession().awaitDelivery(sendMessageCount); - //Check that they are all waiting to be acknoledged + //Check that they are all waiting to be acknowledged assertEquals("Channel should have unacked msgs", sendMessageCount, getChannel().getUnacknowledgedMessageMap().size()); List messages = getSession().getDelivers(getChannel().getChannelId(), subscriber, sendMessageCount); @@ -159,7 +159,7 @@ public class AcknowledgeTest extends Qpi assertEquals("First message does not have expected deliveryTag", firstDeliveryTag, messages.get(0).getDeliveryTag()); //Send required Acknowledgement - getChannel().acknowledgeMessage(acknowledgeDeliveryTag, acknowldegeMultiple); + getChannel().acknowledgeMessage(acknowledgeDeliveryTag, acknowledgeMultiple); if (getChannel().isTransactional()) { Modified: qpid/trunk/qpid/java/broker-plugins/amqp-0-8-protocol/src/test/java/org/apache/qpid/server/protocol/v0_8/BrokerTestHelper_0_8.java URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/broker-plugins/amqp-0-8-protocol/src/test/java/org/apache/qpid/server/protocol/v0_8/BrokerTestHelper_0_8.java?rev=1560853&r1=1560852&r2=1560853&view=diff ============================================================================== --- qpid/trunk/qpid/java/broker-plugins/amqp-0-8-protocol/src/test/java/org/apache/qpid/server/protocol/v0_8/BrokerTestHelper_0_8.java (original) +++ qpid/trunk/qpid/java/broker-plugins/amqp-0-8-protocol/src/test/java/org/apache/qpid/server/protocol/v0_8/BrokerTestHelper_0_8.java Thu Jan 23 23:37:48 2014 @@ -66,11 +66,11 @@ public class BrokerTestHelper_0_8 extend public static void publishMessages(AMQChannel channel, int numberOfMessages, String queueName, String exchangeName) throws AMQException { - AMQShortString rouningKey = new AMQShortString(queueName); + AMQShortString routingKey = new AMQShortString(queueName); AMQShortString exchangeNameAsShortString = new AMQShortString(exchangeName); MessagePublishInfo info = mock(MessagePublishInfo.class); when(info.getExchange()).thenReturn(exchangeNameAsShortString); - when(info.getRoutingKey()).thenReturn(rouningKey); + when(info.getRoutingKey()).thenReturn(routingKey); Exchange exchange = channel.getVirtualHost().getExchange(exchangeName); for (int count = 0; count < numberOfMessages; count++) Modified: qpid/trunk/qpid/java/broker-plugins/amqp-0-8-protocol/src/test/java/org/apache/qpid/server/protocol/v0_8/ExtractResendAndRequeueTest.java URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/broker-plugins/amqp-0-8-protocol/src/test/java/org/apache/qpid/server/protocol/v0_8/ExtractResendAndRequeueTest.java?rev=1560853&r1=1560852&r2=1560853&view=diff ============================================================================== --- qpid/trunk/qpid/java/broker-plugins/amqp-0-8-protocol/src/test/java/org/apache/qpid/server/protocol/v0_8/ExtractResendAndRequeueTest.java (original) +++ qpid/trunk/qpid/java/broker-plugins/amqp-0-8-protocol/src/test/java/org/apache/qpid/server/protocol/v0_8/ExtractResendAndRequeueTest.java Thu Jan 23 23:37:48 2014 @@ -45,12 +45,12 @@ import java.util.Map; * * This clearing/prep for resend was done as a result of the rollback call. HOWEVER, the delivery thread was still * in the process of sending messages to the client. It is therefore possible that a message could block on the - * _unackedMap lock waiting for the visit to compelete so that it can add the new message to the unackedMap.... + * _unackedMap lock waiting for the visit to complete so that it can add the new message to the unackedMap.... * which is then cleared by the resend/rollback thread. * * This problem was encountered by the testSend2ThenRollback test. * - * To try and increase the chance of the race condition occuring this test will send multiple messages so that the + * To try and increase the chance of the race condition occurring this test will send multiple messages so that the * delivery thread will be in progress while the rollback method is called. Hopefully this will cause the * deliveryTag to be lost */ @@ -82,7 +82,7 @@ public class ExtractResendAndRequeueTest id++; } - // Iterate through the QueueEntryList and add entries to unacknowledgeMessageMap and referecenList + // Iterate through the QueueEntryList and add entries to unacknowledgedMessageMap and referenceList QueueEntryIterator queueEntries = list.iterator(); while(queueEntries.advance()) { @@ -97,13 +97,13 @@ public class ExtractResendAndRequeueTest } /** - * Helper method to create a new subscription and aquire the given messages. + * Helper method to create a new subscription and acquire the given messages. * - * @param messageList The messages to aquire + * @param messageList The messages to acquire * - * @return Subscription that performed the aquire + * @return Subscription that performed the acquire */ - private Subscription createSubscriptionAndAquireMessages(LinkedList messageList) + private Subscription createSubscriptionAndAcquireMessages(LinkedList messageList) { Subscription subscription = new MockSubscription(); @@ -119,7 +119,7 @@ public class ExtractResendAndRequeueTest /** * This is the normal consumer rollback method. * - * An active consumer that has aquired messages expects those messasges to be reset when rollback is requested. + * An active consumer that has acquired messages expects those messages to be reset when rollback is requested. * * This test validates that the msgToResend map includes all the messages and none are left behind. * @@ -128,12 +128,12 @@ public class ExtractResendAndRequeueTest public void testResend() throws AMQException { //We don't need the subscription object here. - createSubscriptionAndAquireMessages(_referenceList); + createSubscriptionAndAcquireMessages(_referenceList); final Map msgToRequeue = new LinkedHashMap(); final Map msgToResend = new LinkedHashMap(); - // requeueIfUnabletoResend doesn't matter here. + // requeueIfUnableToResend doesn't matter here. _unacknowledgedMessageMap.visit(new ExtractResendAndRequeue(_unacknowledgedMessageMap, msgToRequeue, msgToResend, true, _messageStore)); @@ -145,8 +145,8 @@ public class ExtractResendAndRequeueTest /** * This is the normal consumer close method. * - * When a consumer that has aquired messages expects closes the messages that it has aquired should be removed from - * the unacknowledgeMap and placed in msgToRequeue + * When a consumer that has acquired messages expects closes the messages that it has acquired should be removed from + * the unacknowledgedMap and placed in msgToRequeue * * This test validates that the msgToRequeue map includes all the messages and none are left behind. * @@ -154,7 +154,7 @@ public class ExtractResendAndRequeueTest */ public void testRequeueDueToSubscriptionClosure() throws AMQException { - Subscription subscription = createSubscriptionAndAquireMessages(_referenceList); + Subscription subscription = createSubscriptionAndAcquireMessages(_referenceList); // Close subscription subscription.close(); @@ -162,7 +162,7 @@ public class ExtractResendAndRequeueTest final Map msgToRequeue = new LinkedHashMap(); final Map msgToResend = new LinkedHashMap(); - // requeueIfUnabletoResend doesn't matter here. + // requeueIfUnableToResend doesn't matter here. _unacknowledgedMessageMap.visit(new ExtractResendAndRequeue(_unacknowledgedMessageMap, msgToRequeue, msgToResend, true, _messageStore)); @@ -173,7 +173,7 @@ public class ExtractResendAndRequeueTest /** * If the subscription is null, due to message being retrieved via a GET, And we request that messages are requeued - * requeueIfUnabletoResend(set to true) then all messages should be sent to the msgToRequeue map. + * requeueIfUnableToResend(set to true) then all messages should be sent to the msgToRequeue map. * * @throws AMQException the visit interface throws this */ @@ -183,7 +183,7 @@ public class ExtractResendAndRequeueTest final Map msgToRequeue = new LinkedHashMap(); final Map msgToResend = new LinkedHashMap(); - // requeueIfUnabletoResend = true so all messages should go to msgToRequeue + // requeueIfUnableToResend = true so all messages should go to msgToRequeue _unacknowledgedMessageMap.visit(new ExtractResendAndRequeue(_unacknowledgedMessageMap, msgToRequeue, msgToResend, true, _messageStore)); @@ -194,7 +194,7 @@ public class ExtractResendAndRequeueTest /** * If the subscription is null, due to message being retrieved via a GET, And we request that we don't - * requeueIfUnabletoResend(set to false) then all messages should be dropped as we do not have a dead letter queue. + * requeueIfUnableToResend(set to false) then all messages should be dropped as we do not have a dead letter queue. * * @throws AMQException the visit interface throws this */ @@ -204,7 +204,7 @@ public class ExtractResendAndRequeueTest final Map msgToRequeue = new LinkedHashMap(); final Map msgToResend = new LinkedHashMap(); - // requeueIfUnabletoResend = false so all messages should be dropped all maps should be empty + // requeueIfUnableToResend = false so all messages should be dropped all maps should be empty _unacknowledgedMessageMap.visit(new ExtractResendAndRequeue(_unacknowledgedMessageMap, msgToRequeue, msgToResend, false, _messageStore)); @@ -222,7 +222,7 @@ public class ExtractResendAndRequeueTest /** * If the subscription is null, due to message being retrieved via a GET, AND the queue upon which the message was - * delivered has been deleted then it is not possible to requeue. Currently we simply discar the message but in the + * delivered has been deleted then it is not possible to requeue. Currently we simply discard the message but in the * future we may wish to dead letter the message. * * Validate that at the end of the visit all Maps are empty and all messages are marked as deleted @@ -236,7 +236,7 @@ public class ExtractResendAndRequeueTest _queue.delete(); - // requeueIfUnabletoResend : value doesn't matter here as queue has been deleted + // requeueIfUnableToResend : value doesn't matter here as queue has been deleted _unacknowledgedMessageMap.visit(new ExtractResendAndRequeue(_unacknowledgedMessageMap, msgToRequeue, msgToResend, false, _messageStore)); Modified: qpid/trunk/qpid/java/broker-plugins/amqp-0-8-protocol/src/test/java/org/apache/qpid/server/protocol/v0_8/InternalTestProtocolSession.java URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/broker-plugins/amqp-0-8-protocol/src/test/java/org/apache/qpid/server/protocol/v0_8/InternalTestProtocolSession.java?rev=1560853&r1=1560852&r2=1560853&view=diff ============================================================================== --- qpid/trunk/qpid/java/broker-plugins/amqp-0-8-protocol/src/test/java/org/apache/qpid/server/protocol/v0_8/InternalTestProtocolSession.java (original) +++ qpid/trunk/qpid/java/broker-plugins/amqp-0-8-protocol/src/test/java/org/apache/qpid/server/protocol/v0_8/InternalTestProtocolSession.java Thu Jan 23 23:37:48 2014 @@ -191,7 +191,7 @@ public class InternalTestProtocolSession } catch (InterruptedException e) { - _logger.error("Thread interupted", e); + _logger.error("Thread interrupted", e); } } } Modified: qpid/trunk/qpid/java/broker-plugins/amqp-0-8-protocol/src/test/java/org/apache/qpid/server/protocol/v0_8/MaxChannelsTest.java URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/broker-plugins/amqp-0-8-protocol/src/test/java/org/apache/qpid/server/protocol/v0_8/MaxChannelsTest.java?rev=1560853&r1=1560852&r2=1560853&view=diff ============================================================================== --- qpid/trunk/qpid/java/broker-plugins/amqp-0-8-protocol/src/test/java/org/apache/qpid/server/protocol/v0_8/MaxChannelsTest.java (original) +++ qpid/trunk/qpid/java/broker-plugins/amqp-0-8-protocol/src/test/java/org/apache/qpid/server/protocol/v0_8/MaxChannelsTest.java Thu Jan 23 23:37:48 2014 @@ -60,7 +60,7 @@ public class MaxChannelsTest extends Qpi } catch (AMQException e) { - assertEquals("Wrong exception recevied.", e.getErrorCode(), AMQConstant.NOT_ALLOWED); + assertEquals("Wrong exception received.", e.getErrorCode(), AMQConstant.NOT_ALLOWED); } assertEquals("Maximum number of channels not set.", new Long(maxChannels), new Long(_session.getChannels().size())); } Modified: qpid/trunk/qpid/java/broker-plugins/amqp-0-8-protocol/src/test/java/org/apache/qpid/server/protocol/v0_8/QueueBrowserUsesNoAckTest.java URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/broker-plugins/amqp-0-8-protocol/src/test/java/org/apache/qpid/server/protocol/v0_8/QueueBrowserUsesNoAckTest.java?rev=1560853&r1=1560852&r2=1560853&view=diff ============================================================================== --- qpid/trunk/qpid/java/broker-plugins/amqp-0-8-protocol/src/test/java/org/apache/qpid/server/protocol/v0_8/QueueBrowserUsesNoAckTest.java (original) +++ qpid/trunk/qpid/java/broker-plugins/amqp-0-8-protocol/src/test/java/org/apache/qpid/server/protocol/v0_8/QueueBrowserUsesNoAckTest.java Thu Jan 23 23:37:48 2014 @@ -95,7 +95,7 @@ public class QueueBrowserUsesNoAckTest e //Check store is empty checkStoreContents(0); - //Send required messsages to the queue + //Send required messages to the queue BrokerTestHelper_0_8.publishMessages(getChannel(), sendMessageCount, _queueName, @@ -124,7 +124,7 @@ public class QueueBrowserUsesNoAckTest e getSession().getDelivers(getChannel().getChannelId(), browser, prefetch); - //Ensure we recevied the prefetched messages + //Ensure we received the prefetched messages assertEquals(prefetch, messages.size()); //Check the process didn't suspend the subscription as this would Modified: qpid/trunk/qpid/java/broker-plugins/amqp-0-8-protocol/src/test/java/org/apache/qpid/server/protocol/v0_8/SubscriptionFactoryImplTest.java URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/broker-plugins/amqp-0-8-protocol/src/test/java/org/apache/qpid/server/protocol/v0_8/SubscriptionFactoryImplTest.java?rev=1560853&r1=1560852&r2=1560853&view=diff ============================================================================== --- qpid/trunk/qpid/java/broker-plugins/amqp-0-8-protocol/src/test/java/org/apache/qpid/server/protocol/v0_8/SubscriptionFactoryImplTest.java (original) +++ qpid/trunk/qpid/java/broker-plugins/amqp-0-8-protocol/src/test/java/org/apache/qpid/server/protocol/v0_8/SubscriptionFactoryImplTest.java Thu Jan 23 23:37:48 2014 @@ -81,9 +81,9 @@ public class SubscriptionFactoryImplTest //create a browser subscription FieldTable filters = new FieldTable(); filters.put(AMQPFilterTypes.NO_CONSUME.getValue(), true); - Subscription browerSub = SubscriptionFactoryImpl.INSTANCE.createSubscription(1, _session, new AMQShortString("1"), true, null, false, _channel.getCreditManager()); - assertEquals("Unexpected Subscription ID allocated", previousId + 1, browerSub.getSubscriptionID()); - previousId = browerSub.getSubscriptionID(); + Subscription browserSub = SubscriptionFactoryImpl.INSTANCE.createSubscription(1, _session, new AMQShortString("1"), true, null, false, _channel.getCreditManager()); + assertEquals("Unexpected Subscription ID allocated", previousId + 1, browserSub.getSubscriptionID()); + previousId = browserSub.getSubscriptionID(); //create an BasicGet NoAck subscription Subscription getNoAckSub = SubscriptionFactoryImpl.INSTANCE.createBasicGetNoAckSubscription(_channel, _session, new AMQShortString("1"), null, false, Modified: qpid/trunk/qpid/java/broker-plugins/amqp-1-0-protocol/src/main/java/org/apache/qpid/server/protocol/v1_0/MessageMetaData_1_0.java URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/broker-plugins/amqp-1-0-protocol/src/main/java/org/apache/qpid/server/protocol/v1_0/MessageMetaData_1_0.java?rev=1560853&r1=1560852&r2=1560853&view=diff ============================================================================== --- qpid/trunk/qpid/java/broker-plugins/amqp-1-0-protocol/src/main/java/org/apache/qpid/server/protocol/v1_0/MessageMetaData_1_0.java (original) +++ qpid/trunk/qpid/java/broker-plugins/amqp-1-0-protocol/src/main/java/org/apache/qpid/server/protocol/v1_0/MessageMetaData_1_0.java Thu Jan 23 23:37:48 2014 @@ -88,9 +88,9 @@ public class MessageMetaData_1_0 impleme this(fragments, decoder, new ArrayList(3)); } - public MessageMetaData_1_0(ByteBuffer[] fragments, SectionDecoder decoder, List immuatableSections) + public MessageMetaData_1_0(ByteBuffer[] fragments, SectionDecoder decoder, List immutableSections) { - this(constructSections(fragments, decoder,immuatableSections), immuatableSections); + this(constructSections(fragments, decoder,immutableSections), immutableSections); } private MessageMetaData_1_0(List

sections, List encodedSections) Modified: qpid/trunk/qpid/java/broker-plugins/amqp-1-0-protocol/src/main/java/org/apache/qpid/server/protocol/v1_0/TxnCoordinatorLink_1_0.java URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/broker-plugins/amqp-1-0-protocol/src/main/java/org/apache/qpid/server/protocol/v1_0/TxnCoordinatorLink_1_0.java?rev=1560853&r1=1560852&r2=1560853&view=diff ============================================================================== --- qpid/trunk/qpid/java/broker-plugins/amqp-1-0-protocol/src/main/java/org/apache/qpid/server/protocol/v1_0/TxnCoordinatorLink_1_0.java (original) +++ qpid/trunk/qpid/java/broker-plugins/amqp-1-0-protocol/src/main/java/org/apache/qpid/server/protocol/v1_0/TxnCoordinatorLink_1_0.java Thu Jan 23 23:37:48 2014 @@ -104,7 +104,7 @@ public class TxnCoordinatorLink_1_0 impl } - // Only interested int he amqp-value section that holds the message to the co-ordinator + // Only interested int he amqp-value section that holds the message to the coordinator try { List
sections = _sectionDecoder.parseAll(payload); @@ -182,7 +182,7 @@ public class TxnCoordinatorLink_1_0 impl { error = new Error(); error.setCondition(AmqpError.NOT_FOUND); - error.setDescription("Unkown transactionId" + transactionId); + error.setDescription("Unknown transactionId" + transactionId); } return error; } Modified: qpid/trunk/qpid/java/broker-plugins/management-http/src/main/java/org/apache/qpid/server/management/plugin/filter/RedirectingAuthorisationFilter.java URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/broker-plugins/management-http/src/main/java/org/apache/qpid/server/management/plugin/filter/RedirectingAuthorisationFilter.java?rev=1560853&r1=1560852&r2=1560853&view=diff ============================================================================== --- qpid/trunk/qpid/java/broker-plugins/management-http/src/main/java/org/apache/qpid/server/management/plugin/filter/RedirectingAuthorisationFilter.java (original) +++ qpid/trunk/qpid/java/broker-plugins/management-http/src/main/java/org/apache/qpid/server/management/plugin/filter/RedirectingAuthorisationFilter.java Thu Jan 23 23:37:48 2014 @@ -53,10 +53,10 @@ public class RedirectingAuthorisationFil @Override public void init(FilterConfig config) throws ServletException { - String loginlUrl = config.getInitParameter(INIT_PARAM_LOGIN_URL); - if (loginlUrl != null) + String loginUrl = config.getInitParameter(INIT_PARAM_LOGIN_URL); + if (loginUrl != null) { - _loginUrl = loginlUrl; + _loginUrl = loginUrl; } ServletContext servletContext = config.getServletContext(); _broker = HttpManagementUtil.getBroker(servletContext); Modified: qpid/trunk/qpid/java/broker-plugins/management-http/src/main/java/org/apache/qpid/server/management/plugin/log/LogFileHelper.java URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/broker-plugins/management-http/src/main/java/org/apache/qpid/server/management/plugin/log/LogFileHelper.java?rev=1560853&r1=1560852&r2=1560853&view=diff ============================================================================== --- qpid/trunk/qpid/java/broker-plugins/management-http/src/main/java/org/apache/qpid/server/management/plugin/log/LogFileHelper.java (original) +++ qpid/trunk/qpid/java/broker-plugins/management-http/src/main/java/org/apache/qpid/server/management/plugin/log/LogFileHelper.java Thu Jan 23 23:37:48 2014 @@ -202,12 +202,12 @@ public class LogFileHelper String name = file.getName(); if (name.startsWith(baseFileName)) { - String diplayPath = name; + String displayPath = name; if (!relativePath.equals("")) { - diplayPath = relativePath + name; + displayPath = relativePath + name; } - files.add(new LogFileDetails(diplayPath, appenderName, includeLogFileLocation ? file : null, getMimeType(name), file.length(), + files.add(new LogFileDetails(displayPath, appenderName, includeLogFileLocation ? file : null, getMimeType(name), file.length(), file.lastModified())); } } Modified: qpid/trunk/qpid/java/broker-plugins/management-http/src/main/java/org/apache/qpid/server/management/plugin/servlet/rest/MessageServlet.java URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/broker-plugins/management-http/src/main/java/org/apache/qpid/server/management/plugin/servlet/rest/MessageServlet.java?rev=1560853&r1=1560852&r2=1560853&view=diff ============================================================================== --- qpid/trunk/qpid/java/broker-plugins/management-http/src/main/java/org/apache/qpid/server/management/plugin/servlet/rest/MessageServlet.java (original) +++ qpid/trunk/qpid/java/broker-plugins/management-http/src/main/java/org/apache/qpid/server/management/plugin/servlet/rest/MessageServlet.java Thu Jan 23 23:37:48 2014 @@ -445,7 +445,7 @@ public class MessageServlet extends Abst } catch(RuntimeException e) { - LOGGER.error("Failure to perform message opertion", e); + LOGGER.error("Failure to perform message operation", e); response.setStatus(HttpServletResponse.SC_INTERNAL_SERVER_ERROR); } } Modified: qpid/trunk/qpid/java/broker-plugins/management-http/src/main/java/org/apache/qpid/server/management/plugin/servlet/rest/RestServlet.java URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/broker-plugins/management-http/src/main/java/org/apache/qpid/server/management/plugin/servlet/rest/RestServlet.java?rev=1560853&r1=1560852&r2=1560853&view=diff ============================================================================== --- qpid/trunk/qpid/java/broker-plugins/management-http/src/main/java/org/apache/qpid/server/management/plugin/servlet/rest/RestServlet.java (original) +++ qpid/trunk/qpid/java/broker-plugins/management-http/src/main/java/org/apache/qpid/server/management/plugin/servlet/rest/RestServlet.java Thu Jan 23 23:37:48 2014 @@ -104,8 +104,8 @@ public class RestServlet extends Abstrac Class clazz = (Class)itemClass; classes.add(clazz); } - Class[] hierachyClasses = (Class[])new Class[classes.size()]; - _hierarchy = classes.toArray(hierachyClasses); + Class[] hierarchyClasses = (Class[])new Class[classes.size()]; + _hierarchy = classes.toArray(hierarchyClasses); } else { Modified: qpid/trunk/qpid/java/broker-plugins/management-http/src/test/java/org/apache/qpid/server/management/plugin/log/LogFileHelperTest.java URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/broker-plugins/management-http/src/test/java/org/apache/qpid/server/management/plugin/log/LogFileHelperTest.java?rev=1560853&r1=1560852&r2=1560853&view=diff ============================================================================== --- qpid/trunk/qpid/java/broker-plugins/management-http/src/test/java/org/apache/qpid/server/management/plugin/log/LogFileHelperTest.java (original) +++ qpid/trunk/qpid/java/broker-plugins/management-http/src/test/java/org/apache/qpid/server/management/plugin/log/LogFileHelperTest.java Thu Jan 23 23:37:48 2014 @@ -214,9 +214,9 @@ public class LogFileHelperTest extends Q { assertEquals("Unexpected mime type", LogFileHelper.TEXT_MIME_TYPE, d.getMimeType()); } - assertEquals("Unexpecte file location", files[j], d.getLocation()); - assertEquals("Unexpecte file size", files[j].length(), d.getSize()); - assertEquals("Unexpecte file last modified date", files[j].lastModified(), d.getLastModified()); + assertEquals("Unexpected file location", files[j], d.getLocation()); + assertEquals("Unexpected file size", files[j].length(), d.getSize()); + assertEquals("Unexpected file last modified date", files[j].lastModified(), d.getLastModified()); } assertTrue("Gzip log file is not found", gzipFileFound); } @@ -235,13 +235,13 @@ public class LogFileHelperTest extends Q assertTrue("No details should be created for non-existing file", details.isEmpty()); } - public void testFindLogFileDetailsForIncorectlySpecifiedLogFilePath() + public void testFindLogFileDetailsForIncorrectlySpecifiedLogFilePath() { String[] logFileDisplayedPaths = { "FileAppender\\" + _appendersFiles.get("FileAppender").get(0).getName() }; try { _helper.findLogFileDetails(logFileDisplayedPaths); - fail("Exception is expected for incorectly set path to log file"); + fail("Exception is expected for incorrectly set path to log file"); } catch (IllegalArgumentException e) { Modified: qpid/trunk/qpid/java/broker-plugins/management-jmx/src/main/java/org/apache/qpid/server/jmx/MBeanIntrospector.java URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/broker-plugins/management-jmx/src/main/java/org/apache/qpid/server/jmx/MBeanIntrospector.java?rev=1560853&r1=1560852&r2=1560853&view=diff ============================================================================== --- qpid/trunk/qpid/java/broker-plugins/management-jmx/src/main/java/org/apache/qpid/server/jmx/MBeanIntrospector.java (original) +++ qpid/trunk/qpid/java/broker-plugins/management-jmx/src/main/java/org/apache/qpid/server/jmx/MBeanIntrospector.java Thu Jan 23 23:37:48 2014 @@ -47,7 +47,7 @@ class MBeanIntrospector { private static final String _defaultAttributeDescription = "Management attribute"; - private static final String _defaultOerationDescription = "Management operation"; + private static final String _defaultOperationDescription = "Management operation"; private static final String _defaultConstructorDescription = "MBean constructor"; private static final String _defaultMbeanDescription = "Management interface of the MBean"; @@ -221,7 +221,7 @@ class MBeanIntrospector * Helper method to retrieve the attribute index from the list of attributes. * @param attribute * @param list - * @return attribute index no. -1 if attribtue doesn't exist + * @return attribute index no. -1 if attribute doesn't exist * @throws javax.management.NotCompliantMBeanException */ private static int getIndexIfAlreadyExists(MBeanAttributeInfo attribute, @@ -281,7 +281,7 @@ class MBeanIntrospector MBeanParameterInfo[] paramsInfo = getParametersInfo(operation.getParameterAnnotations(), operation.getParameterTypes()); - String operationDesc = _defaultOerationDescription; + String operationDesc = _defaultOperationDescription; int impact = MBeanOperationInfo.UNKNOWN; if (operation.getAnnotation(MBeanOperation.class) != null) Modified: qpid/trunk/qpid/java/broker-plugins/management-jmx/src/main/java/org/apache/qpid/server/jmx/MBeanInvocationHandlerImpl.java URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/broker-plugins/management-jmx/src/main/java/org/apache/qpid/server/jmx/MBeanInvocationHandlerImpl.java?rev=1560853&r1=1560852&r2=1560853&view=diff ============================================================================== --- qpid/trunk/qpid/java/broker-plugins/management-jmx/src/main/java/org/apache/qpid/server/jmx/MBeanInvocationHandlerImpl.java (original) +++ qpid/trunk/qpid/java/broker-plugins/management-jmx/src/main/java/org/apache/qpid/server/jmx/MBeanInvocationHandlerImpl.java Thu Jan 23 23:37:48 2014 @@ -198,7 +198,7 @@ public class MBeanInvocationHandlerImpl } else { - _logger.error("Unexpected error occured on invoking of " + method + " with arguments " + Arrays.toString(args), targetException); + _logger.error("Unexpected error occurred on invoking of " + method + " with arguments " + Arrays.toString(args), targetException); } } Modified: qpid/trunk/qpid/java/broker-plugins/management-jmx/src/main/java/org/apache/qpid/server/jmx/ManagedObjectRegistry.java URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/broker-plugins/management-jmx/src/main/java/org/apache/qpid/server/jmx/ManagedObjectRegistry.java?rev=1560853&r1=1560852&r2=1560853&view=diff ============================================================================== --- qpid/trunk/qpid/java/broker-plugins/management-jmx/src/main/java/org/apache/qpid/server/jmx/ManagedObjectRegistry.java (original) +++ qpid/trunk/qpid/java/broker-plugins/management-jmx/src/main/java/org/apache/qpid/server/jmx/ManagedObjectRegistry.java Thu Jan 23 23:37:48 2014 @@ -29,12 +29,12 @@ import java.io.IOException; /** * Handles the registration (and unregistration and so on) of managed objects. * - * Managed objects are responsible for exposting attributes, operations and notifications. They will expose + * Managed objects are responsible for exporting attributes, operations and notifications. They will expose * these outside the JVM therefore it is important not to use implementation objects directly as managed objects. * Instead, creating inner classes and exposing those is an effective way of exposing internal state in a * controlled way. * - * Although we do not explictly use them while targetting Java 5, the enhanced MXBean approach in Java 6 will + * Although we do not explicitly use them while targeting Java 5, the enhanced MXBean approach in Java 6 will * be the obvious choice for managed objects. * */ Modified: qpid/trunk/qpid/java/broker-plugins/management-jmx/src/main/java/org/apache/qpid/server/jmx/mbeans/QueueMBean.java URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/broker-plugins/management-jmx/src/main/java/org/apache/qpid/server/jmx/mbeans/QueueMBean.java?rev=1560853&r1=1560852&r2=1560853&view=diff ============================================================================== --- qpid/trunk/qpid/java/broker-plugins/management-jmx/src/main/java/org/apache/qpid/server/jmx/mbeans/QueueMBean.java (original) +++ qpid/trunk/qpid/java/broker-plugins/management-jmx/src/main/java/org/apache/qpid/server/jmx/mbeans/QueueMBean.java Thu Jan 23 23:37:48 2014 @@ -69,7 +69,7 @@ public class QueueMBean extends AMQManag private static final CompositeType MSG_DATA_TYPE; private static final TabularType MSG_LIST_DATA_TYPE; private static final CompositeType MSG_CONTENT_TYPE; - private static final String[] VIEW_MSG_COMPOSIT_ITEM_NAMES_ARRAY = VIEW_MSG_CONTENT_COMPOSITE_ITEM_NAMES_DESC.toArray( + private static final String[] VIEW_MSG_COMPOSITE_ITEM_NAMES_ARRAY = VIEW_MSG_CONTENT_COMPOSITE_ITEM_NAMES_DESC.toArray( new String[VIEW_MSG_CONTENT_COMPOSITE_ITEM_NAMES_DESC.size()]); static @@ -396,7 +396,7 @@ public class QueueMBean extends AMQManag Object[] itemValues = { messageId, mimeType, encoding, msgContent }; - return new CompositeDataSupport(MSG_CONTENT_TYPE, VIEW_MSG_COMPOSIT_ITEM_NAMES_ARRAY, itemValues); + return new CompositeDataSupport(MSG_CONTENT_TYPE, VIEW_MSG_COMPOSITE_ITEM_NAMES_ARRAY, itemValues); } Modified: qpid/trunk/qpid/java/broker-plugins/management-jmx/src/test/java/org/apache/qpid/server/jmx/mbeans/UserManagementMBeanTest.java URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/broker-plugins/management-jmx/src/test/java/org/apache/qpid/server/jmx/mbeans/UserManagementMBeanTest.java?rev=1560853&r1=1560852&r2=1560853&view=diff ============================================================================== --- qpid/trunk/qpid/java/broker-plugins/management-jmx/src/test/java/org/apache/qpid/server/jmx/mbeans/UserManagementMBeanTest.java (original) +++ qpid/trunk/qpid/java/broker-plugins/management-jmx/src/test/java/org/apache/qpid/server/jmx/mbeans/UserManagementMBeanTest.java Thu Jan 23 23:37:48 2014 @@ -120,7 +120,7 @@ public class UserManagementMBeanTest ext { boolean reloadSuccess = _userManagement.reloadData(); - assertTrue("Reload should return true to flag succesful update", reloadSuccess); + assertTrue("Reload should return true to flag successful update", reloadSuccess); verify(_mockProvider).reload(); } --------------------------------------------------------------------- To unsubscribe, e-mail: commits-unsubscribe@qpid.apache.org For additional commands, e-mail: commits-help@qpid.apache.org