You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@qpid.apache.org by rg...@apache.org on 2007/01/04 09:33:51 UTC

svn commit: r492450 [1/5] - in /incubator/qpid/branches/new_persistence: java/ java/broker/src/main/java/org/apache/qpid/server/ java/broker/src/main/java/org/apache/qpid/server/queue/ java/client/src/main/java/org/apache/qpid/client/ java/cluster/src/...

Author: rgreig
Date: Thu Jan  4 00:33:50 2007
New Revision: 492450

URL: http://svn.apache.org/viewvc?view=rev&rev=492450
Log:
Merged up to trunk rev 491879

Added:
    incubator/qpid/branches/new_persistence/java/broker/src/main/java/org/apache/qpid/server/AMQBrokerManagerMBean.java
      - copied unchanged from r491879, incubator/qpid/trunk/qpid/java/broker/src/main/java/org/apache/qpid/server/AMQBrokerManagerMBean.java
    incubator/qpid/branches/new_persistence/java/cluster/src/test/java/log4j.properties   (with props)
    incubator/qpid/branches/new_persistence/java/perftests/
      - copied from r491879, incubator/qpid/trunk/qpid/java/perftests/
    incubator/qpid/branches/new_persistence/java/perftests/bin/
      - copied from r491879, incubator/qpid/trunk/qpid/java/perftests/bin/
    incubator/qpid/branches/new_persistence/java/perftests/bin/run_many.sh
      - copied unchanged from r491879, incubator/qpid/trunk/qpid/java/perftests/bin/run_many.sh
    incubator/qpid/branches/new_persistence/java/perftests/bin/serviceProvidingClient.sh
      - copied, changed from r491879, incubator/qpid/trunk/qpid/java/perftests/bin/serviceProvidingClient.sh
    incubator/qpid/branches/new_persistence/java/perftests/bin/serviceRequestingClient.sh
      - copied unchanged from r491879, incubator/qpid/trunk/qpid/java/perftests/bin/serviceRequestingClient.sh
    incubator/qpid/branches/new_persistence/java/perftests/bin/setupclasspath.sh
      - copied unchanged from r491879, incubator/qpid/trunk/qpid/java/perftests/bin/setupclasspath.sh
    incubator/qpid/branches/new_persistence/java/perftests/bin/topicListener.sh
      - copied unchanged from r491879, incubator/qpid/trunk/qpid/java/perftests/bin/topicListener.sh
    incubator/qpid/branches/new_persistence/java/perftests/bin/topicPublisher.sh
      - copied unchanged from r491879, incubator/qpid/trunk/qpid/java/perftests/bin/topicPublisher.sh
    incubator/qpid/branches/new_persistence/java/perftests/pom.xml
      - copied unchanged from r491879, incubator/qpid/trunk/qpid/java/perftests/pom.xml
    incubator/qpid/branches/new_persistence/java/perftests/src/
      - copied from r491879, incubator/qpid/trunk/qpid/java/perftests/src/
    incubator/qpid/branches/new_persistence/java/perftests/src/main/
      - copied from r491879, incubator/qpid/trunk/qpid/java/perftests/src/main/
    incubator/qpid/branches/new_persistence/java/perftests/src/main/java/
      - copied from r491879, incubator/qpid/trunk/qpid/java/perftests/src/main/java/
    incubator/qpid/branches/new_persistence/java/perftests/src/main/java/org/
      - copied from r491879, incubator/qpid/trunk/qpid/java/perftests/src/main/java/org/
    incubator/qpid/branches/new_persistence/java/perftests/src/main/java/org/apache/
      - copied from r491879, incubator/qpid/trunk/qpid/java/perftests/src/main/java/org/apache/
    incubator/qpid/branches/new_persistence/java/perftests/src/main/java/org/apache/qpid/
      - copied from r491879, incubator/qpid/trunk/qpid/java/perftests/src/main/java/org/apache/qpid/
    incubator/qpid/branches/new_persistence/java/perftests/src/main/java/org/apache/qpid/config/
      - copied from r491879, incubator/qpid/trunk/qpid/java/perftests/src/main/java/org/apache/qpid/config/
    incubator/qpid/branches/new_persistence/java/perftests/src/main/java/org/apache/qpid/config/AMQConnectionFactoryInitialiser.java
      - copied unchanged from r491879, incubator/qpid/trunk/qpid/java/perftests/src/main/java/org/apache/qpid/config/AMQConnectionFactoryInitialiser.java
    incubator/qpid/branches/new_persistence/java/perftests/src/main/java/org/apache/qpid/config/AbstractConfig.java
      - copied unchanged from r491879, incubator/qpid/trunk/qpid/java/perftests/src/main/java/org/apache/qpid/config/AbstractConfig.java
    incubator/qpid/branches/new_persistence/java/perftests/src/main/java/org/apache/qpid/config/ConnectionFactoryInitialiser.java
      - copied unchanged from r491879, incubator/qpid/trunk/qpid/java/perftests/src/main/java/org/apache/qpid/config/ConnectionFactoryInitialiser.java
    incubator/qpid/branches/new_persistence/java/perftests/src/main/java/org/apache/qpid/config/Connector.java
      - copied unchanged from r491879, incubator/qpid/trunk/qpid/java/perftests/src/main/java/org/apache/qpid/config/Connector.java
    incubator/qpid/branches/new_persistence/java/perftests/src/main/java/org/apache/qpid/config/ConnectorConfig.java
      - copied unchanged from r491879, incubator/qpid/trunk/qpid/java/perftests/src/main/java/org/apache/qpid/config/ConnectorConfig.java
    incubator/qpid/branches/new_persistence/java/perftests/src/main/java/org/apache/qpid/config/JBossConnectionFactoryInitialiser.java
      - copied unchanged from r491879, incubator/qpid/trunk/qpid/java/perftests/src/main/java/org/apache/qpid/config/JBossConnectionFactoryInitialiser.java
    incubator/qpid/branches/new_persistence/java/perftests/src/main/java/org/apache/qpid/requestreply/
      - copied from r491879, incubator/qpid/trunk/qpid/java/perftests/src/main/java/org/apache/qpid/requestreply/
    incubator/qpid/branches/new_persistence/java/perftests/src/main/java/org/apache/qpid/requestreply/ServiceProvidingClient.java
      - copied unchanged from r491879, incubator/qpid/trunk/qpid/java/perftests/src/main/java/org/apache/qpid/requestreply/ServiceProvidingClient.java
    incubator/qpid/branches/new_persistence/java/perftests/src/main/java/org/apache/qpid/requestreply/ServiceRequestingClient.java
      - copied unchanged from r491879, incubator/qpid/trunk/qpid/java/perftests/src/main/java/org/apache/qpid/requestreply/ServiceRequestingClient.java
    incubator/qpid/branches/new_persistence/java/perftests/src/main/java/org/apache/qpid/topic/
      - copied from r491879, incubator/qpid/trunk/qpid/java/perftests/src/main/java/org/apache/qpid/topic/
    incubator/qpid/branches/new_persistence/java/perftests/src/main/java/org/apache/qpid/topic/Config.java
      - copied unchanged from r491879, incubator/qpid/trunk/qpid/java/perftests/src/main/java/org/apache/qpid/topic/Config.java
    incubator/qpid/branches/new_persistence/java/perftests/src/main/java/org/apache/qpid/topic/Listener.java
      - copied unchanged from r491879, incubator/qpid/trunk/qpid/java/perftests/src/main/java/org/apache/qpid/topic/Listener.java
    incubator/qpid/branches/new_persistence/java/perftests/src/main/java/org/apache/qpid/topic/MessageFactory.java
      - copied unchanged from r491879, incubator/qpid/trunk/qpid/java/perftests/src/main/java/org/apache/qpid/topic/MessageFactory.java
    incubator/qpid/branches/new_persistence/java/perftests/src/main/java/org/apache/qpid/topic/Publisher.java
      - copied unchanged from r491879, incubator/qpid/trunk/qpid/java/perftests/src/main/java/org/apache/qpid/topic/Publisher.java
    incubator/qpid/branches/new_persistence/java/systests/src/test/java/org/apache/qpid/server/AMQBrokerManagerMBeanTest.java
      - copied unchanged from r491879, incubator/qpid/trunk/qpid/java/systests/src/test/java/org/apache/qpid/server/AMQBrokerManagerMBeanTest.java
    incubator/qpid/branches/new_persistence/specs/amqp.0-8.xml   (with props)
    incubator/qpid/branches/new_persistence/specs/amqp.0-9.xml   (with props)
    incubator/qpid/branches/new_persistence/specs/cluster.0-8.xml   (with props)
    incubator/qpid/branches/new_persistence/specs/cluster.0-9.xml   (with props)
