You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@qpid.apache.org by ri...@apache.org on 2007/02/06 14:05:02 UTC

svn commit: r504121 - in /incubator/qpid/branches/perftesting/qpid/java: broker/src/main/java/org/apache/qpid/server/ broker/src/main/java/org/apache/qpid/server/configuration/ broker/src/main/java/org/apache/qpid/server/management/ broker/src/main/jav...

Author: ritchiem
Date: Tue Feb  6 05:05:01 2007
New Revision: 504121

URL: http://svn.apache.org/viewvc?view=rev&rev=504121
Log:
Revision: 504112
Author: bhupendrab
Date: 12:44:21, 06 February 2007
Message:
To make this management console with the java broker with no virtual host mbean implementation, default virtual host is assigned to all mbeans
----
Modified : /incubator/qpid/trunk/qpid/java/management/eclipse-plugin/src/main/java/org/apache/qpid/management/ui/Constants.java
Modified : /incubator/qpid/trunk/qpid/java/management/eclipse-plugin/src/main/java/org/apache/qpid/management/ui/ManagedBean.java
Modified : /incubator/qpid/trunk/qpid/java/management/eclipse-plugin/src/main/java/org/apache/qpid/management/ui/views/MBeanTypeTabControl.java
Modified : /incubator/qpid/trunk/qpid/java/management/eclipse-plugin/src/main/java/org/apache/qpid/management/ui/views/NavigationView.java
Modified : /incubator/qpid/trunk/qpid/java/management/eclipse-plugin/src/main/java/org/apache/qpid/management/ui/views/OperationTabControl.java
Modified : /incubator/qpid/trunk/qpid/java/management/eclipse-plugin/src/main/java/org/apache/qpid/management/ui/views/TreeObject.java




Revision: 504025
Author: gsim
Date: 08:24:41, 06 February 2007
Message:
Applied patch from Jonathan Anstey <ja...@iona.com> to fix trivial compile error.

----
Modified : /incubator/qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/server/AMQBrokerManagerMBeanTest.java


Revision: 503790
Author: bhupendrab
Date: 17:45:09, 05 February 2007
Message:
QPID-326
AMQQueueMBean updated with attribute MaximumMessageAge
----
Modified : /incubator/qpid/trunk/qpid/java/broker/src/main/java/org/apache/qpid/server/AMQBrokerManagerMBean.java
Modified : /incubator/qpid/trunk/qpid/java/broker/src/main/java/org/apache/qpid/server/management/ManagedBroker.java
Modified : /incubator/qpid/trunk/qpid/java/broker/src/main/java/org/apache/qpid/server/protocol/AMQProtocolSessionMBean.java
Modified : /incubator/qpid/trunk/qpid/java/broker/src/main/java/org/apache/qpid/server/queue/AMQQueueMBean.java
Modified : /incubator/qpid/trunk/qpid/java/broker/src/main/java/org/apache/qpid/server/queue/ManagedQueue.java


Revision: 503706
Author: bhupendrab
Date: 14:45:18, 05 February 2007
Message:
QPID-213 
Also the parameter selection of boolean type is made as check-boxes instead of a drop-down.
----
Modified : /incubator/qpid/trunk/qpid/java/management/eclipse-plugin/src/main/java/org/apache/qpid/management/ui/Constants.java
Modified : /incubator/qpid/trunk/qpid/java/management/eclipse-plugin/src/main/java/org/apache/qpid/management/ui/views/AttributesTabControl.java
Modified : /incubator/qpid/trunk/qpid/java/management/eclipse-plugin/src/main/java/org/apache/qpid/management/ui/views/MBeanTypeTabControl.java
Modified : /incubator/qpid/trunk/qpid/java/management/eclipse-plugin/src/main/java/org/apache/qpid/management/ui/views/OperationTabControl.java





ConcurrentSelectorDeliveryManager.java - comment change
management pom skip tests as there are none.


