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 [2/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/ActiveMQSession.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/ActiveMQSession.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/ActiveMQSession.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/ActiveMQSession.java Thu Aug  9 09:37:49 2007
@@ -178,22 +178,14 @@
 public class ActiveMQSession implements Session, QueueSession, TopicSession, StatsCapable, ActiveMQDispatcher {
 
     public static interface DeliveryListener {
-        public void beforeDelivery(ActiveMQSession session, Message msg);
+        void beforeDelivery(ActiveMQSession session, Message msg);
 
-        public void afterDelivery(ActiveMQSession session, Message msg);
+        void afterDelivery(ActiveMQSession session, Message msg);
     }
 
-    private static final Log log = LogFactory.getLog(ActiveMQSession.class);
+    private static final Log LOG = LogFactory.getLog(ActiveMQSession.class);
 
     protected int acknowledgementMode;
-
-    private MessageListener messageListener;
-    private JMSSessionStatsImpl stats;
-    private TransactionContext transactionContext;
-    private DeliveryListener deliveryListener;
-    private MessageTransformer transformer;
-    private BlobTransferPolicy blobTransferPolicy;
-
     protected final ActiveMQConnection connection;
     protected final SessionInfo info;
     protected final LongSequenceGenerator consumerIdGenerator = new LongSequenceGenerator();
@@ -211,6 +203,13 @@
     protected final boolean debug;
     protected Object sendMutex = new Object();
 
+    private MessageListener messageListener;
+    private JMSSessionStatsImpl stats;
+    private TransactionContext transactionContext;
+    private DeliveryListener deliveryListener;
+    private MessageTransformer transformer;
+    private BlobTransferPolicy blobTransferPolicy;
+
     /**
      * Construct the Session
      * 
@@ -223,7 +222,7 @@
      * @throws JMSException on internal error
      */
     protected ActiveMQSession(ActiveMQConnection connection, SessionId sessionId, int acknowledgeMode, boolean asyncDispatch, boolean sessionAsyncDispatch) throws JMSException {
-        this.debug = log.isDebugEnabled();
+        this.debug = LOG.isDebugEnabled();
         this.connection = connection;
         this.acknowledgementMode = acknowledgeMode;
         this.asyncDispatch = asyncDispatch;
@@ -602,7 +601,7 @@
         }
     }
 
-    synchronized public void dispose() throws JMSException {
+    public synchronized void dispose() throws JMSException {
         if (!closed) {
 
             try {
@@ -765,7 +764,7 @@
                 messageListener.onMessage(message);
             } catch (Throwable e) {
                 // TODO: figure out proper way to handle error.
-                log.error("error dispatching message: ", e);
+                LOG.error("error dispatching message: ", e);
                 connection.onAsyncException(e);
             }
 
@@ -1577,7 +1576,7 @@
             msg.onSend();
             msg.setProducerId(msg.getMessageId().getProducerId());
             if (this.debug) {
-                log.debug("Sending message: " + msg);
+                LOG.debug("Sending message: " + msg);
             }
             if (!connection.isAlwaysSyncSend() && (!msg.isPersistent() || connection.isUseAsyncSend() || txid != null)) {
                 this.connection.asyncSendPacket(msg);
@@ -1823,9 +1822,9 @@
                 try {
                     c.close();
                 } catch (JMSException e) {
-                    log.warn("Exception closing consumer", e);
+                    LOG.warn("Exception closing consumer", e);
                 }
-                log.warn("Closed consumer on Command");
+                LOG.warn("Closed consumer on Command");
                 break;
             }
         }

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/ActiveMQSessionExecutor.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/ActiveMQSessionExecutor.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/ActiveMQSessionExecutor.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/ActiveMQSessionExecutor.java Thu Aug  9 09:37:49 2007
@@ -38,7 +38,7 @@
  * @see javax.jms.Session
  */
 public class ActiveMQSessionExecutor implements Task {
-    private static final transient Log log = LogFactory.getLog(ActiveMQSessionExecutor.class);
+    private static final Log LOG = LogFactory.getLog(ActiveMQSessionExecutor.class);
 
     private ActiveMQSession session;
     private MessageDispatchChannel messageQueue = new MessageDispatchChannel();
@@ -69,7 +69,7 @@
                 // lets only warn when a significant amount of time has passed
                 // just in case its normal operation
                 if (elapsedTime > aboutUnstartedConnectionTimeout) {
-                    log.warn("Received a message on a connection which is not yet started. Have you forgotten to call Connection.start()? Connection: " + connection
+                    LOG.warn("Received a message on a connection which is not yet started. Have you forgotten to call Connection.start()? Connection: " + connection
                              + " Received: " + message);
                     startedOrWarnedThatNotStarted = true;
                 }

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/ActiveMQTopicSession.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/ActiveMQTopicSession.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/ActiveMQTopicSession.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/ActiveMQTopicSession.java Thu Aug  9 09:37:49 2007
@@ -126,15 +126,15 @@
     /**
      * @param destination
      * @param messageSelector
-     * @param NoLocal
+     * @param noLocal
      * @return
      * @throws JMSException
      */
-    public MessageConsumer createConsumer(Destination destination, String messageSelector, boolean NoLocal) throws JMSException {
+    public MessageConsumer createConsumer(Destination destination, String messageSelector, boolean noLocal) throws JMSException {
         if (destination instanceof Queue) {
             throw new InvalidDestinationException("Queues are not supported by a TopicSession");
         }
-        return next.createConsumer(destination, messageSelector, NoLocal);
+        return next.createConsumer(destination, messageSelector, noLocal);
     }
 
     /**

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/AdvisoryConsumer.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/AdvisoryConsumer.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/AdvisoryConsumer.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/AdvisoryConsumer.java Thu Aug  9 09:37:49 2007
@@ -30,12 +30,13 @@
 import org.apache.commons.logging.LogFactory;
 
 public class AdvisoryConsumer implements ActiveMQDispatcher {
-    private static final transient Log log = LogFactory.getLog(AdvisoryConsumer.class);
+    private static final transient Log LOG = LogFactory.getLog(AdvisoryConsumer.class);
+
+    int deliveredCounter;
 
     private final ActiveMQConnection connection;
     private ConsumerInfo info;
     private boolean closed;
-    int deliveredCounter;
 
     public AdvisoryConsumer(ActiveMQConnection connection, ConsumerId consumerId) throws JMSException {
         this.connection = connection;
@@ -53,7 +54,7 @@
             try {
                 this.connection.asyncSendPacket(info.createRemoveCommand());
             } catch (JMSException e) {
-                log.info("Failed to send remove command: " + e, e);
+                LOG.info("Failed to send remove command: " + e, e);
             }
             this.connection.removeDispatcher(info.getConsumerId());
             closed = true;

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/BlobMessage.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/BlobMessage.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/BlobMessage.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/BlobMessage.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/main/java/org/apache/activemq/Closeable.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/Closeable.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/Closeable.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/Closeable.java Thu Aug  9 09:37:49 2007
@@ -36,5 +36,5 @@
      * @throws JMSException if the JMS provider fails to close the object due to
      *                 some internal error.
      */
-    public void close() throws JMSException;
+    void close() throws JMSException;
 }

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/ConnectionFailedException.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/ConnectionFailedException.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/ConnectionFailedException.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/ConnectionFailedException.java Thu Aug  9 09:37:49 2007
@@ -40,7 +40,7 @@
         super("The JMS connection has failed due to a Transport problem");
     }
 
-    static private String extractMessage(IOException cause) {
+    private static String extractMessage(IOException cause) {
         String m = cause.getMessage();
         if (m == null || m.length() == 0)
             m = cause.toString();

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/CustomDestination.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/CustomDestination.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/CustomDestination.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/CustomDestination.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/main/java/org/apache/activemq/LocalTransactionEventListener.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/LocalTransactionEventListener.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/LocalTransactionEventListener.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/LocalTransactionEventListener.java Thu Aug  9 09:37:49 2007
@@ -21,9 +21,9 @@
  * @version $Revision: 1.2 $
  */
 public interface LocalTransactionEventListener {
-    public void beginEvent();
+    void beginEvent();
 
-    public void commitEvent();
+    void commitEvent();
 
-    public void rollbackEvent();
+    void rollbackEvent();
 }

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/Message.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/Message.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/Message.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/Message.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,6 +28,6 @@
      * the MIME types of the different JMS messages, or in the case of {@link org.apache.activemq.BlobMessage}
      * it allows you to create a selector on the MIME type of the BLOB body
      */
-    public String getJMSXMimeType();
+    String getJMSXMimeType();
 
 }

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/MessageAvailableConsumer.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/MessageAvailableConsumer.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/MessageAvailableConsumer.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/MessageAvailableConsumer.java Thu Aug  9 09:37:49 2007
@@ -31,11 +31,11 @@
      * Sets the listener used to notify synchronous consumers that there is a message
      * available so that the {@link MessageConsumer#receiveNoWait()} can be called.
      */
-    public void setAvailableListener(MessageAvailableListener availableListener);
+    void setAvailableListener(MessageAvailableListener availableListener);
 
     /**
      * Gets the listener used to notify synchronous consumers that there is a message
      * available so that the {@link MessageConsumer#receiveNoWait()} can be called.
      */
-    public MessageAvailableListener getAvailableListener();
+    MessageAvailableListener getAvailableListener();
 }

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/MessageTransformer.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/MessageTransformer.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/MessageTransformer.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/MessageTransformer.java Thu Aug  9 09:37:49 2007
@@ -33,10 +33,10 @@
     /**
      * Transforms the given message inside the producer before it is sent to the JMS bus.
      */
-    public Message producerTransform(Session session, MessageProducer producer, Message message) throws JMSException;
+    Message producerTransform(Session session, MessageProducer producer, Message message) throws JMSException;
 
     /**
      * Transforms the given message inside the consumer before being dispatched to the client code
      */
-    public Message consumerTransform(Session session, MessageConsumer consumer, Message message)throws JMSException;
+    Message consumerTransform(Session session, MessageConsumer consumer, Message message)throws JMSException;
 }

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/Service.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/Service.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/Service.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/Service.java Thu Aug  9 09:37:49 2007
@@ -29,8 +29,8 @@
  */
 public interface Service {
 
-    public void start() throws Exception;
+    void start() throws Exception;
     
-    public void stop() throws Exception;
+    void stop() throws Exception;
     
 }

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/StreamConnection.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/StreamConnection.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/StreamConnection.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/StreamConnection.java Thu Aug  9 09:37:49 2007
@@ -36,21 +36,21 @@
  */
 public interface StreamConnection extends Connection {
 
-    public InputStream createInputStream(Destination dest) throws JMSException;
+    InputStream createInputStream(Destination dest) throws JMSException;
 
-    public InputStream createInputStream(Destination dest, String messageSelector) throws JMSException;
+    InputStream createInputStream(Destination dest, String messageSelector) throws JMSException;
 
-    public InputStream createInputStream(Destination dest, String messageSelector, boolean noLocal) throws JMSException;
+    InputStream createInputStream(Destination dest, String messageSelector, boolean noLocal) throws JMSException;
 
-    public InputStream createDurableInputStream(Topic dest, String name) throws JMSException;
+    InputStream createDurableInputStream(Topic dest, String name) throws JMSException;
 
-    public InputStream createDurableInputStream(Topic dest, String name, String messageSelector) throws JMSException;
+    InputStream createDurableInputStream(Topic dest, String name, String messageSelector) throws JMSException;
 
-    public InputStream createDurableInputStream(Topic dest, String name, String messageSelector, boolean noLocal) throws JMSException;
+    InputStream createDurableInputStream(Topic dest, String name, String messageSelector, boolean noLocal) throws JMSException;
 
-    public OutputStream createOutputStream(Destination dest) throws JMSException;
+    OutputStream createOutputStream(Destination dest) throws JMSException;
 
-    public OutputStream createOutputStream(Destination dest, Map streamProperties, int deliveryMode, int priority, long timeToLive) throws JMSException;
+    OutputStream createOutputStream(Destination dest, Map streamProperties, int deliveryMode, int priority, long timeToLive) throws JMSException;
 
     /**
      * Unsubscribes a durable subscription that has been created by a client.
@@ -71,5 +71,5 @@
      *                 specified.
      * @since 1.1
      */
-    public void unsubscribe(String name) throws JMSException;
+    void unsubscribe(String name) throws JMSException;
 }

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/ThreadPriorities.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/ThreadPriorities.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/ThreadPriorities.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/ThreadPriorities.java Thu Aug  9 09:37:49 2007
@@ -24,9 +24,9 @@
 */
 
 public interface ThreadPriorities {
-    public static final int INBOUND_BROKER_CONNECTION = 6;
-    public static final int OUT_BOUND_BROKER_DISPATCH = 6;
-    public static final int INBOUND_CLIENT_CONNECTION = 7;
-    public static final int INBOUND_CLIENT_SESSION = 7;
-    public static final int BROKER_MANAGEMENT = 9;
+    int INBOUND_BROKER_CONNECTION = 6;
+    int OUT_BOUND_BROKER_DISPATCH = 6;
+    int INBOUND_CLIENT_CONNECTION = 7;
+    int INBOUND_CLIENT_SESSION = 7;
+    int BROKER_MANAGEMENT = 9;
 }

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/TransactionContext.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/TransactionContext.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/TransactionContext.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/TransactionContext.java Thu Aug  9 09:37:49 2007
@@ -62,10 +62,10 @@
  */
 public class TransactionContext implements XAResource {
 
-    static final private Log log = LogFactory.getLog(TransactionContext.class);
+    private static final Log LOG = LogFactory.getLog(TransactionContext.class);
 
     // XATransactionId -> ArrayList of TransactionContext objects
-    private static final ConcurrentHashMap endedXATransactionContexts = new ConcurrentHashMap();
+    private static final ConcurrentHashMap ENDED_XA_TRANSACTION_CONTEXTS = new ConcurrentHashMap();
 
     private final ActiveMQConnection connection;
     private final LongSequenceGenerator localTransactionIdGenerator;
@@ -267,12 +267,12 @@
      */
     public void start(Xid xid, int flags) throws XAException {
 
-        if (log.isDebugEnabled())
-            log.debug("Start: " + xid);
-
-        if (isInLocalTransaction())
+        if (LOG.isDebugEnabled()) {
+            LOG.debug("Start: " + xid);
+        }
+        if (isInLocalTransaction()) {
             throw new XAException(XAException.XAER_PROTO);
-
+        }
         // Are we already associated?
         if (associatedXid != null) {
             throw new XAException(XAException.XAER_PROTO);
@@ -299,8 +299,8 @@
 
     public void end(Xid xid, int flags) throws XAException {
 
-        if (log.isDebugEnabled())
-            log.debug("End: " + xid);
+        if (LOG.isDebugEnabled())
+            LOG.debug("End: " + xid);
 
         if (isInLocalTransaction())
             throw new XAException(XAException.XAER_PROTO);
@@ -344,8 +344,8 @@
     }
 
     public int prepare(Xid xid) throws XAException {
-        if (log.isDebugEnabled())
-            log.debug("Prepare: " + xid);
+        if (LOG.isDebugEnabled())
+            LOG.debug("Prepare: " + xid);
 
         // We allow interleaving multiple transactions, so
         // we don't limit prepare to the associated xid.
@@ -373,8 +373,8 @@
 
     public void rollback(Xid xid) throws XAException {
 
-        if (log.isDebugEnabled())
-            log.debug("Rollback: " + xid);
+        if (LOG.isDebugEnabled())
+            LOG.debug("Rollback: " + xid);
 
         // We allow interleaving multiple transactions, so
         // we don't limit rollback to the associated xid.
@@ -398,7 +398,7 @@
             TransactionInfo info = new TransactionInfo(getConnectionId(), x, TransactionInfo.ROLLBACK);
             this.connection.syncSendPacket(info);
 
-            ArrayList l = (ArrayList)endedXATransactionContexts.remove(x);
+            ArrayList l = (ArrayList)ENDED_XA_TRANSACTION_CONTEXTS.remove(x);
             if (l != null && !l.isEmpty()) {
                 for (Iterator iter = l.iterator(); iter.hasNext();) {
                     TransactionContext ctx = (TransactionContext)iter.next();
@@ -414,8 +414,8 @@
     // XAResource interface
     public void commit(Xid xid, boolean onePhase) throws XAException {
 
-        if (log.isDebugEnabled())
-            log.debug("Commit: " + xid);
+        if (LOG.isDebugEnabled())
+            LOG.debug("Commit: " + xid);
 
         // We allow interleaving multiple transactions, so
         // we don't limit commit to the associated xid.
@@ -437,7 +437,7 @@
 
             this.connection.syncSendPacket(info);
 
-            ArrayList l = (ArrayList)endedXATransactionContexts.remove(x);
+            ArrayList l = (ArrayList)ENDED_XA_TRANSACTION_CONTEXTS.remove(x);
             if (l != null && !l.isEmpty()) {
                 for (Iterator iter = l.iterator(); iter.hasNext();) {
                     TransactionContext ctx = (TransactionContext)iter.next();
@@ -452,8 +452,8 @@
     }
 
     public void forget(Xid xid) throws XAException {
-        if (log.isDebugEnabled())
-            log.debug("Forget: " + xid);
+        if (LOG.isDebugEnabled())
+            LOG.debug("Forget: " + xid);
 
         // We allow interleaving multiple transactions, so
         // we don't limit forget to the associated xid.
@@ -494,8 +494,8 @@
     }
 
     public Xid[] recover(int flag) throws XAException {
-        if (log.isDebugEnabled())
-            log.debug("Recover: " + flag);
+        if (LOG.isDebugEnabled())
+            LOG.debug("Recover: " + flag);
 
         TransactionInfo info = new TransactionInfo(getConnectionId(), null, TransactionInfo.RECOVER);
         try {
@@ -551,8 +551,8 @@
             TransactionInfo info = new TransactionInfo(connectionId, transactionId, TransactionInfo.BEGIN);
             try {
                 this.connection.asyncSendPacket(info);
-                if (log.isDebugEnabled())
-                    log.debug("Started XA transaction: " + transactionId);
+                if (LOG.isDebugEnabled())
+                    LOG.debug("Started XA transaction: " + transactionId);
             } catch (JMSException e) {
                 throw toXAException(e);
             }
@@ -563,18 +563,18 @@
                 TransactionInfo info = new TransactionInfo(connectionId, transactionId, TransactionInfo.END);
                 try {
                     this.connection.syncSendPacket(info);
-                    if (log.isDebugEnabled())
-                        log.debug("Ended XA transaction: " + transactionId);
+                    if (LOG.isDebugEnabled())
+                        LOG.debug("Ended XA transaction: " + transactionId);
                 } catch (JMSException e) {
                     throw toXAException(e);
                 }
 
                 // Add our self to the list of contexts that are interested in
                 // post commit/rollback events.
-                ArrayList l = (ArrayList)endedXATransactionContexts.get(transactionId);
+                ArrayList l = (ArrayList)ENDED_XA_TRANSACTION_CONTEXTS.get(transactionId);
                 if (l == null) {
                     l = new ArrayList(3);
-                    endedXATransactionContexts.put(transactionId, l);
+                    ENDED_XA_TRANSACTION_CONTEXTS.put(transactionId, l);
                     l.add(this);
                 } else if (!l.contains(this)) {
                     l.add(this);

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/advisory/AdvisoryBroker.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/advisory/AdvisoryBroker.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/advisory/AdvisoryBroker.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/advisory/AdvisoryBroker.java Thu Aug  9 09:37:49 2007
@@ -50,20 +50,20 @@
  */
 public class AdvisoryBroker extends BrokerFilter {
 
-    private static final Log log = LogFactory.getLog(AdvisoryBroker.class);
+    private static final Log LOG = LogFactory.getLog(AdvisoryBroker.class);
+    private static final IdGenerator ID_GENERATOR = new IdGenerator();
 
     protected final ConcurrentHashMap connections = new ConcurrentHashMap();
     protected final ConcurrentHashMap consumers = new ConcurrentHashMap();
     protected final ConcurrentHashMap producers = new ConcurrentHashMap();
     protected final ConcurrentHashMap destinations = new ConcurrentHashMap();
-
-    static final private IdGenerator idGenerator = new IdGenerator();
     protected final ProducerId advisoryProducerId = new ProducerId();
-    final private LongSequenceGenerator messageIdGenerator = new LongSequenceGenerator();
+    
+    private final LongSequenceGenerator messageIdGenerator = new LongSequenceGenerator();
 
     public AdvisoryBroker(Broker next) {
         super(next);
-        advisoryProducerId.setConnectionId(idGenerator.generateId());
+        advisoryProducerId.setConnectionId(ID_GENERATOR.generateId());
     }
 
     public void addConnection(ConnectionContext context, ConnectionInfo info) throws Exception {
@@ -238,7 +238,7 @@
             ActiveMQTopic topic = AdvisorySupport.getExpiredMessageTopic(messageReference.getMessage().getDestination());
             fireAdvisory(context, topic, messageReference.getMessage());
         } catch (Exception e) {
-            log.warn("Failed to fire message expired advisory");
+            LOG.warn("Failed to fire message expired advisory");
         }
     }
 

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/advisory/ConsumerEventSource.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/advisory/ConsumerEventSource.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/advisory/ConsumerEventSource.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/advisory/ConsumerEventSource.java Thu Aug  9 09:37:49 2007
@@ -44,7 +44,7 @@
  * @version $Revision$
  */
 public class ConsumerEventSource implements Service, MessageListener {
-    private static final Log log = LogFactory.getLog(ConsumerEventSource.class);
+    private static final Log LOG = LogFactory.getLog(ConsumerEventSource.class);
 
     private final Connection connection;
     private final ActiveMQDestination destination;
@@ -97,10 +97,10 @@
                     fireConsumerEvent(new ConsumerStoppedEvent(this, destination, (ConsumerId)removeInfo.getObjectId(), count));
                 }
             } else {
-                log.warn("Unknown command: " + command);
+                LOG.warn("Unknown command: " + command);
             }
         } else {
-            log.warn("Unknown message type: " + message + ". Message ignored");
+            LOG.warn("Unknown message type: " + message + ". Message ignored");
         }
     }
 
@@ -116,9 +116,9 @@
                 Number n = (Number)value;
                 return n.intValue();
             }
-            log.warn("No consumerCount header available on the message: " + message);
+            LOG.warn("No consumerCount header available on the message: " + message);
         } catch (Exception e) {
-            log.warn("Failed to extract consumerCount from message: " + message + ".Reason: " + e, e);
+            LOG.warn("Failed to extract consumerCount from message: " + message + ".Reason: " + e, e);
         }
         return count;
     }

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/advisory/ConsumerListener.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/advisory/ConsumerListener.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/advisory/ConsumerListener.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/advisory/ConsumerListener.java Thu Aug  9 09:37:49 2007
@@ -23,5 +23,5 @@
  */
 public interface ConsumerListener {
 
-    public void onConsumerEvent(ConsumerEvent event);
+    void onConsumerEvent(ConsumerEvent event);
 }

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/advisory/ConsumerStartedEvent.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/advisory/ConsumerStartedEvent.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/advisory/ConsumerStartedEvent.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/advisory/ConsumerStartedEvent.java Thu Aug  9 09:37:49 2007
@@ -28,7 +28,7 @@
 
     private static final long serialVersionUID = 5088138839609391074L;
 
-    private transient final ConsumerInfo consumerInfo;
+    private final  transient ConsumerInfo consumerInfo;
 
     public ConsumerStartedEvent(ConsumerEventSource source, ActiveMQDestination destination, ConsumerInfo consumerInfo, int count) {
         super(source, destination, consumerInfo.getConsumerId(), count);

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/advisory/ProducerEventSource.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/advisory/ProducerEventSource.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/advisory/ProducerEventSource.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/advisory/ProducerEventSource.java Thu Aug  9 09:37:49 2007
@@ -44,7 +44,7 @@
  * @version $Revision: 359679 $
  */
 public class ProducerEventSource implements Service, MessageListener {
-    private static final Log log = LogFactory.getLog(ProducerEventSource.class);
+    private static final Log LOG = LogFactory.getLog(ProducerEventSource.class);
 
     private final Connection connection;
     private final ActiveMQDestination destination;
@@ -97,10 +97,10 @@
                     fireProducerEvent(new ProducerStoppedEvent(this, destination, (ProducerId)removeInfo.getObjectId(), count));
                 }
             } else {
-                log.warn("Unknown command: " + command);
+                LOG.warn("Unknown command: " + command);
             }
         } else {
-            log.warn("Unknown message type: " + message + ". Message ignored");
+            LOG.warn("Unknown message type: " + message + ". Message ignored");
         }
     }
 
@@ -111,9 +111,9 @@
                 Number n = (Number)value;
                 return n.intValue();
             }
-            log.warn("No producerCount header available on the message: " + message);
+            LOG.warn("No producerCount header available on the message: " + message);
         } catch (Exception e) {
-            log.warn("Failed to extract producerCount from message: " + message + ".Reason: " + e, e);
+            LOG.warn("Failed to extract producerCount from message: " + message + ".Reason: " + e, e);
         }
         return count;
     }

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/advisory/ProducerListener.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/advisory/ProducerListener.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/advisory/ProducerListener.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/advisory/ProducerListener.java Thu Aug  9 09:37:49 2007
@@ -23,5 +23,5 @@
  */
 public interface ProducerListener {
 
-    public void onProducerEvent(ProducerEvent event);
+    void onProducerEvent(ProducerEvent event);
 }

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/advisory/ProducerStartedEvent.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/advisory/ProducerStartedEvent.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/advisory/ProducerStartedEvent.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/advisory/ProducerStartedEvent.java Thu Aug  9 09:37:49 2007
@@ -28,7 +28,7 @@
 
     private static final long serialVersionUID = 5088138839609391074L;
 
-    private transient final ProducerInfo consumerInfo;
+    private final  transient ProducerInfo consumerInfo;
 
     public ProducerStartedEvent(ProducerEventSource source, ActiveMQDestination destination, ProducerInfo consumerInfo, int count) {
         super(source, destination, consumerInfo.getProducerId(), count);

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/blob/BlobTransferPolicy.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/blob/BlobTransferPolicy.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/blob/BlobTransferPolicy.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/blob/BlobTransferPolicy.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/main/java/org/apache/activemq/blob/BlobUploadStrategy.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/blob/BlobUploadStrategy.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/blob/BlobUploadStrategy.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/blob/BlobUploadStrategy.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/main/java/org/apache/activemq/blob/BlobUploader.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/blob/BlobUploader.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/blob/BlobUploader.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/blob/BlobUploader.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/main/java/org/apache/activemq/blob/DefaultBlobUploadStrategy.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/blob/DefaultBlobUploadStrategy.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/blob/DefaultBlobUploadStrategy.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/blob/DefaultBlobUploadStrategy.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/main/java/org/apache/activemq/broker/Broker.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/broker/Broker.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/broker/Broker.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/broker/Broker.java Thu Aug  9 09:37:49 2007
@@ -46,22 +46,22 @@
      * @param type
      * @return
      */
-    public Broker getAdaptor(Class type);
+    Broker getAdaptor(Class type);
 
     /**
      * Get the id of the broker
      */
-    public BrokerId getBrokerId();
+    BrokerId getBrokerId();
 
     /**
      * Get the name of the broker
      */
-    public String getBrokerName();
+    String getBrokerName();
 
     /**
      * A remote Broker connects
      */
-    public void addBroker(Connection connection, BrokerInfo info);
+    void addBroker(Connection connection, BrokerInfo info);
 
     /**
      * Remove a BrokerInfo
@@ -69,14 +69,14 @@
      * @param connection
      * @param info
      */
-    public void removeBroker(Connection connection, BrokerInfo info);
+    void removeBroker(Connection connection, BrokerInfo info);
 
     /**
      * A client is establishing a connection with the broker.
      * 
      * @throws Exception TODO
      */
-    public void addConnection(ConnectionContext context, ConnectionInfo info) throws Exception;
+    void addConnection(ConnectionContext context, ConnectionInfo info) throws Exception;
 
     /**
      * A client is disconnecting from the broker.
@@ -87,7 +87,7 @@
      *                that caused the client to disconnect.
      * @throws Exception TODO
      */
-    public void removeConnection(ConnectionContext context, ConnectionInfo info, Throwable error) throws Exception;
+    void removeConnection(ConnectionContext context, ConnectionInfo info, Throwable error) throws Exception;
 
     /**
      * Adds a session.
@@ -96,7 +96,7 @@
      * @param info
      * @throws Exception TODO
      */
-    public void addSession(ConnectionContext context, SessionInfo info) throws Exception;
+    void addSession(ConnectionContext context, SessionInfo info) throws Exception;
 
     /**
      * Removes a session.
@@ -105,7 +105,7 @@
      * @param info
      * @throws Exception TODO
      */
-    public void removeSession(ConnectionContext context, SessionInfo info) throws Exception;
+    void removeSession(ConnectionContext context, SessionInfo info) throws Exception;
 
     /**
      * Adds a producer.
@@ -113,7 +113,7 @@
      * @param context the enviorment the operation is being executed under.
      * @throws Exception TODO
      */
-    public void addProducer(ConnectionContext context, ProducerInfo info) throws Exception;
+    void addProducer(ConnectionContext context, ProducerInfo info) throws Exception;
 
     /**
      * Removes a producer.
@@ -121,19 +121,19 @@
      * @param context the enviorment the operation is being executed under.
      * @throws Exception TODO
      */
-    public void removeProducer(ConnectionContext context, ProducerInfo info) throws Exception;
+    void removeProducer(ConnectionContext context, ProducerInfo info) throws Exception;
 
     /**
      * @return all clients added to the Broker.
      * @throws Exception TODO
      */
-    public Connection[] getClients() throws Exception;
+    Connection[] getClients() throws Exception;
 
     /**
      * @return all destinations added to the Broker.
      * @throws Exception TODO
      */
-    public ActiveMQDestination[] getDestinations() throws Exception;
+    ActiveMQDestination[] getDestinations() throws Exception;
 
     /**
      * Gets a list of all the prepared xa transactions.
@@ -142,7 +142,7 @@
      * @return
      * @throws Exception TODO
      */
-    public TransactionId[] getPreparedTransactions(ConnectionContext context) throws Exception;
+    TransactionId[] getPreparedTransactions(ConnectionContext context) throws Exception;
 
     /**
      * Starts a transaction.
@@ -151,7 +151,7 @@
      * @param xid
      * @throws Exception TODO
      */
-    public void beginTransaction(ConnectionContext context, TransactionId xid) throws Exception;
+    void beginTransaction(ConnectionContext context, TransactionId xid) throws Exception;
 
     /**
      * Prepares a transaction. Only valid for xa transactions.
@@ -161,7 +161,7 @@
      * @return id
      * @throws Exception TODO
      */
-    public int prepareTransaction(ConnectionContext context, TransactionId xid) throws Exception;
+    int prepareTransaction(ConnectionContext context, TransactionId xid) throws Exception;
 
     /**
      * Rollsback a transaction.
@@ -171,7 +171,7 @@
      * @throws Exception TODO
      */
 
-    public void rollbackTransaction(ConnectionContext context, TransactionId xid) throws Exception;
+    void rollbackTransaction(ConnectionContext context, TransactionId xid) throws Exception;
 
     /**
      * Commits a transaction.
@@ -181,7 +181,7 @@
      * @param onePhase
      * @throws Exception TODO
      */
-    public void commitTransaction(ConnectionContext context, TransactionId xid, boolean onePhase) throws Exception;
+    void commitTransaction(ConnectionContext context, TransactionId xid, boolean onePhase) throws Exception;
 
     /**
      * Forgets a transaction.
@@ -190,7 +190,7 @@
      * @param transactionId
      * @throws Exception
      */
-    public void forgetTransaction(ConnectionContext context, TransactionId transactionId) throws Exception;
+    void forgetTransaction(ConnectionContext context, TransactionId transactionId) throws Exception;
 
     /**
      * Get the BrokerInfo's of any connected Brokers
@@ -204,24 +204,24 @@
      * 
      * @param messageDispatch
      */
-    public void preProcessDispatch(MessageDispatch messageDispatch);
+    void preProcessDispatch(MessageDispatch messageDispatch);
 
     /**
      * Notify the Broker that a dispatch has happened
      * 
      * @param messageDispatch
      */
-    public void postProcessDispatch(MessageDispatch messageDispatch);
+    void postProcessDispatch(MessageDispatch messageDispatch);
 
     /**
      * @return true if the broker has stopped
      */
-    public boolean isStopped();
+    boolean isStopped();
 
     /**
      * @return a Set of all durable destinations
      */
-    public Set getDurableDestinations();
+    Set getDurableDestinations();
 
     /**
      * Add and process a DestinationInfo object
@@ -230,7 +230,7 @@
      * @param info
      * @throws Exception
      */
-    public void addDestinationInfo(ConnectionContext context, DestinationInfo info) throws Exception;
+    void addDestinationInfo(ConnectionContext context, DestinationInfo info) throws Exception;
 
     /**
      * Remove and process a DestinationInfo object
@@ -239,18 +239,18 @@
      * @param info
      * @throws Exception
      */
-    public void removeDestinationInfo(ConnectionContext context, DestinationInfo info) throws Exception;
+    void removeDestinationInfo(ConnectionContext context, DestinationInfo info) throws Exception;
 
     /**
      * @return true if fault tolerant
      */
-    public boolean isFaultTolerantConfiguration();
+    boolean isFaultTolerantConfiguration();
 
     /**
      * @return the connection context used to make administration operations on
      *         startup or via JMX MBeans
      */
-    public abstract ConnectionContext getAdminConnectionContext();
+    ConnectionContext getAdminConnectionContext();
 
     /**
      * Sets the default administration connection context used when configuring
@@ -258,22 +258,22 @@
      * 
      * @param adminConnectionContext
      */
-    public abstract void setAdminConnectionContext(ConnectionContext adminConnectionContext);
+    void setAdminConnectionContext(ConnectionContext adminConnectionContext);
 
     /**
      * @return the temp data store
      */
-    public Store getTempDataStore();
+    Store getTempDataStore();
 
     /**
      * @return the URI that can be used to connect to the local Broker
      */
-    public URI getVmConnectorURI();
+    URI getVmConnectorURI();
 
     /**
      * called when the brokerService starts
      */
-    public void brokerServiceStarted();
+    void brokerServiceStarted();
 
     /**
      * @return the BrokerService
@@ -295,7 +295,7 @@
      * @param messageReference
      * @return true if the message is expired
      */
-    public boolean isExpired(MessageReference messageReference);
+    boolean isExpired(MessageReference messageReference);
 
     /**
      * A Message has Expired
@@ -303,7 +303,7 @@
      * @param context
      * @param messageReference
      */
-    public void messageExpired(ConnectionContext context, MessageReference messageReference);
+    void messageExpired(ConnectionContext context, MessageReference messageReference);
 
     /**
      * A message needs to go the a DLQ
@@ -311,6 +311,6 @@
      * @param context
      * @param messageReference
      */
-    public void sendToDeadLetterQueue(ConnectionContext context, MessageReference messageReference);
+    void sendToDeadLetterQueue(ConnectionContext context, MessageReference messageReference);
 
 }

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/broker/BrokerFactory.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/broker/BrokerFactory.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/broker/BrokerFactory.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/broker/BrokerFactory.java Thu Aug  9 09:37:49 2007
@@ -31,12 +31,11 @@
  */
 public class BrokerFactory {
 
-    static final private FactoryFinder brokerFactoryHandlerFinder = new FactoryFinder(
-                                                                                      "META-INF/services/org/apache/activemq/broker/");
+    private static final FactoryFinder BROKER_FACTORY_HANDLER_FINDER = new FactoryFinder("META-INF/services/org/apache/activemq/broker/");
 
     public static BrokerFactoryHandler createBrokerFactoryHandler(String type) throws IOException {
         try {
-            return (BrokerFactoryHandler)brokerFactoryHandlerFinder.newInstance(type);
+            return (BrokerFactoryHandler)BROKER_FACTORY_HANDLER_FINDER.newInstance(type);
         } catch (Throwable e) {
             throw IOExceptionSupport.create("Could load " + type + " factory:" + e, e);
         }

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/broker/BrokerFactoryHandler.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/broker/BrokerFactoryHandler.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/broker/BrokerFactoryHandler.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/broker/BrokerFactoryHandler.java Thu Aug  9 09:37:49 2007
@@ -24,5 +24,5 @@
  * @version $Revision$
 */
 public interface BrokerFactoryHandler {
-    public BrokerService createBroker(URI brokerURI) throws Exception;
+    BrokerService createBroker(URI brokerURI) throws Exception;
 }

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/broker/BrokerFilter.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/broker/BrokerFilter.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/broker/BrokerFilter.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/broker/BrokerFilter.java Thu Aug  9 09:37:49 2007
@@ -48,7 +48,7 @@
  */
 public class BrokerFilter implements Broker {
 
-    final protected Broker next;
+    protected final Broker next;
 
     public BrokerFilter(Broker next) {
         this.next = next;

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/broker/BrokerPlugin.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/broker/BrokerPlugin.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/broker/BrokerPlugin.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/broker/BrokerPlugin.java Thu Aug  9 09:37:49 2007
@@ -27,6 +27,6 @@
      * Installs the plugin into the interceptor chain of the broker, returning the new
      * intercepted broker to use.
      */
-    public Broker installPlugin(Broker broker) throws Exception;
+    Broker installPlugin(Broker broker) throws Exception;
     
 }

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/broker/BrokerRegistry.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/broker/BrokerRegistry.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/broker/BrokerRegistry.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/broker/BrokerRegistry.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.broker;
 
 import java.util.HashMap;
@@ -24,16 +26,16 @@
  */
 public class BrokerRegistry {
 
-    private static final Log log = LogFactory.getLog(BrokerRegistry.class);
-    static final private BrokerRegistry instance = new BrokerRegistry();
-
-    public static BrokerRegistry getInstance() {
-        return instance;
-    }
+    private static final Log LOG = LogFactory.getLog(BrokerRegistry.class);
+    private static final BrokerRegistry INSTANCE = new BrokerRegistry();
 
     private final Object mutex = new Object();
     private final HashMap<String, BrokerService> brokers = new HashMap<String, BrokerService>();
 
+    public static BrokerRegistry getInstance() {
+        return INSTANCE;
+    }
+
     /**
      * @param brokerName
      * @return the BrokerService
@@ -45,7 +47,7 @@
             if (result == null && brokerName != null && brokerName.equals(BrokerService.DEFAULT_BROKER_NAME)) {
                 result = findFirst();
                 if (result != null) {
-                    log.warn("Broker localhost not started so using " + result.getBrokerName() + " instead");
+                    LOG.warn("Broker localhost not started so using " + result.getBrokerName() + " instead");
                 }
             }
         }

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/broker/BrokerServiceAware.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/broker/BrokerServiceAware.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/broker/BrokerServiceAware.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/broker/BrokerServiceAware.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.
@@ -24,5 +24,5 @@
  */
 public interface BrokerServiceAware {
 
-    public void setBrokerService(BrokerService brokerService);
+    void setBrokerService(BrokerService brokerService);
 }

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/broker/Connection.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/broker/Connection.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/broker/Connection.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/broker/Connection.java Thu Aug  9 09:37:49 2007
@@ -31,78 +31,78 @@
     /**
      * @return the connector that created this connection.
      */
-    public Connector getConnector();
+    Connector getConnector();
 
     /**
      * Sends a message to the client.
      * 
      * @param message the message to send to the client.
      */
-    public void dispatchSync(Command message);
+    void dispatchSync(Command message);
 
     /**
      * Sends a message to the client.
      * 
      * @param command
      */
-    public void dispatchAsync(Command command);
+    void dispatchAsync(Command command);
 
     /**
      * Services a client command and submits it to the broker.
      * 
      * @param command
      */
-    public Response service(Command command);
+    Response service(Command command);
 
     /**
      * Handles an unexpected error associated with a connection.
      * 
      * @param error
      */
-    public void serviceException(Throwable error);
+    void serviceException(Throwable error);
 
     /**
      * @return true if the Connection is slow
      */
-    public boolean isSlow();
+    boolean isSlow();
 
     /**
      * @return if after being marked, the Connection is still writing
      */
-    public boolean isBlocked();
+    boolean isBlocked();
 
     /**
      * @return true if the Connection is connected
      */
-    public boolean isConnected();
+    boolean isConnected();
 
     /**
      * @return true if the Connection is active
      */
-    public boolean isActive();
+    boolean isActive();
 
     /**
      * Returns the number of messages to be dispatched to this connection
      */
-    public int getDispatchQueueSize();
+    int getDispatchQueueSize();
 
     /**
      * Returns the statistics for this connection
      */
-    public ConnectionStatistics getStatistics();
+    ConnectionStatistics getStatistics();
 
     /**
      * @return true if the Connection will process control commands
      */
-    public boolean isManageable();
+    boolean isManageable();
 
     /**
      * @return the source address for this connection
      */
-    public String getRemoteAddress();
+    String getRemoteAddress();
 
-    public void serviceExceptionAsync(IOException e);
+    void serviceExceptionAsync(IOException e);
 
-    public String getConnectionId();
+    String getConnectionId();
 
 }

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/broker/Connector.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/broker/Connector.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/broker/Connector.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/broker/Connector.java Thu Aug  9 09:37:49 2007
@@ -31,10 +31,10 @@
      * 
      * @return
      */
-    public BrokerInfo getBrokerInfo();
+    BrokerInfo getBrokerInfo();
 
     /**
      * @return the statistics for this connector
      */
-    public ConnectorStatistics getStatistics();
+    ConnectorStatistics getStatistics();
 }

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

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

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/broker/TransactionBroker.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/broker/TransactionBroker.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/broker/TransactionBroker.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/broker/TransactionBroker.java Thu Aug  9 09:37:49 2007
@@ -51,7 +51,7 @@
  */
 public class TransactionBroker extends BrokerFilter {
 
-    private static final Log log = LogFactory.getLog(TransactionBroker.class);
+    private static final Log LOG = LogFactory.getLog(TransactionBroker.class);
 
     // The prepared XA transactions.
     private TransactionStore transactionStore;
@@ -222,8 +222,8 @@
             if (sync != null && transaction != null) {
                 transaction.removeSynchronization(sync);
             }
-            if (log.isDebugEnabled()) {
-                log.debug("IGNORING duplicate message " + message);
+            if (LOG.isDebugEnabled()) {
+                LOG.debug("IGNORING duplicate message " + message);
             }
         }
     }
@@ -234,7 +234,7 @@
                 Transaction transaction = (Transaction)iter.next();
                 transaction.rollback();
             } catch (Exception e) {
-                log.warn("ERROR Rolling back disconnected client's transactions: ", e);
+                LOG.warn("ERROR Rolling back disconnected client's transactions: ", e);
             }
             iter.remove();
         }

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/broker/TransportConnection.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/broker/TransportConnection.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/broker/TransportConnection.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/broker/TransportConnection.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.broker;
 
 import java.io.IOException;
@@ -143,7 +145,7 @@
     private boolean networkConnection;
     private AtomicInteger protocolVersion = new AtomicInteger(CommandTypes.PROTOCOL_VERSION);
     private DemandForwardingBridge duplexBridge;
-    final private TaskRunnerFactory taskRunnerFactory;
+    private final TaskRunnerFactory taskRunnerFactory;
     private TransportConnectionState connectionState;
 
     static class TransportConnectionState extends org.apache.activemq.state.ConnectionState {
@@ -366,7 +368,7 @@
         return null;
     }
 
-    synchronized public Response processBeginTransaction(TransactionInfo info) throws Exception {
+    public synchronized Response processBeginTransaction(TransactionInfo info) throws Exception {
         TransportConnectionState cs = lookupConnectionState(info.getConnectionId());
         context = null;
         if (cs != null) {
@@ -383,14 +385,14 @@
         return null;
     }
 
-    synchronized public Response processEndTransaction(TransactionInfo info) throws Exception {
+    public synchronized Response processEndTransaction(TransactionInfo info) throws Exception {
         // No need to do anything. This packet is just sent by the client
         // make sure he is synced with the server as commit command could
         // come from a different connection.
         return null;
     }
 
-    synchronized public Response processPrepareTransaction(TransactionInfo info) throws Exception {
+    public synchronized Response processPrepareTransaction(TransactionInfo info) throws Exception {
         TransportConnectionState cs = lookupConnectionState(info.getConnectionId());
         context = null;
         if (cs != null) {
@@ -415,7 +417,7 @@
         }
     }
 
-    synchronized public Response processCommitTransactionOnePhase(TransactionInfo info) throws Exception {
+    public synchronized Response processCommitTransactionOnePhase(TransactionInfo info) throws Exception {
         TransportConnectionState cs = lookupConnectionState(info.getConnectionId());
         context = cs.getContext();
         cs.removeTransactionState(info.getTransactionId());
@@ -423,7 +425,7 @@
         return null;
     }
 
-    synchronized public Response processCommitTransactionTwoPhase(TransactionInfo info) throws Exception {
+    public synchronized Response processCommitTransactionTwoPhase(TransactionInfo info) throws Exception {
         TransportConnectionState cs = lookupConnectionState(info.getConnectionId());
         context = cs.getContext();
         cs.removeTransactionState(info.getTransactionId());
@@ -431,7 +433,7 @@
         return null;
     }
 
-    synchronized public Response processRollbackTransaction(TransactionInfo info) throws Exception {
+    public synchronized Response processRollbackTransaction(TransactionInfo info) throws Exception {
         TransportConnectionState cs = lookupConnectionState(info.getConnectionId());
         context = cs.getContext();
         cs.removeTransactionState(info.getTransactionId());
@@ -439,14 +441,14 @@
         return null;
     }
 
-    synchronized public Response processForgetTransaction(TransactionInfo info) throws Exception {
+    public synchronized Response processForgetTransaction(TransactionInfo info) throws Exception {
         TransportConnectionState cs = lookupConnectionState(info.getConnectionId());
         context = cs.getContext();
         broker.forgetTransaction(context, info.getTransactionId());
         return null;
     }
 
-    synchronized public Response processRecoverTransactions(TransactionInfo info) throws Exception {
+    public synchronized Response processRecoverTransactions(TransactionInfo info) throws Exception {
         TransportConnectionState cs = lookupConnectionState(info.getConnectionId());
         context = cs.getContext();
         TransactionId[] preparedTransactions = broker.getPreparedTransactions(context);
@@ -475,7 +477,7 @@
         return null;
     }
 
-    synchronized public Response processAddDestination(DestinationInfo info) throws Exception {
+    public synchronized Response processAddDestination(DestinationInfo info) throws Exception {
         TransportConnectionState cs = lookupConnectionState(info.getConnectionId());
         broker.addDestinationInfo(cs.getContext(), info);
         if (info.getDestination().isTemporary()) {
@@ -484,7 +486,7 @@
         return null;
     }
 
-    synchronized public Response processRemoveDestination(DestinationInfo info) throws Exception {
+    public synchronized Response processRemoveDestination(DestinationInfo info) throws Exception {
         TransportConnectionState cs = lookupConnectionState(info.getConnectionId());
         broker.removeDestinationInfo(cs.getContext(), info);
         if (info.getDestination().isTemporary()) {
@@ -493,7 +495,7 @@
         return null;
     }
 
-    synchronized public Response processAddProducer(ProducerInfo info) throws Exception {
+    public synchronized Response processAddProducer(ProducerInfo info) throws Exception {
         SessionId sessionId = info.getProducerId().getParentId();
         ConnectionId connectionId = sessionId.getParentId();
         TransportConnectionState cs = lookupConnectionState(connectionId);
@@ -512,7 +514,7 @@
         return null;
     }
 
-    synchronized public Response processRemoveProducer(ProducerId id) throws Exception {
+    public synchronized Response processRemoveProducer(ProducerId id) throws Exception {
         SessionId sessionId = id.getParentId();
         ConnectionId connectionId = sessionId.getParentId();
         TransportConnectionState cs = lookupConnectionState(connectionId);
@@ -527,7 +529,7 @@
         return null;
     }
 
-    synchronized public Response processAddConsumer(ConsumerInfo info) throws Exception {
+    public synchronized Response processAddConsumer(ConsumerInfo info) throws Exception {
         SessionId sessionId = info.getConsumerId().getParentId();
         ConnectionId connectionId = sessionId.getParentId();
         TransportConnectionState cs = lookupConnectionState(connectionId);
@@ -546,7 +548,7 @@
         return null;
     }
 
-    synchronized public Response processRemoveConsumer(ConsumerId id) throws Exception {
+    public synchronized Response processRemoveConsumer(ConsumerId id) throws Exception {
         SessionId sessionId = id.getParentId();
         ConnectionId connectionId = sessionId.getParentId();
         TransportConnectionState cs = lookupConnectionState(connectionId);
@@ -561,7 +563,7 @@
         return null;
     }
 
-    synchronized public Response processAddSession(SessionInfo info) throws Exception {
+    public synchronized Response processAddSession(SessionInfo info) throws Exception {
         ConnectionId connectionId = info.getSessionId().getParentId();
         TransportConnectionState cs = lookupConnectionState(connectionId);
         // Avoid replaying dup commands
@@ -576,7 +578,7 @@
         return null;
     }
 
-    synchronized public Response processRemoveSession(SessionId id) throws Exception {
+    public synchronized Response processRemoveSession(SessionId id) throws Exception {
         ConnectionId connectionId = id.getParentId();
         TransportConnectionState cs = lookupConnectionState(connectionId);
         SessionState session = cs.getSessionState(id);
@@ -665,7 +667,7 @@
         return null;
     }
 
-    synchronized public Response processRemoveConnection(ConnectionId id) {
+    public synchronized Response processRemoveConnection(ConnectionId id) {
         TransportConnectionState cs = lookupConnectionState(id);
         // Don't allow things to be added to the connection state while we are
         // shutting down.
@@ -1061,7 +1063,7 @@
         return starting;
     }
 
-    synchronized protected void setStarting(boolean starting) {
+    protected synchronized void setStarting(boolean starting) {
         this.starting = starting;
     }
 

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/broker/TransportStatusDetector.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/broker/TransportStatusDetector.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/broker/TransportStatusDetector.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/broker/TransportStatusDetector.java Thu Aug  9 09:37:49 2007
@@ -32,7 +32,7 @@
  * @version $Revision: 1.5 $
  */
 public class TransportStatusDetector implements Service, Runnable {
-    private static final Log log = LogFactory.getLog(TransportStatusDetector.class);
+    private static final Log LOG = LogFactory.getLog(TransportStatusDetector.class);
     private TransportConnector connector;
     private Set collectionCandidates = new CopyOnWriteArraySet();
     private AtomicBoolean started = new AtomicBoolean(false);
@@ -86,11 +86,11 @@
     }
 
     protected void doCollection(TransportConnection tc) {
-        log.warn("found a blocked client - stopping: " + tc);
+        LOG.warn("found a blocked client - stopping: " + tc);
         try {
             tc.stop();
         } catch (Exception e) {
-            log.error("Error stopping " + tc, e);
+            LOG.error("Error stopping " + tc, e);
         }
     }
 
@@ -101,7 +101,7 @@
                 doSweep();
                 Thread.sleep(sweepInterval);
             } catch (Throwable e) {
-                log.error("failed to complete a sweep for blocked clients", e);
+                LOG.error("failed to complete a sweep for blocked clients", e);
             }
         }
     }

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/broker/ft/MasterBroker.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/broker/ft/MasterBroker.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/broker/ft/MasterBroker.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/broker/ft/MasterBroker.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.broker.ft;
 
 import java.util.concurrent.atomic.AtomicBoolean;
@@ -51,7 +53,7 @@
  */
 public class MasterBroker extends InsertableMutableBrokerFilter {
 
-    private static final Log log = LogFactory.getLog(MasterBroker.class);
+    private static final Log LOG = LogFactory.getLog(MasterBroker.class);
     private Transport slave;
     private AtomicBoolean started = new AtomicBoolean(false);
 
@@ -86,7 +88,7 @@
                 }
             }
         } catch (Exception e) {
-            log.error("Failed to get Connections", e);
+            LOG.error("Failed to get Connections", e);
         }
     }
 
@@ -344,7 +346,7 @@
         try {
             slave.oneway(command);
         } catch (Throwable e) {
-            log.error("Slave Failed", e);
+            LOG.error("Slave Failed", e);
             stopProcessing();
         }
     }
@@ -354,10 +356,10 @@
             Response response = (Response)slave.request(command);
             if (response.isException()) {
                 ExceptionResponse er = (ExceptionResponse)response;
-                log.error("Slave Failed", er.getException());
+                LOG.error("Slave Failed", er.getException());
             }
         } catch (Throwable e) {
-            log.error("Slave Failed", e);
+            LOG.error("Slave Failed", e);
         }
     }
 }

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/broker/ft/MasterConnector.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/broker/ft/MasterConnector.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/broker/ft/MasterConnector.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/broker/ft/MasterConnector.java Thu Aug  9 09:37:49 2007
@@ -55,7 +55,7 @@
  */
 public class MasterConnector implements Service, BrokerServiceAware {
 
-    private static final Log log = LogFactory.getLog(MasterConnector.class);
+    private static final Log LOG = LogFactory.getLog(MasterConnector.class);
     private BrokerService broker;
     private URI remoteURI;
     private URI localURI;
@@ -104,7 +104,7 @@
         }
         localBroker = TransportFactory.connect(localURI);
         remoteBroker = TransportFactory.connect(remoteURI);
-        log.info("Starting a network connection between " + localBroker + " and " + remoteBroker + " has been established.");
+        LOG.info("Starting a network connection between " + localBroker + " and " + remoteBroker + " has been established.");
         localBroker.setTransportListener(new DefaultTransportListener() {
 
             public void onCommand(Object command) {
@@ -141,7 +141,7 @@
                     startBridge();
                 } catch (Exception e) {
                     masterActive.set(false);
-                    log.error("Failed to start network bridge: " + e, e);
+                    LOG.error("Failed to start network bridge: " + e, e);
                 }
             }
         };
@@ -175,7 +175,7 @@
         brokerInfo.setPeerBrokerInfos(broker.getBroker().getPeerBrokerInfos());
         brokerInfo.setSlaveBroker(true);
         remoteBroker.oneway(brokerInfo);
-        log.info("Slave connection between " + localBroker + " and " + remoteBroker + " has been established.");
+        LOG.info("Slave connection between " + localBroker + " and " + remoteBroker + " has been established.");
     }
 
     public void stop() throws Exception {
@@ -192,7 +192,7 @@
             remoteBroker.oneway(new ShutdownInfo());
             localBroker.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);
@@ -202,7 +202,7 @@
     }
 
     protected void serviceRemoteException(IOException error) {
-        log.error("Network connection between " + localBroker + " and " + remoteBroker + " shutdown: " + error.getMessage(), error);
+        LOG.error("Network connection between " + localBroker + " and " + remoteBroker + " shutdown: " + error.getMessage(), error);
         shutDown();
     }
 
@@ -213,7 +213,7 @@
                 command = md.getMessage();
             }
             if (command.getDataStructureType() == CommandTypes.SHUTDOWN_INFO) {
-                log.warn("The Master has shutdown");
+                LOG.warn("The Master has shutdown");
                 shutDown();
             } else {
                 boolean responseRequired = command.isResponseRequired();
@@ -232,7 +232,7 @@
     }
 
     protected void serviceLocalException(Throwable error) {
-        log.info("Network connection between " + localBroker + " and " + remoteBroker + " shutdown: " + error.getMessage(), error);
+        LOG.info("Network connection between " + localBroker + " and " + remoteBroker + " shutdown: " + error.getMessage(), error);
         ServiceSupport.dispose(this);
     }