Removed:
    incubator/qpid/branches/new_persistence/specs/amqp-8.0.xml
Modified:
    incubator/qpid/branches/new_persistence/java/broker/src/main/java/org/apache/qpid/server/Main.java
    incubator/qpid/branches/new_persistence/java/broker/src/main/java/org/apache/qpid/server/queue/ConcurrentSelectorDeliveryManager.java
    incubator/qpid/branches/new_persistence/java/client/src/main/java/org/apache/qpid/client/QueueSenderAdapter.java
    incubator/qpid/branches/new_persistence/java/pom.xml

Modified: incubator/qpid/branches/new_persistence/java/broker/src/main/java/org/apache/qpid/server/Main.java
URL: http://svn.apache.org/viewvc/incubator/qpid/branches/new_persistence/java/broker/src/main/java/org/apache/qpid/server/Main.java?view=diff&rev=492450&r1=492449&r2=492450
==============================================================================
--- incubator/qpid/branches/new_persistence/java/broker/src/main/java/org/apache/qpid/server/Main.java (original)
+++ incubator/qpid/branches/new_persistence/java/broker/src/main/java/org/apache/qpid/server/Main.java Thu Jan  4 00:33:50 2007
@@ -40,29 +40,16 @@
 import org.apache.qpid.framing.ProtocolVersionList;
 import org.apache.qpid.pool.ReadWriteThreadModel;
 import org.apache.qpid.server.configuration.VirtualHostConfiguration;