Modified:
    incubator/qpid/branches/perftesting/qpid/java/broker/src/main/java/org/apache/qpid/server/AMQBrokerManagerMBean.java
    incubator/qpid/branches/perftesting/qpid/java/broker/src/main/java/org/apache/qpid/server/configuration/Configurator.java
    incubator/qpid/branches/perftesting/qpid/java/broker/src/main/java/org/apache/qpid/server/configuration/VirtualHostConfiguration.java
    incubator/qpid/branches/perftesting/qpid/java/broker/src/main/java/org/apache/qpid/server/management/ManagedBroker.java
    incubator/qpid/branches/perftesting/qpid/java/broker/src/main/java/org/apache/qpid/server/protocol/AMQProtocolSessionMBean.java
    incubator/qpid/branches/perftesting/qpid/java/broker/src/main/java/org/apache/qpid/server/queue/AMQQueueMBean.java
    incubator/qpid/branches/perftesting/qpid/java/broker/src/main/java/org/apache/qpid/server/queue/ConcurrentSelectorDeliveryManager.java
    incubator/qpid/branches/perftesting/qpid/java/broker/src/main/java/org/apache/qpid/server/queue/ManagedQueue.java
    incubator/qpid/branches/perftesting/qpid/java/management/eclipse-plugin/pom.xml
    incubator/qpid/branches/perftesting/qpid/java/systests/src/test/java/org/apache/qpid/server/AMQBrokerManagerMBeanTest.java

Modified: incubator/qpid/branches/perftesting/qpid/java/broker/src/main/java/org/apache/qpid/server/AMQBrokerManagerMBean.java
URL: http://svn.apache.org/viewvc/incubator/qpid/branches/perftesting/qpid/java/broker/src/main/java/org/apache/qpid/server/AMQBrokerManagerMBean.java?view=diff&rev=504121&r1=504120&r2=504121
==============================================================================
--- incubator/qpid/branches/perftesting/qpid/java/broker/src/main/java/org/apache/qpid/server/AMQBrokerManagerMBean.java (original)
+++ incubator/qpid/branches/perftesting/qpid/java/broker/src/main/java/org/apache/qpid/server/AMQBrokerManagerMBean.java Tue Feb  6 05:05:01 2007
@@ -132,8 +132,7 @@
      * @param autoDelete
      * @throws JMException
      */
-    public void createNewQueue(String queueName, boolean durable, String owner, boolean autoDelete)
-            throws JMException
+    public void createNewQueue(String queueName, String owner, boolean durable,boolean autoDelete)            throws JMException
     {
         AMQQueue queue = _queueRegistry.getQueue(queueName);
         if (queue != null)

Modified: incubator/qpid/branches/perftesting/qpid/java/broker/src/main/java/org/apache/qpid/server/configuration/Configurator.java
URL: http://svn.apache.org/viewvc/incubator/qpid/branches/perftesting/qpid/java/broker/src/main/java/org/apache/qpid/server/configuration/Configurator.java?view=diff&rev=504121&r1=504120&r2=504121
==============================================================================
--- incubator/qpid/branches/perftesting/qpid/java/broker/src/main/java/org/apache/qpid/server/configuration/Configurator.java (original)
+++ incubator/qpid/branches/perftesting/qpid/java/broker/src/main/java/org/apache/qpid/server/configuration/Configurator.java Tue Feb  6 05:05:01 2007
@@ -38,13 +38,13 @@
     private static final Logger _logger = Logger.getLogger(Configurator.class);
 
     /**
-     * Configure a given instance using the application configuration. Note that superclasses are <b>not</b>
+     * Configure a given instance using the supplied configuration. Note that superclasses are <b>not</b>
      * currently configured but this could easily be added if required.
      * @param instance the instance to configure
+     * @param config the configuration to use to configure the object
      */
-    public static void configure(Object instance)
+    public static void configure(Object instance, Configuration config)
     {
-        final Configuration config = ApplicationRegistry.getInstance().getConfiguration();
 
         for (Field f : instance.getClass().getDeclaredFields())
         {
@@ -55,6 +55,17 @@
             }
         }
     }
