You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@activemq.apache.org by ch...@apache.org on 2007/08/09 18:40:08 UTC

svn commit: r564271 [12/18] - in /activemq/trunk: activemq-core/src/main/java/org/apache/activemq/ activemq-core/src/main/java/org/apache/activemq/advisory/ activemq-core/src/main/java/org/apache/activemq/blob/ activemq-core/src/main/java/org/apache/ac...

Modified: activemq/trunk/activemq-core/src/test/java/org/apache/activemq/CreateConsumerButDontStartConnectionWarningTest.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/CreateConsumerButDontStartConnectionWarningTest.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/test/java/org/apache/activemq/CreateConsumerButDontStartConnectionWarningTest.java (original)
+++ activemq/trunk/activemq-core/src/test/java/org/apache/activemq/CreateConsumerButDontStartConnectionWarningTest.java Thu Aug  9 09:37:49 2007
@@ -25,7 +25,7 @@
  * @version $Revision: 1.1 $
  */
 public class CreateConsumerButDontStartConnectionWarningTest extends JmsQueueSendReceiveTest {
-    private static final transient Log log = LogFactory.getLog(CreateConsumerButDontStartConnectionWarningTest.class);
+    private static final transient Log LOG = LogFactory.getLog(CreateConsumerButDontStartConnectionWarningTest.class);
 
     @Override
     protected void startConnection() throws JMSException {
@@ -37,7 +37,7 @@
         try {
             Thread.sleep(1000);
         } catch (InterruptedException e) {
-            log.warn("Caught: " + e, e);
+            LOG.warn("Caught: " + e, e);
         }
     }
 }

