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 [7/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/act...

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/memory/UsageListener.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/memory/UsageListener.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/memory/UsageListener.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/memory/UsageListener.java Thu Aug  9 09:37:49 2007
@@ -17,5 +17,5 @@
 package org.apache.activemq.memory;
 
 public interface UsageListener {
-    public void onMemoryUseChanged( UsageManager memoryManager, int oldPercentUsage, int newPercentUsage );
+    void onMemoryUseChanged( UsageManager memoryManager, int oldPercentUsage, int newPercentUsage );
 }

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/memory/UsageManager.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/memory/UsageManager.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/memory/UsageManager.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/memory/UsageManager.java Thu Aug  9 09:37:49 2007
@@ -38,7 +38,7 @@
  */
 public class UsageManager implements Service {
 
-    private static final Log log = LogFactory.getLog(UsageManager.class);
+    private static final Log LOG = LogFactory.getLog(UsageManager.class);
 
     private final UsageManager parent;
     private long limit;
@@ -58,7 +58,7 @@
      * manager
      */
     private boolean sendFailIfNoSpaceExplicitySet;
-    private final boolean debug = log.isDebugEnabled();
+    private final boolean debug = LOG.isDebugEnabled();
     private String name = "";
     private float usagePortion = 1.0f;
     private List<UsageManager> children = new CopyOnWriteArrayList<UsageManager>();
@@ -331,7 +331,7 @@
 
     private void fireEvent(int oldPercentUsage, int newPercentUsage) {
         if (debug) {
-            log.debug("Memory usage change.  from: " + oldPercentUsage + ", to: " + newPercentUsage);
+            LOG.debug("Memory usage change.  from: " + oldPercentUsage + ", to: " + newPercentUsage);
         }
         // Switching from being full to not being full..
         if (oldPercentUsage >= 100 && newPercentUsage < 100) {

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/memory/buffer/MessageBuffer.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/memory/buffer/MessageBuffer.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/memory/buffer/MessageBuffer.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/memory/buffer/MessageBuffer.java Thu Aug  9 09:37:49 2007
@@ -25,12 +25,12 @@
  */
 public interface MessageBuffer {
 
-    public int getSize();
+    int getSize();
 
     /**
      * Creates a new message queue instance
      */
-    public MessageQueue createMessageQueue();
+    MessageQueue createMessageQueue();
 
     /**
      * After a message queue has changed we may need to perform some evictions
@@ -38,8 +38,8 @@
      * @param delta
      * @param queueSize
      */
-    public void onSizeChanged(MessageQueue queue, int delta, int queueSize);
+    void onSizeChanged(MessageQueue queue, int delta, int queueSize);
 
-    public void clear();
+    void clear();
 
 }

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/memory/list/SimpleMessageList.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/memory/list/SimpleMessageList.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/memory/list/SimpleMessageList.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/memory/list/SimpleMessageList.java Thu Aug  9 09:37:49 2007
@@ -37,7 +37,7 @@
  * @version $Revision: 1.1 $
  */
 public class SimpleMessageList implements MessageList {
-    static final private Log log = LogFactory.getLog(SimpleMessageList.class);
+    private static final Log LOG = LogFactory.getLog(SimpleMessageList.class);
     private LinkedList list = new LinkedList();
     private int maximumSize = 100 * 64 * 1024;
     private int size;
@@ -79,7 +79,7 @@
                         result.add(msg);
                     }
                 } catch (IOException e) {
-                    log.error("Failed to get Message from MessageReference: " + ref, e);
+                    LOG.error("Failed to get Message from MessageReference: " + ref, e);
                 }
 
             }

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/network/CompositeDemandForwardingBridge.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/network/CompositeDemandForwardingBridge.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/network/CompositeDemandForwardingBridge.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/network/CompositeDemandForwardingBridge.java Thu Aug  9 09:37:49 2007
@@ -26,6 +26,8 @@
 import org.apache.activemq.command.NetworkBridgeFilter;
 import org.apache.activemq.transport.Transport;
 import org.apache.activemq.util.ServiceSupport;
+import org.apache.commons.logging.Log;
+import org.apache.commons.logging.LogFactory;
 
 /**
  * A demand forwarding bridge which works with multicast style transports where
@@ -36,6 +38,7 @@
  * @version $Revision$
  */
 public class CompositeDemandForwardingBridge extends DemandForwardingBridgeSupport {
+    private static final Log LOG = LogFactory.getLog(CompositeDemandForwardingBridge.class);
 
     protected final BrokerId remoteBrokerPath[] = new BrokerId[] {null};
     protected Object brokerInfoMutex = new Object();
@@ -56,13 +59,13 @@
             // refer to it later
             Endpoint from = command.getFrom();
             if (from == null) {
-                log.warn("Incoming command does not have a from endpoint: " + command);
+                LOG.warn("Incoming command does not have a from endpoint: " + command);
             } else {
                 from.setBrokerInfo(remoteBrokerInfo);
             }
             if (localBrokerId != null) {
                 if (localBrokerId.equals(remoteBrokerId)) {
-                    log.info("Disconnecting loop back connection.");
+                    LOG.info("Disconnecting loop back connection.");
                     // waitStarted();
                     ServiceSupport.dispose(this);
                 }
@@ -84,7 +87,7 @@
         BrokerId answer = null;
         Endpoint from = command.getFrom();
         if (from == null) {
-            log.warn("Incoming command does not have a from endpoint: " + command);
+            LOG.warn("Incoming command does not have a from endpoint: " + command);
         } else {
             answer = from.getBrokerId();
         }

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/network/ConduitBridge.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/network/ConduitBridge.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/network/ConduitBridge.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/network/ConduitBridge.java Thu Aug  9 09:37:49 2007
@@ -34,7 +34,7 @@
  * @version $Revision: 1.1 $
  */
 public class ConduitBridge extends DemandForwardingBridge {
-    static final private Log log = LogFactory.getLog(ConduitBridge.class);
+    private static final Log LOG = LogFactory.getLog(ConduitBridge.class);
 
     /**
      * Constructor
@@ -91,8 +91,8 @@
             DemandSubscription ds = (DemandSubscription)i.next();
             subscriptionMapByLocalId.remove(ds.getRemoteInfo().getConsumerId());
             removeSubscription(ds);
-            if (log.isTraceEnabled())
-                log.trace("removing sub on " + localBroker + " from " + remoteBrokerName + " :  "
+            if (LOG.isTraceEnabled())
+                LOG.trace("removing sub on " + localBroker + " from " + remoteBrokerName + " :  "
                           + ds.getRemoteInfo());
         }
 

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/network/DemandForwardingBridge.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/network/DemandForwardingBridge.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/network/DemandForwardingBridge.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/network/DemandForwardingBridge.java Thu Aug  9 09:37:49 2007
@@ -25,6 +25,8 @@
 import org.apache.activemq.command.NetworkBridgeFilter;
 import org.apache.activemq.transport.Transport;
 import org.apache.activemq.util.ServiceSupport;
+import org.apache.commons.logging.Log;
+import org.apache.commons.logging.LogFactory;
 
 /**
  * Forwards messages from the local broker to the remote broker based on demand.
@@ -34,6 +36,7 @@
  * @version $Revision$
  */
 public class DemandForwardingBridge extends DemandForwardingBridgeSupport {
+    private static final Log LOG = LogFactory.getLog(DemandForwardingBridge.class);
 
     protected final BrokerId remoteBrokerPath[] = new BrokerId[] {null};
     protected Object brokerInfoMutex = new Object();
@@ -52,7 +55,7 @@
             remoteBrokerName = remoteBrokerInfo.getBrokerName();
             if (localBrokerId != null) {
                 if (localBrokerId.equals(remoteBrokerId)) {
-                    log.info("Disconnecting loop back connection.");
+                    LOG.info("Disconnecting loop back connection.");
                     // waitStarted();
                     ServiceSupport.dispose(this);
                 }
@@ -71,7 +74,7 @@
             localBrokerPath[0] = localBrokerId;
             if (remoteBrokerId != null) {
                 if (remoteBrokerId.equals(localBrokerId)) {
-                    log.info("Disconnecting loop back connection.");
+                    LOG.info("Disconnecting loop back connection.");
                     waitStarted();
                     ServiceSupport.dispose(this);
                 }

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/network/DemandForwardingBridgeSupport.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/network/DemandForwardingBridgeSupport.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/network/DemandForwardingBridgeSupport.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/network/DemandForwardingBridgeSupport.java Thu Aug  9 09:37:49 2007
@@ -73,7 +73,9 @@
  * @version $Revision$
  */
 public abstract class DemandForwardingBridgeSupport implements NetworkBridge {
-    protected static final Log log = LogFactory.getLog(DemandForwardingBridge.class);
+    
+    private static final Log LOG = LogFactory.getLog(DemandForwardingBridge.class);
+    
     protected final Transport localBroker;
     protected final Transport remoteBroker;
     protected final IdGenerator idGenerator = new IdGenerator();
@@ -153,16 +155,16 @@
                     // clear any subscriptions - to try and prevent the bridge
                     // from stalling the broker
                     if (remoteInterupted.compareAndSet(false, true)) {
-                        log.info("Outbound transport to " + remoteBrokerName + " interrupted.");
+                        LOG.info("Outbound transport to " + remoteBrokerName + " interrupted.");
                         if (localBridgeStarted.get()) {
                             clearDownSubscriptions();
                             synchronized (DemandForwardingBridgeSupport.this) {
                                 try {
                                     localBroker.oneway(localConnectionInfo.createRemoveCommand());
                                 } catch (TransportDisposedIOException td) {
-                                    log.debug("local broker is now disposed", td);
+                                    LOG.debug("local broker is now disposed", td);
                                 } catch (IOException e) {
-                                    log.warn("Caught exception from local start", e);
+                                    LOG.warn("Caught exception from local start", e);
                                 }
                             }
                         }
@@ -179,7 +181,7 @@
                         // False connects can occurr if you using SSH tunnels.
                         if (!lastConnectSucceeded.get()) {
                             try {
-                                log.debug("Previous connection was never fully established. Sleeping for second to avoid busy loop.");
+                                LOG.debug("Previous connection was never fully established. Sleeping for second to avoid busy loop.");
                                 Thread.sleep(1000);
                             } catch (InterruptedException e) {
                                 Thread.currentThread().interrupt();
@@ -190,9 +192,9 @@
                             startLocalBridge();
                             remoteBridgeStarted.set(true);
                             startedLatch.countDown();
-                            log.info("Outbound transport to " + remoteBrokerName + " resumed");
+                            LOG.info("Outbound transport to " + remoteBrokerName + " resumed");
                         } catch (Exception e) {
-                            log.error("Caught exception  from local start in resume transport", e);
+                            LOG.error("Caught exception  from local start in resume transport", e);
                         }
                     }
                 }
@@ -203,7 +205,7 @@
             try {
                 triggerRemoteStartBridge();
             } catch (IOException e) {
-                log.warn("Caught exception from remote start", e);
+                LOG.warn("Caught exception from remote start", e);
             }
             NetworkBridgeListener l = this.networkBridgeListener;
             if (l != null) {
@@ -255,7 +257,7 @@
                 localSessionInfo = new SessionInfo(localConnectionInfo, 1);
                 localBroker.oneway(localSessionInfo);
 
-                log.info("Network connection between " + localBroker + " and " + remoteBroker + "(" + remoteBrokerName + ") has been established.");
+                LOG.info("Network connection between " + localBroker + " and " + remoteBroker + "(" + remoteBrokerName + ") has been established.");
 
                 startedLatch.countDown();
                 setupStaticDestinations();
@@ -314,7 +316,7 @@
 
     public void stop() throws Exception {
         if (started.compareAndSet(true, false)) {
-            log.debug(" stopping " + configuration.getBrokerName() + " bridge to " + remoteBrokerName + " is disposed already ? " + disposed);
+            LOG.debug(" stopping " + configuration.getBrokerName() + " bridge to " + remoteBrokerName + " is disposed already ? " + disposed);
             boolean wasDisposedAlready = disposed;
             if (!disposed) {
                 NetworkBridgeListener l = this.networkBridgeListener;
@@ -327,7 +329,7 @@
                     localBroker.oneway(new ShutdownInfo());
                     remoteBroker.oneway(new ShutdownInfo());
                 } catch (IOException e) {
-                    log.debug("Caught exception stopping", e);
+                    LOG.debug("Caught exception stopping", e);
                 } finally {
                     ServiceStopper ss = new ServiceStopper();
                     ss.stop(localBroker);
@@ -340,9 +342,9 @@
                 }
             }
             if (wasDisposedAlready) {
-                log.debug(configuration.getBrokerName() + " bridge to " + remoteBrokerName + " stopped");
+                LOG.debug(configuration.getBrokerName() + " bridge to " + remoteBrokerName + " stopped");
             } else {
-                log.info(configuration.getBrokerName() + " bridge to " + remoteBrokerName + " stopped");
+                LOG.info(configuration.getBrokerName() + " bridge to " + remoteBrokerName + " stopped");
             }
         }
     }
@@ -350,11 +352,11 @@
     public void serviceRemoteException(Throwable error) {
         if (!disposed) {
             if (error instanceof SecurityException || error instanceof GeneralSecurityException) {
-                log.error("Network connection between " + localBroker + " and " + remoteBroker + " shutdown due to a remote error: " + error);
+                LOG.error("Network connection between " + localBroker + " and " + remoteBroker + " shutdown due to a remote error: " + error);
             } else {
-                log.warn("Network connection between " + localBroker + " and " + remoteBroker + " shutdown due to a remote error: " + error);
+                LOG.warn("Network connection between " + localBroker + " and " + remoteBroker + " shutdown due to a remote error: " + error);
             }
-            log.debug("The remote Exception was: " + error, error);
+            LOG.debug("The remote Exception was: " + error, error);
             new Thread() {
 
                 public void run() {
@@ -404,13 +406,13 @@
                                 break;
                             case ConsumerInfo.DATA_STRUCTURE_TYPE:
                                 if (!addConsumerInfo((ConsumerInfo)command)) {
-                                    if (log.isDebugEnabled())
-                                        log.debug("Ignoring ConsumerInfo: " + command);
+                                    if (LOG.isDebugEnabled())
+                                        LOG.debug("Ignoring ConsumerInfo: " + command);
                                 }
                                 break;
                             default:
-                                if (log.isDebugEnabled())
-                                    log.debug("Ignoring remote command: " + command);
+                                if (LOG.isDebugEnabled())
+                                    LOG.debug("Ignoring remote command: " + command);
                             }
                         }
                     } else {
@@ -420,7 +422,7 @@
                         case ShutdownInfo.DATA_STRUCTURE_TYPE:
                             break;
                         default:
-                            log.warn("Unexpected remote command: " + command);
+                            LOG.warn("Unexpected remote command: " + command);
                         }
                     }
                 }
@@ -437,29 +439,29 @@
             ConsumerInfo info = (ConsumerInfo)data;
             BrokerId[] path = info.getBrokerPath();
             if (path != null && path.length >= networkTTL) {
-                if (log.isDebugEnabled())
-                    log.debug(configuration.getBrokerName() + " Ignoring Subscription " + info + " restricted to " + networkTTL + " network hops only");
+                if (LOG.isDebugEnabled())
+                    LOG.debug(configuration.getBrokerName() + " Ignoring Subscription " + info + " restricted to " + networkTTL + " network hops only");
                 return;
             }
             if (contains(info.getBrokerPath(), localBrokerPath[0])) {
                 // Ignore this consumer as it's a consumer we locally sent to
                 // the broker.
-                if (log.isDebugEnabled())
-                    log.debug(configuration.getBrokerName() + " Ignoring sub " + info + " already routed through this broker once");
+                if (LOG.isDebugEnabled())
+                    LOG.debug(configuration.getBrokerName() + " Ignoring sub " + info + " already routed through this broker once");
                 return;
             }
             if (!isPermissableDestination(info.getDestination())) {
                 // ignore if not in the permited or in the excluded list
-                if (log.isDebugEnabled())
-                    log.debug(configuration.getBrokerName() + " Ignoring sub " + info + " destination " + info.getDestination() + " is not permiited");
+                if (LOG.isDebugEnabled())
+                    LOG.debug(configuration.getBrokerName() + " Ignoring sub " + info + " destination " + info.getDestination() + " is not permiited");
                 return;
             }
             if (addConsumerInfo(info)) {
-                if (log.isDebugEnabled())
-                    log.debug(configuration.getBrokerName() + " Forwarding sub on " + localBroker + " from " + remoteBrokerName + " :  " + info);
+                if (LOG.isDebugEnabled())
+                    LOG.debug(configuration.getBrokerName() + " Forwarding sub on " + localBroker + " from " + remoteBrokerName + " :  " + info);
             } else {
-                if (log.isDebugEnabled())
-                    log.debug(configuration.getBrokerName() + " Ignoring sub " + info + " already subscribed to matching destination");
+                if (LOG.isDebugEnabled())
+                    LOG.debug(configuration.getBrokerName() + " Ignoring sub " + info + " already subscribed to matching destination");
             }
         } else if (data.getClass() == DestinationInfo.class) {
             // It's a destination info - we want to pass up
@@ -467,16 +469,16 @@
             DestinationInfo destInfo = (DestinationInfo)data;
             BrokerId[] path = destInfo.getBrokerPath();
             if (path != null && path.length >= networkTTL) {
-                if (log.isDebugEnabled()) {
-                    log.debug("Ignoring Subscription " + destInfo + " restricted to " + networkTTL + " network hops only");
+                if (LOG.isDebugEnabled()) {
+                    LOG.debug("Ignoring Subscription " + destInfo + " restricted to " + networkTTL + " network hops only");
                 }
                 return;
             }
             if (contains(destInfo.getBrokerPath(), localBrokerPath[0])) {
                 // Ignore this consumer as it's a consumer we locally sent to
                 // the broker.
-                if (log.isDebugEnabled()) {
-                    log.debug("Ignoring sub " + destInfo + " already routed through this broker once");
+                if (LOG.isDebugEnabled()) {
+                    LOG.debug("Ignoring sub " + destInfo + " already routed through this broker once");
                 }
                 return;
             }
@@ -487,7 +489,7 @@
                 tempDest.setConnectionId(localSessionInfo.getSessionId().getConnectionId());
             }
             destInfo.setBrokerPath(appendToBrokerPath(destInfo.getBrokerPath(), getRemoteBrokerPath()));
-            log.debug("Replying destination control command: " + destInfo);
+            LOG.debug("Replying destination control command: " + destInfo);
             localBroker.oneway(destInfo);
         } else if (data.getClass() == RemoveInfo.class) {
             ConsumerId id = (ConsumerId)((RemoveInfo)data).getObjectId();
@@ -497,8 +499,8 @@
 
     public void serviceLocalException(Throwable error) {
         if (!disposed) {
-            log.info("Network connection between " + localBroker + " and " + remoteBroker + " shutdown due to a local error: " + error);
-            log.debug("The local Exception was:" + error, error);
+            LOG.info("Network connection between " + localBroker + " and " + remoteBroker + " shutdown due to a local error: " + error);
+            LOG.debug("The local Exception was:" + error, error);
             new Thread() {
 
                 public void run() {
@@ -540,7 +542,7 @@
 
     protected void serviceLocalCommand(Command command) {
         if (!disposed) {
-            final boolean trace = log.isTraceEnabled();
+            final boolean trace = LOG.isTraceEnabled();
             try {
                 if (command.isMessageDispatch()) {
                     enqueueCounter.incrementAndGet();
@@ -550,7 +552,7 @@
                     if (sub != null) {
                         Message message = configureMessage(md);
                         if (trace)
-                            log.trace("bridging " + configuration.getBrokerName() + " -> " + remoteBrokerName + ": " + message);
+                            LOG.trace("bridging " + configuration.getBrokerName() + " -> " + remoteBrokerName + ": " + message);
 
                         if (!message.isResponseRequired()) {
 
@@ -590,13 +592,13 @@
 
                     } else {
                         if (trace)
-                            log.trace("No subscription registered with this network bridge for consumerId " + md.getConsumerId() + " for message: " + md.getMessage());
+                            LOG.trace("No subscription registered with this network bridge for consumerId " + md.getConsumerId() + " for message: " + md.getMessage());
                     }
                 } else if (command.isBrokerInfo()) {
                     localBrokerInfo = ((BrokerInfo)command);
                     serviceLocalBrokerInfo(command);
                 } else if (command.isShutdownInfo()) {
-                    log.info(configuration.getBrokerName() + " Shutting down");
+                    LOG.info(configuration.getBrokerName() + " Shutting down");
                     // Don't shut down the whole connector if the remote side
                     // was interrupted.
                     // the local transport is just shutting down temporarily
@@ -613,7 +615,7 @@
                     case WireFormatInfo.DATA_STRUCTURE_TYPE:
                         break;
                     default:
-                        log.warn("Unexpected local command: " + command);
+                        LOG.warn("Unexpected local command: " + command);
                     }
                 }
             } catch (Exception e) {
@@ -777,10 +779,10 @@
                 try {
                     addSubscription(sub);
                 } catch (IOException e) {
-                    log.error("Failed to add static destination " + dest, e);
+                    LOG.error("Failed to add static destination " + dest, e);
                 }
-                if (log.isTraceEnabled())
-                    log.trace("Forwarding messages for static destination: " + dest);
+                if (LOG.isTraceEnabled())
+                    LOG.trace("Forwarding messages for static destination: " + dest);
             }
         }
     }
@@ -851,8 +853,8 @@
         DemandSubscription sub = (DemandSubscription)subscriptionMapByRemoteId.remove(id);
         if (sub != null) {
             removeSubscription(sub);
-            if (log.isTraceEnabled())
-                log.trace("removing sub on " + localBroker + " from " + remoteBrokerName + " :  " + sub.getRemoteInfo());
+            if (LOG.isTraceEnabled())
+                LOG.trace("removing sub on " + localBroker + " from " + remoteBrokerName + " :  " + sub.getRemoteInfo());
         }
     }
 

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/network/DiscoveryNetworkConnector.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/network/DiscoveryNetworkConnector.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/network/DiscoveryNetworkConnector.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/network/DiscoveryNetworkConnector.java Thu Aug  9 09:37:49 2007
@@ -30,6 +30,8 @@
 import org.apache.activemq.transport.discovery.DiscoveryListener;
 import org.apache.activemq.util.ServiceStopper;
 import org.apache.activemq.util.ServiceSupport;
+import org.apache.commons.logging.Log;
+import org.apache.commons.logging.LogFactory;
 
 /**
  * A network connector which uses a discovery agent to detect the remote brokers
@@ -40,6 +42,7 @@
  * @version $Revision$
  */
 public class DiscoveryNetworkConnector extends NetworkConnector implements DiscoveryListener {
+    private static final Log LOG = LogFactory.getLog(DiscoveryNetworkConnector.class);
 
     private DiscoveryAgent discoveryAgent;
     private ConcurrentHashMap bridges = new ConcurrentHashMap();
@@ -66,7 +69,7 @@
             try {
                 uri = new URI(url);
             } catch (URISyntaxException e) {
-                log.warn("Could not connect to remote URI: " + url + " due to bad URI syntax: " + e, e);
+                LOG.warn("Could not connect to remote URI: " + url + " due to bad URI syntax: " + e, e);
                 return;
             }
             // Should we try to connect to that URI?
@@ -74,13 +77,13 @@
                 || (connectionFilter != null && !connectionFilter.connectTo(uri)))
                 return;
             URI connectUri = uri;
-            log.info("Establishing network connection between from " + localURIName + " to " + connectUri);
+            LOG.info("Establishing network connection between from " + localURIName + " to " + connectUri);
             Transport remoteTransport;
             try {
                 remoteTransport = TransportFactory.connect(connectUri);
             } catch (Exception e) {
-                log.warn("Could not connect to remote URI: " + localURIName + ": " + e.getMessage());
-                log.debug("Connection failure exception: " + e, e);
+                LOG.warn("Could not connect to remote URI: " + localURIName + ": " + e.getMessage());
+                LOG.debug("Connection failure exception: " + e, e);
                 return;
             }
             Transport localTransport;
@@ -88,8 +91,8 @@
                 localTransport = createLocalTransport();
             } catch (Exception e) {
                 ServiceSupport.dispose(remoteTransport);
-                log.warn("Could not connect to local URI: " + localURIName + ": " + e.getMessage());
-                log.debug("Connection failure exception: " + e, e);
+                LOG.warn("Could not connect to local URI: " + localURIName + ": " + e.getMessage());
+                LOG.debug("Connection failure exception: " + e, e);
                 return;
             }
             NetworkBridge bridge = createBridge(localTransport, remoteTransport, event);
@@ -99,9 +102,9 @@
             } catch (Exception e) {
                 ServiceSupport.dispose(localTransport);
                 ServiceSupport.dispose(remoteTransport);
-                log.warn("Could not start network bridge between: " + localURIName + " and: " + uri
+                LOG.warn("Could not start network bridge between: " + localURIName + " and: " + uri
                          + " due to: " + e);
-                log.debug("Start failure exception: " + e, e);
+                LOG.debug("Start failure exception: " + e, e);
                 try {
                     discoveryAgent.serviceFailed(event);
                 } catch (IOException e1) {
@@ -118,7 +121,7 @@
             try {
                 uri = new URI(url);
             } catch (URISyntaxException e) {
-                log.warn("Could not connect to remote URI: " + url + " due to bad URI syntax: " + e, e);
+                LOG.warn("Could not connect to remote URI: " + url + " due to bad URI syntax: " + e, e);
                 return;
             }
 

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/network/DurableConduitBridge.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/network/DurableConduitBridge.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/network/DurableConduitBridge.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/network/DurableConduitBridge.java Thu Aug  9 09:37:49 2007
@@ -33,7 +33,7 @@
  * @version $Revision: 1.1 $
  */
 public class DurableConduitBridge extends ConduitBridge {
-    static final private Log log = LogFactory.getLog(DurableConduitBridge.class);
+    private static final Log LOG = LogFactory.getLog(DurableConduitBridge.class);
 
     /**
      * Constructor
@@ -66,10 +66,10 @@
                     try {
                         addSubscription(sub);
                     } catch (IOException e) {
-                        log.error("Failed to add static destination " + dest, e);
+                        LOG.error("Failed to add static destination " + dest, e);
                     }
-                    if (log.isTraceEnabled())
-                        log.trace("Forwarding messages for durable destination: " + dest);
+                    if (LOG.isTraceEnabled())
+                        LOG.trace("Forwarding messages for durable destination: " + dest);
                 }
             }
         }

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/network/ForwardingBridge.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/network/ForwardingBridge.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/network/ForwardingBridge.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/network/ForwardingBridge.java Thu Aug  9 09:37:49 2007
@@ -55,7 +55,7 @@
  */
 public class ForwardingBridge implements Service {
 
-    static final private Log log = LogFactory.getLog(ForwardingBridge.class);
+    private static final Log LOG = LogFactory.getLog(ForwardingBridge.class);
 
     private final Transport localBroker;
     private final Transport remoteBroker;
@@ -88,7 +88,7 @@
     }
 
     public void start() throws Exception {
-        log.info("Starting a network connection between " + localBroker + " and " + remoteBroker
+        LOG.info("Starting a network connection between " + localBroker + " and " + remoteBroker
                  + " has been established.");
 
         localBroker.setTransportListener(new DefaultTransportListener() {
@@ -123,7 +123,7 @@
                 try {
                     startBridge();
                 } catch (IOException e) {
-                    log.error("Failed to start network bridge: " + e, e);
+                    LOG.error("Failed to start network bridge: " + e, e);
                 }
             }
         };
@@ -165,7 +165,7 @@
             topicConsumerInfo.setPriority(ConsumerInfo.NETWORK_CONSUMER_PRIORITY);
             localBroker.oneway(topicConsumerInfo);
         }
-        log.info("Network connection between " + localBroker + " and " + remoteBroker
+        LOG.info("Network connection between " + localBroker + " and " + remoteBroker
                  + " has been established.");
     }
 
@@ -188,8 +188,8 @@
     }
 
     public void serviceRemoteException(Throwable error) {
-        log.info("Unexpected remote exception: " + error);
-        log.debug("Exception trace: ", error);
+        LOG.info("Unexpected remote exception: " + error);
+        LOG.debug("Exception trace: ", error);
     }
 
     protected void serviceRemoteCommand(Command command) {
@@ -200,7 +200,7 @@
                     remoteBrokerId = remoteBrokerInfo.getBrokerId();
                     if (localBrokerId != null) {
                         if (localBrokerId.equals(remoteBrokerId)) {
-                            log.info("Disconnecting loop back connection.");
+                            LOG.info("Disconnecting loop back connection.");
                             ServiceSupport.dispose(this);
                         } else {
                             triggerStartBridge();
@@ -208,7 +208,7 @@
                     }
                 }
             } else {
-                log.warn("Unexpected remote command: " + command);
+                LOG.warn("Unexpected remote command: " + command);
             }
         } catch (IOException e) {
             serviceLocalException(e);
@@ -216,8 +216,8 @@
     }
 
     public void serviceLocalException(Throwable error) {
-        log.info("Unexpected local exception: " + error);
-        log.debug("Exception trace: ", error);
+        LOG.info("Unexpected local exception: " + error);
+        LOG.debug("Exception trace: ", error);
         fireBridgeFailed();
     }
 
@@ -303,7 +303,7 @@
                     localBrokerId = localBrokerInfo.getBrokerId();
                     if (remoteBrokerId != null) {
                         if (remoteBrokerId.equals(localBrokerId)) {
-                            log.info("Disconnecting loop back connection.");
+                            LOG.info("Disconnecting loop back connection.");
                             ServiceSupport.dispose(this);
                         } else {
                             triggerStartBridge();
@@ -311,7 +311,7 @@
                     }
                 }
             } else {
-                log.debug("Unexpected local command: " + command);
+                LOG.debug("Unexpected local command: " + command);
             }
         } catch (IOException e) {
             serviceLocalException(e);

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/network/NetworkBridge.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/network/NetworkBridge.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/network/NetworkBridge.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/network/NetworkBridge.java Thu Aug  9 09:37:49 2007
@@ -30,30 +30,30 @@
      * Service an exception
      * @param error
      */
-    public void serviceRemoteException(Throwable error);
+    void serviceRemoteException(Throwable error);
     
     /**
      * servicee an exception
      * @param error
      */
-    public void serviceLocalException(Throwable error);
+    void serviceLocalException(Throwable error);
     
     /**
      * Set the NetworkBridgeFailedListener
      * @param listener
      */
-    public void setNetworkBridgeListener(NetworkBridgeListener listener);
+    void setNetworkBridgeListener(NetworkBridgeListener listener);
     
     
-    public String getRemoteAddress();
+    String getRemoteAddress();
 
-    public String getRemoteBrokerName();
+    String getRemoteBrokerName();
 
-    public String getLocalAddress();
+    String getLocalAddress();
 
-    public String getLocalBrokerName();
+    String getLocalBrokerName();
 
-    public long getEnqueueCounter();
+    long getEnqueueCounter();
 
-    public long getDequeueCounter();
+    long getDequeueCounter();
 }

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/network/NetworkBridgeConfiguration.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/network/NetworkBridgeConfiguration.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/network/NetworkBridgeConfiguration.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/network/NetworkBridgeConfiguration.java Thu Aug  9 09:37:49 2007
@@ -1,17 +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.
+ * 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.network;
 
 /**

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/network/NetworkBridgeFactory.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/network/NetworkBridgeFactory.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/network/NetworkBridgeFactory.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/network/NetworkBridgeFactory.java Thu Aug  9 09:37:49 2007
@@ -1,17 +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.
+ * 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.network;
 
 import org.apache.activemq.transport.Transport;

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/network/NetworkBridgeListener.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/network/NetworkBridgeListener.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/network/NetworkBridgeListener.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/network/NetworkBridgeListener.java Thu Aug  9 09:37:49 2007
@@ -26,16 +26,16 @@
     /**
      * called when the transport fails
      */
-    public void bridgeFailed();
+    void bridgeFailed();
 
     /**
      * called after the bridge is started.
      */
-    public void onStart(NetworkBridge bridge);
+    void onStart(NetworkBridge bridge);
 
     /**
      * called before the bridge is stopped.
      */
-    public void onStop(NetworkBridge bridge);
+    void onStop(NetworkBridge bridge);
 
 }

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/network/NetworkConnector.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/network/NetworkConnector.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/network/NetworkConnector.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/network/NetworkConnector.java Thu Aug  9 09:37:49 2007
@@ -1,17 +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.
+ * 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.network;
 
 import java.net.URI;
@@ -43,7 +45,7 @@
  */
 public abstract class NetworkConnector extends NetworkBridgeConfiguration implements Service {
 
-    protected static final Log log = LogFactory.getLog(NetworkConnector.class);
+    private static final Log LOG = LogFactory.getLog(NetworkConnector.class);
     protected URI localURI;
     private Set durableDestinations;
     private List excludedDestinations = new CopyOnWriteArrayList();
@@ -196,11 +198,11 @@
         if (localURI == null) {
             throw new IllegalStateException("You must configure the 'localURI' property");
         }
-        log.info("Network Connector " + getName() + " Started");
+        LOG.info("Network Connector " + getName() + " Started");
     }
 
     protected void handleStop(ServiceStopper stopper) throws Exception {
-        log.info("Network Connector " + getName() + " Stopped");
+        LOG.info("Network Connector " + getName() + " Stopped");
     }
 
     public ObjectName getObjectName() {
@@ -230,7 +232,7 @@
                 ObjectName objectName = createNetworkBridgeObjectName(bridge);
                 mbeanServer.registerMBean(view, objectName);
             } catch (Throwable e) {
-                log.debug("Network bridge could not be registered in JMX: " + e.getMessage(), e);
+                LOG.debug("Network bridge could not be registered in JMX: " + e.getMessage(), e);
             }
         }
     }
@@ -245,7 +247,7 @@
                 ObjectName objectName = createNetworkBridgeObjectName(bridge);
                 mbeanServer.unregisterMBean(objectName);
             } catch (Throwable e) {
-                log.debug("Network bridge could not be unregistered in JMX: " + e.getMessage(), e);
+                LOG.debug("Network bridge could not be unregistered in JMX: " + e.getMessage(), e);
             }
         }
     }

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/network/jms/DestinationBridge.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/network/jms/DestinationBridge.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/network/jms/DestinationBridge.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/network/jms/DestinationBridge.java Thu Aug  9 09:37:49 2007
@@ -37,7 +37,7 @@
  * @version $Revision: 1.1.1.1 $
  */
 public abstract class DestinationBridge implements Service, MessageListener {
-    private static final Log log = LogFactory.getLog(DestinationBridge.class);
+    private static final Log LOG = LogFactory.getLog(DestinationBridge.class);
     protected MessageConsumer consumer;
     protected AtomicBoolean started = new AtomicBoolean(false);
     protected JmsMesageConvertor jmsMessageConvertor;
@@ -130,12 +130,12 @@
                 sendMessage(converted);
                 message.acknowledge();
             } catch (Exception e) {
-                log.error("failed to forward message on attempt: " + (++attempt) + " reason: " + e + " message: " + message, e);
+                LOG.error("failed to forward message on attempt: " + (++attempt) + " reason: " + e + " message: " + message, e);
                 if (maximumRetries > 0 && attempt >= maximumRetries) {
                     try {
                         stop();
                     } catch (Exception e1) {
-                        log.warn("Failed to stop cleanly", e1);
+                        LOG.warn("Failed to stop cleanly", e1);
                     }
                 }
             }
@@ -170,7 +170,7 @@
         try {
             getConnectionForProducer().close();
         } catch (Exception e) {
-            log.debug("Ignoring failure to close producer connection: " + e, e);
+            LOG.debug("Ignoring failure to close producer connection: " + e, e);
         }
         jmsConnector.restartProducerConnection();
         createProducer();

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/network/jms/JmsConnector.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/network/jms/JmsConnector.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/network/jms/JmsConnector.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/network/jms/JmsConnector.java Thu Aug  9 09:37:49 2007
@@ -44,7 +44,7 @@
  */
 public abstract class JmsConnector implements Service {
 
-    private static final Log log = LogFactory.getLog(JmsConnector.class);
+    private static final Log LOG = LogFactory.getLog(JmsConnector.class);
     protected JndiTemplate jndiLocalTemplate;
     protected JndiTemplate jndiOutboundTemplate;
     protected JmsMesageConvertor inboundMessageConvertor;
@@ -63,7 +63,7 @@
 
     protected LRUCache replyToBridges = createLRUCache();
 
-    static private LRUCache createLRUCache() {
+    private static LRUCache createLRUCache() {
         return new LRUCache() {
             private static final long serialVersionUID = -7446792754185879286L;
 
@@ -75,9 +75,9 @@
                     DestinationBridge bridge = (DestinationBridge)lru.getValue();
                     try {
                         bridge.stop();
-                        log.info("Expired bridge: " + bridge);
+                        LOG.info("Expired bridge: " + bridge);
                     } catch (Exception e) {
-                        log.warn("stopping expired bridge" + bridge + " caused an exception", e);
+                        LOG.warn("stopping expired bridge" + bridge + " caused an exception", e);
                     }
                 }
                 return false;
@@ -118,7 +118,7 @@
                 DestinationBridge bridge = (DestinationBridge)outboundBridges.get(i);
                 bridge.start();
             }
-            log.info("JMS Connector " + getName() + " Started");
+            LOG.info("JMS Connector " + getName() + " Started");
         }
     }
 
@@ -132,7 +132,7 @@
                 DestinationBridge bridge = (DestinationBridge)outboundBridges.get(i);
                 bridge.stop();
             }
-            log.info("JMS Connector " + getName() + " Stopped");
+            LOG.info("JMS Connector " + getName() + " Stopped");
         }
     }
 
@@ -300,7 +300,7 @@
 
     static int nextId;
 
-    static private synchronized int getNextId() {
+    private static synchronized int getNextId() {
         return nextId++;
     }
 

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/network/jms/JmsMesageConvertor.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/network/jms/JmsMesageConvertor.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/network/jms/JmsMesageConvertor.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/network/jms/JmsMesageConvertor.java Thu Aug  9 09:37:49 2007
@@ -34,10 +34,10 @@
      * @return the converted message
      * @throws JMSException
      */
-    public Message convert(Message message) throws JMSException;
+    Message convert(Message message) throws JMSException;
     
-    public Message convert(Message message, Destination replyTo) throws JMSException;
+    Message convert(Message message, Destination replyTo) throws JMSException;
     
-    public void setConnection(Connection connection);
+    void setConnection(Connection connection);
    
 }

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/network/jms/JmsQueueConnector.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/network/jms/JmsQueueConnector.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/network/jms/JmsQueueConnector.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/network/jms/JmsQueueConnector.java Thu Aug  9 09:37:49 2007
@@ -37,7 +37,7 @@
  * @version $Revision: 1.1.1.1 $
  */
 public class JmsQueueConnector extends JmsConnector {
-    private static final Log log = LogFactory.getLog(JmsQueueConnector.class);
+    private static final Log LOG = LogFactory.getLog(JmsQueueConnector.class);
     private String outboundQueueConnectionFactoryName;
     private String localConnectionFactoryName;
     private QueueConnectionFactory outboundQueueConnectionFactory;
@@ -58,7 +58,7 @@
                 initializeInboundQueueBridges();
                 initializeOutboundQueueBridges();
             } catch (Exception e) {
-                log.error("Failed to initialize the JMSConnector", e);
+                LOG.error("Failed to initialize the JMSConnector", e);
             }
         }
         return result;
@@ -336,9 +336,9 @@
                     }
                     bridge.setJmsConnector(this);
                     bridge.start();