+
+    /**
+     * Configure a given instance using the application configuration. Note that superclasses are <b>not</b>
+     * currently configured but this could easily be added if required.
+     * @param instance the instance to configure
+     */
+    public static void configure(Object instance)
+    {
+        configure(instance, ApplicationRegistry.getInstance().getConfiguration());
+    }
+
 
     private static void setValueInField(Field f, Object instance, Configuration config, Configured annotation)
     {

Modified: incubator/qpid/branches/perftesting/qpid/java/broker/src/main/java/org/apache/qpid/server/configuration/VirtualHostConfiguration.java
URL: http://svn.apache.org/viewvc/incubator/qpid/branches/perftesting/qpid/java/broker/src/main/java/org/apache/qpid/server/configuration/VirtualHostConfiguration.java?view=diff&rev=504121&r1=504120&r2=504121
==============================================================================
--- incubator/qpid/branches/perftesting/qpid/java/broker/src/main/java/org/apache/qpid/server/configuration/VirtualHostConfiguration.java (original)
+++ incubator/qpid/branches/perftesting/qpid/java/broker/src/main/java/org/apache/qpid/server/configuration/VirtualHostConfiguration.java Tue Feb  6 05:05:01 2007
@@ -154,8 +154,7 @@
 
         }
 
-
-        Configurator.configure(queue);//, queueConfiguration);
+        Configurator.configure(queue, queueConfiguration);
     }
 
 

Modified: incubator/qpid/branches/perftesting/qpid/java/broker/src/main/java/org/apache/qpid/server/management/ManagedBroker.java
URL: http://svn.apache.org/viewvc/incubator/qpid/branches/perftesting/qpid/java/broker/src/main/java/org/apache/qpid/server/management/ManagedBroker.java?view=diff&rev=504121&r1=504120&r2=504121
==============================================================================
--- incubator/qpid/branches/perftesting/qpid/java/broker/src/main/java/org/apache/qpid/server/management/ManagedBroker.java (original)
+++ incubator/qpid/branches/perftesting/qpid/java/broker/src/main/java/org/apache/qpid/server/management/ManagedBroker.java Tue Feb  6 05:05:01 2007
@@ -79,8 +79,8 @@
      */
     @MBeanOperation(name="createNewQueue", description="Create a new Queue on the Broker server", impact= MBeanOperationInfo.ACTION)
     void createNewQueue(@MBeanOperationParameter(name="queue name", description="Name of the new queue")String queueName,
-                        @MBeanOperationParameter(name="durable", description="true if the queue should be durable")boolean durable,
                         @MBeanOperationParameter(name="owner", description="Owner name")String owner,
+                        @MBeanOperationParameter(name="durable", description="true if the queue should be durable")boolean durable,
                         @MBeanOperationParameter(name="autoDelete", description="true if the queue should be auto delete") boolean autoDelete)
         throws IOException, JMException;
 

Modified: incubator/qpid/branches/perftesting/qpid/java/broker/src/main/java/org/apache/qpid/server/protocol/AMQProtocolSessionMBean.java
URL: http://svn.apache.org/viewvc/incubator/qpid/branches/perftesting/qpid/java/broker/src/main/java/org/apache/qpid/server/protocol/AMQProtocolSessionMBean.java?view=diff&rev=504121&r1=504120&r2=504121
==============================================================================
--- incubator/qpid/branches/perftesting/qpid/java/broker/src/main/java/org/apache/qpid/server/protocol/AMQProtocolSessionMBean.java (original)
+++ incubator/qpid/branches/perftesting/qpid/java/broker/src/main/java/org/apache/qpid/server/protocol/AMQProtocolSessionMBean.java Tue Feb  6 05:05:01 2007
@@ -53,30 +53,42 @@
     private AMQMinaProtocolSession _session = null;
     private String _name = null;
     //openmbean data types for representing the channel attributes
