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 [5/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/camel/CamelTopic.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/camel/CamelTopic.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/camel/CamelTopic.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/camel/CamelTopic.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/camel/CamelTopicPublisher.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/camel/CamelTopicPublisher.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/camel/CamelTopicPublisher.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/camel/CamelTopicPublisher.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/camel/CamelTopicSubscriber.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/camel/CamelTopicSubscriber.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/camel/CamelTopicSubscriber.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/camel/CamelTopicSubscriber.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/command/ActiveMQBlobMessage.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/command/ActiveMQBlobMessage.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/command/ActiveMQBlobMessage.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/command/ActiveMQBlobMessage.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/command/ActiveMQBytesMessage.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/command/ActiveMQBytesMessage.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/command/ActiveMQBytesMessage.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/command/ActiveMQBytesMessage.java Thu Aug  9 09:37:49 2007
@@ -94,10 +94,10 @@
 
     public static final byte DATA_STRUCTURE_TYPE = CommandTypes.ACTIVEMQ_BYTES_MESSAGE;
 
-    transient protected DataOutputStream dataOut;
-    transient protected ByteArrayOutputStream bytesOut;
-    transient protected DataInputStream dataIn;
-    transient protected int length;
+    protected transient DataOutputStream dataOut;
+    protected transient ByteArrayOutputStream bytesOut;
+    protected transient DataInputStream dataIn;
+    protected transient int length;
 
     public Message copy() {
         ActiveMQBytesMessage copy = new ActiveMQBytesMessage();

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/command/ActiveMQDestination.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/command/ActiveMQDestination.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/command/ActiveMQDestination.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/command/ActiveMQDestination.java Thu Aug  9 09:37:49 2007
@@ -41,7 +41,7 @@
  * @openwire:marshaller
  * @version $Revision: 1.10 $
  */
-abstract public class ActiveMQDestination extends JNDIBaseStorable implements DataStructure, Destination,
+public abstract class ActiveMQDestination extends JNDIBaseStorable implements DataStructure, Destination,
     Externalizable, Comparable {
 
     private static final long serialVersionUID = -3885260014960795889L;
@@ -64,15 +64,15 @@
 
     protected String physicalName;
 
-    transient protected ActiveMQDestination[] compositeDestinations;
-    transient protected String[] destinationPaths;
-    transient protected boolean isPattern;
-    transient protected int hashValue;
+    protected transient ActiveMQDestination[] compositeDestinations;
+    protected transient String[] destinationPaths;
+    protected transient boolean isPattern;
+    protected transient int hashValue;
     protected Map options;
 
     // static helper methods for working with destinations
     // -------------------------------------------------------------------------
-    static public ActiveMQDestination createDestination(String name, byte defaultType) {
+    public static ActiveMQDestination createDestination(String name, byte defaultType) {
 
         if (name.startsWith(QUEUE_QUALIFIED_PREFIX)) {
             return new ActiveMQQueue(name.substring(QUEUE_QUALIFIED_PREFIX.length()));
@@ -186,7 +186,7 @@
         return getQualifiedPrefix() + physicalName;
     }
 
-    abstract protected String getQualifiedPrefix();
+    protected abstract String getQualifiedPrefix();
 
     /**
      * @openwire:property version=1
@@ -271,7 +271,7 @@
         return destinationPaths;
     }
 
-    abstract public byte getDestinationType();
+    public abstract byte getDestinationType();
 
     public boolean isQueue() {
         return false;

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/command/ActiveMQMapMessage.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/command/ActiveMQMapMessage.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/command/ActiveMQMapMessage.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/command/ActiveMQMapMessage.java Thu Aug  9 09:37:49 2007
@@ -99,7 +99,7 @@
 
     public static final byte DATA_STRUCTURE_TYPE = CommandTypes.ACTIVEMQ_MAP_MESSAGE;
 
-    transient protected Map map = new HashMap();
+    protected transient Map map = new HashMap();
 
     public Message copy() {
         ActiveMQMapMessage copy = new ActiveMQMapMessage();

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/command/ActiveMQMessage.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/command/ActiveMQMessage.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/command/ActiveMQMessage.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/command/ActiveMQMessage.java Thu Aug  9 09:37:49 2007
@@ -50,7 +50,7 @@
         return DATA_STRUCTURE_TYPE;
     }
 
-    transient protected Callback acknowledgeCallback;
+    protected transient Callback acknowledgeCallback;
 
     public Message copy() {
         ActiveMQMessage copy = new ActiveMQMessage();
@@ -180,7 +180,7 @@
         return "jms/message";
     }
 
-    static protected String decodeString(byte[] data) throws JMSException {
+    protected static String decodeString(byte[] data) throws JMSException {
         try {
             if (data == null) {
                 return null;
@@ -191,7 +191,7 @@
         }
     }
 
-    static protected byte[] encodeString(String data) throws JMSException {
+    protected static byte[] encodeString(String data) throws JMSException {
         try {
             if (data == null) {
                 return null;
@@ -280,10 +280,10 @@
     }
 
     interface PropertySetter {
-        public void set(Message message, Object value) throws MessageFormatException;
+        void set(Message message, Object value) throws MessageFormatException;
     }
 
-    static final private HashMap JMS_PROPERTY_SETERS = new HashMap();
+    private static final HashMap JMS_PROPERTY_SETERS = new HashMap();
     static {
         JMS_PROPERTY_SETERS.put("JMSXDeliveryCount", new PropertySetter() {
             public void set(Message message, Object value) throws MessageFormatException {

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/command/ActiveMQStreamMessage.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/command/ActiveMQStreamMessage.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/command/ActiveMQStreamMessage.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/command/ActiveMQStreamMessage.java Thu Aug  9 09:37:49 2007
@@ -113,10 +113,10 @@
 
     public static final byte DATA_STRUCTURE_TYPE = CommandTypes.ACTIVEMQ_STREAM_MESSAGE;
 
-    transient protected DataOutputStream dataOut;
-    transient protected ByteArrayOutputStream bytesOut;
-    transient protected DataInputStream dataIn;
-    transient protected int remainingBytes = -1;
+    protected transient DataOutputStream dataOut;
+    protected transient ByteArrayOutputStream bytesOut;
+    protected transient DataInputStream dataIn;
+    protected transient int remainingBytes = -1;
 
     public Message copy() {
         ActiveMQStreamMessage copy = new ActiveMQStreamMessage();

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/command/ActiveMQTempDestination.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/command/ActiveMQTempDestination.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/command/ActiveMQTempDestination.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/command/ActiveMQTempDestination.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.command;
 
 import javax.jms.JMSException;
@@ -23,9 +25,9 @@
  * @openwire:marshaller
  * @version $Revision: 1.5 $
  */
-abstract public class ActiveMQTempDestination extends ActiveMQDestination {
+public abstract class ActiveMQTempDestination extends ActiveMQDestination {
 
-    private static final Log log = LogFactory.getLog(ActiveMQTempDestination.class);
+    private static final Log LOG = LogFactory.getLog(ActiveMQTempDestination.class);
     protected transient ActiveMQConnection connection;
     protected transient String connectionId;
     protected transient int sequenceId;
@@ -70,7 +72,7 @@
                     try {
                         sequenceId = Integer.parseInt(seqStr);
                     } catch (NumberFormatException e) {
-                        log.debug("Did not parse sequence Id from " + physicalName);
+                        LOG.debug("Did not parse sequence Id from " + physicalName);
                     }
                     // The rest should be the connection id.
                     connectionId = this.physicalName.substring(0, p);

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/command/BaseCommand.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/command/BaseCommand.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/command/BaseCommand.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/command/BaseCommand.java Thu Aug  9 09:37:49 2007
@@ -24,7 +24,7 @@
  * @openwire:marshaller
  * @version $Revision: 1.11 $
  */
-abstract public class BaseCommand implements Command {
+public abstract class BaseCommand implements Command {
 
     protected int commandId;
     protected boolean responseRequired;

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/command/Command.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/command/Command.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/command/Command.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/command/Command.java Thu Aug  9 09:37:49 2007
@@ -51,14 +51,14 @@
      * The endpoint within the transport where this message came from which could be null if the 
      * transport only supports a single endpoint.
      */
-    public Endpoint getFrom();
+    Endpoint getFrom();
 
-    public void setFrom(Endpoint from);
+    void setFrom(Endpoint from);
 
     /**
      * The endpoint within the transport where this message is going to - null means all endpoints.
      */
-    public Endpoint getTo();
+    Endpoint getTo();
 
-    public void setTo(Endpoint to);
+    void setTo(Endpoint to);
 }

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/command/CommandTypes.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/command/CommandTypes.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/command/CommandTypes.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/command/CommandTypes.java Thu Aug  9 09:37:49 2007
@@ -22,155 +22,138 @@
  * @version $Revision: 1.21 $
  */
 public interface CommandTypes {
-	
-	// What is the latest version of the openwire protocol
-    byte  PROTOCOL_VERSION                  = 3;
+
+    // What is the latest version of the openwire protocol
+    byte PROTOCOL_VERSION = 3;
 
     // A marshaling layer can use this type to specify a null object.
-    byte  NULL                              = 0;
+    byte NULL = 0;
 
-    ///////////////////////////////////////////////////
+    // /////////////////////////////////////////////////
     //
     // Info objects sent back and forth client/server when
     // setting up a client connection.
     //
-    ///////////////////////////////////////////////////    
-    byte  WIREFORMAT_INFO                   = 1;
-    byte  BROKER_INFO                       = 2;
-    byte  CONNECTION_INFO                   = 3;
-    byte  SESSION_INFO                      = 4;
-    byte  CONSUMER_INFO                     = 5;
-    byte  PRODUCER_INFO                     = 6;
-    byte  TRANSACTION_INFO                  = 7;
-    byte  DESTINATION_INFO                  = 8;
-    byte  REMOVE_SUBSCRIPTION_INFO          = 9;
-    byte  KEEP_ALIVE_INFO                   = 10;
-    byte  SHUTDOWN_INFO                     = 11;
-    byte  REMOVE_INFO                       = 12;
-    byte  CONTROL_COMMAND                   = 14;
-    byte  FLUSH_COMMAND                     = 15;
-    byte  CONNECTION_ERROR                  = 16;
-    byte CONSUMER_CONTROL                   = 17;
-    byte CONNECTION_CONTROL                 = 18;
-    
-    ///////////////////////////////////////////////////
+    // /////////////////////////////////////////////////
+    byte WIREFORMAT_INFO = 1;
+    byte BROKER_INFO = 2;
+    byte CONNECTION_INFO = 3;
+    byte SESSION_INFO = 4;
+    byte CONSUMER_INFO = 5;
+    byte PRODUCER_INFO = 6;
+    byte TRANSACTION_INFO = 7;
+    byte DESTINATION_INFO = 8;
+    byte REMOVE_SUBSCRIPTION_INFO = 9;
+    byte KEEP_ALIVE_INFO = 10;
+    byte SHUTDOWN_INFO = 11;
+    byte REMOVE_INFO = 12;
+    byte CONTROL_COMMAND = 14;
+    byte FLUSH_COMMAND = 15;
+    byte CONNECTION_ERROR = 16;
+    byte CONSUMER_CONTROL = 17;
+    byte CONNECTION_CONTROL = 18;
+
+    // /////////////////////////////////////////////////
     //
     // Messages that go back and forth between the client
     // and the server.
     //
-    ///////////////////////////////////////////////////    
-    byte  PRODUCER_ACK                      = 19;
-    byte  MESSAGE_PULL                      = 20;
-    byte  MESSAGE_DISPATCH                  = 21;
-    byte  MESSAGE_ACK                       = 22;
-    
-    byte  ACTIVEMQ_MESSAGE                  = 23;
-    byte  ACTIVEMQ_BYTES_MESSAGE            = 24;
-    byte  ACTIVEMQ_MAP_MESSAGE              = 25;
-    byte  ACTIVEMQ_OBJECT_MESSAGE           = 26;
-    byte  ACTIVEMQ_STREAM_MESSAGE           = 27;
-    byte  ACTIVEMQ_TEXT_MESSAGE             = 28;
-    byte  ACTIVEMQ_BLOB_MESSAGE             = 29;
+    // /////////////////////////////////////////////////
+    byte PRODUCER_ACK = 19;
+    byte MESSAGE_PULL = 20;
+    byte MESSAGE_DISPATCH = 21;
+    byte MESSAGE_ACK = 22;
+
+    byte ACTIVEMQ_MESSAGE = 23;
+    byte ACTIVEMQ_BYTES_MESSAGE = 24;
+    byte ACTIVEMQ_MAP_MESSAGE = 25;
+    byte ACTIVEMQ_OBJECT_MESSAGE = 26;
+    byte ACTIVEMQ_STREAM_MESSAGE = 27;
+    byte ACTIVEMQ_TEXT_MESSAGE = 28;
+    byte ACTIVEMQ_BLOB_MESSAGE = 29;
 
-    ///////////////////////////////////////////////////
+    // /////////////////////////////////////////////////
     //
     // Command Response messages
     //
-    ///////////////////////////////////////////////////    
-    byte  RESPONSE                          = 30;
-    byte  EXCEPTION_RESPONSE                = 31;
-    byte  DATA_RESPONSE                     = 32;
-    byte  DATA_ARRAY_RESPONSE               = 33;
-    byte  INTEGER_RESPONSE                  = 34;
-
+    // /////////////////////////////////////////////////
+    byte RESPONSE = 30;
+    byte EXCEPTION_RESPONSE = 31;
+    byte DATA_RESPONSE = 32;
+    byte DATA_ARRAY_RESPONSE = 33;
+    byte INTEGER_RESPONSE = 34;
 
-    ///////////////////////////////////////////////////
+    // /////////////////////////////////////////////////
     //
     // Used by discovery
     //
-    ///////////////////////////////////////////////////    
-    byte  DISCOVERY_EVENT                   = 40;
-    
-    ///////////////////////////////////////////////////
+    // /////////////////////////////////////////////////
+    byte DISCOVERY_EVENT = 40;
+
+    // /////////////////////////////////////////////////
     //
     // Command object used by the Journal
     //
-    ///////////////////////////////////////////////////    
-    byte  JOURNAL_ACK                       = 50;
-    byte  JOURNAL_REMOVE                    = 52;
-    byte  JOURNAL_TRACE                     = 53;
-    byte  JOURNAL_TRANSACTION               = 54;
-    byte  DURABLE_SUBSCRIPTION_INFO         = 55;
-
+    // /////////////////////////////////////////////////
+    byte JOURNAL_ACK = 50;
+    byte JOURNAL_REMOVE = 52;
+    byte JOURNAL_TRACE = 53;
+    byte JOURNAL_TRANSACTION = 54;
+    byte DURABLE_SUBSCRIPTION_INFO = 55;
 
-    ///////////////////////////////////////////////////
+    // /////////////////////////////////////////////////
     //
     // Reliability and fragmentation
     //
-    ///////////////////////////////////////////////////    
-    byte  PARTIAL_COMMAND                   = 60;
-    byte  PARTIAL_LAST_COMMAND              = 61;
-    
-    byte  REPLAY                            = 65;
+    // /////////////////////////////////////////////////
+    byte PARTIAL_COMMAND = 60;
+    byte PARTIAL_LAST_COMMAND = 61;
 
+    byte REPLAY = 65;
 
-
-    
-    ///////////////////////////////////////////////////
+    // /////////////////////////////////////////////////
     //
     // Types used represent basic Java types.
     //
-    ///////////////////////////////////////////////////    
-    byte  BYTE_TYPE                         = 70;
-    byte  CHAR_TYPE                         = 71;
-    byte  SHORT_TYPE                        = 72;
-    byte  INTEGER_TYPE                      = 73;
-    byte  LONG_TYPE                         = 74;
-    byte  DOUBLE_TYPE                       = 75;
-    byte  FLOAT_TYPE                        = 76;
-    byte  STRING_TYPE                       = 77;
-    byte  BOOLEAN_TYPE                      = 78;
-    byte  BYTE_ARRAY_TYPE                   = 79;
-    
-   
-    
-   
-    
-    
-    ///////////////////////////////////////////////////
+    // /////////////////////////////////////////////////
+    byte BYTE_TYPE = 70;
+    byte CHAR_TYPE = 71;
+    byte SHORT_TYPE = 72;
+    byte INTEGER_TYPE = 73;
+    byte LONG_TYPE = 74;
+    byte DOUBLE_TYPE = 75;
+    byte FLOAT_TYPE = 76;
+    byte STRING_TYPE = 77;
+    byte BOOLEAN_TYPE = 78;
+    byte BYTE_ARRAY_TYPE = 79;
+
+    // /////////////////////////////////////////////////
     //
     // Broker to Broker command objects
     //
-    /////////////////////////////////////////////////// 
-    
-    byte  MESSAGE_DISPATCH_NOTIFICATION     = 90;
-    byte  NETWORK_BRIDGE_FILTER             = 91;
-    
-    
-    ///////////////////////////////////////////////////
+    // /////////////////////////////////////////////////
+
+    byte MESSAGE_DISPATCH_NOTIFICATION = 90;
+    byte NETWORK_BRIDGE_FILTER = 91;
+
+    // /////////////////////////////////////////////////
     //
     // Data structures contained in the command objects.
     //
-    ///////////////////////////////////////////////////    
-    byte  ACTIVEMQ_QUEUE                    = 100;
-    byte  ACTIVEMQ_TOPIC                    = 101;
-    byte  ACTIVEMQ_TEMP_QUEUE               = 102;
-    byte  ACTIVEMQ_TEMP_TOPIC               = 103;
-    
-    byte  MESSAGE_ID                        = 110;
-    byte  ACTIVEMQ_LOCAL_TRANSACTION_ID     = 111;
-    byte  ACTIVEMQ_XA_TRANSACTION_ID        = 112;
-
-    byte  CONNECTION_ID                     = 120;
-    byte  SESSION_ID                        = 121;
-    byte  CONSUMER_ID                       = 122;
-    byte  PRODUCER_ID                       = 123;
-    byte  BROKER_ID                         = 124;
-    
-    
-    
-   
-   
-
+    // /////////////////////////////////////////////////
+    byte ACTIVEMQ_QUEUE = 100;
+    byte ACTIVEMQ_TOPIC = 101;
+    byte ACTIVEMQ_TEMP_QUEUE = 102;
+    byte ACTIVEMQ_TEMP_TOPIC = 103;
+
+    byte MESSAGE_ID = 110;
+    byte ACTIVEMQ_LOCAL_TRANSACTION_ID = 111;
+    byte ACTIVEMQ_XA_TRANSACTION_ID = 112;
+
+    byte CONNECTION_ID = 120;
+    byte SESSION_ID = 121;
+    byte CONSUMER_ID = 122;
+    byte PRODUCER_ID = 123;
+    byte BROKER_ID = 124;
 
 }

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/command/Endpoint.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/command/Endpoint.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/command/Endpoint.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/command/Endpoint.java Thu Aug  9 09:37:49 2007
@@ -30,20 +30,20 @@
     /**
      * Returns the name of the endpoint.
      */
-    public String getName();
+    String getName();
 
     /**
      * Returns the broker ID for this endpoint, if the endpoint is a broker or
      * null
      */
-    public BrokerId getBrokerId();
+    BrokerId getBrokerId();
 
     /**
      * Returns the broker information for this endpoint, if the endpoint is a
      * broker or null
      */
-    public BrokerInfo getBrokerInfo();
+    BrokerInfo getBrokerInfo();
 
-    public void setBrokerInfo(BrokerInfo brokerInfo);
+    void setBrokerInfo(BrokerInfo brokerInfo);
 
 }

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/command/MarshallAware.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/command/MarshallAware.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/command/MarshallAware.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/command/MarshallAware.java Thu Aug  9 09:37:49 2007
@@ -22,10 +22,12 @@
 
 public interface MarshallAware {
 
-    public void beforeMarshall(WireFormat wireFormat) throws IOException;
-    public void afterMarshall(WireFormat wireFormat) throws IOException;
-    
-    public void beforeUnmarshall(WireFormat wireFormat) throws IOException;
-    public void afterUnmarshall(WireFormat wireFormat) throws IOException;
-    
+    void beforeMarshall(WireFormat wireFormat) throws IOException;
+
+    void afterMarshall(WireFormat wireFormat) throws IOException;
+
+    void beforeUnmarshall(WireFormat wireFormat) throws IOException;
+
+    void afterUnmarshall(WireFormat wireFormat) throws IOException;
+
 }

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/command/Message.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/command/Message.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/command/Message.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/command/Message.java Thu Aug  9 09:37:49 2007
@@ -38,7 +38,7 @@
  * @openwire:marshaller
  * @version $Revision$
  */
-abstract public class Message extends BaseCommand implements MarshallAware, MessageReference {
+public abstract class Message extends BaseCommand implements MarshallAware, MessageReference {
 
     public static final int AVERAGE_MESSAGE_SIZE_OVERHEAD = 500;
 
@@ -85,7 +85,7 @@
     protected boolean droppable;
     private BrokerId[] cluster;
 
-    abstract public Message copy();
+    public abstract Message copy();
 
     protected void copy(Message copy) {
         super.copy(copy);
@@ -108,10 +108,11 @@
         copy.userID = userID;
         copy.groupSequence = groupSequence;
 
-        if (properties != null)
+        if (properties != null) {
             copy.properties = new HashMap(properties);
-        else
+        } else {
             copy.properties = properties;
+        }
 
         copy.content = content;
         copy.marshalledProperties = marshalledProperties;
@@ -585,7 +586,7 @@
         return rc;
     }
 
-    synchronized public int decrementReferenceCount() {
+    public synchronized int decrementReferenceCount() {
         int rc;
         int size;
         synchronized (this) {

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/command/MessageDispatch.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/command/MessageDispatch.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/command/MessageDispatch.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/command/MessageDispatch.java Thu Aug  9 09:37:49 2007
@@ -32,9 +32,9 @@
     protected Message message;
     protected int redeliveryCounter;
 
-    transient protected long deliverySequenceId;
-    transient protected Object consumer;
-    transient protected Runnable transmitCallback;
+    protected transient long deliverySequenceId;
+    protected transient Object consumer;
+    protected transient Runnable transmitCallback;
 
     public byte getDataStructureType() {
         return DATA_STRUCTURE_TYPE;

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/command/MessageId.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/command/MessageId.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/command/MessageId.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/command/MessageId.java Thu Aug  9 09:37:49 2007
@@ -28,8 +28,8 @@
     protected long producerSequenceId;
     protected long brokerSequenceId;
 
-    transient private String key;
-    transient private int hashCode;
+    private transient String key;
+    private transient int hashCode;
 
     public MessageId() {
         this.producerId = new ProducerId();

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/command/NetworkBridgeFilter.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/command/NetworkBridgeFilter.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/command/NetworkBridgeFilter.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/command/NetworkBridgeFilter.java Thu Aug  9 09:37:49 2007
@@ -32,8 +32,8 @@
  */
 public class NetworkBridgeFilter implements DataStructure, BooleanExpression {
 
-    static final Log log = LogFactory.getLog(NetworkBridgeFilter.class);
     public static final byte DATA_STRUCTURE_TYPE = CommandTypes.NETWORK_BRIDGE_FILTER;
+    static final Log LOG = LogFactory.getLog(NetworkBridgeFilter.class);
 
     private BrokerId networkBrokerId;
     private int networkTTL;
@@ -74,8 +74,8 @@
     protected boolean matchesForwardingFilter(Message message) {
 
         if (contains(message.getBrokerPath(), networkBrokerId)) {
-            if (log.isTraceEnabled()) {
-                log.trace("Message all ready routed once through this broker - ignoring: " + message);
+            if (LOG.isTraceEnabled()) {
+                LOG.trace("Message all ready routed once through this broker - ignoring: " + message);
             }
             return false;
         }
@@ -83,8 +83,8 @@
         int hops = message.getBrokerPath() == null ? 0 : message.getBrokerPath().length;
 
         if (hops >= networkTTL) {
-            if (log.isTraceEnabled()) {
-                log.trace("Message restricted to " + networkTTL + " network hops ignoring: " + message);
+            if (LOG.isTraceEnabled()) {
+                LOG.trace("Message restricted to " + networkTTL + " network hops ignoring: " + message);
             }
             return false;
         }
@@ -94,8 +94,8 @@
             ConsumerInfo info = (ConsumerInfo)message.getDataStructure();
             hops = info.getBrokerPath() == null ? 0 : info.getBrokerPath().length;
             if (hops >= networkTTL) {
-                if (log.isTraceEnabled()) {
-                    log.trace("ConsumerInfo advisory restricted to " + networkTTL + " network hops ignoring: " + message);
+                if (LOG.isTraceEnabled()) {
+                    LOG.trace("ConsumerInfo advisory restricted to " + networkTTL + " network hops ignoring: " + message);
                 }
                 return false;
             }

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/command/TransactionId.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/command/TransactionId.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/command/TransactionId.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/command/TransactionId.java Thu Aug  9 09:37:49 2007
@@ -20,11 +20,11 @@
  * @openwire:marshaller
  * @version $Revision: 1.6 $
  */
-abstract public class TransactionId implements DataStructure {
+public abstract class TransactionId implements DataStructure {
 
-    abstract public boolean isXATransaction();
-    abstract public boolean isLocalTransaction();
-    abstract public String getTransactionKey();
+    public abstract boolean isXATransaction();
+    public abstract boolean isLocalTransaction();
+    public abstract String getTransactionKey();
 
     public boolean isMarshallAware() {
         return false;

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/command/WireFormatInfo.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/command/WireFormatInfo.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/command/WireFormatInfo.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/command/WireFormatInfo.java Thu Aug  9 09:37:49 2007
@@ -40,7 +40,7 @@
 
     private static final int MAX_PROPERTY_SIZE = 1024 * 4;
     public static final byte DATA_STRUCTURE_TYPE = CommandTypes.WIREFORMAT_INFO;
-    static final private byte MAGIC[] = new byte[] {'A', 'c', 't', 'i', 'v', 'e', 'M', 'Q'};
+    private static final byte MAGIC[] = new byte[] {'A', 'c', 't', 'i', 'v', 'e', 'M', 'Q'};
 
     protected byte magic[] = MAGIC;
     protected int version;

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/filter/ArithmeticExpression.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/filter/ArithmeticExpression.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/filter/ArithmeticExpression.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/filter/ArithmeticExpression.java Thu Aug  9 09:37:49 2007
@@ -199,6 +199,6 @@
      * @param rvalue
      * @return
      */
-    abstract protected Object evaluate(Object lvalue, Object rvalue);
+    protected abstract Object evaluate(Object lvalue, Object rvalue);
 
 }

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/filter/BinaryExpression.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/filter/BinaryExpression.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/filter/BinaryExpression.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/filter/BinaryExpression.java Thu Aug  9 09:37:49 2007
@@ -23,7 +23,7 @@
  * 
  * @version $Revision: 1.2 $
  */
-abstract public class BinaryExpression implements Expression {
+public abstract class BinaryExpression implements Expression {
     protected Expression left;
     protected Expression right;
 
@@ -77,7 +77,7 @@
      *
      * @return
      */
-    abstract public String getExpressionSymbol();
+    public abstract String getExpressionSymbol();
 
     /**
      * @param expression

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/filter/BooleanExpression.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/filter/BooleanExpression.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/filter/BooleanExpression.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/filter/BooleanExpression.java Thu Aug  9 09:37:49 2007
@@ -32,6 +32,6 @@
      * @return true if the expression evaluates to Boolean.TRUE.
      * @throws JMSException
      */
-    public boolean matches(MessageEvaluationContext message) throws JMSException;
+    boolean matches(MessageEvaluationContext message) throws JMSException;
 
 }

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/filter/ComparisonExpression.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/filter/ComparisonExpression.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/filter/ComparisonExpression.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/filter/ComparisonExpression.java Thu Aug  9 09:37:49 2007
@@ -38,7 +38,7 @@
         return LogicExpression.createOR(createLessThan(value, left), createGreaterThan(value, right));
     }
 
-    static final private HashSet REGEXP_CONTROL_CHARS = new HashSet();
+    private static final HashSet REGEXP_CONTROL_CHARS = new HashSet();
 
     static {
         REGEXP_CONTROL_CHARS.add(Character.valueOf('.'));
@@ -415,8 +415,9 @@
                 } else {
                     return Boolean.FALSE;
                 }
-            } else
+            } else {
                 return Boolean.FALSE;
+            }
         }
         return asBoolean(lv.compareTo(rv)) ? Boolean.TRUE : Boolean.FALSE;
     }

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/filter/Expression.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/filter/Expression.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/filter/Expression.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/filter/Expression.java Thu Aug  9 09:37:49 2007
@@ -30,6 +30,6 @@
     /**
      * @return the value of this expression
      */
-    public Object evaluate(MessageEvaluationContext message) throws JMSException;
+    Object evaluate(MessageEvaluationContext message) throws JMSException;
     
 }

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/filter/LogicExpression.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/filter/LogicExpression.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/filter/LogicExpression.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/filter/LogicExpression.java Thu Aug  9 09:37:49 2007
@@ -78,7 +78,7 @@
         super(left, right);
     }
 
-    abstract public Object evaluate(MessageEvaluationContext message) throws JMSException;
+    public abstract Object evaluate(MessageEvaluationContext message) throws JMSException;
 
     public boolean matches(MessageEvaluationContext message) throws JMSException {
         Object object = evaluate(message);

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/filter/MultiExpressionEvaluator.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/filter/MultiExpressionEvaluator.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/filter/MultiExpressionEvaluator.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/filter/MultiExpressionEvaluator.java Thu Aug  9 09:37:49 2007
@@ -133,7 +133,7 @@
      * implement this interface.
      */
     static interface ExpressionListener {
-        public void evaluateResultEvent(Expression selector, MessageEvaluationContext message, Object result);
+        void evaluateResultEvent(Expression selector, MessageEvaluationContext message, Object result);
     }
 
     /**

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/filter/PropertyExpression.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/filter/PropertyExpression.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/filter/PropertyExpression.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/filter/PropertyExpression.java Thu Aug  9 09:37:49 2007
@@ -36,10 +36,10 @@
 public class PropertyExpression implements Expression {
 
     interface SubExpression {
-        public Object evaluate(Message message);
+        Object evaluate(Message message);
     }
 
-    static final private HashMap JMS_PROPERTY_EXPRESSIONS = new HashMap();
+    private static final HashMap JMS_PROPERTY_EXPRESSIONS = new HashMap();
     static {
         JMS_PROPERTY_EXPRESSIONS.put("JMSDestination", new SubExpression() {
 

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/filter/UnaryExpression.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/filter/UnaryExpression.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/filter/UnaryExpression.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/filter/UnaryExpression.java Thu Aug  9 09:37:49 2007
@@ -107,10 +107,11 @@
             }
 
             public String getExpressionSymbol() {
-                if (not)
+                if (not) {
                     return "NOT IN";
-                else
+                } else {
                     return "IN";
+                }
             }
         };
     }
@@ -249,6 +250,6 @@
      * 
      * @return
      */
-    abstract public String getExpressionSymbol();
+    public abstract String getExpressionSymbol();
 
 }

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/filter/XPathExpression.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/filter/XPathExpression.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/filter/XPathExpression.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/filter/XPathExpression.java Thu Aug  9 09:37:49 2007
@@ -32,7 +32,7 @@
  */
 public final class XPathExpression implements BooleanExpression {
 
-    private static final Log log = LogFactory.getLog(XPathExpression.class);
+    private static final Log LOG = LogFactory.getLog(XPathExpression.class);
     private static final String EVALUATOR_SYSTEM_PROPERTY = "org.apache.activemq.XPathEvaluatorClassName";
     private static final String DEFAULT_EVALUATOR_CLASS_NAME = XalanXPathEvaluator.class.getName();
 
@@ -45,13 +45,13 @@
             try {
                 m = getXPathEvaluatorConstructor(cn);
             } catch (Throwable e) {
-                log.warn("Invalid " + XPathEvaluator.class.getName() + " implementation: " + cn
+                LOG.warn("Invalid " + XPathEvaluator.class.getName() + " implementation: " + cn
                          + ", reason: " + e, e);
                 cn = DEFAULT_EVALUATOR_CLASS_NAME;
                 try {
                     m = getXPathEvaluatorConstructor(cn);
                 } catch (Throwable e2) {
-                    log.error("Default XPath evaluator could not be loaded", e);
+                    LOG.error("Default XPath evaluator could not be loaded", e);
                 }
             }
         } finally {
@@ -71,8 +71,8 @@
     private final String xpath;
     private final XPathEvaluator evaluator;
 
-    static public interface XPathEvaluator {
-        public boolean evaluate(Message message) throws JMSException;
+    public static interface XPathEvaluator {
+        boolean evaluate(Message message) throws JMSException;
     }
 
     XPathExpression(String xpath) {

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/jndi/ActiveMQInitialContextFactory.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/jndi/ActiveMQInitialContextFactory.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/jndi/ActiveMQInitialContextFactory.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/jndi/ActiveMQInitialContextFactory.java Thu Aug  9 09:37:49 2007
@@ -47,9 +47,7 @@
  */
 public class ActiveMQInitialContextFactory implements InitialContextFactory {
 
-    private static final String[] defaultConnectionFactoryNames = {"ConnectionFactory",
-                                                                   "QueueConnectionFactory",
-                                                                   "TopicConnectionFactory"};
+    private static final String[] DEFAULT_CONNECTION_FACTORY_NAMES = {"ConnectionFactory", "QueueConnectionFactory", "TopicConnectionFactory"};
 
     private String connectionPrefix = "connection.";
     private String queuePrefix = "queue.";
@@ -126,8 +124,7 @@
         return new ReadOnlyContext(environment, data);
     }
 
-    protected ActiveMQConnectionFactory createConnectionFactory(String name, Hashtable environment)
-        throws URISyntaxException {
+    protected ActiveMQConnectionFactory createConnectionFactory(String name, Hashtable environment) throws URISyntaxException {
         Hashtable temp = new Hashtable(environment);
         String prefix = connectionPrefix + name + ".";
         for (Iterator iter = environment.entrySet().iterator(); iter.hasNext();) {
@@ -147,8 +144,7 @@
         String factoryNames = (String)environment.get("connectionFactoryNames");
         if (factoryNames != null) {
             List list = new ArrayList();
-            for (StringTokenizer enumeration = new StringTokenizer(factoryNames, ","); enumeration
-                .hasMoreTokens();) {
+            for (StringTokenizer enumeration = new StringTokenizer(factoryNames, ","); enumeration.hasMoreTokens();) {
                 list.add(enumeration.nextToken().trim());
             }
             int size = list.size();
@@ -158,7 +154,7 @@
                 return answer;
             }
         }
-        return defaultConnectionFactoryNames;
+        return DEFAULT_CONNECTION_FACTORY_NAMES;
     }
 
     protected void createQueues(Map data, Hashtable environment) {
@@ -201,8 +197,7 @@
      * Factory method to create a new connection factory from the given
      * environment
      */
-    protected ActiveMQConnectionFactory createConnectionFactory(Hashtable environment)
-        throws URISyntaxException {
+    protected ActiveMQConnectionFactory createConnectionFactory(Hashtable environment) throws URISyntaxException {
         ActiveMQConnectionFactory answer = new ActiveMQConnectionFactory();
         Properties properties = new Properties();
         properties.putAll(environment);

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/jndi/JNDIStorableInterface.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/jndi/JNDIStorableInterface.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/jndi/JNDIStorableInterface.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/jndi/JNDIStorableInterface.java Thu Aug  9 09:37:49 2007
@@ -32,7 +32,7 @@
      * @param properties
      */
 
-    public void setProperties(Properties properties);
+    void setProperties(Properties properties);
 
     /**
      * Get the properties from this instance for storing in JNDI
@@ -40,6 +40,6 @@
      * @return
      */
 
-    public Properties getProperties();
+    Properties getProperties();
 
 }

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/jndi/ReadOnlyContext.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/jndi/ReadOnlyContext.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/jndi/ReadOnlyContext.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/jndi/ReadOnlyContext.java Thu Aug  9 09:37:49 2007
@@ -60,9 +60,10 @@
  * @version $Revision: 1.2 $ $Date: 2005/08/27 03:52:39 $
  */
 public class ReadOnlyContext implements Context, Serializable {
-    private static final long serialVersionUID = -5754338187296859149L;
-    protected static final NameParser nameParser = new NameParserImpl();
+
     public static final String SEPARATOR = "/";
+    protected static final NameParser NAME_PARSER = new NameParserImpl();
+    private static final long serialVersionUID = -5754338187296859149L;
 
     protected final Hashtable environment; // environment for this context
     protected final Map bindings; // bindings at my level
@@ -339,11 +340,11 @@
     }
 
     public NameParser getNameParser(Name name) throws NamingException {
-        return nameParser;
+        return NAME_PARSER;
     }
 
     public NameParser getNameParser(String name) throws NamingException {
-        return nameParser;
+        return NAME_PARSER;
     }
 
     public void rebind(Name name, Object obj) throws NamingException {

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/kaha/ListContainer.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/kaha/ListContainer.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/kaha/ListContainer.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/kaha/ListContainer.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.kaha;
 
 import java.util.List;
@@ -30,18 +32,18 @@
      * populates the container will all the indexes used etc and should be
      * called before any operations on the container
      */
-    public void load();
+    void load();
 
     /**
      * unload indexes from the container
      * 
      */
-    public void unload();
+    void unload();
 
     /**
      * @return true if the indexes are loaded
      */
-    public boolean isLoaded();
+    boolean isLoaded();
 
     /**
      * For homogenous containers can set a custom marshaller for loading values
@@ -49,24 +51,24 @@
      * 
      * @param marshaller
      */
-    public void setMarshaller(Marshaller marshaller);
+    void setMarshaller(Marshaller marshaller);
 
     /**
      * @return the id the MapContainer was create with
      */
-    public Object getId();
+    Object getId();
 
     /**
      * @return the number of values in the container
      */
-    public int size();
+    int size();
 
     /**
      * Inserts the given element at the beginning of this list.
      * 
      * @param o the element to be inserted at the beginning of this list.
      */
-    public void addFirst(V o);
+    void addFirst(V o);
 
     /**
      * Appends the given element to the end of this list. (Identical in function
@@ -74,7 +76,7 @@
      * 
      * @param o the element to be inserted at the end of this list.
      */
-    public void addLast(V o);
+    void addLast(V o);
 
     /**
      * Removes and returns the first element from this list.
@@ -82,7 +84,7 @@
      * @return the first element from this list.
      * @throws NoSuchElementException if this list is empty.
      */
-    public V removeFirst();
+    V removeFirst();
 
     /**
      * Removes and returns the last element from this list.
@@ -90,7 +92,7 @@
      * @return the last element from this list.
      * @throws NoSuchElementException if this list is empty.
      */
-    public V removeLast();
+    V removeLast();
 
     /**
      * remove an objecr from the list without retrieving the old value from the
@@ -99,7 +101,7 @@
      * @param position
      * @return true if successful
      */
-    public boolean doRemove(int position);
+    boolean doRemove(int position);
 
     /**
      * add an Object to the list but get a StoreEntry of its position
@@ -107,7 +109,7 @@
      * @param object
      * @return the entry in the Store
      */
-    public StoreEntry placeLast(V object);
+    StoreEntry placeLast(V object);
 
     /**
      * insert an Object in first position int the list but get a StoreEntry of
@@ -116,7 +118,7 @@
      * @param object
      * @return the location in the Store
      */
-    public StoreEntry placeFirst(V object);
+    StoreEntry placeFirst(V object);
 
     /**
      * Advanced feature = must ensure the object written doesn't overwrite other
@@ -125,7 +127,7 @@
      * @param entry
      * @param object
      */
-    public void update(StoreEntry entry, V object);
+    void update(StoreEntry entry, V object);
 
     /**
      * Retrieve an Object from the Store by its location
@@ -133,21 +135,21 @@
      * @param entry
      * @return the Object at that entry
      */
-    public V get(StoreEntry entry);
+    V get(StoreEntry entry);
 
     /**
      * Get the StoreEntry for the first item of the list
      * 
      * @return the first StoreEntry or null if the list is empty
      */
-    public StoreEntry getFirst();
+    StoreEntry getFirst();
 
     /**
      * Get the StoreEntry for the last item of the list
      * 
      * @return the last StoreEntry or null if the list is empty
      */
-    public StoreEntry getLast();
+    StoreEntry getLast();
 
     /**
      * Get the next StoreEntry from the list
@@ -155,7 +157,7 @@
      * @param entry
      * @return the next StoreEntry or null
      */
-    public StoreEntry getNext(StoreEntry entry);
+    StoreEntry getNext(StoreEntry entry);
 
     /**
      * Get the previous StoreEntry from the list
@@ -163,7 +165,7 @@
      * @param entry
      * @return the previous store entry or null
      */
-    public StoreEntry getPrevious(StoreEntry entry);
+    StoreEntry getPrevious(StoreEntry entry);
 
     /**
      * remove the Object at the StoreEntry
@@ -171,7 +173,7 @@
      * @param entry
      * @return true if successful
      */
-    public boolean remove(StoreEntry entry);
+    boolean remove(StoreEntry entry);
 
     /**
      * It's possible that a StoreEntry could be come stale this will return an
@@ -180,5 +182,5 @@
      * @param entry old entry
      * @return a refreshed StoreEntry
      */
-    public StoreEntry refresh(StoreEntry entry);
+    StoreEntry refresh(StoreEntry entry);
 }

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/kaha/MapContainer.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/kaha/MapContainer.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/kaha/MapContainer.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/kaha/MapContainer.java Thu Aug  9 09:37:49 2007
@@ -33,18 +33,18 @@
      * populates the container will all the indexes used etc and should be
      * called before any operations on the container
      */
-    public void load();
+    void load();
 
     /**
      * unload indexes from the container
      * 
      */
-    public void unload();
+    void unload();
 
     /**
      * @return true if the indexes are loaded
      */
-    public boolean isLoaded();
+    boolean isLoaded();
 
     /**
      * For homogenous containers can set a custom marshaller for loading keys
@@ -52,7 +52,7 @@
      * 
      * @param keyMarshaller
      */
-    public void setKeyMarshaller(Marshaller<K> keyMarshaller);
+    void setKeyMarshaller(Marshaller<K> keyMarshaller);
 
     /**
      * For homogenous containers can set a custom marshaller for loading values
@@ -61,28 +61,28 @@
      * @param valueMarshaller
      * 
      */
-    public void setValueMarshaller(Marshaller<V> valueMarshaller);
+    void setValueMarshaller(Marshaller<V> valueMarshaller);
 
     /**
      * @return the id the MapContainer was create with
      */
-    public Object getId();
+    Object getId();
 
     /**
      * @return the number of values in the container
      */
-    public int size();
+    int size();
 
     /**
      * @return true if there are no values stored in the container
      */
-    public boolean isEmpty();
+    boolean isEmpty();
 
     /**
      * @param key
      * @return true if the container contains the key
      */
-    public boolean containsKey(K key);
+    boolean containsKey(K key);
 
     /**
      * Get the value associated with the key
@@ -90,37 +90,37 @@
      * @param key
      * @return the value associated with the key from the store
      */
-    public V get(K key);
+    V get(K key);
 
     /**
      * @param o
      * @return true if the MapContainer contains the value o
      */
-    public boolean containsValue(K o);
+    boolean containsValue(K o);
 
     /**
      * Add add entries in the supplied Map
      * 
      * @param map
      */
-    public void putAll(Map<K, V> map);
+    void putAll(Map<K, V> map);
 
     /**
      * @return a Set of all the keys
      */
-    public Set<K> keySet();
+    Set<K> keySet();
 
     /**
      * @return a collection of all the values - the values will be lazily pulled
      *         out of the store if iterated etc.
      */
-    public Collection<V> values();
+    Collection<V> values();
 
     /**
      * @return a Set of all the Map.Entry instances - the values will be lazily
      *         pulled out of the store if iterated etc.
      */
-    public Set<Map.Entry<K, V>> entrySet();
+    Set<Map.Entry<K, V>> entrySet();
 
     /**
      * Add an entry
@@ -129,7 +129,7 @@
      * @param value
      * @return the old value for the key
      */
-    public V put(K key, V value);
+    V put(K key, V value);
 
     /**
      * remove an entry associated with the key
@@ -137,12 +137,12 @@
      * @param key
      * @return the old value assocaited with the key or null
      */
-    public V remove(K key);
+    V remove(K key);
 
     /**
      * empty the container
      */
-    public void clear();
+    void clear();
 
     /**
      * Add an entry to the Store Map
@@ -151,14 +151,14 @@
      * @param Value
      * @return the StoreEntry associated with the entry
      */
-    public StoreEntry place(K key, V Value);
+    StoreEntry place(K key, V value);
 
     /**
      * Remove an Entry from ther Map
      * 
      * @param entry
      */
-    public void remove(StoreEntry entry);
+    void remove(StoreEntry entry);
 
     /**
      * Get the Key object from it's location
@@ -166,7 +166,7 @@
      * @param keyLocation
      * @return the key for the entry
      */
-    public K getKey(StoreEntry keyLocation);
+    K getKey(StoreEntry keyLocation);
 
     /**
      * Get the value from it's location
@@ -174,21 +174,21 @@
      * @param Valuelocation
      * @return the Object
      */
-    public V getValue(StoreEntry Valuelocation);
+    V getValue(StoreEntry valueLocation);
 
     /**
      * Get the StoreEntry for the first value in the Map
      * 
      * @return the first StoreEntry or null if the map is empty
      */
-    public StoreEntry getFirst();
+    StoreEntry getFirst();
 
     /**
      * Get the StoreEntry for the last value item of the Map
      * 
      * @return the last StoreEntry or null if the list is empty
      */
-    public StoreEntry getLast();
+    StoreEntry getLast();
 
     /**
      * Get the next StoreEntry value from the map
@@ -196,7 +196,7 @@
      * @param entry
      * @return the next StoreEntry or null
      */
-    public StoreEntry getNext(StoreEntry entry);
+    StoreEntry getNext(StoreEntry entry);
 
     /**
      * Get the previous StoreEntry from the map
@@ -204,7 +204,7 @@
      * @param entry
      * @return the previous store entry or null
      */
-    public StoreEntry getPrevious(StoreEntry entry);
+    StoreEntry getPrevious(StoreEntry entry);
 
     /**
      * It's possible that a StoreEntry could be come stale this will return an
@@ -213,7 +213,7 @@
      * @param entry old entry
      * @return a refreshed StoreEntry
      */
-    public StoreEntry refresh(StoreEntry entry);
+    StoreEntry refresh(StoreEntry entry);
 
     /**
      * Get the StoreEntry associated with the key
@@ -221,5 +221,5 @@
      * @param key
      * @return the StoreEntry
      */
-    public StoreEntry getEntry(K key);
+    StoreEntry getEntry(K key);
 }

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/kaha/Marshaller.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/kaha/Marshaller.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/kaha/Marshaller.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/kaha/Marshaller.java Thu Aug  9 09:37:49 2007
@@ -34,7 +34,7 @@
      * @param dataOut
      * @throws IOException
      */
-    public void writePayload(T object, DataOutput dataOut) throws IOException;
+    void writePayload(T object, DataOutput dataOut) throws IOException;
     
     
     /**
@@ -43,7 +43,7 @@
      * @return unmarshalled object
      * @throws IOException
      */
-    public T readPayload(DataInput dataIn) throws IOException;
+    T readPayload(DataInput dataIn) throws IOException;
 
    
 }

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

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/kaha/Store.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/kaha/Store.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/kaha/Store.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/kaha/Store.java Thu Aug  9 09:37:49 2007
@@ -28,48 +28,48 @@
     /**
      * Defauly container name
      */
-    public static final String DEFAULT_CONTAINER_NAME = "kaha";
+    String DEFAULT_CONTAINER_NAME = "kaha";
 
     /**
      * Byte Marshaller
      */
-    public final static Marshaller BytesMarshaller = new BytesMarshaller();
+    Marshaller BYTES_MARSHALLER = new BytesMarshaller();
 
     /**
      * Object Marshaller
      */
-    public final static Marshaller ObjectMarshaller = new ObjectMarshaller();
+    Marshaller OBJECT_MARSHALLER = new ObjectMarshaller();
 
     /**
      * String Marshaller
      */
-    public final static Marshaller StringMarshaller = new StringMarshaller();
+    Marshaller STRING_MARSHALLER = new StringMarshaller();
 
     /**
      * Command Marshaller
      */
-    public final static Marshaller CommandMarshaller = new CommandMarshaller();
+    Marshaller COMMAND_MARSHALLER = new CommandMarshaller();
 
     /**
      * close the store
      * 
      * @throws IOException
      */
-    public void close() throws IOException;
+    void close() throws IOException;
 
     /**
      * Force all writes to disk
      * 
      * @throws IOException
      */
-    public void force() throws IOException;
+    void force() throws IOException;
 
     /**
      * empty all the contents of the store
      * 
      * @throws IOException
      */
-    public void clear() throws IOException;
+    void clear() throws IOException;
 
     /**
      * delete the store
@@ -77,7 +77,7 @@
      * @return true if the delete was successful
      * @throws IOException
      */
-    public boolean delete() throws IOException;
+    boolean delete() throws IOException;
 
     /**
      * Checks if a MapContainer exists in the default container
@@ -86,7 +86,7 @@
      * @return new MapContainer
      * @throws IOException
      */
-    public boolean doesMapContainerExist(Object id) throws IOException;
+    boolean doesMapContainerExist(Object id) throws IOException;
 
     /**
      * Checks if a MapContainer exists in the named container
@@ -96,7 +96,7 @@
      * @return new MapContainer
      * @throws IOException
      */
-    public boolean doesMapContainerExist(Object id, String containerName) throws IOException;
+    boolean doesMapContainerExist(Object id, String containerName) throws IOException;
 
     /**
      * Get a MapContainer with the given id - the MapContainer is created if
@@ -106,7 +106,7 @@
      * @return container for the associated id or null if it doesn't exist
      * @throws IOException
      */
-    public MapContainer getMapContainer(Object id) throws IOException;
+    MapContainer getMapContainer(Object id) throws IOException;
 
     /**
      * Get a MapContainer with the given id - the MapContainer is created if
@@ -117,7 +117,7 @@
      * @return container for the associated id or null if it doesn't exist
      * @throws IOException
      */
-    public MapContainer getMapContainer(Object id, String containerName) throws IOException;
+    MapContainer getMapContainer(Object id, String containerName) throws IOException;
 
     /**
      * Get a MapContainer with the given id - the MapContainer is created if
@@ -129,8 +129,7 @@
      * @return container for the associated id or null if it doesn't exist
      * @throws IOException
      */
-    public MapContainer getMapContainer(Object id, String containerName, boolean persistentIndex)
-        throws IOException;
+    MapContainer getMapContainer(Object id, String containerName, boolean persistentIndex) throws IOException;
 
     /**
      * delete a container from the default container
@@ -138,7 +137,7 @@
      * @param id
      * @throws IOException
      */
-    public void deleteMapContainer(Object id) throws IOException;
+    void deleteMapContainer(Object id) throws IOException;
 
     /**
      * delete a MapContainer from the name container
@@ -147,7 +146,7 @@
      * @param containerName
      * @throws IOException
      */
-    public void deleteMapContainer(Object id, String containerName) throws IOException;
+    void deleteMapContainer(Object id, String containerName) throws IOException;
 
     /**
      * Delete Map container
@@ -155,7 +154,7 @@
      * @param id
      * @throws IOException
      */
-    public void deleteMapContainer(ContainerId id) throws IOException;
+    void deleteMapContainer(ContainerId id) throws IOException;
 
     /**
      * Get a Set of call MapContainer Ids
@@ -163,7 +162,7 @@
      * @return the set of ids
      * @throws IOException
      */
-    public Set<ContainerId> getMapContainerIds() throws IOException;
+    Set<ContainerId> getMapContainerIds() throws IOException;
 
     /**
      * Checks if a ListContainer exists in the default container
@@ -172,7 +171,7 @@
      * @return new MapContainer
      * @throws IOException
      */
-    public boolean doesListContainerExist(Object id) throws IOException;
+    boolean doesListContainerExist(Object id) throws IOException;
 
     /**
      * Checks if a ListContainer exists in the named container
@@ -182,7 +181,7 @@
      * @return new MapContainer
      * @throws IOException
      */
-    public boolean doesListContainerExist(Object id, String containerName) throws IOException;
+    boolean doesListContainerExist(Object id, String containerName) throws IOException;
 
     /**
      * Get a ListContainer with the given id and creates it if it doesn't exist
@@ -191,7 +190,7 @@
      * @return container for the associated id or null if it doesn't exist
      * @throws IOException
      */
-    public ListContainer getListContainer(Object id) throws IOException;
+    ListContainer getListContainer(Object id) throws IOException;
 
     /**
      * Get a ListContainer with the given id and creates it if it doesn't exist
@@ -201,7 +200,7 @@
      * @return container for the associated id or null if it doesn't exist
      * @throws IOException
      */
-    public ListContainer getListContainer(Object id, String containerName) throws IOException;
+    ListContainer getListContainer(Object id, String containerName) throws IOException;
 
     /**
      * Get a ListContainer with the given id and creates it if it doesn't exist
@@ -212,8 +211,7 @@
      * @return container for the associated id or null if it doesn't exist
      * @throws IOException
      */
-    public ListContainer getListContainer(Object id, String containerName, boolean persistentIndex)
-        throws IOException;
+    ListContainer getListContainer(Object id, String containerName, boolean persistentIndex) throws IOException;
 
     /**
      * delete a ListContainer from the default container
@@ -221,7 +219,7 @@
      * @param id
      * @throws IOException
      */
-    public void deleteListContainer(Object id) throws IOException;
+    void deleteListContainer(Object id) throws IOException;
 
     /**
      * delete a ListContainer from the named container
@@ -230,7 +228,7 @@
      * @param containerName
      * @throws IOException
      */
-    public void deleteListContainer(Object id, String containerName) throws IOException;
+    void deleteListContainer(Object id, String containerName) throws IOException;
 
     /**
      * delete a list container
@@ -238,7 +236,7 @@
      * @param id
      * @throws IOException
      */
-    public void deleteListContainer(ContainerId id) throws IOException;
+    void deleteListContainer(ContainerId id) throws IOException;
 
     /**
      * Get a Set of call ListContainer Ids
@@ -246,23 +244,23 @@
      * @return the set of ids
      * @throws IOException
      */
-    public Set<ContainerId> getListContainerIds() throws IOException;
+    Set<ContainerId> getListContainerIds() throws IOException;
 
     /**
      * @return the maxDataFileLength
      */
-    public long getMaxDataFileLength();
+    long getMaxDataFileLength();
 
     /**
      * @param maxDataFileLength the maxDataFileLength to set
      */
-    public void setMaxDataFileLength(long maxDataFileLength);
+    void setMaxDataFileLength(long maxDataFileLength);
 
     /**
      * @see org.apache.activemq.kaha.IndexTypes
      * @return the default index type
      */
-    public String getIndexTypeAsString();
+    String getIndexTypeAsString();
 
     /**
      * Set the default index type
@@ -270,10 +268,10 @@
      * @param type
      * @see org.apache.activemq.kaha.IndexTypes
      */
-    public void setIndexTypeAsString(String type);
+    void setIndexTypeAsString(String type);
 
     /**
      * @return true if the store has been initialized
      */
-    public boolean isInitialized();
+    boolean isInitialized();
 }

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/kaha/StoreEntry.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/kaha/StoreEntry.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/kaha/StoreEntry.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/kaha/StoreEntry.java Thu Aug  9 09:37:49 2007
@@ -23,36 +23,36 @@
  */
 public interface StoreEntry {
 
-    public abstract StoreLocation getKeyDataItem();
+    StoreLocation getKeyDataItem();
 
-    public abstract StoreLocation getValueDataItem();
+    StoreLocation getValueDataItem();
 
     /**
      * @return next item
      */
-    public abstract long getNextItem();
+    long getNextItem();
 
     /**
      * @return Returns the keyFile.
      */
-    public abstract int getKeyFile();
+    int getKeyFile();
 
     /**
      * @return Returns the valueFile.
      */
-    public abstract int getValueFile();
+    int getValueFile();
 
     /**
      * @return Returns the valueOffset.
      */
-    public abstract long getValueOffset();
+    long getValueOffset();
 
     /**
      * @return Returns the offset.
      */
-    public abstract long getOffset();
+    long getOffset();
 
-    public abstract int getKeySize();
+    int getKeySize();
 
-    public abstract int getValueSize();
+    int getValueSize();
 }

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/kaha/StoreLocation.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/kaha/StoreLocation.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/kaha/StoreLocation.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/kaha/StoreLocation.java Thu Aug  9 09:37:49 2007
@@ -1,21 +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
- * 
+ * 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.
+ * 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.kaha;
 
 /**
@@ -28,15 +26,15 @@
     /**
      * @return Returns the size.
      */
-    public int getSize();
+    int getSize();
 
     /**
      * @return Returns the offset.
      */
-    public long getOffset();
+    long getOffset();
 
     /**
      * @return Returns the file.
      */
-    public int getFile();
+    int getFile();
 }

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

Modified: activemq/trunk/activemq-core/src/main/java/org/apache/activemq/kaha/impl/IndexRootContainer.java
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/kaha/impl/IndexRootContainer.java?view=diff&rev=564271&r1=564270&r2=564271
==============================================================================
--- activemq/trunk/activemq-core/src/main/java/org/apache/activemq/kaha/impl/IndexRootContainer.java (original)
+++ activemq/trunk/activemq-core/src/main/java/org/apache/activemq/kaha/impl/IndexRootContainer.java Thu Aug  9 09:37:49 2007
@@ -40,8 +40,8 @@
  */
 
 class IndexRootContainer {
-    private static final Log log = LogFactory.getLog(IndexRootContainer.class);
-    protected static final Marshaller rootMarshaller = Store.ObjectMarshaller;
+    private static final Log LOG = LogFactory.getLog(IndexRootContainer.class);
+    protected static final Marshaller ROOT_MARSHALLER = Store.OBJECT_MARSHALLER;
     protected IndexItem root;
     protected IndexManager indexManager;
     protected DataManager dataManager;
@@ -56,7 +56,7 @@
         while (nextItem != Item.POSITION_NOT_SET) {
             StoreEntry item = indexManager.getIndex(nextItem);
             StoreLocation data = item.getKeyDataItem();
-            Object key = dataManager.readItem(rootMarshaller, data);
+            Object key = dataManager.readItem(ROOT_MARSHALLER, data);
             map.put(key, item);
             list.add(item);
             nextItem = item.getNextItem();
@@ -73,7 +73,7 @@
             removeRoot(containerIndexManager, key);
         }
 
-        StoreLocation data = dataManager.storeDataItem(rootMarshaller, key);
+        StoreLocation data = dataManager.storeDataItem(ROOT_MARSHALLER, key);
         IndexItem newRoot = indexManager.createNewIndex();
         newRoot.setKeyData(data);
         IndexItem containerRoot = containerIndexManager.createNewIndex();