-                    log.info("Created replyTo bridge for " + replyToProducerQueue);
+                    LOG.info("Created replyTo bridge for " + replyToProducerQueue);
                 } catch (Exception e) {
-                    log.error("Failed to create replyTo bridge for queue: " + replyToProducerQueue, e);
+                    LOG.error("Failed to create replyTo bridge for queue: " + replyToProducerQueue, e);
                     return null;
                 }
                 replyToBridges.put(replyToProducerQueue, bridge);
@@ -367,9 +367,9 @@
                     }
                     bridge.setJmsConnector(this);
                     bridge.start();
-                    log.info("Created replyTo bridge for " + replyToProducerQueue);
+                    LOG.info("Created replyTo bridge for " + replyToProducerQueue);
                 } catch (Exception e) {
-                    log.error("Failed to create replyTo bridge for queue: " + replyToProducerQueue, e);
+                    LOG.error("Failed to create replyTo bridge for queue: " + replyToProducerQueue, e);
                     return null;
                 }
                 replyToBridges.put(replyToProducerQueue, bridge);
@@ -392,7 +392,7 @@
                 result = (Queue)jndiOutboundTemplate.lookup(queueName, Queue.class);
             } catch (NamingException e1) {
                 String errStr = "Failed to look-up Queue for name: " + queueName;
-                log.error(errStr, e);
+                LOG.error(errStr, e);
                 JMSException jmsEx = new JMSException(errStr);
                 jmsEx.setLinkedException(e1);
                 throw jmsEx;

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/network/jms/JmsTopicConnector.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/network/jms/JmsTopicConnector.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/network/jms/JmsTopicConnector.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/network/jms/JmsTopicConnector.java Thu Aug  9 09:37:49 2007
@@ -37,7 +37,7 @@
  * @version $Revision: 1.1.1.1 $
  */
 public class JmsTopicConnector extends JmsConnector {
-    private static final Log log = LogFactory.getLog(JmsTopicConnector.class);
+    private static final Log LOG = LogFactory.getLog(JmsTopicConnector.class);
     private String outboundTopicConnectionFactoryName;
     private String localConnectionFactoryName;
     private TopicConnectionFactory outboundTopicConnectionFactory;
@@ -58,7 +58,7 @@
                 initializeInboundTopicBridges();
                 initializeOutboundTopicBridges();
             } catch (Exception e) {
-                log.error("Failed to initialize the JMSConnector", e);
+                LOG.error("Failed to initialize the JMSConnector", e);
             }
         }
         return result;