-    private String[] _channelAtttibuteNames = {"Channel Id", "Transactional", "Default Queue", "Unacknowledged Message Count"};
-    private String[] _indexNames = {_channelAtttibuteNames[0]};
-    private OpenType[] _channelAttributeTypes = {SimpleType.INTEGER, SimpleType.BOOLEAN, SimpleType.STRING, SimpleType.INTEGER};
-    private CompositeType _channelType = null;      // represents the data type for channel data
-    private TabularType _channelsType = null;       // Data type for list of channels type
+    private final static String[] _channelAtttibuteNames = {"Channel Id", "Transactional", "Default Queue", "Unacknowledged Message Count"};
+    private final static String[] _indexNames = {_channelAtttibuteNames[0]};
+    private final static OpenType[] _channelAttributeTypes = {SimpleType.INTEGER, SimpleType.BOOLEAN, SimpleType.STRING, SimpleType.INTEGER};
+    private static CompositeType _channelType = null;      // represents the data type for channel data
+    private static TabularType _channelsType = null;       // Data type for list of channels type
+    private static final String BROKER_MANAGEMENT_CONSOLE_HAS_CLOSED_THE_CONNECTION = "Broker Management Console has closed the connection.";
 
     @MBeanConstructor("Creates an MBean exposing an AMQ Broker Connection")
     public AMQProtocolSessionMBean(AMQMinaProtocolSession session) throws JMException
     {
         super(ManagedConnection.class, ManagedConnection.TYPE);
         _session = session;
+        String remote = getRemoteAddress();
+        remote = "anonymous".equals(remote) ? remote + hashCode() : remote;
+        _name = jmxEncode(new StringBuffer(remote), 0).toString();
         init();
     }
 
-    /**
-     * initialises the openmbean data types
-     */
-    private void init() throws OpenDataException
+    static
+    {
+        try
+        {
+            init();
+        }
+        catch (JMException ex)
+        {
+            // It should never occur
+            System.out.println(ex.getMessage());
+        }
+    }
+
+    /** initialises the openmbean data types */
+    private static void init() throws OpenDataException
     {
-        String remote = getRemoteAddress();
-        remote = "anonymous".equals(remote) ? remote + hashCode() : remote;
-        _name = jmxEncode(new StringBuffer(remote), 0).toString();
         _channelType = new CompositeType("Channel", "Channel Details", _channelAtttibuteNames,
-                _channelAtttibuteNames, _channelAttributeTypes);
+                                         _channelAtttibuteNames, _channelAttributeTypes);
         _channelsType = new TabularType("Channels", "Channels", _channelType, _indexNames);
     }
 
@@ -119,6 +131,7 @@
      * commits transactions for a transactional channel
      *
      * @param channelId
+     *
      * @throws JMException if channel with given id doesn't exist or if commit fails
      */
     public void commitTransactions(int channelId) throws JMException
@@ -142,6 +155,7 @@
      * rollsback the transactions for a transactional channel
      *
      * @param channelId
+     *
      * @throws JMException if channel with given id doesn't exist or if rollback fails
      */
     public void rollbackTransactions(int channelId) throws JMException
@@ -165,6 +179,7 @@
      * Creates the list of channels in tabular form from the _channelMap.
      *
      * @return list of channels in tabular form.
+     *
      * @throws OpenDataException
      */
     public TabularData channels() throws OpenDataException
@@ -175,8 +190,8 @@
         for (AMQChannel channel : list)
         {
             Object[] itemValues = {channel.getChannelId(), channel.isTransactional(),
-                    (channel.getDefaultQueue() != null) ? channel.getDefaultQueue().getName() : null,
-                    channel.getUnacknowledgedMessageMap().size()};
+                                   (channel.getDefaultQueue() != null) ? channel.getDefaultQueue().getName() : null,
+                                   channel.getUnacknowledgedMessageMap().size()};
 
             CompositeData channelData = new CompositeDataSupport(_channelType, _channelAtttibuteNames, itemValues);
             channelsList.put(channelData);