-import org.apache.qpid.server.exchange.Exchange;
-import org.apache.qpid.server.exchange.ExchangeFactory;
-import org.apache.qpid.server.exchange.ExchangeRegistry;
-import org.apache.qpid.server.management.AMQManagedObject;
-import org.apache.qpid.server.management.MBeanConstructor;
-import org.apache.qpid.server.management.MBeanDescription;
-import org.apache.qpid.server.management.ManagedBroker;
+import org.apache.qpid.server.management.Managable;
 import org.apache.qpid.server.management.ManagedObject;
 import org.apache.qpid.server.protocol.AMQPFastProtocolHandler;
 import org.apache.qpid.server.protocol.AMQPProtocolProvider;
-import org.apache.qpid.server.queue.AMQQueue;
-import org.apache.qpid.server.queue.QueueRegistry;
 import org.apache.qpid.server.registry.ApplicationRegistry;
 import org.apache.qpid.server.registry.ConfigurationFileApplicationRegistry;
-import org.apache.qpid.server.registry.IApplicationRegistry;
-import org.apache.qpid.server.store.MessageStore;
 import org.apache.qpid.server.transport.ConnectorConfiguration;
 import org.apache.qpid.url.URLSyntaxException;
 
 import javax.management.JMException;
-import javax.management.MBeanException;
-import javax.management.MalformedObjectNameException;
-import javax.management.ObjectName;
 import java.io.File;
 import java.io.IOException;
 import java.net.InetAddress;