Modified: activemq/trunk/activemq-core/src/test/java/org/apache/activemq/EmbeddedBrokerTestSupport.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/EmbeddedBrokerTestSupport.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/test/java/org/apache/activemq/EmbeddedBrokerTestSupport.java (original)
+++ activemq/trunk/activemq-core/src/test/java/org/apache/activemq/EmbeddedBrokerTestSupport.java Thu Aug  9 09:37:49 2007
@@ -37,7 +37,7 @@
  */
 public abstract class EmbeddedBrokerTestSupport extends TestCase {
 
-    protected static final Log LOG = LogFactory.getLog(EmbeddedBrokerTestSupport.class);
+    private static final Log LOG = LogFactory.getLog(EmbeddedBrokerTestSupport.class);
 
     protected BrokerService broker;
     // protected String bindAddress = "tcp://localhost:61616";

Modified: activemq/trunk/activemq-core/src/test/java/org/apache/activemq/ExclusiveConsumerTest.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/ExclusiveConsumerTest.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/test/java/org/apache/activemq/ExclusiveConsumerTest.java (original)
+++ activemq/trunk/activemq-core/src/test/java/org/apache/activemq/ExclusiveConsumerTest.java Thu Aug  9 09:37:49 2007
@@ -1,18 +1,18 @@
 /**
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
  *
- * Copyright 2005-2006 The Apache Software Foundation
+ *      http://www.apache.org/licenses/LICENSE-2.0
  *
- *  Licensed under the Apache License, Version 2.0 (the "License");
- *  you may not use this file except in compliance with the License.
- *  You may obtain a copy of the License at
- *
- *     http://www.apache.org/licenses/LICENSE-2.0
- *
- *  Unless required by applicable law or agreed to in writing, software
- *  distributed under the License is distributed on an "AS IS" BASIS,
- *  WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- *  See the License for the specific language governing permissions and
- *  limitations under the License.
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
  */
 package org.apache.activemq;
 

Modified: activemq/trunk/activemq-core/src/test/java/org/apache/activemq/JMSConsumerTest.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/JMSConsumerTest.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/test/java/org/apache/activemq/JMSConsumerTest.java (original)
+++ activemq/trunk/activemq-core/src/test/java/org/apache/activemq/JMSConsumerTest.java Thu Aug  9 09:37:49 2007
@@ -41,7 +41,7 @@
  */
 public class JMSConsumerTest extends JmsTestSupport {
 
-    private static final org.apache.commons.logging.Log log = org.apache.commons.logging.LogFactory
+    private static final org.apache.commons.logging.Log LOG = org.apache.commons.logging.LogFactory
         .getLog(JMSConsumerTest.class);
 
     public static Test suite() {
@@ -83,10 +83,12 @@
         consumer.setMessageListener(new MessageListener() {
             public void onMessage(Message m) {
                 counter.incrementAndGet();
-                if (counter.get() == 1)
+                if (counter.get() == 1) {
                     done1.countDown();
-                if (counter.get() == 2)
+                }
+                if (counter.get() == 2) {
                     done2.countDown();
+                }
             }
         });
 
@@ -254,8 +256,9 @@
         consumer.setMessageListener(new MessageListener() {
             public void onMessage(Message m) {
                 counter.incrementAndGet();
-                if (counter.get() == 4)
+                if (counter.get() == 4) {
                     done.countDown();
+                }
             }
         });
 
@@ -298,7 +301,7 @@
             public void onMessage(Message m) {
                 try {
                     TextMessage tm = (TextMessage)m;
-                    log.info("Got in first listener: " + tm.getText());
+                    LOG.info("Got in first listener: " + tm.getText());
                     assertEquals("" + counter.get(), tm.getText());
                     counter.incrementAndGet();
                     m.acknowledge();
@@ -335,11 +338,12 @@
             public void onMessage(Message m) {
                 try {
                     TextMessage tm = (TextMessage)m;
-                    log.info("Got in second listener: " + tm.getText());
+                    LOG.info("Got in second listener: " + tm.getText());
                     assertEquals("" + counter.get(), tm.getText());
                     counter.incrementAndGet();
-                    if (counter.get() == 4)
+                    if (counter.get() == 4) {
                         done2.countDown();
+                    }
                 } catch (Throwable e) {
                     e.printStackTrace();
                 }
@@ -379,8 +383,9 @@
         consumer.setMessageListener(new MessageListener() {
             public void onMessage(Message m) {
                 counter.incrementAndGet();
-                if (counter.get() == 4)
+                if (counter.get() == 4) {
                     done.countDown();
+                }
             }
         });
 
@@ -417,8 +422,9 @@
         consumer.setMessageListener(new MessageListener() {
             public void onMessage(Message m) {
                 counter.incrementAndGet();
-                if (counter.get() == 4)
+                if (counter.get() == 4) {
                     done.countDown();
+                }
             }
         });
 

Modified: activemq/trunk/activemq-core/src/test/java/org/apache/activemq/JMSDurableTopicRedeliverTest.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/JMSDurableTopicRedeliverTest.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/test/java/org/apache/activemq/JMSDurableTopicRedeliverTest.java (original)
+++ activemq/trunk/activemq-core/src/test/java/org/apache/activemq/JMSDurableTopicRedeliverTest.java Thu Aug  9 09:37:49 2007
@@ -25,7 +25,7 @@
  */
 public class JMSDurableTopicRedeliverTest extends JmsTopicRedeliverTest {
 
-    private static final org.apache.commons.logging.Log log = org.apache.commons.logging.LogFactory.getLog(JMSDurableTopicRedeliverTest.class);
+    private static final org.apache.commons.logging.Log LOG = org.apache.commons.logging.LogFactory.getLog(JMSDurableTopicRedeliverTest.class);
 
     protected void setUp() throws Exception {
         durable = true;
@@ -42,7 +42,7 @@
         Message sendMessage = session.createTextMessage(text);
 
         if (verbose) {
-            log.info("About to send a message: " + sendMessage + " with text: " + text);
+            LOG.info("About to send a message: " + sendMessage + " with text: " + text);
         }
         producer.send(producerDestination, sendMessage);
 

Modified: activemq/trunk/activemq-core/src/test/java/org/apache/activemq/JmsBenchmark.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/JmsBenchmark.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/test/java/org/apache/activemq/JmsBenchmark.java (original)
+++ activemq/trunk/activemq-core/src/test/java/org/apache/activemq/JmsBenchmark.java Thu Aug  9 09:37:49 2007
@@ -54,7 +54,7 @@
  * @version $Revision$
  */
 public class JmsBenchmark extends JmsTestSupport {
-    private static final transient Log log = LogFactory.getLog(JmsBenchmark.class);
+    private static final transient Log LOG = LogFactory.getLog(JmsBenchmark.class);
 
     private static final long SAMPLE_DELAY = Integer.parseInt(System.getProperty("SAMPLE_DELAY", "" + 1000 * 5));
     private static final long SAMPLES = Integer.parseInt(System.getProperty("SAMPLES", "10"));
@@ -169,12 +169,12 @@
             }.start();
         }
 
-        log.info(getName() + ": Waiting for Producers and Consumers to startup.");
+        LOG.info(getName() + ": Waiting for Producers and Consumers to startup.");
         connectionsEstablished.acquire();
-        log.info("Producers and Consumers are now running.  Waiting for system to reach steady state: " + (SAMPLE_DELAY / 1000.0f) + " seconds");
+        LOG.info("Producers and Consumers are now running.  Waiting for system to reach steady state: " + (SAMPLE_DELAY / 1000.0f) + " seconds");
         Thread.sleep(1000 * 10);
 
-        log.info("Starting sample: " + SAMPLES + " each lasting " + (SAMPLE_DURATION / 1000.0f) + " seconds");
+        LOG.info("Starting sample: " + SAMPLES + " each lasting " + (SAMPLE_DURATION / 1000.0f) + " seconds");
 
         long now = System.currentTimeMillis();
         for (int i = 0; i < SAMPLES; i++) {
@@ -189,10 +189,10 @@
             int r = receivedMessages.get();
             int p = producedMessages.get();
 
-            log.info("published: " + p + " msgs at " + (p * 1000f / (end - start)) + " msgs/sec, " + "consumed: " + r + " msgs at " + (r * 1000f / (end - start)) + " msgs/sec");
+            LOG.info("published: " + p + " msgs at " + (p * 1000f / (end - start)) + " msgs/sec, " + "consumed: " + r + " msgs at " + (r * 1000f / (end - start)) + " msgs/sec");
         }
 
-        log.info("Sample done.");
+        LOG.info("Sample done.");
         sampleTimeDone.countDown();
 
         workerDone.acquire();

Modified: activemq/trunk/activemq-core/src/test/java/org/apache/activemq/JmsConnectionStartStopTest.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/JmsConnectionStartStopTest.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/test/java/org/apache/activemq/JmsConnectionStartStopTest.java (original)
+++ activemq/trunk/activemq-core/src/test/java/org/apache/activemq/JmsConnectionStartStopTest.java Thu Aug  9 09:37:49 2007
@@ -30,7 +30,7 @@
  */
 public class JmsConnectionStartStopTest extends TestSupport {
 
-    private static final org.apache.commons.logging.Log log = org.apache.commons.logging.LogFactory
+    private static final org.apache.commons.logging.Log LOG = org.apache.commons.logging.LogFactory
         .getLog(JmsConnectionStartStopTest.class);
 
     private Connection startedConnection;
@@ -41,7 +41,7 @@
      */
     protected void setUp() throws Exception {
 
-        log.info(getClass().getClassLoader().getResource("log4j.properties"));
+        LOG.info(getClass().getClassLoader().getResource("log4j.properties"));
 
         ActiveMQConnectionFactory factory = createConnectionFactory();
         startedConnection = factory.createConnection();

Modified: activemq/trunk/activemq-core/src/test/java/org/apache/activemq/JmsDurableTopicSendReceiveTest.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/JmsDurableTopicSendReceiveTest.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/test/java/org/apache/activemq/JmsDurableTopicSendReceiveTest.java (original)
+++ activemq/trunk/activemq-core/src/test/java/org/apache/activemq/JmsDurableTopicSendReceiveTest.java Thu Aug  9 09:37:49 2007
@@ -31,7 +31,7 @@
  * @version $Revision: 1.5 $
  */
 public class JmsDurableTopicSendReceiveTest extends JmsTopicSendReceiveTest {
-    private static final org.apache.commons.logging.Log log = org.apache.commons.logging.LogFactory.getLog(JmsDurableTopicSendReceiveTest.class);
+    private static final org.apache.commons.logging.Log LOG = org.apache.commons.logging.LogFactory.getLog(JmsDurableTopicSendReceiveTest.class);
 
     protected Connection connection2;
     protected Session session2;
@@ -75,7 +75,7 @@
         message.setStringProperty("test", "test");
         message.setJMSType("test");
         producer2.send(producerDestination2, message);
-        log.info("Creating durable consumer");
+        LOG.info("Creating durable consumer");
         consumer2 = consumeSession2.createDurableSubscriber((Topic)consumerDestination2, getName());
         Message msg = consumer2.receive(1000);
         assertNotNull(msg);

Modified: activemq/trunk/activemq-core/src/test/java/org/apache/activemq/JmsMultipleBrokersTestSupport.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/JmsMultipleBrokersTestSupport.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/test/java/org/apache/activemq/JmsMultipleBrokersTestSupport.java (original)
+++ activemq/trunk/activemq-core/src/test/java/org/apache/activemq/JmsMultipleBrokersTestSupport.java Thu Aug  9 09:37:49 2007
@@ -59,7 +59,7 @@
  */
 public class JmsMultipleBrokersTestSupport extends CombinationTestSupport {
     public static final String AUTO_ASSIGN_TRANSPORT = "tcp://localhost:0";
-    public static int MAX_SETUP_TIME = 5000;
+    public static int maxSetupTime = 5000;
 
     protected Map brokers;
     protected Map destinations;
@@ -99,7 +99,7 @@
             connector.setDynamicOnly(dynamicOnly);
             connector.setNetworkTTL(networkTTL);
             localBroker.addNetworkConnector(connector);
-            MAX_SETUP_TIME = 2000;
+            maxSetupTime = 2000;
             return connector;
         } else {
             throw new Exception("Remote broker has no registered connectors.");
@@ -129,7 +129,7 @@
         }
 
         // Multicasting may take longer to setup
-        MAX_SETUP_TIME = 8000;
+        maxSetupTime = 8000;
     }
 
     protected void startAllBrokers() throws Exception {
@@ -139,7 +139,7 @@
             broker.start();
         }
 
-        Thread.sleep(MAX_SETUP_TIME);
+        Thread.sleep(maxSetupTime);
     }
 
     protected BrokerService createBroker(String brokerName) throws Exception {

Modified: activemq/trunk/activemq-core/src/test/java/org/apache/activemq/JmsQueueBrowserTest.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/JmsQueueBrowserTest.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/test/java/org/apache/activemq/JmsQueueBrowserTest.java (original)
+++ activemq/trunk/activemq-core/src/test/java/org/apache/activemq/JmsQueueBrowserTest.java Thu Aug  9 09:37:49 2007
@@ -32,7 +32,7 @@
  * @version $Revision: 1.4 $
  */
 public class JmsQueueBrowserTest extends JmsTestSupport {
-    private static final org.apache.commons.logging.Log log = org.apache.commons.logging.LogFactory
+    private static final org.apache.commons.logging.Log LOG = org.apache.commons.logging.LogFactory
             .getLog(JmsQueueBrowserTest.class);
     
 
@@ -81,7 +81,7 @@
         // There should be no more.
         boolean tooMany = false;
         while (enumeration.hasMoreElements()) {
-            log.info("Got extra message: " + ((TextMessage) enumeration.nextElement()).getText());
+            LOG.info("Got extra message: " + ((TextMessage) enumeration.nextElement()).getText());
             tooMany = true;
         }
         assertFalse(tooMany);

Modified: activemq/trunk/activemq-core/src/test/java/org/apache/activemq/JmsQueueCompositeSendReceiveTest.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/JmsQueueCompositeSendReceiveTest.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/test/java/org/apache/activemq/JmsQueueCompositeSendReceiveTest.java (original)
+++ activemq/trunk/activemq-core/src/test/java/org/apache/activemq/JmsQueueCompositeSendReceiveTest.java Thu Aug  9 09:37:49 2007
@@ -28,7 +28,7 @@
  * @version $Revision: 1.3 $
  */
 public class JmsQueueCompositeSendReceiveTest extends JmsTopicSendReceiveTest {
-    private static final org.apache.commons.logging.Log log = org.apache.commons.logging.LogFactory
+    private static final org.apache.commons.logging.Log LOG = org.apache.commons.logging.LogFactory
             .getLog(JmsQueueCompositeSendReceiveTest.class);
     
     /**
@@ -71,10 +71,10 @@
         super.testSendReceive();
         messages.clear();
         Destination consumerDestination = consumeSession.createQueue("FOO.BAR.HUMBUG2");
-        log.info("Created  consumer destination: " + consumerDestination + " of type: " + consumerDestination.getClass());
+        LOG.info("Created  consumer destination: " + consumerDestination + " of type: " + consumerDestination.getClass());
         MessageConsumer consumer = null;
         if (durable) {
-            log.info("Creating durable consumer");
+            LOG.info("Creating durable consumer");
             consumer = consumeSession.createDurableSubscriber((Topic) consumerDestination, getName());
         } else {
             consumer = consumeSession.createConsumer(consumerDestination);
@@ -82,6 +82,6 @@
         consumer.setMessageListener(this);
 
         assertMessagesAreReceived();
-        log.info("" + data.length + " messages(s) received, closing down connections");
+        LOG.info("" + data.length + " messages(s) received, closing down connections");
     }
 }

Modified: activemq/trunk/activemq-core/src/test/java/org/apache/activemq/JmsQueueRequestReplyTest.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/JmsQueueRequestReplyTest.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/test/java/org/apache/activemq/JmsQueueRequestReplyTest.java (original)
+++ activemq/trunk/activemq-core/src/test/java/org/apache/activemq/JmsQueueRequestReplyTest.java Thu Aug  9 09:37:49 2007
@@ -20,12 +20,12 @@
  * @version $Revision: 1.2 $
  */
 public class JmsQueueRequestReplyTest extends JmsTopicRequestReplyTest {
-	
+
     /**
-     * Set up the test with a queue. 
+     * Set up the test with a queue.
      * 
      * @see junit.framework.TestCase#setUp()
-     */	
+     */
     protected void setUp() throws Exception {
         topic = false;
         super.setUp();

Modified: activemq/trunk/activemq-core/src/test/java/org/apache/activemq/JmsQueueSendReceiveTest.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/JmsQueueSendReceiveTest.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/test/java/org/apache/activemq/JmsQueueSendReceiveTest.java (original)
+++ activemq/trunk/activemq-core/src/test/java/org/apache/activemq/JmsQueueSendReceiveTest.java Thu Aug  9 09:37:49 2007
@@ -18,17 +18,16 @@
 
 import org.apache.activemq.test.JmsTopicSendReceiveTest;
 
-
 /**
  * @version $Revision: 1.2 $
  */
 public class JmsQueueSendReceiveTest extends JmsTopicSendReceiveTest {
 
     /**
-     * Set up the test with a queue. 
+     * Set up the test with a queue.
      * 
      * @see junit.framework.TestCase#setUp()
-     */	
+     */
     protected void setUp() throws Exception {
         topic = false;
         super.setUp();

Modified: activemq/trunk/activemq-core/src/test/java/org/apache/activemq/JmsQueueSendReceiveTwoConnectionsStartBeforeBrokerTest.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/JmsQueueSendReceiveTwoConnectionsStartBeforeBrokerTest.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/test/java/org/apache/activemq/JmsQueueSendReceiveTwoConnectionsStartBeforeBrokerTest.java (original)
+++ activemq/trunk/activemq-core/src/test/java/org/apache/activemq/JmsQueueSendReceiveTwoConnectionsStartBeforeBrokerTest.java Thu Aug  9 09:37:49 2007
@@ -20,12 +20,14 @@
 import java.util.concurrent.ConcurrentLinkedQueue;
 
 import org.apache.activemq.broker.BrokerService;
+import org.apache.commons.logging.Log;
+import org.apache.commons.logging.LogFactory;
 
 /**
  * @version $Revision$
  */
-public class JmsQueueSendReceiveTwoConnectionsStartBeforeBrokerTest extends
-    JmsQueueSendReceiveTwoConnectionsTest {
+public class JmsQueueSendReceiveTwoConnectionsStartBeforeBrokerTest extends JmsQueueSendReceiveTwoConnectionsTest {
+    private static final Log LOG = LogFactory.getLog(JmsQueueSendReceiveTwoConnectionsStartBeforeBrokerTest.class);
 
     private Queue errors = new ConcurrentLinkedQueue();
     private int delayBeforeStartingBroker = 1000;
@@ -33,28 +35,27 @@
 
     public void startBroker() {
         // Initialize the broker
-        log.info("Lets wait: " + delayBeforeStartingBroker + " millis  before creating the broker");
+        LOG.info("Lets wait: " + delayBeforeStartingBroker + " millis  before creating the broker");
         try {
             Thread.sleep(delayBeforeStartingBroker);
         } catch (InterruptedException e) {
             e.printStackTrace();
         }
 
-        log.info("Now starting the broker");
+        LOG.info("Now starting the broker");
         try {
             broker = new BrokerService();
             broker.setPersistent(false);
             broker.addConnector("tcp://localhost:61616");
             broker.start();
         } catch (Exception e) {
-            log.info("Caught: " + e);
+            LOG.info("Caught: " + e);
             errors.add(e);
         }
     }
 
     protected ActiveMQConnectionFactory createConnectionFactory() throws Exception {
-        return new ActiveMQConnectionFactory(
-                                             "failover:(tcp://localhost:61616)?maxReconnectAttempts=10&useExponentialBackOff=false&initialReconnectDelay=200");
+        return new ActiveMQConnectionFactory("failover:(tcp://localhost:61616)?maxReconnectAttempts=10&useExponentialBackOff=false&initialReconnectDelay=200");
     }
 
     protected void setUp() throws Exception {

Modified: activemq/trunk/activemq-core/src/test/java/org/apache/activemq/JmsQueueSendReceiveTwoConnectionsTest.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/JmsQueueSendReceiveTwoConnectionsTest.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/test/java/org/apache/activemq/JmsQueueSendReceiveTwoConnectionsTest.java (original)
+++ activemq/trunk/activemq-core/src/test/java/org/apache/activemq/JmsQueueSendReceiveTwoConnectionsTest.java Thu Aug  9 09:37:49 2007
@@ -25,13 +25,13 @@
  */
 public class JmsQueueSendReceiveTwoConnectionsTest extends JmsTopicSendReceiveWithTwoConnectionsTest {
 
-    protected static final Log log = LogFactory.getLog(JmsQueueSendReceiveTwoConnectionsTest.class);
-    
+    private static final Log LOG = LogFactory.getLog(JmsQueueSendReceiveTwoConnectionsTest.class);
+
     /**
-     * Set up the test with a queue and using two connections. 
+     * Set up the test with a queue and using two connections.
      * 
      * @see junit.framework.TestCase#setUp()
-     */	
+     */
     protected void setUp() throws Exception {
         topic = false;
         super.setUp();

Modified: activemq/trunk/activemq-core/src/test/java/org/apache/activemq/JmsQueueSendReceiveUsingTwoSessionsTest.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/JmsQueueSendReceiveUsingTwoSessionsTest.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/test/java/org/apache/activemq/JmsQueueSendReceiveUsingTwoSessionsTest.java (original)
+++ activemq/trunk/activemq-core/src/test/java/org/apache/activemq/JmsQueueSendReceiveUsingTwoSessionsTest.java Thu Aug  9 09:37:49 2007
@@ -22,10 +22,10 @@
 public class JmsQueueSendReceiveUsingTwoSessionsTest extends JmsQueueSendReceiveTest {
 
     /**
-     * Set up the test using two sessions.  
+     * Set up the test using two sessions.
      * 
      * @see junit.framework.TestCase#setUp()
-     */	
+     */
     protected void setUp() throws Exception {
         useSeparateSession = true;
         super.setUp();

Modified: activemq/trunk/activemq-core/src/test/java/org/apache/activemq/JmsQueueTopicCompositeSendReceiveTest.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/JmsQueueTopicCompositeSendReceiveTest.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/test/java/org/apache/activemq/JmsQueueTopicCompositeSendReceiveTest.java (original)
+++ activemq/trunk/activemq-core/src/test/java/org/apache/activemq/JmsQueueTopicCompositeSendReceiveTest.java Thu Aug  9 09:37:49 2007
@@ -28,7 +28,7 @@
  * @version $Revision: 1.3 $
  */
 public class JmsQueueTopicCompositeSendReceiveTest extends JmsTopicSendReceiveTest {
-    private static final org.apache.commons.logging.Log log = org.apache.commons.logging.LogFactory
+    private static final org.apache.commons.logging.Log LOG = org.apache.commons.logging.LogFactory
             .getLog(JmsQueueTopicCompositeSendReceiveTest.class);
     Destination consumerDestination2;
     MessageConsumer consumer2;
@@ -43,9 +43,9 @@
         topic = false;
         super.setUp();
         consumerDestination2 = consumeSession.createTopic("FOO.BAR.HUMBUG2");
-        log.info("Created  consumer destination: " + consumerDestination2 + " of type: " + consumerDestination2.getClass());
+        LOG.info("Created  consumer destination: " + consumerDestination2 + " of type: " + consumerDestination2.getClass());
         if (durable) {
-            log.info("Creating durable consumer");
+            LOG.info("Creating durable consumer");
             consumer2 = consumeSession.createDurableSubscriber((Topic) consumerDestination2, getName());
         } else {
             consumer2 = consumeSession.createConsumer(consumerDestination2);
@@ -83,6 +83,6 @@
         messages.clear();
         consumer2.setMessageListener(this);
         assertMessagesAreReceived();
-        log.info("" + data.length + " messages(s) received, closing down connections");
+        LOG.info("" + data.length + " messages(s) received, closing down connections");
     }
 }

Modified: activemq/trunk/activemq-core/src/test/java/org/apache/activemq/JmsQueueTransactionTest.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/JmsQueueTransactionTest.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/test/java/org/apache/activemq/JmsQueueTransactionTest.java (original)
+++ activemq/trunk/activemq-core/src/test/java/org/apache/activemq/JmsQueueTransactionTest.java Thu Aug  9 09:37:49 2007
@@ -33,7 +33,7 @@
  * @version $Revision: 1.2 $
  */
 public class JmsQueueTransactionTest extends JmsTransactionTestSupport {
-    private static final org.apache.commons.logging.Log log = org.apache.commons.logging.LogFactory.getLog(JmsQueueTransactionTest.class);
+    private static final org.apache.commons.logging.Log LOG = org.apache.commons.logging.LogFactory.getLog(JmsQueueTransactionTest.class);
 
     /**
      * @see org.apache.activemq.JmsTransactionTestSupport#getJmsResourceProvider()
@@ -62,8 +62,8 @@
         producer.send(outbound[1]);
         session.commit();
 
-        log.info("Sent 0: " + outbound[0]);
-        log.info("Sent 1: " + outbound[1]);
+        LOG.info("Sent 0: " + outbound[0]);
+        LOG.info("Sent 1: " + outbound[1]);
 
         ArrayList messages = new ArrayList();
         Message message = consumer.receive(1000);
@@ -170,7 +170,7 @@
         // There should be no more.
         boolean tooMany = false;
         while (enumeration.hasMoreElements()) {
-            log.info("Got extra message: " + ((TextMessage)enumeration.nextElement()).getText());
+            LOG.info("Got extra message: " + ((TextMessage)enumeration.nextElement()).getText());
             tooMany = true;
         }
         assertFalse(tooMany);

Modified: activemq/trunk/activemq-core/src/test/java/org/apache/activemq/JmsRedeliveredTest.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/JmsRedeliveredTest.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/test/java/org/apache/activemq/JmsRedeliveredTest.java (original)
+++ activemq/trunk/activemq-core/src/test/java/org/apache/activemq/JmsRedeliveredTest.java Thu Aug  9 09:37:49 2007
@@ -396,7 +396,7 @@
     /**
      * Run the JmsRedeliverTest with the delivery mode set as persistent.
      */
-    static final public class PersistentCase extends JmsRedeliveredTest {
+    public static final class PersistentCase extends JmsRedeliveredTest {
 
         /**
          * Returns delivery mode.
@@ -411,7 +411,7 @@
     /**
      * Run the JmsRedeliverTest with the delivery mode set as non-persistent.
      */
-    static final public class TransientCase extends JmsRedeliveredTest {
+    public static final class TransientCase extends JmsRedeliveredTest {
 
         /**
          * Returns delivery mode.

Modified: activemq/trunk/activemq-core/src/test/java/org/apache/activemq/JmsTopicCompositeSendReceiveTest.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/JmsTopicCompositeSendReceiveTest.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/test/java/org/apache/activemq/JmsTopicCompositeSendReceiveTest.java (original)
+++ activemq/trunk/activemq-core/src/test/java/org/apache/activemq/JmsTopicCompositeSendReceiveTest.java Thu Aug  9 09:37:49 2007
@@ -28,7 +28,7 @@
  * @version $Revision: 1.3 $
  */
 public class JmsTopicCompositeSendReceiveTest extends JmsTopicSendReceiveTest {
-    private static final org.apache.commons.logging.Log log = org.apache.commons.logging.LogFactory
+    private static final org.apache.commons.logging.Log LOG = org.apache.commons.logging.LogFactory
             .getLog(JmsTopicCompositeSendReceiveTest.class);
     
     Destination consumerDestination2;
@@ -43,9 +43,9 @@
         deliveryMode = DeliveryMode.NON_PERSISTENT;
         super.setUp();
         consumerDestination2 = consumeSession.createTopic("FOO.BAR.HUMBUG2");
-        log.info("Created  consumer destination: " + consumerDestination2 + " of type: " + consumerDestination2.getClass());
+        LOG.info("Created  consumer destination: " + consumerDestination2 + " of type: " + consumerDestination2.getClass());
         if (durable) {
-            log.info("Creating durable consumer");
+            LOG.info("Creating durable consumer");
             consumer2 = consumeSession.createDurableSubscriber((Topic) consumerDestination2, getName());
         } else {
             consumer2 = consumeSession.createConsumer(consumerDestination2);
@@ -83,6 +83,6 @@
         messages.clear();
         consumer2.setMessageListener(this);
         assertMessagesAreReceived();
-        log.info("" + data.length + " messages(s) received, closing down connections");
+        LOG.info("" + data.length + " messages(s) received, closing down connections");
     }
 }

Modified: activemq/trunk/activemq-core/src/test/java/org/apache/activemq/JmsTopicRedeliverTest.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/JmsTopicRedeliverTest.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/test/java/org/apache/activemq/JmsTopicRedeliverTest.java (original)
+++ activemq/trunk/activemq-core/src/test/java/org/apache/activemq/JmsTopicRedeliverTest.java Thu Aug  9 09:37:49 2007
@@ -31,7 +31,7 @@
  */
 public class JmsTopicRedeliverTest extends TestSupport {
 
-    private static final org.apache.commons.logging.Log log = org.apache.commons.logging.LogFactory.getLog(JmsTopicRedeliverTest.class);
+    private static final org.apache.commons.logging.Log LOG = org.apache.commons.logging.LogFactory.getLog(JmsTopicRedeliverTest.class);
 
     protected Connection connection;
     protected Session session;
@@ -56,17 +56,17 @@
             connection.setClientID(getClass().getName());
         }
 
-        log.info("Created connection: " + connection);
+        LOG.info("Created connection: " + connection);
 
         session = connection.createSession(false, Session.CLIENT_ACKNOWLEDGE);
         consumeSession = connection.createSession(false, Session.CLIENT_ACKNOWLEDGE);
 
-        log.info("Created session: " + session);
-        log.info("Created consumeSession: " + consumeSession);
+        LOG.info("Created session: " + session);
+        LOG.info("Created consumeSession: " + consumeSession);
         producer = session.createProducer(null);
         // producer.setDeliveryMode(deliveryMode);
 
-        log.info("Created producer: " + producer);
+        LOG.info("Created producer: " + producer);
 
         if (topic) {
             consumerDestination = session.createTopic(getConsumerSubject());
@@ -76,12 +76,12 @@
             producerDestination = session.createQueue(getProducerSubject());
         }
 
-        log.info("Created  consumer destination: " + consumerDestination + " of type: " + consumerDestination.getClass());
-        log.info("Created  producer destination: " + producerDestination + " of type: " + producerDestination.getClass());
+        LOG.info("Created  consumer destination: " + consumerDestination + " of type: " + consumerDestination.getClass());
+        LOG.info("Created  producer destination: " + producerDestination + " of type: " + producerDestination.getClass());
         consumer = createConsumer();
         connection.start();
 
-        log.info("Created connection: " + connection);
+        LOG.info("Created connection: " + connection);
     }
 
     protected void tearDown() throws Exception {
@@ -121,7 +121,7 @@
         Message sendMessage = session.createTextMessage(text);
 
         if (verbose) {
-            log.info("About to send a message: " + sendMessage + " with text: " + text);
+            LOG.info("About to send a message: " + sendMessage + " with text: " + text);
         }
         producer.send(producerDestination, sendMessage);
 
@@ -149,7 +149,7 @@
 
     protected MessageConsumer createConsumer() throws JMSException {
         if (durable) {
-            log.info("Creating durable consumer");
+            LOG.info("Creating durable consumer");
             return consumeSession.createDurableSubscriber((Topic)consumerDestination, getName());
         }
         return consumeSession.createConsumer(consumerDestination);

Modified: activemq/trunk/activemq-core/src/test/java/org/apache/activemq/JmsTopicSendReceiveTest.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/JmsTopicSendReceiveTest.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/test/java/org/apache/activemq/JmsTopicSendReceiveTest.java (original)
+++ activemq/trunk/activemq-core/src/test/java/org/apache/activemq/JmsTopicSendReceiveTest.java Thu Aug  9 09:37:49 2007
@@ -27,7 +27,7 @@
  * @version $Revision: 1.3 $
  */
 public class JmsTopicSendReceiveTest extends JmsSendReceiveTestSupport {
-    private static final org.apache.commons.logging.Log log = org.apache.commons.logging.LogFactory.getLog(JmsTopicSendReceiveTest.class);
+    private static final org.apache.commons.logging.Log LOG = org.apache.commons.logging.LogFactory.getLog(JmsTopicSendReceiveTest.class);
 
     protected Connection connection;
 
@@ -40,15 +40,15 @@
             connection.setClientID(getClass().getName());
         }
 
-        log.info("Created connection: " + connection);
+        LOG.info("Created connection: " + connection);
 
         session = connection.createSession(false, Session.AUTO_ACKNOWLEDGE);
 
-        log.info("Created session: " + session);
+        LOG.info("Created session: " + session);
         producer = session.createProducer(null);
         producer.setDeliveryMode(deliveryMode);
 
-        log.info("Created producer: " + producer + " delivery mode = " + (deliveryMode == DeliveryMode.PERSISTENT ? "PERSISTENT" : "NON_PERSISTENT"));
+        LOG.info("Created producer: " + producer + " delivery mode = " + (deliveryMode == DeliveryMode.PERSISTENT ? "PERSISTENT" : "NON_PERSISTENT"));
 
         if (topic) {
             consumerDestination = session.createTopic(getConsumerSubject());
@@ -58,8 +58,8 @@
             producerDestination = session.createQueue(getProducerSubject());
         }
 
-        log.info("Created  consumer destination: " + consumerDestination + " of type: " + consumerDestination.getClass());
-        log.info("Created  producer destination: " + producerDestination + " of type: " + producerDestination.getClass());
+        LOG.info("Created  consumer destination: " + consumerDestination + " of type: " + consumerDestination.getClass());
+        LOG.info("Created  producer destination: " + producerDestination + " of type: " + producerDestination.getClass());
         consumer = createConsumer();
         consumer.setMessageListener(this);
         connection.start();
@@ -69,17 +69,17 @@
 
     protected MessageConsumer createConsumer() throws JMSException {
         if (durable) {
-            log.info("Creating durable consumer");
+            LOG.info("Creating durable consumer");
             return session.createDurableSubscriber((Topic)consumerDestination, getName());
         }
         return session.createConsumer(consumerDestination);
     }
 
     protected void tearDown() throws Exception {
-        log.info("Dumping stats...");
+        LOG.info("Dumping stats...");
         // connectionFactory.getStats().reset();
 
-        log.info("Closing down connection");
+        LOG.info("Closing down connection");
 
         /** TODO we should be able to shut down properly */
         session.close();

Modified: activemq/trunk/activemq-core/src/test/java/org/apache/activemq/JmsTopicSendReceiveWithTwoConnectionsTest.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/JmsTopicSendReceiveWithTwoConnectionsTest.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/test/java/org/apache/activemq/JmsTopicSendReceiveWithTwoConnectionsTest.java (original)
+++ activemq/trunk/activemq-core/src/test/java/org/apache/activemq/JmsTopicSendReceiveWithTwoConnectionsTest.java Thu Aug  9 09:37:49 2007
@@ -28,7 +28,7 @@
  */
 public class JmsTopicSendReceiveWithTwoConnectionsTest extends JmsSendReceiveTestSupport {
 
-    private static final org.apache.commons.logging.Log log = org.apache.commons.logging.LogFactory
+    private static final org.apache.commons.logging.Log LOG = org.apache.commons.logging.LogFactory
         .getLog(JmsTopicSendReceiveWithTwoConnectionsTest.class);
 
     protected Connection sendConnection;
@@ -46,19 +46,19 @@
         receiveConnection = createReceiveConnection();
         receiveConnection.start();
 
-        log.info("Created sendConnection: " + sendConnection);
-        log.info("Created receiveConnection: " + receiveConnection);
+        LOG.info("Created sendConnection: " + sendConnection);
+        LOG.info("Created receiveConnection: " + receiveConnection);
 
         session = sendConnection.createSession(false, Session.AUTO_ACKNOWLEDGE);
         receiveSession = receiveConnection.createSession(false, Session.AUTO_ACKNOWLEDGE);
 
-        log.info("Created sendSession: " + session);
-        log.info("Created receiveSession: " + receiveSession);
+        LOG.info("Created sendSession: " + session);
+        LOG.info("Created receiveSession: " + receiveSession);
 
         producer = session.createProducer(null);
         producer.setDeliveryMode(deliveryMode);
 
-        log.info("Created producer: " + producer + " delivery mode = "
+        LOG.info("Created producer: " + producer + " delivery mode = "
                  + (deliveryMode == DeliveryMode.PERSISTENT ? "PERSISTENT" : "NON_PERSISTENT"));
 
         if (topic) {
@@ -69,15 +69,15 @@
             producerDestination = session.createQueue(getProducerSubject());
         }
 
-        log.info("Created  consumer destination: " + consumerDestination + " of type: "
+        LOG.info("Created  consumer destination: " + consumerDestination + " of type: "
                  + consumerDestination.getClass());
-        log.info("Created  producer destination: " + producerDestination + " of type: "
+        LOG.info("Created  producer destination: " + producerDestination + " of type: "
                  + producerDestination.getClass());
 
         consumer = createConsumer(receiveSession, consumerDestination);
         consumer.setMessageListener(this);
 
-        log.info("Started connections");
+        LOG.info("Started connections");
     }
 
     protected Connection createReceiveConnection() throws Exception {

Modified: activemq/trunk/activemq-core/src/test/java/org/apache/activemq/JmsTopicSendSameMessageTest.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/JmsTopicSendSameMessageTest.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/test/java/org/apache/activemq/JmsTopicSendSameMessageTest.java (original)
+++ activemq/trunk/activemq-core/src/test/java/org/apache/activemq/JmsTopicSendSameMessageTest.java Thu Aug  9 09:37:49 2007
@@ -23,7 +23,7 @@
  */
 public class JmsTopicSendSameMessageTest extends JmsTopicSendReceiveWithTwoConnectionsTest {
 
-    private static final org.apache.commons.logging.Log log = org.apache.commons.logging.LogFactory
+    private static final org.apache.commons.logging.Log LOG = org.apache.commons.logging.LogFactory
         .getLog(JmsTopicSendSameMessageTest.class);
 
     public void testSendReceive() throws Exception {
@@ -37,7 +37,7 @@
             message.setIntProperty("intProperty", i);
 
             if (verbose) {
-                log.info("About to send a message: " + message + " with text: " + data[i]);
+                LOG.info("About to send a message: " + message + " with text: " + data[i]);
             }
 
             producer.send(producerDestination, message);

Modified: activemq/trunk/activemq-core/src/test/java/org/apache/activemq/JmsTransactionTestSupport.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/JmsTransactionTestSupport.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/test/java/org/apache/activemq/JmsTransactionTestSupport.java (original)
+++ activemq/trunk/activemq-core/src/test/java/org/apache/activemq/JmsTransactionTestSupport.java Thu Aug  9 09:37:49 2007
@@ -39,9 +39,11 @@
 /**
  * @version $Revision: 1.9 $
  */
-abstract public class JmsTransactionTestSupport extends TestSupport implements MessageListener {
+public abstract class JmsTransactionTestSupport extends TestSupport implements MessageListener {
 
     private static final org.apache.commons.logging.Log LOG = org.apache.commons.logging.LogFactory.getLog(JmsTransactionTestSupport.class);
+    private static final int MESSAGE_COUNT = 5;
+    private static final String MESSAGE_TEXT = "message";
 
     protected ConnectionFactory connectionFactory;
     protected Connection connection;
@@ -52,10 +54,8 @@
     protected Destination destination;
 
     // for message listener test
-    private static final int messageCount = 5;
-    private static final String messageText = "message";
-    private List unackMessages = new ArrayList(messageCount);
-    private List ackMessages = new ArrayList(messageCount);
+    private List unackMessages = new ArrayList(MESSAGE_COUNT);
+    private List ackMessages = new ArrayList(MESSAGE_COUNT);
     private boolean resendPhase;
     protected int batchCount = 10;
     protected int batchSize = 20;
@@ -402,8 +402,9 @@
      * @throws Exception
      */
     public void testReceiveTwoThenRollbackManyTimes() throws Exception {
-        for (int i = 0; i < 5; i++)
+        for (int i = 0; i < 5; i++) {
             testReceiveTwoThenRollback();
+        }
     }
 
     /**
@@ -559,17 +560,17 @@
 
     public void testMessageListener() throws Exception {
         // send messages
-        for (int i = 0; i < messageCount; i++) {
-            producer.send(session.createTextMessage(messageText + i));
+        for (int i = 0; i < MESSAGE_COUNT; i++) {
+            producer.send(session.createTextMessage(MESSAGE_TEXT + i));
         }
         session.commit();
         consumer.setMessageListener(this);
         // wait receive
         waitReceiveUnack();
-        assertEquals(unackMessages.size(), messageCount);
+        assertEquals(unackMessages.size(), MESSAGE_COUNT);
         // resend phase
         waitReceiveAck();
-        assertEquals(ackMessages.size(), messageCount);
+        assertEquals(ackMessages.size(), MESSAGE_COUNT);
         // should no longer re-receive
         consumer.setMessageListener(null);
         assertNull(consumer.receive(500));
@@ -579,7 +580,7 @@
     public void onMessage(Message message) {
         if (!resendPhase) {
             unackMessages.add(message);
-            if (unackMessages.size() == messageCount) {
+            if (unackMessages.size() == MESSAGE_COUNT) {
                 try {
                     session.rollback();
                     resendPhase = true;
@@ -589,7 +590,7 @@
             }
         } else {
             ackMessages.add(message);
-            if (ackMessages.size() == messageCount) {
+            if (ackMessages.size() == MESSAGE_COUNT) {
                 try {
                     session.commit();
                 } catch (Exception e) {
@@ -607,9 +608,9 @@
     }
 
     private void waitReceiveAck() throws Exception {
-        for (int i = 0; i < 100 && ackMessages.size() < messageCount; i++) {
+        for (int i = 0; i < 100 && ackMessages.size() < MESSAGE_COUNT; i++) {
             Thread.sleep(100);
         }
-        assertFalse(ackMessages.size() < messageCount);
+        assertFalse(ackMessages.size() < MESSAGE_COUNT);
     }
 }

Modified: activemq/trunk/activemq-core/src/test/java/org/apache/activemq/LargeMessageTestSupport.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/LargeMessageTestSupport.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/test/java/org/apache/activemq/LargeMessageTestSupport.java (original)
+++ activemq/trunk/activemq-core/src/test/java/org/apache/activemq/LargeMessageTestSupport.java Thu Aug  9 09:37:49 2007
@@ -41,10 +41,11 @@
  */
 public class LargeMessageTestSupport extends ClientTestSupport implements MessageListener {
 
-    private static final org.apache.commons.logging.Log log = org.apache.commons.logging.LogFactory.getLog(LargeMessageTestSupport.class);
-
     protected static final int LARGE_MESSAGE_SIZE = 128 * 1024;
     protected static final int MESSAGE_COUNT = 100;
+
+    private static final org.apache.commons.logging.Log LOG = org.apache.commons.logging.LogFactory.getLog(LargeMessageTestSupport.class);
+
     protected Connection producerConnection;
     protected Connection consumerConnection;
     protected MessageConsumer consumer;
@@ -82,7 +83,7 @@
     public void setUp() throws Exception {
         super.setUp();
         ClientTestSupport.removeMessageStore();
-        log.info("Setting up . . . . . ");
+        LOG.info("Setting up . . . . . ");
         messageCount.set(0);
 
         destination = createDestination();
@@ -117,7 +118,7 @@
         consumerSession = consumerConnection.createSession(false, Session.AUTO_ACKNOWLEDGE);
         consumer = createConsumer();
         consumer.setMessageListener(this);
-        log.info("Setup complete");
+        LOG.info("Setup complete");
     }
 
     protected void setPrefetchPolicy(ActiveMQConnection activeMQConnection) {
@@ -144,8 +145,9 @@
 
         for (int i = 0; i < LARGE_MESSAGE_SIZE; i++) {
             result = msg1.readByte() == largeMessageData[i];
-            if (!result)
+            if (!result) {
                 break;
+            }
         }
 
         return result;
@@ -161,9 +163,9 @@
                     messageCount.notify();
                 }
             }
-            log.info("got message = " + messageCount);
+            LOG.info("got message = " + messageCount);
             if (messageCount.get() % 50 == 0) {
-                log.info("count = " + messageCount);
+                LOG.info("count = " + messageCount);
             }
         } catch (Exception e) {
             e.printStackTrace();
@@ -172,22 +174,22 @@
 
     public void testLargeMessages() throws Exception {
         for (int i = 0; i < MESSAGE_COUNT; i++) {
-            log.info("Sending message: " + i);
+            LOG.info("Sending message: " + i);
             BytesMessage msg = producerSession.createBytesMessage();
             msg.writeBytes(largeMessageData);
             producer.send(msg);
         }
         long now = System.currentTimeMillis();
         while (now + 60000 > System.currentTimeMillis() && messageCount.get() < MESSAGE_COUNT) {
-            log.info("message count = " + messageCount);
+            LOG.info("message count = " + messageCount);
             synchronized (messageCount) {
                 messageCount.wait(1000);
             }
         }
-        log.info("Finished count = " + messageCount);
+        LOG.info("Finished count = " + messageCount);
         assertTrue("Not enough messages - expected " + MESSAGE_COUNT + " but got " + messageCount, messageCount.get() == MESSAGE_COUNT);
         assertTrue("received messages are not valid", validMessageConsumption);
         Thread.sleep(1000);
-        log.info("FINAL count = " + messageCount);
+        LOG.info("FINAL count = " + messageCount);
     }
 }

Modified: activemq/trunk/activemq-core/src/test/java/org/apache/activemq/LargeStreamletTest.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/LargeStreamletTest.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/test/java/org/apache/activemq/LargeStreamletTest.java (original)
+++ activemq/trunk/activemq-core/src/test/java/org/apache/activemq/LargeStreamletTest.java Thu Aug  9 09:37:49 2007
@@ -1,3 +1,19 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *      http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
 package org.apache.activemq;
 
 /**
@@ -37,7 +53,7 @@
  */
 public final class LargeStreamletTest extends TestCase {
 
-    private static final Log log = LogFactory.getLog(LargeStreamletTest.class);
+    private static final Log LOG = LogFactory.getLog(LargeStreamletTest.class);
     private static final String BROKER_URL = "vm://localhost?broker.persistent=false";
     private static final int BUFFER_SIZE = 1 * 1024;
     private static final int MESSAGE_COUNT = 10 * 1024;
@@ -80,7 +96,7 @@
                             readerException = e;
                             e.printStackTrace();
                         } finally {
-                            log.info(totalRead + " total bytes read.");
+                            LOG.info(totalRead + " total bytes read.");
                         }
                     }
                 });
@@ -108,7 +124,7 @@
                             writerException = e;
                             e.printStackTrace();
                         } finally {
-                            log.info(totalWritten + " total bytes written.");
+                            LOG.info(totalWritten + " total bytes written.");
                         }
                     }
                 });

Modified: activemq/trunk/activemq-core/src/test/java/org/apache/activemq/LoadTestBurnIn.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/LoadTestBurnIn.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/test/java/org/apache/activemq/LoadTestBurnIn.java (original)
+++ activemq/trunk/activemq-core/src/test/java/org/apache/activemq/LoadTestBurnIn.java Thu Aug  9 09:37:49 2007
@@ -49,14 +49,14 @@
  * @version $Revision$
  */
 public class LoadTestBurnIn extends JmsTestSupport {
-    private static final transient Log log = LogFactory.getLog(LoadTestBurnIn.class);
+    private static final transient Log LOG = LogFactory.getLog(LoadTestBurnIn.class);
 
     public static Test suite() {
         return suite(LoadTestBurnIn.class);
     }
 
     protected void setUp() throws Exception {
-        log.info("Start: " + getName());
+        LOG.info("Start: " + getName());
         super.setUp();
     }
 
@@ -66,7 +66,7 @@
         } catch (Throwable e) {
             e.printStackTrace(System.out);
         } finally {
-            log.info("End: " + getName());
+            LOG.info("End: " + getName());
         }
     }
 

Modified: activemq/trunk/activemq-core/src/test/java/org/apache/activemq/ProducerFlowControlTest.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/ProducerFlowControlTest.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/test/java/org/apache/activemq/ProducerFlowControlTest.java (original)
+++ activemq/trunk/activemq-core/src/test/java/org/apache/activemq/ProducerFlowControlTest.java Thu Aug  9 09:37:49 2007
@@ -1,3 +1,19 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *      http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
 package org.apache.activemq;
 
 import java.io.IOException;

Modified: activemq/trunk/activemq-core/src/test/java/org/apache/activemq/ReconnectWithSameClientIDTest.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/ReconnectWithSameClientIDTest.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/test/java/org/apache/activemq/ReconnectWithSameClientIDTest.java (original)
+++ activemq/trunk/activemq-core/src/test/java/org/apache/activemq/ReconnectWithSameClientIDTest.java Thu Aug  9 09:37:49 2007
@@ -21,11 +21,16 @@
 import javax.jms.JMSException;
 import javax.jms.Session;
 
+import org.apache.activemq.store.kahadaptor.KahaPersistenceAdapter;
+import org.apache.commons.logging.Log;
+import org.apache.commons.logging.LogFactory;
+
 /**
  * 
  * @version $Revision$
  */
 public class ReconnectWithSameClientIDTest extends EmbeddedBrokerTestSupport {
+    private static final Log LOG = LogFactory.getLog(ReconnectWithSameClientIDTest.class);
 
     protected Connection connection;
     protected boolean transacted;

Modified: activemq/trunk/activemq-core/src/test/java/org/apache/activemq/TimeStampTest.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/TimeStampTest.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/test/java/org/apache/activemq/TimeStampTest.java (original)
+++ activemq/trunk/activemq-core/src/test/java/org/apache/activemq/TimeStampTest.java Thu Aug  9 09:37:49 2007
@@ -1,18 +1,18 @@
 /**
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
  *
- * Copyright 2006 The Apache Software Foundation
+ *      http://www.apache.org/licenses/LICENSE-2.0
  *
- *  Licensed under the Apache License, Version 2.0 (the "License");
- *  you may not use this file except in compliance with the License.
- *  You may obtain a copy of the License at
- *
- *     http://www.apache.org/licenses/LICENSE-2.0
- *
- *  Unless required by applicable law or agreed to in writing, software
- *  distributed under the License is distributed on an "AS IS" BASIS,
- *  WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- *  See the License for the specific language governing permissions and
- *  limitations under the License.
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
  */
 package org.apache.activemq;
 

Modified: activemq/trunk/activemq-core/src/test/java/org/apache/activemq/ZeroPrefetchConsumerTest.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/ZeroPrefetchConsumerTest.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/test/java/org/apache/activemq/ZeroPrefetchConsumerTest.java (original)
+++ activemq/trunk/activemq-core/src/test/java/org/apache/activemq/ZeroPrefetchConsumerTest.java Thu Aug  9 09:37:49 2007
@@ -1,12 +1,12 @@
 /**
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
  *
- * Copyright 2005-2006 The Apache Software Foundation
- *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
- *
- * http://www.apache.org/licenses/LICENSE-2.0
+ *      http://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing, software
  * distributed under the License is distributed on an "AS IS" BASIS,
@@ -36,7 +36,7 @@
  */
 public class ZeroPrefetchConsumerTest extends EmbeddedBrokerTestSupport {
 
-    private static final Log log = LogFactory.getLog(ZeroPrefetchConsumerTest.class);
+    private static final Log LOG = LogFactory.getLog(ZeroPrefetchConsumerTest.class);
 
     protected Connection connection;
     protected Queue queue;
@@ -50,7 +50,7 @@
             consumer.setMessageListener(listener);
             fail("Should have thrown JMSException as we cannot use MessageListener with zero prefetch");
         } catch (JMSException e) {
-            log.info("Received expected exception : " + e);
+            LOG.info("Received expected exception : " + e);
         }
     }
 

Modified: activemq/trunk/activemq-core/src/test/java/org/apache/activemq/advisory/ConsumerListenerTest.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/advisory/ConsumerListenerTest.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/test/java/org/apache/activemq/advisory/ConsumerListenerTest.java (original)
+++ activemq/trunk/activemq-core/src/test/java/org/apache/activemq/advisory/ConsumerListenerTest.java Thu Aug  9 09:37:49 2007
@@ -28,12 +28,16 @@
 import javax.jms.Session;
 
 import org.apache.activemq.EmbeddedBrokerTestSupport;
+import org.apache.activemq.ReconnectWithSameClientIDTest;
+import org.apache.commons.logging.Log;
+import org.apache.commons.logging.LogFactory;
 
 /**
  * 
  * @version $Revision$
  */
 public class ConsumerListenerTest extends EmbeddedBrokerTestSupport implements ConsumerListener {
+    private static final Log LOG = LogFactory.getLog(ConsumerListenerTest.class);
 
     protected Session consumerSession1;
     protected Session consumerSession2;

Modified: activemq/trunk/activemq-core/src/test/java/org/apache/activemq/advisory/ProducerListenerTest.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/advisory/ProducerListenerTest.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/test/java/org/apache/activemq/advisory/ProducerListenerTest.java (original)
+++ activemq/trunk/activemq-core/src/test/java/org/apache/activemq/advisory/ProducerListenerTest.java Thu Aug  9 09:37:49 2007
@@ -26,12 +26,15 @@
 import javax.jms.Session;
 
 import org.apache.activemq.EmbeddedBrokerTestSupport;
+import org.apache.commons.logging.Log;
+import org.apache.commons.logging.LogFactory;
 
 /**
  * 
  * @version $Revision: 359679 $
  */
 public class ProducerListenerTest extends EmbeddedBrokerTestSupport implements ProducerListener {
+    private static final Log LOG = LogFactory.getLog(ProducerListenerTest.class);
 
     protected Session consumerSession1;
     protected Session consumerSession2;

Modified: activemq/trunk/activemq-core/src/test/java/org/apache/activemq/advisory/TempDestDeleteTest.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/advisory/TempDestDeleteTest.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/test/java/org/apache/activemq/advisory/TempDestDeleteTest.java (original)
+++ activemq/trunk/activemq-core/src/test/java/org/apache/activemq/advisory/TempDestDeleteTest.java Thu Aug  9 09:37:49 2007
@@ -33,12 +33,15 @@
 import org.apache.activemq.broker.region.RegionBroker;
 import org.apache.activemq.command.ActiveMQTempQueue;
 import org.apache.activemq.command.ActiveMQTempTopic;
+import org.apache.commons.logging.Log;
+import org.apache.commons.logging.LogFactory;
 
 /**
  * 
  * @version $Revision: 397249 $
  */
 public class TempDestDeleteTest extends EmbeddedBrokerTestSupport implements ConsumerListener {
+    private static final Log LOG = LogFactory.getLog(TempDestDeleteTest.class);
 
     protected int consumerCounter;
     protected ConsumerEventSource topicConsumerEventSource;

Modified: activemq/trunk/activemq-core/src/test/java/org/apache/activemq/blob/DefaultBlobUploadStrategyTest.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/blob/DefaultBlobUploadStrategyTest.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/test/java/org/apache/activemq/blob/DefaultBlobUploadStrategyTest.java (original)
+++ activemq/trunk/activemq-core/src/test/java/org/apache/activemq/blob/DefaultBlobUploadStrategyTest.java Thu Aug  9 09:37:49 2007
@@ -1,3 +1,19 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *      http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
 package org.apache.activemq.blob;
 
 import java.io.BufferedWriter;
@@ -24,7 +40,8 @@
 
     }
 
-    public void DISABLED_UNTIL_WE_EMBED_JETTY_testUploadViaDefaultBlobUploadStrategy() throws Exception {
+    // DISABLED UNTIL WE EMBED JETTY
+    public void xtestUploadViaDefaultBlobUploadStrategy() throws Exception {
         // 0. Initialise
         File file = File.createTempFile("amq-data-file-", ".dat");
         // lets write some data

Modified: activemq/trunk/activemq-core/src/test/java/org/apache/activemq/broker/BrokerBenchmark.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/broker/BrokerBenchmark.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/test/java/org/apache/activemq/broker/BrokerBenchmark.java (original)
+++ activemq/trunk/activemq-core/src/test/java/org/apache/activemq/broker/BrokerBenchmark.java Thu Aug  9 09:37:49 2007
@@ -45,12 +45,12 @@
  * @version $Revision: 1.9 $
  */
 public class BrokerBenchmark extends BrokerTestSupport {
-    private static final transient Log log = LogFactory.getLog(BrokerBenchmark.class);
+    private static final transient Log LOG = LogFactory.getLog(BrokerBenchmark.class);
 
-    public int PRODUCE_COUNT = Integer.parseInt(System.getProperty("PRODUCE_COUNT", "10000"));
+    public int produceCount = Integer.parseInt(System.getProperty("PRODUCE_COUNT", "10000"));
     public ActiveMQDestination destination;
-    public int PRODUCER_COUNT;
-    public int CONSUMER_COUNT;
+    public int prodcuerCount;
+    public int consumerCount;
     public boolean deliveryMode;
 
     public void initCombosForTestPerformance() {
@@ -63,13 +63,13 @@
 
     public void testPerformance() throws Exception {
 
-        log.info("Running Benchmark for destination=" + destination + ", producers=" + PRODUCER_COUNT + ", consumers=" + CONSUMER_COUNT + ", deliveryMode=" + deliveryMode);
-        final int CONSUME_COUNT = destination.isTopic() ? CONSUMER_COUNT * PRODUCE_COUNT : PRODUCE_COUNT;
+        LOG.info("Running Benchmark for destination=" + destination + ", producers=" + prodcuerCount + ", consumers=" + consumerCount + ", deliveryMode=" + deliveryMode);
+        final int consumeCount = destination.isTopic() ? consumerCount * produceCount : produceCount;
 
-        final Semaphore consumersStarted = new Semaphore(1 - CONSUMER_COUNT);
-        final Semaphore producersFinished = new Semaphore(1 - PRODUCER_COUNT);
-        final Semaphore consumersFinished = new Semaphore(1 - CONSUMER_COUNT);
-        final ProgressPrinter printer = new ProgressPrinter(PRODUCE_COUNT + CONSUME_COUNT, 10);
+        final Semaphore consumersStarted = new Semaphore(1 - consumerCount);
+        final Semaphore producersFinished = new Semaphore(1 - prodcuerCount);
+        final Semaphore consumersFinished = new Semaphore(1 - consumerCount);
+        final ProgressPrinter printer = new ProgressPrinter(produceCount + consumeCount, 10);
 
         // Start a producer and consumer
 
@@ -78,7 +78,7 @@
         long start = System.currentTimeMillis();
 
         final AtomicInteger receiveCounter = new AtomicInteger(0);
-        for (int i = 0; i < CONSUMER_COUNT; i++) {
+        for (int i = 0; i < consumerCount; i++) {
             new Thread() {
                 public void run() {
                     try {
@@ -96,7 +96,7 @@
 
                         consumersStarted.release();
 
-                        while (receiveCounter.get() < CONSUME_COUNT) {
+                        while (receiveCounter.get() < consumeCount) {
 
                             int counter = 0;
                             // Get a least 1 message.
@@ -120,8 +120,8 @@
 
                             if (msg != null) {
                                 connection.send(createAck(consumerInfo, msg, counter, MessageAck.STANDARD_ACK_TYPE));
-                            } else if (receiveCounter.get() < CONSUME_COUNT) {
-                                log.info("Consumer stall, waiting for message #" + receiveCounter.get() + 1);
+                            } else if (receiveCounter.get() < consumeCount) {
+                                LOG.info("Consumer stall, waiting for message #" + receiveCounter.get() + 1);
                             }
                         }
 
@@ -142,7 +142,7 @@
         consumersStarted.acquire();
 
         // Send the messages in an async thread.
-        for (int i = 0; i < PRODUCER_COUNT; i++) {
+        for (int i = 0; i < prodcuerCount; i++) {
             new Thread() {
                 public void run() {
                     try {
@@ -155,7 +155,7 @@
                         connection.send(sessionInfo);
                         connection.send(producerInfo);
 
-                        for (int i = 0; i < PRODUCE_COUNT / PRODUCER_COUNT; i++) {
+                        for (int i = 0; i < produceCount / prodcuerCount; i++) {
                             Message message = createMessage(producerInfo, destination);
                             message.setPersistent(deliveryMode);
                             message.setResponseRequired(false);
@@ -176,9 +176,9 @@
         consumersFinished.acquire();
         long end2 = System.currentTimeMillis();
 
-        log.info("Results for destination=" + destination + ", producers=" + PRODUCER_COUNT + ", consumers=" + CONSUMER_COUNT + ", deliveryMode=" + deliveryMode);
-        log.info("Produced at messages/sec: " + (PRODUCE_COUNT * 1000.0 / (end1 - start)));
-        log.info("Consumed at messages/sec: " + (CONSUME_COUNT * 1000.0 / (end2 - start)));
+        LOG.info("Results for destination=" + destination + ", producers=" + prodcuerCount + ", consumers=" + consumerCount + ", deliveryMode=" + deliveryMode);
+        LOG.info("Produced at messages/sec: " + (produceCount * 1000.0 / (end1 - start)));
+        LOG.info("Consumed at messages/sec: " + (consumeCount * 1000.0 / (end2 - start)));
         profilerPause("Benchmark done.  Stop profiler ");
     }
 

Modified: activemq/trunk/activemq-core/src/test/java/org/apache/activemq/broker/BrokerServiceTest.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/broker/BrokerServiceTest.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/test/java/org/apache/activemq/broker/BrokerServiceTest.java (original)
+++ activemq/trunk/activemq-core/src/test/java/org/apache/activemq/broker/BrokerServiceTest.java Thu Aug  9 09:37:49 2007
@@ -1,12 +1,12 @@
 /**
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
  *
- * Copyright 2005-2006 The Apache Software Foundation
- *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
- *
- * http://www.apache.org/licenses/LICENSE-2.0
+ *      http://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing, software
  * distributed under the License is distributed on an "AS IS" BASIS,

Modified: activemq/trunk/activemq-core/src/test/java/org/apache/activemq/broker/BrokerTest.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/broker/BrokerTest.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/test/java/org/apache/activemq/broker/BrokerTest.java (original)
+++ activemq/trunk/activemq-core/src/test/java/org/apache/activemq/broker/BrokerTest.java Thu Aug  9 09:37:49 2007
@@ -111,7 +111,7 @@
      * 
      * @throws Exception
      */
-    public void XtestQueueBrowserWith2Consumers() throws Exception {
+    public void xtestQueueBrowserWith2Consumers() throws Exception {
 
         ActiveMQDestination destination = new ActiveMQQueue("TEST");
 
@@ -1061,7 +1061,7 @@
         // Send another message, connection1 should not get the message.
         connection2.send(createMessage(producerInfo2, destination, deliveryMode));
 
-        assertNull(connection1.getDispatchQueue().poll(MAX_WAIT, TimeUnit.MILLISECONDS));
+        assertNull(connection1.getDispatchQueue().poll(maxWait, TimeUnit.MILLISECONDS));
     }
 
     public void initCombosForTestSessionCloseCascades() {
@@ -1113,7 +1113,7 @@
         // Send another message, connection1 should not get the message.
         connection2.send(createMessage(producerInfo2, destination, deliveryMode));
 
-        assertNull(connection1.getDispatchQueue().poll(MAX_WAIT, TimeUnit.MILLISECONDS));
+        assertNull(connection1.getDispatchQueue().poll(maxWait, TimeUnit.MILLISECONDS));
     }
 
     public void initCombosForTestConsumerClose() {
@@ -1165,7 +1165,7 @@
         // Send another message, connection1 should not get the message.
         connection2.send(createMessage(producerInfo2, destination, deliveryMode));
 
-        assertNull(connection1.getDispatchQueue().poll(MAX_WAIT, TimeUnit.MILLISECONDS));
+        assertNull(connection1.getDispatchQueue().poll(maxWait, TimeUnit.MILLISECONDS));
     }
 
     public void initCombosForTestTopicNoLocal() {

Modified: activemq/trunk/activemq-core/src/test/java/org/apache/activemq/broker/BrokerTestSupport.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/broker/BrokerTestSupport.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/test/java/org/apache/activemq/broker/BrokerTestSupport.java (original)
+++ activemq/trunk/activemq-core/src/test/java/org/apache/activemq/broker/BrokerTestSupport.java Thu Aug  9 09:37:49 2007
@@ -58,14 +58,15 @@
 
 public class BrokerTestSupport extends CombinationTestSupport {
 
-    protected static final Log LOG = LogFactory.getLog(BrokerTestSupport.class);
-
     /**
      * Setting this to false makes the test run faster but they may be less
      * accurate.
      */
     public static final boolean FAST_NO_MESSAGE_LEFT_ASSERT = System.getProperty("FAST_NO_MESSAGE_LEFT_ASSERT", "true").equals("true");
 
+    private static final Log LOG = LogFactory.getLog(BrokerTestSupport.class);
+
+
     protected RegionBroker regionBroker;
     protected BrokerService broker;
     protected long idGenerator;
@@ -74,7 +75,7 @@
     protected int tempDestGenerator;
     protected PersistenceAdapter persistenceAdapter;
 
-    protected int MAX_WAIT = 4000;
+    protected int maxWait = 4000;
 
     protected UsageManager memoryManager;
 
@@ -249,7 +250,7 @@
         ArrayList skipped = new ArrayList();
 
         // Now get the messages.
-        Object m = connection.getDispatchQueue().poll(MAX_WAIT, TimeUnit.MILLISECONDS);
+        Object m = connection.getDispatchQueue().poll(maxWait, TimeUnit.MILLISECONDS);
         int i = 0;
         while (m != null) {
             if (m instanceof MessageDispatch && ((MessageDispatch)m).getConsumerId().equals(consumerInfo.getConsumerId())) {
@@ -263,7 +264,7 @@
             } else {
                 skipped.add(m);
             }
-            m = connection.getDispatchQueue().poll(MAX_WAIT, TimeUnit.MILLISECONDS);
+            m = connection.getDispatchQueue().poll(maxWait, TimeUnit.MILLISECONDS);
         }
 
         for (Iterator iter = skipped.iterator(); iter.hasNext();) {
@@ -319,22 +320,22 @@
      * @throws InterruptedException
      */
     public Message receiveMessage(StubConnection connection) throws InterruptedException {
-        return receiveMessage(connection, MAX_WAIT);
+        return receiveMessage(connection, maxWait);
     }
 
     public Message receiveMessage(StubConnection connection, long timeout) throws InterruptedException {
         while (true) {
             Object o = connection.getDispatchQueue().poll(timeout, TimeUnit.MILLISECONDS);
 
-            if (o == null)
+            if (o == null) {
                 return null;
-
+            }
             if (o instanceof MessageDispatch) {
 
                 MessageDispatch dispatch = (MessageDispatch)o;
-                if (dispatch.getMessage() == null)
+                if (dispatch.getMessage() == null) {
                     return null;
-
+                }
                 dispatch.setMessage(dispatch.getMessage().copy());
                 dispatch.getMessage().setRedeliveryCounter(dispatch.getRedeliveryCounter());
                 return dispatch.getMessage();
@@ -343,11 +344,12 @@
     };
 
     protected void assertNoMessagesLeft(StubConnection connection) throws InterruptedException {
-        long wait = FAST_NO_MESSAGE_LEFT_ASSERT ? 0 : MAX_WAIT;
+        long wait = FAST_NO_MESSAGE_LEFT_ASSERT ? 0 : maxWait;
         while (true) {
             Object o = connection.getDispatchQueue().poll(wait, TimeUnit.MILLISECONDS);
-            if (o == null)
+            if (o == null) {
                 return;
+            }
             if (o instanceof MessageDispatch && ((MessageDispatch)o).getMessage() != null) {
                 fail("Received a message.");
             }

Modified: activemq/trunk/activemq-core/src/test/java/org/apache/activemq/broker/CreateDestinationsOnStartupViaXBeanTest.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/broker/CreateDestinationsOnStartupViaXBeanTest.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/test/java/org/apache/activemq/broker/CreateDestinationsOnStartupViaXBeanTest.java (original)
+++ activemq/trunk/activemq-core/src/test/java/org/apache/activemq/broker/CreateDestinationsOnStartupViaXBeanTest.java Thu Aug  9 09:37:49 2007
@@ -1,4 +1,4 @@
-/*
+/**
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements.  See the NOTICE file distributed with
  * this work for additional information regarding copyright ownership.

Modified: activemq/trunk/activemq-core/src/test/java/org/apache/activemq/broker/MessageExpirationTest.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/broker/MessageExpirationTest.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/test/java/org/apache/activemq/broker/MessageExpirationTest.java (original)
+++ activemq/trunk/activemq-core/src/test/java/org/apache/activemq/broker/MessageExpirationTest.java Thu Aug  9 09:37:49 2007
@@ -211,7 +211,7 @@
         connection.send(closeConnectionInfo(connectionInfo));
     }
 
-    public void TestMessagesInSubscriptionPendingListExpire() {
+    public void xinitCombosForTestMessagesInSubscriptionPendingListExpire() {
         addCombinationValues("deliveryMode", new Object[] {Integer.valueOf(DeliveryMode.NON_PERSISTENT), Integer.valueOf(DeliveryMode.PERSISTENT)});
         addCombinationValues("destinationType", new Object[] {Byte.valueOf(ActiveMQDestination.QUEUE_TYPE), Byte.valueOf(ActiveMQDestination.TOPIC_TYPE),
                                                               Byte.valueOf(ActiveMQDestination.TEMP_QUEUE_TYPE), Byte.valueOf(ActiveMQDestination.TEMP_TOPIC_TYPE)});

Modified: activemq/trunk/activemq-core/src/test/java/org/apache/activemq/broker/ProgressPrinter.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/broker/ProgressPrinter.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/test/java/org/apache/activemq/broker/ProgressPrinter.java (original)
+++ activemq/trunk/activemq-core/src/test/java/org/apache/activemq/broker/ProgressPrinter.java Thu Aug  9 09:37:49 2007
@@ -29,11 +29,11 @@
         this.interval = interval;
     }
 
-    synchronized public void increment() {
+    public synchronized void increment() {
         update(++counter);
     }
 
-    synchronized public void update(long current) {
+    public synchronized void update(long current) {
         long at = 100 * current / total;
         if ((percentDone / interval) != (at / interval)) {
             percentDone = at;

Modified: activemq/trunk/activemq-core/src/test/java/org/apache/activemq/broker/QueueSubscriptionTest.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/broker/QueueSubscriptionTest.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/test/java/org/apache/activemq/broker/QueueSubscriptionTest.java (original)
+++ activemq/trunk/activemq-core/src/test/java/org/apache/activemq/broker/QueueSubscriptionTest.java Thu Aug  9 09:37:49 2007
@@ -149,8 +149,9 @@
         // Wait for messages to be received. Make it proportional to the
         // messages delivered.
         int totalMessageCount = messageCount * producerCount;
-        if (dest.isTopic())
+        if (dest.isTopic()) {
             totalMessageCount *= consumerCount;
+        }
         waitForAllMessagesToBeReceived(totalMessageCount);
     }
 }

Modified: activemq/trunk/activemq-core/src/test/java/org/apache/activemq/broker/SpringTest.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/broker/SpringTest.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/test/java/org/apache/activemq/broker/SpringTest.java (original)
+++ activemq/trunk/activemq-core/src/test/java/org/apache/activemq/broker/SpringTest.java Thu Aug  9 09:37:49 2007
@@ -31,7 +31,7 @@
 
 public class SpringTest extends TestCase {
     
-    private static final Log log = LogFactory.getLog(SpringTest.class);
+    private static final Log LOG = LogFactory.getLog(SpringTest.class);
 
     protected AbstractApplicationContext context;
     protected SpringConsumer consumer;
@@ -66,10 +66,10 @@
 
         // now lets check that the consumer has received some messages
         List messages = consumer.flushMessages();
-        log.info("Consumer has received messages....");
+        LOG.info("Consumer has received messages....");
         for (Iterator iter = messages.iterator(); iter.hasNext();) {
             Object message = iter.next();
-            log.info("Received: " + message);
+            LOG.info("Received: " + message);
         }
 
         assertEquals("Message count", producer.getMessageCount(), messages.size());