@@ -188,25 +203,26 @@
     /**
      * closes the connection. The administrator can use this management operation to close connection to free up
      * resources.
+     *
      * @throws JMException
      */
     public void closeConnection() throws JMException
     {
-        
+
         // AMQP version change: Hardwire the version to 0-8 (major=8, minor=0)
         // TODO: Connect this to the session version obtained from ProtocolInitiation for this session.
         // Be aware of possible changes to parameter order as versions change.
         final AMQFrame response = ConnectionCloseBody.createAMQFrame(0,
-            (byte)8, (byte)0,	// AMQP version (major, minor)
-            0,	// classId
-            0,	// methodId
-        	AMQConstant.REPLY_SUCCESS.getCode(),	// replyCode
-            "Broker Management Console has closing the connection."	// replyText
-            );
+                                                                     (byte) 8, (byte) 0,    // AMQP version (major, minor)
+                                                                     0,    // classId
+                                                                     0,    // methodId
+                                                                     AMQConstant.REPLY_SUCCESS.getCode(),    // replyCode
+                                                                     BROKER_MANAGEMENT_CONSOLE_HAS_CLOSED_THE_CONNECTION    // replyText
+        );
         _session.writeFrame(response);
 
         try
-        {
+        {                               
             _session.closeSession();
         }
         catch (AMQException ex)
@@ -229,7 +245,7 @@
     public void notifyClients(String notificationMsg)
     {
         Notification n = new Notification(MonitorNotification.THRESHOLD_VALUE_EXCEEDED, this,
-                ++_notificationSequenceNumber, System.currentTimeMillis(), notificationMsg);
+                                          ++_notificationSequenceNumber, System.currentTimeMillis(), notificationMsg);
         _broadcaster.sendNotification(n);
     }
 

Modified: incubator/qpid/branches/perftesting/qpid/java/broker/src/main/java/org/apache/qpid/server/queue/AMQQueueMBean.java
URL: http://svn.apache.org/viewvc/incubator/qpid/branches/perftesting/qpid/java/broker/src/main/java/org/apache/qpid/server/queue/AMQQueueMBean.java?view=diff&rev=504121&r1=504120&r2=504121
==============================================================================
--- incubator/qpid/branches/perftesting/qpid/java/broker/src/main/java/org/apache/qpid/server/queue/AMQQueueMBean.java (original)
+++ incubator/qpid/branches/perftesting/qpid/java/broker/src/main/java/org/apache/qpid/server/queue/AMQQueueMBean.java Tue Feb  6 05:05:01 2007
@@ -37,10 +37,7 @@
 import java.util.List;
 import java.util.ArrayList;
 
-/**
- * MBean class for AMQQueue. It implements all the management features exposed
- * for an AMQQueue.
- */
+/** MBean class for AMQQueue. It implements all the management features exposed for an AMQQueue. */
 @MBeanDescription("Management Interface for AMQQueue")
 public class AMQQueueMBean extends AMQManagedObject implements ManagedQueue, QueueNotificationListener
 {
@@ -84,9 +81,7 @@
         }
     }
 
-    /**
-     * initialises the openmbean data types
-     */
+    /** initialises the openmbean data types */
     private static void init() throws OpenDataException
     {
         _msgContentAttributeTypes[0] = SimpleType.LONG;                    // For message id
@@ -135,6 +130,16 @@
         return _queue.getMessageCount();
     }
 
+    public Long getMaximumMessageAge()
+    {
+        return _queue.getMaximumMessageAge();
+    }
+
+    public void setMaximumMessageAge(Long maximumMessageAge)
+    {
+        _queue.setMaximumMessageAge(maximumMessageAge);
+    }
+
     public Long getMaximumMessageSize()
     {
         return _queue.getMaximumMessageSize();
@@ -180,9 +185,7 @@
         _queue.setMaximumQueueDepth(value);
     }
 
-    /**
-     * returns the size of messages(KB) in the queue.
-     */
+    /** returns the size of messages(KB) in the queue. */
     public Long getQueueDepth()
     {
 //        List<AMQMessage> list = _queue.getMessagesOnTheQueue();
@@ -203,9 +206,7 @@
         return 0L;
     }
 