@@ -75,7 +62,7 @@
  * Main entry point for AMQPD.
  *
  */
-public class Main implements ProtocolVersionList
+public class Main implements ProtocolVersionList, Managable
 {
     private static final Logger _logger = Logger.getLogger(Main.class);
 
@@ -83,6 +70,8 @@
 
     private static final String DEFAULT_LOG_CONFIG_FILENAME = "log4j.xml";
 
+    private AMQBrokerManagerMBean _mbean = null;
+
     protected static class InitException extends Exception
     {
         InitException(String msg)
@@ -445,7 +434,8 @@
     {
         try
         {
-            new AMQBrokerManager().register();
+            _mbean = new AMQBrokerManagerMBean();
+            _mbean.register();
         }
         catch (JMException ex)
         {
@@ -453,156 +443,8 @@
         }
     }
 
-    /**
-     * AMQPBrokerMBean implements the broker management interface and exposes the
-     * Broker level management features like creating and deleting exchanges and queue.
-     */
-    @MBeanDescription("This MBean exposes the broker level management features")
-    private final class AMQBrokerManager extends AMQManagedObject implements ManagedBroker
-    {
-        private final QueueRegistry    _queueRegistry;
-        private final ExchangeRegistry _exchangeRegistry;
-        private final ExchangeFactory  _exchangeFactory;
-        private final MessageStore     _messageStore;
-
-        @MBeanConstructor("Creates the Broker Manager MBean")
-        protected AMQBrokerManager()  throws JMException
-        {
-            super(ManagedBroker.class, ManagedBroker.TYPE);
-            IApplicationRegistry appRegistry = ApplicationRegistry.getInstance();
-            _queueRegistry    = appRegistry.getQueueRegistry();
-            _exchangeRegistry = appRegistry.getExchangeRegistry();
-            _exchangeFactory  = ApplicationRegistry.getInstance().getExchangeFactory();
-            _messageStore     = ApplicationRegistry.getInstance().getMessageStore();
-       }
-
-        public String getObjectInstanceName()
-        {
-            return this.getClass().getName();
-        }
-
-        /**
-         * Creates new exchange and registers it with the registry.
-         * @param exchangeName
-         * @param type
-         * @param durable
-         * @param autoDelete
-         * @throws JMException
-         */
-        public void createNewExchange(String exchangeName, String type, boolean durable, boolean autoDelete)
-            throws JMException
-        {
-            try
-            {
-                synchronized(_exchangeRegistry)
-                {
-                    Exchange exchange = _exchangeRegistry.getExchange(exchangeName);
-                    if (exchange == null)
-                    {
-                        exchange = _exchangeFactory.createExchange(exchangeName, type, durable, autoDelete, 0);
-                        _exchangeRegistry.registerExchange(exchange);
-                    }
-                    else
-                    {
-                        throw new JMException("The exchange \"" + exchangeName + "\" already exists.");
-                    }
-                }
-            }
-            catch(AMQException ex)
-            {
-                _logger.error("Error in creating exchange " + exchangeName, ex);
-                throw new MBeanException(ex, ex.toString());
-            }
-        }
-
-        /**
-         * Unregisters the exchange from registry.
-         * @param exchangeName
-         * @throws JMException
-         */
-        public void unregisterExchange(String exchangeName) throws JMException
-        {
-            // TODO
-            // Check if the exchange is in use.
-        	// boolean inUse = false;
-            // Check if there are queue-bindings with the exchange and unregister
-            // when there are no bindings.
-            try
-            {
-                _exchangeRegistry.unregisterExchange(exchangeName, false);
-            }
-            catch(AMQException ex)
-            {
-                _logger.error("Error in unregistering exchange " + exchangeName, ex);
-                throw new MBeanException(ex, ex.toString());
-            }
-        }
-
-        /**
-         * Creates a new queue and registers it with the registry and puts it
-         * in persistance storage if durable queue.
-         * @param queueName
-         * @param durable
-         * @param owner
-         * @param autoDelete
-         * @throws JMException
-         */
-        public void createNewQueue(String queueName, boolean durable, String owner, boolean autoDelete)
-            throws JMException
-        {
-            AMQQueue queue = _queueRegistry.getQueue(queueName);
-            if (queue != null)
-            {
-                throw new JMException("The queue \"" + queueName + "\" already exists.");
-            }
-            
-            try
-            {
-                queue = new AMQQueue(queueName, durable, owner, autoDelete, _queueRegistry);
-                if (queue.isDurable() && !queue.isAutoDelete())
-                {
-                    _messageStore.createQueue(queue);
-                }
-                _queueRegistry.registerQueue(queue);
-            }
-            catch (AMQException ex)
-            {
-                _logger.error("Error in creating queue " + queueName, ex);
-                throw new MBeanException(ex, ex.toString());
-            }
-        }
-
-        /**
-         * Deletes the queue from queue registry and persistant storage.
-         * @param queueName
-         * @throws JMException
-         */
-        public void deleteQueue(String queueName) throws JMException
-        {
-            AMQQueue queue = _queueRegistry.getQueue(queueName);
-            if (queue == null)
-            {
-                throw new JMException("The Queue " + queueName + " is not a registerd queue.");
-            }
-
-            try
-            {
-                queue.delete();
-                _messageStore.removeQueue(queueName);
-
-            }
-            catch (AMQException ex)
-            {
-                throw new MBeanException(ex, ex.toString());
-            }
-        }
-
-        public ObjectName getObjectName() throws MalformedObjectNameException
-        {
-            StringBuffer objectName = new StringBuffer(ManagedObject.DOMAIN);
-            objectName.append(":type=").append(getType());
-
-            return new ObjectName(objectName.toString());
-        }
-    } // End of MBean class
+    public ManagedObject getManagedObject()
+    {
+        return _mbean;
+    }    
 }

Modified: incubator/qpid/branches/new_persistence/java/broker/src/main/java/org/apache/qpid/server/queue/ConcurrentSelectorDeliveryManager.java
URL: http://svn.apache.org/viewvc/incubator/qpid/branches/new_persistence/java/broker/src/main/java/org/apache/qpid/server/queue/ConcurrentSelectorDeliveryManager.java?view=diff&rev=492450&r1=492449&r2=492450
==============================================================================
--- incubator/qpid/branches/new_persistence/java/broker/src/main/java/org/apache/qpid/server/queue/ConcurrentSelectorDeliveryManager.java (original)
+++ incubator/qpid/branches/new_persistence/java/broker/src/main/java/org/apache/qpid/server/queue/ConcurrentSelectorDeliveryManager.java Thu Jan  4 00:33:50 2007
@@ -213,7 +213,10 @@
             {
                 return;
             }
-            _log.info("Async Delivery Message:" + message + " to :" + sub);
+            if (_log.isDebugEnabled())
+            {
+                _log.debug("Async Delivery Message:" + message + " to :" + sub);
+            }
 
             sub.send(message, _queue);
 
@@ -278,7 +281,10 @@
 
     public void deliver(String name, AMQMessage msg) throws AMQException
     {
-        _log.info(id() + "deliver :" + System.identityHashCode(msg));
+        if (_log.isDebugEnabled())
+        {
+            _log.debug(id() + "deliver :" + System.identityHashCode(msg));
+        }
 
         //Check if we have someone to deliver the message to.
         _lock.lock();
@@ -288,7 +294,10 @@
 
             if (s == null) //no-one can take the message right now.
             {
-                _log.info(id() + "Testing Message(" + System.identityHashCode(msg) + ") for Queued Delivery");
+                if (_log.isDebugEnabled())
+                {
+                    _log.debug(id() + "Testing Message(" + System.identityHashCode(msg) + ") for Queued Delivery");
+                }
                 if (!msg.getPublishBody().immediate)
                 {
                     addMessageToQueue(msg);
@@ -297,21 +306,33 @@
                     _lock.unlock();
 
                     //Pre Deliver to all subscriptions
-                    _log.info(id() + "We have " + _subscriptions.getSubscriptions().size() + " subscribers to give the message to.");
+                    if (_log.isDebugEnabled())
+                    {
+                        _log.debug(id() + "We have " + _subscriptions.getSubscriptions().size() + 
+                                   " subscribers to give the message to.");
+                    }
                     for (Subscription sub : _subscriptions.getSubscriptions())
                     {
 
                         // stop if the message gets delivered whilst PreDelivering if we have a shared queue.
                         if (_queue.isShared() && msg.getDeliveredToConsumer())
                         {
-                            _log.info(id() + "Stopping PreDelivery as message(" + System.identityHashCode(msg) + ") is already delivered.");
+                            if (_log.isDebugEnabled())
+                            {
+                                _log.debug(id() + "Stopping PreDelivery as message(" + System.identityHashCode(msg) +
+                                           ") is already delivered.");
+                            }
                             continue;
                         }
 
                         // Only give the message to those that want them.
                         if (sub.hasInterest(msg))
                         {
-                            _log.info(id() + "Queuing message(" + System.identityHashCode(msg) + ") for PreDelivery for subscriber(" + System.identityHashCode(sub) + ")");
+                            if (_log.isDebugEnabled())
+                            {
+                                _log.debug(id() + "Queuing message(" + System.identityHashCode(msg) + 
+                                           ") for PreDelivery for subscriber(" + System.identityHashCode(sub) + ")");
+                            }
                             sub.enqueueForPreDelivery(msg);
                         }
                     }
@@ -322,7 +343,11 @@
                 //release lock now
                 _lock.unlock();
 
-                _log.info(id() + "Delivering Message:" + System.identityHashCode(msg) + " to(" + System.identityHashCode(s) + ") :" + s);
+                if (_log.isDebugEnabled())
+                {
+                    _log.debug(id() + "Delivering Message:" + System.identityHashCode(msg) + " to(" + 
+                               System.identityHashCode(s) + ") :" + s);
+                }
                 //Deliver the message
                 s.send(msg, _queue);
             }
@@ -330,7 +355,7 @@
         finally
         {
             //ensure lock is released
-            if (_lock.isLocked())
+            if (_lock.isHeldByCurrentThread())
             {
                 _lock.unlock();
             }
@@ -371,9 +396,12 @@
 
     public void processAsync(Executor executor)
     {
-        _log.info("Processing Async. Queued:" + hasQueuedMessages() + "(" + getQueueMessageCount() + ")" +
-                  " Active:" + _subscriptions.hasActiveSubscribers() +
-                  " Processing:" + _processing.get());
+        if (_log.isDebugEnabled())
+        {
+            _log.debug("Processing Async. Queued:" + hasQueuedMessages() + "(" + getQueueMessageCount() + ")" +
+                       " Active:" + _subscriptions.hasActiveSubscribers() +
+                       " Processing:" + _processing.get());
+        }
 
         if (hasQueuedMessages() && _subscriptions.hasActiveSubscribers())
         {

Modified: incubator/qpid/branches/new_persistence/java/client/src/main/java/org/apache/qpid/client/QueueSenderAdapter.java
URL: http://svn.apache.org/viewvc/incubator/qpid/branches/new_persistence/java/client/src/main/java/org/apache/qpid/client/QueueSenderAdapter.java?view=diff&rev=492450&r1=492449&r2=492450
==============================================================================
--- incubator/qpid/branches/new_persistence/java/client/src/main/java/org/apache/qpid/client/QueueSenderAdapter.java (original)
+++ incubator/qpid/branches/new_persistence/java/client/src/main/java/org/apache/qpid/client/QueueSenderAdapter.java Thu Jan  4 00:33:50 2007
@@ -132,10 +132,6 @@
 			throw new javax.jms.IllegalStateException("Publisher is closed");
 		}
 		
-		if(queue == null){
-			throw new UnsupportedOperationException("Queue is null");
-		}
-		
 		AMQSession session = ((BasicMessageProducer) _delegate).getSession();
 		
 		if(session == null || session.isClosed()){

Added: incubator/qpid/branches/new_persistence/java/cluster/src/test/java/log4j.properties
URL: http://svn.apache.org/viewvc/incubator/qpid/branches/new_persistence/java/cluster/src/test/java/log4j.properties?view=auto&rev=492450
==============================================================================
--- incubator/qpid/branches/new_persistence/java/cluster/src/test/java/log4j.properties (added)
+++ incubator/qpid/branches/new_persistence/java/cluster/src/test/java/log4j.properties Thu Jan  4 00:33:50 2007
@@ -0,0 +1,28 @@
+#
+# 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.
+#
+log4j.rootLogger=${root.logging.level}
+
+
+log4j.logger.org.apache.qpid=${amqj.logging.level}, console
+log4j.additivity.org.apache.qpid=false
+
+log4j.appender.console=org.apache.log4j.ConsoleAppender
+log4j.appender.console.Threshold=all
+log4j.appender.console.layout=org.apache.log4j.PatternLayout
+log4j.appender.console.layout.ConversionPattern=%t %d %p [%c{4}] %m%n

Propchange: incubator/qpid/branches/new_persistence/java/cluster/src/test/java/log4j.properties
------------------------------------------------------------------------------
    svn:eol-style = native

Copied: incubator/qpid/branches/new_persistence/java/perftests/bin/serviceProvidingClient.sh (from r491879, incubator/qpid/trunk/qpid/java/perftests/bin/serviceProvidingClient.sh)
URL: http://svn.apache.org/viewvc/incubator/qpid/branches/new_persistence/java/perftests/bin/serviceProvidingClient.sh?view=diff&rev=492450&p1=incubator/qpid/trunk/qpid/java/perftests/bin/serviceProvidingClient.sh&r1=491879&p2=incubator/qpid/branches/new_persistence/java/perftests/bin/serviceProvidingClient.sh&r2=492450
==============================================================================
--- incubator/qpid/trunk/qpid/java/perftests/bin/serviceProvidingClient.sh (original)
+++ incubator/qpid/branches/new_persistence/java/perftests/bin/serviceProvidingClient.sh Thu Jan  4 00:33:50 2007
@@ -22,4 +22,4 @@
 . ./setupclasspath.sh
 echo $CP
 # usage: just pass in the host(s)
-$JAVA_HOME/bin/java -cp $CP org.apache.qpid.requestreply.ServiceProvidingClient $1 guest guest /test serviceQ
+$JAVA_HOME/bin/java -cp $CP -Damqj.logging.level=INFO org.apache.qpid.requestreply.ServiceProvidingClient $1 guest guest /test serviceQ

Modified: incubator/qpid/branches/new_persistence/java/pom.xml
URL: http://svn.apache.org/viewvc/incubator/qpid/branches/new_persistence/java/pom.xml?view=diff&rev=492450&r1=492449&r2=492450
==============================================================================
--- incubator/qpid/branches/new_persistence/java/pom.xml (original)
+++ incubator/qpid/branches/new_persistence/java/pom.xml Thu Jan  4 00:33:50 2007
@@ -40,6 +40,14 @@
         <maven>2.0.4</maven>
     </prerequisites>
 
+    <distributionManagement>
+        <snapshotRepository>
+            <id>apache.snapshots</id>
+            <name>Apache SNAPSHOT Repository</name>
+            <url>scp://people.apache.org/www/people.apache.org/repo/m2-snapshot-repository</url>
+        </snapshotRepository>
+    </distributionManagement>
+
     <inceptionYear>2006</inceptionYear>
     <mailingLists>
         <mailingList>