@@ -336,9 +336,9 @@
                     }
                     bridge.setJmsConnector(this);
                     bridge.start();
-                    log.info("Created replyTo bridge for " + replyToProducerTopic);
+                    LOG.info("Created replyTo bridge for " + replyToProducerTopic);
                 } catch (Exception e) {
-                    log.error("Failed to create replyTo bridge for topic: " + replyToProducerTopic, e);
+                    LOG.error("Failed to create replyTo bridge for topic: " + replyToProducerTopic, e);
                     return null;
                 }
                 replyToBridges.put(replyToProducerTopic, bridge);
@@ -367,9 +367,9 @@
                     }
                     bridge.setJmsConnector(this);
                     bridge.start();
-                    log.info("Created replyTo bridge for " + replyToProducerTopic);
+                    LOG.info("Created replyTo bridge for " + replyToProducerTopic);
                 } catch (Exception e) {
-                    log.error("Failed to create replyTo bridge for topic: " + replyToProducerTopic, e);
+                    LOG.error("Failed to create replyTo bridge for topic: " + replyToProducerTopic, e);
                     return null;
                 }
                 replyToBridges.put(replyToProducerTopic, bridge);
@@ -392,7 +392,7 @@
                 result = (Topic)jndiOutboundTemplate.lookup(topicName, Topic.class);
             } catch (NamingException e1) {
                 String errStr = "Failed to look-up Topic for name: " + topicName;
-                log.error(errStr, e);
+                LOG.error(errStr, e);
                 JMSException jmsEx = new JMSException(errStr);
                 jmsEx.setLinkedException(e1);
                 throw jmsEx;

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/openwire/BooleanStream.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/openwire/BooleanStream.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/openwire/BooleanStream.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/openwire/BooleanStream.java Thu Aug  9 09:37:49 2007
@@ -21,7 +21,7 @@
 import java.io.IOException;
 import java.nio.ByteBuffer;
 
-final public class BooleanStream {
+public final class BooleanStream {
 
     byte data[] = new byte[48];
     short arrayLimit;

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/openwire/OpenWireFormat.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/openwire/OpenWireFormat.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/openwire/OpenWireFormat.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/openwire/OpenWireFormat.java Thu Aug  9 09:37:49 2007
@@ -38,7 +38,7 @@
  * 
  * @version $Revision$
  */
-final public class OpenWireFormat implements WireFormat {
+public final class OpenWireFormat implements WireFormat {
 
     public static final int DEFAULT_VERSION = CommandTypes.PROTOCOL_VERSION;
 

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/openwire/v1/BaseDataStreamMarshaller.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/openwire/v1/BaseDataStreamMarshaller.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/openwire/v1/BaseDataStreamMarshaller.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/openwire/v1/BaseDataStreamMarshaller.java Thu Aug  9 09:37:49 2007
@@ -28,9 +28,9 @@
 import org.apache.activemq.util.ByteSequence;
 import org.apache.activemq.util.ClassLoading;
 
-abstract public class BaseDataStreamMarshaller implements DataStreamMarshaller {
+public abstract class BaseDataStreamMarshaller implements DataStreamMarshaller {
 
-    static final public Constructor STACK_TRACE_ELEMENT_CONSTRUCTOR;
+    public static final Constructor STACK_TRACE_ELEMENT_CONSTRUCTOR;
 
     static {
         Constructor constructor = null;
@@ -42,9 +42,9 @@
         STACK_TRACE_ELEMENT_CONSTRUCTOR = constructor;
     }
 
-    abstract public byte getDataStructureType();
+    public abstract byte getDataStructureType();
 
-    abstract public DataStructure createObject();
+    public abstract DataStructure createObject();
 
     public int tightMarshal1(OpenWireFormat wireFormat, Object o, BooleanStream bs) throws IOException {
         return 0;

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/openwire/v1/MarshallerFactory.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/openwire/v1/MarshallerFactory.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/openwire/v1/MarshallerFactory.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/openwire/v1/MarshallerFactory.java Thu Aug  9 09:37:49 2007
@@ -33,7 +33,7 @@
     /**
      * Creates a Map of command type -> Marshallers
      */
-    static final private DataStreamMarshaller marshaller[] = new DataStreamMarshaller[256];
+    private static final DataStreamMarshaller MARSHALLER[] = new DataStreamMarshaller[256];
     static {
 
         add(new LocalTransactionIdMarshaller());
@@ -92,11 +92,11 @@
 
     }
 
-    static private void add(DataStreamMarshaller dsm) {
-        marshaller[dsm.getDataStructureType()] = dsm;
+    private static void add(DataStreamMarshaller dsm) {
+        MARSHALLER[dsm.getDataStructureType()] = dsm;
     }
 
-    static public DataStreamMarshaller[] createMarshallerMap(OpenWireFormat wireFormat) {
-        return marshaller;
+    public static DataStreamMarshaller[] createMarshallerMap(OpenWireFormat wireFormat) {
+        return MARSHALLER;
     }
 }

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/openwire/v2/BaseDataStreamMarshaller.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/openwire/v2/BaseDataStreamMarshaller.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/openwire/v2/BaseDataStreamMarshaller.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/openwire/v2/BaseDataStreamMarshaller.java Thu Aug  9 09:37:49 2007
@@ -28,9 +28,9 @@
 import org.apache.activemq.util.ByteSequence;
 import org.apache.activemq.util.ClassLoading;
 
-abstract public class BaseDataStreamMarshaller implements DataStreamMarshaller {
+public abstract class BaseDataStreamMarshaller implements DataStreamMarshaller {
 
-    static final public Constructor STACK_TRACE_ELEMENT_CONSTRUCTOR;
+    public static final Constructor STACK_TRACE_ELEMENT_CONSTRUCTOR;
 
     static {
         Constructor constructor = null;
@@ -42,9 +42,9 @@
         STACK_TRACE_ELEMENT_CONSTRUCTOR = constructor;
     }
 
-    abstract public byte getDataStructureType();
+    public abstract byte getDataStructureType();
 
-    abstract public DataStructure createObject();
+    public abstract DataStructure createObject();
 
     public int tightMarshal1(OpenWireFormat wireFormat, Object o, BooleanStream bs) throws IOException {
         return 0;

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/openwire/v2/MarshallerFactory.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/openwire/v2/MarshallerFactory.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/openwire/v2/MarshallerFactory.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/openwire/v2/MarshallerFactory.java Thu Aug  9 09:37:49 2007
@@ -36,7 +36,7 @@
     /**
      * Creates a Map of command type -> Marshallers
      */
-    static final private DataStreamMarshaller marshaller[] = new DataStreamMarshaller[256];
+    private static final DataStreamMarshaller MARSHALLER[] = new DataStreamMarshaller[256];
     static {
 
         add(new ActiveMQBytesMessageMarshaller());
@@ -96,11 +96,11 @@
 
     }
 
-    static private void add(DataStreamMarshaller dsm) {
-        marshaller[dsm.getDataStructureType()] = dsm;
+    private static void add(DataStreamMarshaller dsm) {
+        MARSHALLER[dsm.getDataStructureType()] = dsm;
     }
     
-    static public DataStreamMarshaller[] createMarshallerMap(OpenWireFormat wireFormat) {
-        return marshaller;
+    public static DataStreamMarshaller[] createMarshallerMap(OpenWireFormat wireFormat) {
+        return MARSHALLER;
     }
 }

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/openwire/v3/BaseDataStreamMarshaller.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/openwire/v3/BaseDataStreamMarshaller.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/openwire/v3/BaseDataStreamMarshaller.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/openwire/v3/BaseDataStreamMarshaller.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.
@@ -28,9 +28,9 @@
 import org.apache.activemq.util.ByteSequence;
 import org.apache.activemq.util.ClassLoading;
 
-abstract public class BaseDataStreamMarshaller implements DataStreamMarshaller {
+public abstract class BaseDataStreamMarshaller implements DataStreamMarshaller {
 
-    static final public Constructor STACK_TRACE_ELEMENT_CONSTRUCTOR;
+    public static final Constructor STACK_TRACE_ELEMENT_CONSTRUCTOR;
 
     static {
         Constructor constructor = null;
@@ -41,9 +41,9 @@
         STACK_TRACE_ELEMENT_CONSTRUCTOR = constructor;
     }
 
-    abstract public byte getDataStructureType();
+    public abstract byte getDataStructureType();
 
-    abstract public DataStructure createObject();
+    public abstract DataStructure createObject();
 
     public int tightMarshal1(OpenWireFormat wireFormat, Object o, BooleanStream bs) throws IOException {
         return 0;

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/openwire/v3/MarshallerFactory.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/openwire/v3/MarshallerFactory.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/openwire/v3/MarshallerFactory.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/openwire/v3/MarshallerFactory.java Thu Aug  9 09:37:49 2007
@@ -36,7 +36,7 @@
     /**
      * Creates a Map of command type -> Marshallers
      */
-    static final private DataStreamMarshaller marshaller[] = new DataStreamMarshaller[256];
+    private static final DataStreamMarshaller MARSHALLER[] = new DataStreamMarshaller[256];
     static {
 
         add(new ActiveMQBlobMessageMarshaller());
@@ -98,11 +98,11 @@
 
     }
 
-    static private void add(DataStreamMarshaller dsm) {
-        marshaller[dsm.getDataStructureType()] = dsm;
+    private static void add(DataStreamMarshaller dsm) {
+        MARSHALLER[dsm.getDataStructureType()] = dsm;
     }
     
-    static public DataStreamMarshaller[] createMarshallerMap(OpenWireFormat wireFormat) {
-        return marshaller;
+    public static DataStreamMarshaller[] createMarshallerMap(OpenWireFormat wireFormat) {
+        return MARSHALLER;
     }
 }

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/pool/ConnectionPool.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/pool/ConnectionPool.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/pool/ConnectionPool.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/pool/ConnectionPool.java Thu Aug  9 09:37:49 2007
@@ -90,7 +90,7 @@
         }
     }
 
-    synchronized public ActiveMQConnection getConnection() {
+    public synchronized ActiveMQConnection getConnection() {
         return connection;
     }
 
@@ -126,7 +126,7 @@
         }
     }
 
-    synchronized public void close() {
+    public synchronized void close() {
         if (connection != null) {
             try {
                 Iterator i = cache.values().iterator();
@@ -149,12 +149,12 @@
         }
     }
 
-    synchronized public void incrementReferenceCount() {
+    public synchronized void incrementReferenceCount() {
         referenceCount++;
         lastUsed = System.currentTimeMillis();
     }
 
-    synchronized public void decrementReferenceCount() {
+    public synchronized void decrementReferenceCount() {
         referenceCount--;
         lastUsed = System.currentTimeMillis();
         if (referenceCount == 0) {
@@ -165,7 +165,7 @@
     /**
      * @return true if this connection has expired.
      */
-    synchronized public boolean expiredCheck() {
+    public synchronized boolean expiredCheck() {
         if (connection == null) {
             return true;
         }

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/pool/PooledSession.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/pool/PooledSession.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/pool/PooledSession.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/pool/PooledSession.java Thu Aug  9 09:37:49 2007
@@ -55,7 +55,7 @@
  * @version $Revision: 1.1 $
  */
 public class PooledSession implements TopicSession, QueueSession {
-    private static final transient Log log = LogFactory.getLog(PooledSession.class);
+    private static final transient Log LOG = LogFactory.getLog(PooledSession.class);
 
     private ActiveMQSession session;
     private SessionPool sessionPool;
@@ -107,14 +107,14 @@
                 try {
                     getSession().rollback();
                 } catch (JMSException e) {
-                    log.warn("Caught exception trying rollback() when putting session back into the pool: " + e, e);
+                    LOG.warn("Caught exception trying rollback() when putting session back into the pool: " + e, e);
 
                     // lets close the session and not put the session back into
                     // the pool
                     try {
                         session.close();
                     } catch (JMSException e1) {
-                        log.trace("Ignoring exception as discarding session: " + e1, e1);
+                        LOG.trace("Ignoring exception as discarding session: " + e1, e1);
                     }
                     session = null;
                     return;

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/proxy/ProxyConnection.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/proxy/ProxyConnection.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/proxy/ProxyConnection.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/proxy/ProxyConnection.java Thu Aug  9 09:37:49 2007
@@ -30,7 +30,7 @@
 
 class ProxyConnection implements Service {
 
-    static final private Log log = LogFactory.getLog(ProxyConnection.class);
+    private static final Log LOG = LogFactory.getLog(ProxyConnection.class);
 
     private final Transport localTransport;
     private final Transport remoteTransport;
@@ -44,7 +44,7 @@
 
     public void onFailure(IOException e) {
         if (!shuttingDown.get()) {
-            log.debug("Transport error: " + e, e);
+            LOG.debug("Transport error: " + e, e);
             try {
                 stop();
             } catch (Exception ignore) {

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/proxy/ProxyConnector.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/proxy/ProxyConnector.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/proxy/ProxyConnector.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/proxy/ProxyConnector.java Thu Aug  9 09:37:49 2007
@@ -40,7 +40,7 @@
  */
 public class ProxyConnector implements Service {
 
-    private static final Log log = LogFactory.getLog(ProxyConnector.class);
+    private static final Log LOG = LogFactory.getLog(ProxyConnector.class);
     private TransportServer server;
     private URI bind;
     private URI remote;
@@ -64,11 +64,11 @@
             }
 
             public void onAcceptError(Exception error) {
-                log.error("Could not accept connection: " + error, error);
+                LOG.error("Could not accept connection: " + error, error);
             }
         });
         getServer().start();
-        log.info("Proxy Connector " + getName() + " Started");
+        LOG.info("Proxy Connector " + getName() + " Started");
 
     }
 
@@ -78,11 +78,11 @@
             ss.stop(this.server);
         }
         for (Iterator iter = connections.iterator(); iter.hasNext();) {
-            log.info("Connector stopped: Stopping proxy.");
+            LOG.info("Connector stopped: Stopping proxy.");
             ss.stop((Service)iter.next());
         }
         ss.throwFirstException();
-        log.info("Proxy Connector " + getName() + " Stopped");
+        LOG.info("Proxy Connector " + getName() + " Stopped");
     }
 
     // Properties
@@ -140,7 +140,7 @@
         // Add a transport filter so that can track the transport life cycle
         transport = new TransportFilter(transport) {
             public void stop() throws Exception {
-                log.info("Stopping proxy.");
+                LOG.info("Stopping proxy.");
                 super.stop();
                 connections.remove(this);
             }

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/security/AuthorizationMap.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/security/AuthorizationMap.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/security/AuthorizationMap.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/security/AuthorizationMap.java Thu Aug  9 09:37:49 2007
@@ -21,7 +21,6 @@
 import org.apache.activemq.command.ActiveMQDestination;
 
 /**
- *
  * @version $Revision$
  */
 public interface AuthorizationMap {
@@ -30,24 +29,26 @@
      * Returns the set of all ACLs capable of administering temp destination
      */
     Set getTempDestinationAdminACLs();
-	
+
     /**
      * Returns the set of all ACLs capable of reading from temp destination
      */
     Set getTempDestinationReadACLs();
-    
+
     /**
      * Returns the set of all ACLs capable of writing to temp destination
      */
-    Set getTempDestinationWriteACLs();    
-    
+    Set getTempDestinationWriteACLs();
+
     /**
-     * Returns the set of all ACLs capable of administering the given destination
+     * Returns the set of all ACLs capable of administering the given
+     * destination
      */
     Set getAdminACLs(ActiveMQDestination destination);
 
     /**
-     * Returns the set of all ACLs capable of reading (consuming from) the given destination
+     * Returns the set of all ACLs capable of reading (consuming from) the given
+     * destination
      */
     Set getReadACLs(ActiveMQDestination destination);
 

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/security/DefaultAuthorizationMap.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/security/DefaultAuthorizationMap.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/security/DefaultAuthorizationMap.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/security/DefaultAuthorizationMap.java Thu Aug  9 09:37:49 2007
@@ -31,7 +31,6 @@
  * for each operation.
  * 
  * @org.apache.xbean.XBean element="authorizationMap"
- * 
  * @version $Revision$
  */
 public class DefaultAuthorizationMap extends DestinationMap implements AuthorizationMap {
@@ -48,8 +47,7 @@
 
     }
 
-    public void setTempDestinationAuthorizationEntry(
-                                                     TempDestinationAuthorizationEntry tempDestinationAuthorizationEntry) {
+    public void setTempDestinationAuthorizationEntry(TempDestinationAuthorizationEntry tempDestinationAuthorizationEntry) {
         this.tempDestinationAuthorizationEntry = tempDestinationAuthorizationEntry;
     }
 
@@ -58,24 +56,27 @@
     }
 
     public Set getTempDestinationAdminACLs() {
-        if (tempDestinationAuthorizationEntry != null)
+        if (tempDestinationAuthorizationEntry != null) {
             return tempDestinationAuthorizationEntry.getAdminACLs();
-        else
+        } else {
             return null;
+        }
     }
 
     public Set getTempDestinationReadACLs() {
-        if (tempDestinationAuthorizationEntry != null)
+        if (tempDestinationAuthorizationEntry != null) {
             return tempDestinationAuthorizationEntry.getReadACLs();
-        else
+        } else {
             return null;
+        }
     }
 
     public Set getTempDestinationWriteACLs() {
-        if (tempDestinationAuthorizationEntry != null)
+        if (tempDestinationAuthorizationEntry != null) {
             return tempDestinationAuthorizationEntry.getWriteACLs();
-        else
+        } else {
             return null;
+        }
     }
 
     public Set getAdminACLs(ActiveMQDestination destination) {

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/security/SecurityAdminMBean.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/security/SecurityAdminMBean.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/security/SecurityAdminMBean.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/security/SecurityAdminMBean.java Thu Aug  9 09:37:49 2007
@@ -24,20 +24,20 @@
  */
 public interface SecurityAdminMBean {
     
-    public static final String OPERATION_READ = "read";
-    public static final String OPERATION_WRITE = "write";
-    public static final String OPERATION_ADMIN = "admin";
+    String OPERATION_READ = "read";
+    String OPERATION_WRITE = "write";
+    String OPERATION_ADMIN = "admin";
     
-    public void addRole(String role);
-    public void removeRole(String role);
+    void addRole(String role);
+    void removeRole(String role);
 
-    public void addUserRole(String user, String role);
-    public void removeUserRole(String user, String role);
+    void addUserRole(String user, String role);
+    void removeUserRole(String user, String role);
 
-    public void addTopicRole(String topic, String operation, String role);
-    public void removeTopicRole(String topic, String operation, String role);
+    void addTopicRole(String topic, String operation, String role);
+    void removeTopicRole(String topic, String operation, String role);
     
-    public void addQueueRole(String queue, String operation, String role);
-    public void removeQueueRole(String queue, String operation, String role);
+    void addQueueRole(String queue, String operation, String role);
+    void removeQueueRole(String queue, String operation, String role);
     
 }

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/security/SecurityContext.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/security/SecurityContext.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/security/SecurityContext.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/security/SecurityContext.java Thu Aug  9 09:37:49 2007
@@ -26,7 +26,7 @@
  * 
  * @version $Revision$
  */
-abstract public class SecurityContext {
+public abstract class SecurityContext {
 
     public static final SecurityContext BROKER_SECURITY_CONTEXT = new SecurityContext("ActiveMQBroker") {
         @Override
@@ -54,7 +54,7 @@
         return set.size() > 0;
     }
 
-    abstract public Set getPrincipals();
+    public abstract Set getPrincipals();
 
     public String getUserName() {
         return userName;

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/security/SimpleAuthorizationMap.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/security/SimpleAuthorizationMap.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/security/SimpleAuthorizationMap.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/security/SimpleAuthorizationMap.java Thu Aug  9 09:37:49 2007
@@ -64,24 +64,27 @@
     }
 
     public Set getTempDestinationAdminACLs() {
-        if (tempDestinationAuthorizationEntry != null)
+        if (tempDestinationAuthorizationEntry != null) {
             return tempDestinationAuthorizationEntry.getAdminACLs();
-        else
+        } else {
             return null;
+        }
     }
 
     public Set getTempDestinationReadACLs() {
-        if (tempDestinationAuthorizationEntry != null)
+        if (tempDestinationAuthorizationEntry != null) {
             return tempDestinationAuthorizationEntry.getReadACLs();
-        else
+        } else {
             return null;
+        }
     }
 
     public Set getTempDestinationWriteACLs() {
-        if (tempDestinationAuthorizationEntry != null)
+        if (tempDestinationAuthorizationEntry != null) {
             return tempDestinationAuthorizationEntry.getWriteACLs();
-        else
+        } else {
             return null;
+        }
     }
 
     public Set getAdminACLs(ActiveMQDestination destination) {

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/spring/ActiveMQConnectionFactory.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/spring/ActiveMQConnectionFactory.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/spring/ActiveMQConnectionFactory.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/spring/ActiveMQConnectionFactory.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.