-    /**
-     * returns size of message in bytes
-     */
+    /** returns size of message in bytes */
     private long getMessageSize(AMQMessage msg)
     {
         if (msg == null)
@@ -216,9 +217,7 @@
         return msg.getContentHeaderBody().bodySize;
     }
 
-    /**
-     * Checks if there is any notification to be send to the listeners
-     */
+    /** Checks if there is any notification to be send to the listeners */
     public void checkForNotification(AMQMessage msg)
     {
         final long currentTime = System.currentTimeMillis();
@@ -236,9 +235,7 @@
         }
     }
 
-    /**
-     * Sends the notification to the listeners
-     */
+    /** Sends the notification to the listeners */
     public void notifyClients(NotificationCheck notification, AMQQueue queue, String notificationMsg)
     {
         // important : add log to the log file - monitoring tools may be looking for this
@@ -250,9 +247,7 @@
         _broadcaster.sendNotification(n);
     }
 
-    /**
-     * @see org.apache.qpid.server.queue.AMQQueue#deleteMessageFromTop()
-     */
+    /** @see org.apache.qpid.server.queue.AMQQueue#deleteMessageFromTop() */
     public void deleteMessageFromTop() throws JMException
     {
         try
@@ -265,9 +260,7 @@
         }
     }
 
-    /**
-     * @see org.apache.qpid.server.queue.AMQQueue#clearQueue()
-     */
+    /** @see org.apache.qpid.server.queue.AMQQueue#clearQueue() */
     public void clearQueue() throws JMException
     {
         try
@@ -280,9 +273,7 @@
         }
     }
 
-    /**
-     * returns message content as byte array and related attributes for the given message id.
-     */
+    /** returns message content as byte array and related attributes for the given message id. */
     public CompositeData viewMessageContent(long msgId) throws JMException
     {
         AMQMessage msg = _queue.getMessageOnTheQueue(msgId);
@@ -321,9 +312,7 @@
         return new CompositeDataSupport(_msgContentType, _msgContentAttributes, itemValues);
     }
 
-    /**
-     * Returns the header contents of the messages stored in this queue in tabular form.
-     */
+    /** Returns the header contents of the messages stored in this queue in tabular form. */
     public TabularData viewMessages(int beginIndex, int endIndex) throws JMException
     {
         if ((beginIndex > endIndex) || (beginIndex < 1))
@@ -351,9 +340,7 @@
         return _messageList;
     }
 
-    /**
-     * returns Notifications sent by this MBean.
-     */
+    /** returns Notifications sent by this MBean. */
     @Override
     public MBeanNotificationInfo[] getNotificationInfo()
     {

Modified: incubator/qpid/branches/perftesting/qpid/java/broker/src/main/java/org/apache/qpid/server/queue/ConcurrentSelectorDeliveryManager.java
URL: http://svn.apache.org/viewvc/incubator/qpid/branches/perftesting/qpid/java/broker/src/main/java/org/apache/qpid/server/queue/ConcurrentSelectorDeliveryManager.java?view=diff&rev=504121&r1=504120&r2=504121
==============================================================================
--- incubator/qpid/branches/perftesting/qpid/java/broker/src/main/java/org/apache/qpid/server/queue/ConcurrentSelectorDeliveryManager.java (original)
+++ incubator/qpid/branches/perftesting/qpid/java/broker/src/main/java/org/apache/qpid/server/queue/ConcurrentSelectorDeliveryManager.java Tue Feb  6 05:05:01 2007
@@ -37,9 +37,7 @@
 import java.util.concurrent.atomic.AtomicLong;
 
 
-/**
- * Manages delivery of messages on behalf of a queue
- */
+/** Manages delivery of messages on behalf of a queue */
 public class ConcurrentSelectorDeliveryManager implements DeliveryManager
 {
     private static final Logger _log = Logger.getLogger(ConcurrentSelectorDeliveryManager.class);
@@ -47,34 +45,26 @@
     @Configured(path = "advanced.compressBufferOnQueue",
                 defaultValue = "false")
     public boolean compressBufferOnQueue;
-    /**
-     * Holds any queued messages
-     */
+    /** Holds any queued messages */
     private final Queue<AMQMessage> _messages = new ConcurrentLinkedQueueAtomicSize<AMQMessage>();
     //private int _messageCount;
-    /**
-     * Ensures that only one asynchronous task is running for this manager at
-     * any time.
-     */
+    /** Ensures that only one asynchronous task is running for this manager at any time. */
     private final AtomicBoolean _processing = new AtomicBoolean();
-    /**
-     * The subscriptions on the queue to whom messages are delivered
-     */
+    /** The subscriptions on the queue to whom messages are delivered */
     private final SubscriptionManager _subscriptions;
 
     /**
-     * A reference to the queue we are delivering messages for. We need this to be able
-     * to pass the code that handles acknowledgements a handle on the queue.
+     * A reference to the queue we are delivering messages for. We need this to be able to pass the code that handles
+     * acknowledgements a handle on the queue.
      */
     private final AMQQueue _queue;
 
 
     /**
      * Lock used to ensure that an channel that becomes unsuspended during the start of the queueing process is forced
-     * to wait till the first message is added to the queue. This will ensure that the _queue has messages to be delivered
-     * via the async thread.
-     * <p/>
-     * Lock is used to control access to hasQueuedMessages() and over the addition of messages to the queue.
+     * to wait till the first message is added to the queue. This will ensure that the _queue has messages to be
+     * delivered via the async thread. <p/> Lock is used to control access to hasQueuedMessages() and over the addition
+     * of messages to the queue.
      */
     private ReentrantLock _lock = new ReentrantLock();
     private AtomicLong _totalMessageSize = new AtomicLong();
@@ -135,8 +125,8 @@
     }
 
     /**
-     * This is an EXPENSIVE opperation to perform with a ConcurrentLinkedQueue as it must run the queue to determine size.
-     * The ConcurrentLinkedQueueAtomicSize uses an AtomicInteger to record the number of elements on the queue.
+     * This is an EXPENSIVE opperation to perform with a ConcurrentLinkedQueue as it must run the queue to determine
+     * size. The ConcurrentLinkedQueueAtomicSize uses an AtomicInteger to record the number of elements on the queue.
      *
      * @return int the number of messages in the delivery queue.
      */
@@ -248,8 +238,8 @@
     }
 
     /**
-     * Only one thread should ever execute this method concurrently, but
-     * it can do so while other threads invoke deliver().
+     * Only one thread should ever execute this method concurrently, but it can do so while other threads invoke
+     * deliver().
      */
     private void processQueue()
     {

Modified: incubator/qpid/branches/perftesting/qpid/java/broker/src/main/java/org/apache/qpid/server/queue/ManagedQueue.java
URL: http://svn.apache.org/viewvc/incubator/qpid/branches/perftesting/qpid/java/broker/src/main/java/org/apache/qpid/server/queue/ManagedQueue.java?view=diff&rev=504121&r1=504120&r2=504121
==============================================================================
--- incubator/qpid/branches/perftesting/qpid/java/broker/src/main/java/org/apache/qpid/server/queue/ManagedQueue.java (original)
+++ incubator/qpid/branches/perftesting/qpid/java/broker/src/main/java/org/apache/qpid/server/queue/ManagedQueue.java Tue Feb  6 05:05:01 2007
@@ -113,6 +113,21 @@
     boolean isAutoDelete() throws IOException;
 
     /**
+     * Returns the maximum age of a message (expiration time)
+     * @return the maximum age
+     * @throws IOException
+     */
+    Long getMaximumMessageAge() throws IOException;
+
+    /**
+     * Sets the maximum age of a message
+     * @param age  maximum age of message.
+     * @throws IOException
+     */
+    @MBeanAttribute(name="MaximumMessageAge", description="Threshold high value for message age on thr broker")
+    void setMaximumMessageAge(Long age) throws IOException;    
+
+    /**
      * Returns the maximum size of a message (in kbytes) allowed to be accepted by the
      * ManagedQueue. This is useful in setting notifications or taking
      * appropriate action, if the size of the message received is more than

Modified: incubator/qpid/branches/perftesting/qpid/java/management/eclipse-plugin/pom.xml
URL: http://svn.apache.org/viewvc/incubator/qpid/branches/perftesting/qpid/java/management/eclipse-plugin/pom.xml?view=diff&rev=504121&r1=504120&r2=504121
==============================================================================
--- incubator/qpid/branches/perftesting/qpid/java/management/eclipse-plugin/pom.xml (original)
+++ incubator/qpid/branches/perftesting/qpid/java/management/eclipse-plugin/pom.xml Tue Feb  6 05:05:01 2007
@@ -209,6 +209,9 @@
             <plugin>
                 <groupId>org.apache.maven.plugins</groupId>
                 <artifactId>maven-surefire-plugin</artifactId>
+<configuration>
+          <skip>true</skip>
+        </configuration>
             </plugin>
         </plugins>
     </build>

Modified: incubator/qpid/branches/perftesting/qpid/java/systests/src/test/java/org/apache/qpid/server/AMQBrokerManagerMBeanTest.java
URL: http://svn.apache.org/viewvc/incubator/qpid/branches/perftesting/qpid/java/systests/src/test/java/org/apache/qpid/server/AMQBrokerManagerMBeanTest.java?view=diff&rev=504121&r1=504120&r2=504121
==============================================================================
--- incubator/qpid/branches/perftesting/qpid/java/systests/src/test/java/org/apache/qpid/server/AMQBrokerManagerMBeanTest.java (original)
+++ incubator/qpid/branches/perftesting/qpid/java/systests/src/test/java/org/apache/qpid/server/AMQBrokerManagerMBeanTest.java Tue Feb  6 05:05:01 2007
@@ -31,18 +31,18 @@
 
     public void testExchangeOperations() throws Exception
     {
-        String exchange1 = "testExchange1_" +  System.currentTimeMillis();
-        String exchange2 = "testExchange2_" +  System.currentTimeMillis();
-        String exchange3 = "testExchange3_" +  System.currentTimeMillis();
+        String exchange1 = "testExchange1_" + System.currentTimeMillis();
+        String exchange2 = "testExchange2_" + System.currentTimeMillis();
+        String exchange3 = "testExchange3_" + System.currentTimeMillis();
 
         assertTrue(_exchangeRegistry.getExchange(exchange1) == null);
         assertTrue(_exchangeRegistry.getExchange(exchange2) == null);
         assertTrue(_exchangeRegistry.getExchange(exchange3) == null);
 
         ManagedBroker mbean = new AMQBrokerManagerMBean();
-        mbean.createNewExchange(exchange1,"direct",false, false);
-        mbean.createNewExchange(exchange2,"topic",false, false);
-        mbean.createNewExchange(exchange3,"headers",false, false);
+        mbean.createNewExchange(exchange1, "direct", false, false);
+        mbean.createNewExchange(exchange2, "topic", false, false);
+        mbean.createNewExchange(exchange3, "headers", false, false);
 
         assertTrue(_exchangeRegistry.getExchange(exchange1) != null);
         assertTrue(_exchangeRegistry.getExchange(exchange2) != null);
@@ -63,8 +63,8 @@
         ManagedBroker mbean = new AMQBrokerManagerMBean();
 
         assertTrue(_queueRegistry.getQueue(queueName) == null);
-                
-        mbean.createNewQueue(queueName, false, "test", true);
+
+        mbean.createNewQueue(queueName, "test", false, true);
         assertTrue(_queueRegistry.getQueue(queueName) != null);
 
         mbean.deleteQueue(queueName);
@@ -76,7 +76,7 @@
     {
         super.setUp();
         IApplicationRegistry appRegistry = ApplicationRegistry.getInstance();
-        _queueRegistry    = appRegistry.getQueueRegistry();
+        _queueRegistry = appRegistry.getQueueRegistry();
         _exchangeRegistry = appRegistry.getExchangeRegistry();
     }
 }