You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@servicemix.apache.org by jb...@apache.org on 2011/02/04 10:05:55 UTC

svn commit: r1067118 [5/7] - in /servicemix/components/trunk: ./ bindings/servicemix-cxf-bc/ bindings/servicemix-file/ bindings/servicemix-file/src/main/java/org/apache/servicemix/file/ bindings/servicemix-file/src/test/java/org/apache/servicemix/file/...

Modified: servicemix/components/trunk/engines/servicemix-wsn2005/src/main/java/org/apache/servicemix/wsn/jbi/JbiSubscription.java
URL: http://svn.apache.org/viewvc/servicemix/components/trunk/engines/servicemix-wsn2005/src/main/java/org/apache/servicemix/wsn/jbi/JbiSubscription.java?rev=1067118&r1=1067117&r2=1067118&view=diff
==============================================================================
--- servicemix/components/trunk/engines/servicemix-wsn2005/src/main/java/org/apache/servicemix/wsn/jbi/JbiSubscription.java (original)
+++ servicemix/components/trunk/engines/servicemix-wsn2005/src/main/java/org/apache/servicemix/wsn/jbi/JbiSubscription.java Fri Feb  4 09:05:47 2011
@@ -28,13 +28,13 @@ import javax.xml.parsers.DocumentBuilder
 import javax.xml.parsers.DocumentBuilderFactory;
 import javax.xml.transform.dom.DOMSource;
 
+import org.slf4j.Logger;
+import org.slf4j.LoggerFactory;
 import org.w3c.dom.Document;
 import org.w3c.dom.DocumentFragment;
 import org.w3c.dom.Element;
 import org.w3c.dom.NodeList;
 
-import org.apache.commons.logging.Log;
-import org.apache.commons.logging.LogFactory;
 import org.apache.servicemix.wsn.ComponentContextAware;
 import org.apache.servicemix.wsn.client.AbstractWSAClient;
 import org.apache.servicemix.wsn.jms.JmsSubscription;
@@ -53,7 +53,7 @@ import org.oasis_open.docs.wsn.bw_2.Unre
 
 public class JbiSubscription extends JmsSubscription implements ComponentContextAware {
 
-    private static Log log = LogFactory.getLog(JbiSubscription.class);
+    private final Logger logger = LoggerFactory.getLogger(JbiSubscription.class);
 
     private ComponentContext context;
 
@@ -136,7 +136,7 @@ public class JbiSubscription extends Jms
             msg.setContent(new DOMSource(content));
             context.getDeliveryChannel().send(inonly);
         } catch (JBIException e) {
-            log.warn("Could not deliver notification", e);
+            logger.warn("Could not deliver notification", e);
         }
     }
 

Modified: servicemix/components/trunk/engines/servicemix-wsn2005/src/main/java/org/apache/servicemix/wsn/jms/JmsPublisher.java
URL: http://svn.apache.org/viewvc/servicemix/components/trunk/engines/servicemix-wsn2005/src/main/java/org/apache/servicemix/wsn/jms/JmsPublisher.java?rev=1067118&r1=1067117&r2=1067118&view=diff
==============================================================================
--- servicemix/components/trunk/engines/servicemix-wsn2005/src/main/java/org/apache/servicemix/wsn/jms/JmsPublisher.java (original)
+++ servicemix/components/trunk/engines/servicemix-wsn2005/src/main/java/org/apache/servicemix/wsn/jms/JmsPublisher.java Fri Feb  4 09:05:47 2011
@@ -30,8 +30,6 @@ import javax.xml.bind.JAXBException;
 import org.apache.activemq.advisory.ConsumerEvent;
 import org.apache.activemq.advisory.ConsumerEventSource;
 import org.apache.activemq.advisory.ConsumerListener;
-import org.apache.commons.logging.Log;
-import org.apache.commons.logging.LogFactory;
 import org.apache.servicemix.wsn.AbstractPublisher;
 import org.oasis_open.docs.wsn.b_2.InvalidTopicExpressionFaultType;
 import org.oasis_open.docs.wsn.b_2.NotificationMessageHolderType;
@@ -45,10 +43,12 @@ import org.oasis_open.docs.wsn.brw_2.Res
 import org.oasis_open.docs.wsn.bw_2.InvalidTopicExpressionFault;
 import org.oasis_open.docs.wsn.bw_2.TopicNotSupportedFault;
 import org.oasis_open.docs.wsrf.rw_2.ResourceUnknownFault;
+import org.slf4j.Logger;
+import org.slf4j.LoggerFactory;
 
 public abstract class JmsPublisher extends AbstractPublisher implements ConsumerListener {
 
-    private static Log log = LogFactory.getLog(JmsPublisher.class);
+    private final Logger logger = LoggerFactory.getLogger(JmsPublisher.class);
 
     private Connection connection;
 
@@ -94,17 +94,17 @@ public abstract class JmsPublisher exten
             Message message = session.createTextMessage(writer.toString());
             producer.send(message);
         } catch (JMSException e) {
-            log.warn("Error dispatching message", e);
+            logger.warn("Error dispatching message", e);
         } catch (JAXBException e) {
-            log.warn("Error dispatching message", e);
+            logger.warn("Error dispatching message", e);
         } catch (InvalidTopicException e) {
-            log.warn("Error dispatching message", e);
+            logger.warn("Error dispatching message", e);
         } finally {
             if (session != null) {
                 try {
                     session.close();
                 } catch (JMSException e) {
-                    log.debug("Error closing session", e);
+                    logger.debug("Error closing session", e);
                 }
             }
         }

Modified: servicemix/components/trunk/engines/servicemix-wsn2005/src/main/java/org/apache/servicemix/wsn/jms/JmsPullPoint.java
URL: http://svn.apache.org/viewvc/servicemix/components/trunk/engines/servicemix-wsn2005/src/main/java/org/apache/servicemix/wsn/jms/JmsPullPoint.java?rev=1067118&r1=1067117&r2=1067118&view=diff
==============================================================================
--- servicemix/components/trunk/engines/servicemix-wsn2005/src/main/java/org/apache/servicemix/wsn/jms/JmsPullPoint.java (original)
+++ servicemix/components/trunk/engines/servicemix-wsn2005/src/main/java/org/apache/servicemix/wsn/jms/JmsPullPoint.java Fri Feb  4 09:05:47 2011
@@ -32,18 +32,18 @@ import javax.jms.TextMessage;
 import javax.xml.bind.JAXBContext;
 import javax.xml.bind.JAXBException;
 
-import org.apache.commons.logging.Log;
-import org.apache.commons.logging.LogFactory;
 import org.apache.servicemix.wsn.AbstractPullPoint;
 import org.oasis_open.docs.wsn.b_2.NotificationMessageHolderType;
 import org.oasis_open.docs.wsn.b_2.Notify;
 import org.oasis_open.docs.wsn.b_2.UnableToGetMessagesFaultType;
 import org.oasis_open.docs.wsn.bw_2.UnableToGetMessagesFault;
 import org.oasis_open.docs.wsrf.rw_2.ResourceUnknownFault;
+import org.slf4j.Logger;
+import org.slf4j.LoggerFactory;
 
 public class JmsPullPoint extends AbstractPullPoint {
 
-    private static Log log = LogFactory.getLog(JmsPullPoint.class);
+    private final Logger logger = LoggerFactory.getLogger(JmsPullPoint.class);
 
     private JAXBContext jaxbContext;
 
@@ -86,18 +86,18 @@ public class JmsPullPoint extends Abstra
             Message message = session.createTextMessage(writer.toString());
             producer.send(message);
         } catch (JMSException e) {
-            log.warn("Error storing message", e);
+            logger.warn("Error storing message", e);
             if (session != null) {
                 try {
                     session.close();
                 } catch (JMSException inner) {
-                    log.debug("Error closing session", inner);
+                    logger.debug("Error closing session", inner);
                 } finally {
                     session = null;
                 }
             }
         } catch (JAXBException e) {
-            log.warn("Error storing message", e);
+            logger.warn("Error storing message", e);
         }
     }
 
@@ -122,12 +122,12 @@ public class JmsPullPoint extends Abstra
             }
             return messages;
         } catch (JMSException e) {
-            log.info("Error retrieving messages", e);
+            logger.info("Error retrieving messages", e);
             if (session != null) {
                 try {
                     session.close();
                 } catch (JMSException inner) {
-                    log.debug("Error closing session", inner);
+                    logger.debug("Error closing session", inner);
                 } finally {
                     session = null;
                 }
@@ -135,7 +135,7 @@ public class JmsPullPoint extends Abstra
             UnableToGetMessagesFaultType fault = new UnableToGetMessagesFaultType();
             throw new UnableToGetMessagesFault("Unable to retrieve messages", fault, e);
         } catch (JAXBException e) {
-            log.info("Error retrieving messages", e);
+            logger.info("Error retrieving messages", e);
             UnableToGetMessagesFaultType fault = new UnableToGetMessagesFaultType();
             throw new UnableToGetMessagesFault("Unable to retrieve messages", fault, e);
         }

Modified: servicemix/components/trunk/engines/servicemix-wsn2005/src/main/java/org/apache/servicemix/wsn/jms/JmsSubscription.java
URL: http://svn.apache.org/viewvc/servicemix/components/trunk/engines/servicemix-wsn2005/src/main/java/org/apache/servicemix/wsn/jms/JmsSubscription.java?rev=1067118&r1=1067117&r2=1067118&view=diff
==============================================================================
--- servicemix/components/trunk/engines/servicemix-wsn2005/src/main/java/org/apache/servicemix/wsn/jms/JmsSubscription.java (original)
+++ servicemix/components/trunk/engines/servicemix-wsn2005/src/main/java/org/apache/servicemix/wsn/jms/JmsSubscription.java Fri Feb  4 09:05:47 2011
@@ -34,12 +34,12 @@ import javax.xml.xpath.XPathExpression;
 import javax.xml.xpath.XPathExpressionException;
 import javax.xml.xpath.XPathFactory;
 
+import org.slf4j.Logger;
+import org.slf4j.LoggerFactory;
 import org.w3c.dom.Document;
 import org.w3c.dom.Element;
 import org.xml.sax.InputSource;
 
-import org.apache.commons.logging.Log;
-import org.apache.commons.logging.LogFactory;
 import org.apache.servicemix.wsn.AbstractSubscription;
 import org.oasis_open.docs.wsn.b_2.InvalidTopicExpressionFaultType;
 import org.oasis_open.docs.wsn.b_2.PauseFailedFaultType;
@@ -65,7 +65,7 @@ import org.oasis_open.docs.wsn.bw_2.Unre
 
 public abstract class JmsSubscription extends AbstractSubscription implements MessageListener {
 
-    private static Log log = LogFactory.getLog(JmsSubscription.class);
+    private final Logger logger = LoggerFactory.getLogger(JmsSubscription.class);
 
     private Connection connection;
 
@@ -194,7 +194,7 @@ public abstract class JmsSubscription ex
                 }
             }
         } catch (Exception e) {
-            log.warn("Error notifying consumer", e);
+            logger.warn("Error notifying consumer", e);
         }
     }
 
@@ -210,7 +210,7 @@ public abstract class JmsSubscription ex
                 Boolean ret = (Boolean) exp.evaluate(content, XPathConstants.BOOLEAN);
                 return ret.booleanValue();
             } catch (XPathExpressionException e) {
-                log.warn("Could not filter notification", e);
+                logger.warn("Could not filter notification", e);
             }
             return false;
         }

Modified: servicemix/components/trunk/engines/servicemix-wsn2005/src/main/java/org/apache/servicemix/wsn/spring/PublisherComponent.java
URL: http://svn.apache.org/viewvc/servicemix/components/trunk/engines/servicemix-wsn2005/src/main/java/org/apache/servicemix/wsn/spring/PublisherComponent.java?rev=1067118&r1=1067117&r2=1067118&view=diff
==============================================================================
--- servicemix/components/trunk/engines/servicemix-wsn2005/src/main/java/org/apache/servicemix/wsn/spring/PublisherComponent.java (original)
+++ servicemix/components/trunk/engines/servicemix-wsn2005/src/main/java/org/apache/servicemix/wsn/spring/PublisherComponent.java Fri Feb  4 09:05:47 2011
@@ -26,10 +26,10 @@ import javax.jbi.messaging.NormalizedMes
 import javax.xml.bind.JAXBContext;
 import javax.xml.transform.Source;
 
+import org.slf4j.Logger;
+import org.slf4j.LoggerFactory;
 import org.w3c.dom.Element;
 
-import org.apache.commons.logging.Log;
-import org.apache.commons.logging.LogFactory;
 import org.apache.servicemix.components.util.ComponentSupport;
 import org.apache.servicemix.jbi.jaxp.SourceTransformer;
 import org.apache.servicemix.jbi.jaxp.StringSource;
@@ -54,7 +54,7 @@ import org.oasis_open.docs.wsn.b_2.Unsub
  */
 public class PublisherComponent extends ComponentSupport implements MessageExchangeListener {
 
-    private static final Log LOG = LogFactory.getLog(PublisherComponent.class);
+    private final Logger logger = LoggerFactory.getLogger(PublisherComponent.class);
 
     private NotificationBroker wsnBroker;
 
@@ -122,7 +122,7 @@ public class PublisherComponent extends 
                             + subscriptionEndpoint;
                     wsnBroker.registerPublisher(AbstractWSAClient.createWSA(wsaAddress), topic, demand);
                 } catch (Exception e) {
-                    LOG.error("Could not create wsn client", e);
+                    logger.error("Could not create wsn client", e);
                 }
             }
         } .start();
@@ -183,7 +183,7 @@ public class PublisherComponent extends 
                     wsnBroker.notify(topic, elem);
                     done(exchange);
                 } else {
-                    LOG.info("Ingore notification as the publisher is no subscribers");
+                    logger.info("Ingore notification as the publisher is no subscribers");
                 }
             } catch (Exception e) {
                 fail(exchange, e);

Modified: servicemix/components/trunk/pom.xml
URL: http://svn.apache.org/viewvc/servicemix/components/trunk/pom.xml?rev=1067118&r1=1067117&r2=1067118&view=diff
==============================================================================
--- servicemix/components/trunk/pom.xml (original)
+++ servicemix/components/trunk/pom.xml Fri Feb  4 09:05:47 2011
@@ -35,7 +35,7 @@
     <description>This pom provides the common bits for all ServiceMix components, as well as providing a reactor build for those components.</description>
 
     <prerequisites>
-        <maven>2.0.6</maven>
+        <maven>2.2.1</maven>
     </prerequisites>
 
     <scm>
@@ -128,7 +128,6 @@
         <commons-httpclient.version>3.1</commons-httpclient.version>
         <commons-io.version>1.4</commons-io.version>
         <commons-jexl.version>2.0.1</commons-jexl.version>
-        <commons-logging.version>1.1.1</commons-logging.version>
         <commons-management.version>1.0</commons-management.version>
         <commons-net.version>1.4.1</commons-net.version>
         <commons-pool.version>1.5.4</commons-pool.version>
@@ -257,27 +256,6 @@
                 <version>${commons-io.version}</version>
             </dependency>
             <dependency>
-                <groupId>commons-logging</groupId>
-                <artifactId>commons-logging</artifactId>
-                <version>${commons-logging.version}</version>
-                <optional>true</optional>
-                <scope>provided</scope>
-                <exclusions>
-                    <exclusion>
-                        <groupId>avalon-framework</groupId>
-                        <artifactId>avalon-framework</artifactId>
-                    </exclusion>
-                    <exclusion>
-                        <groupId>logkit</groupId>
-                        <artifactId>logkit</artifactId>
-                    </exclusion>
-                    <exclusion>
-                        <groupId>javax.servlet</groupId>
-                        <artifactId>servlet-api</artifactId>
-                    </exclusion>
-                </exclusions>
-            </dependency>
-            <dependency>
                 <groupId>commons-net</groupId>
                 <artifactId>commons-net</artifactId>
                 <version>${commons-net.version}</version>
@@ -599,6 +577,11 @@
                 <version>${slf4j.version}</version>
             </dependency>
             <dependency>
+                <groupId>org.slf4j</groupId>
+                <artifactId>slf4j-simple</artifactId>
+                <version>${slf4j.version}</version>
+            </dependency>
+            <dependency>
                 <groupId>org.ops4j.pax.exam</groupId>
                 <artifactId>pax-exam</artifactId>
                 <version>${pax.exam.version}</version>

Modified: servicemix/components/trunk/shared-libraries/servicemix-common/pom.xml
URL: http://svn.apache.org/viewvc/servicemix/components/trunk/shared-libraries/servicemix-common/pom.xml?rev=1067118&r1=1067117&r2=1067118&view=diff
==============================================================================
--- servicemix/components/trunk/shared-libraries/servicemix-common/pom.xml (original)
+++ servicemix/components/trunk/shared-libraries/servicemix-common/pom.xml Fri Feb  4 09:05:47 2011
@@ -98,10 +98,6 @@
             <artifactId>xbean-classloader</artifactId>
         </dependency>
         <dependency>
-            <groupId>commons-logging</groupId>
-            <artifactId>commons-logging</artifactId>
-        </dependency>
-        <dependency>
             <groupId>org.springframework</groupId>
             <artifactId>spring-context</artifactId>
         </dependency>
@@ -126,6 +122,17 @@
             <scope>provided</scope>
         </dependency>
         <dependency>
+            <groupId>org.slf4j</groupId>
+            <artifactId>slf4j-api</artifactId>
+            <scope>provided</scope>
+        </dependency>
+        <dependency>
+            <groupId>org.slf4j</groupId>
+            <artifactId>slf4j-log4j12</artifactId>
+            <scope>test</scope>
+        </dependency>
+
+        <dependency>
             <groupId>org.apache.activemq</groupId>
             <artifactId>activemq-ra</artifactId>
             <scope>test</scope>
@@ -156,6 +163,7 @@
         <dependency>
             <groupId>org.easymock</groupId>
             <artifactId>easymock</artifactId>
+            <scope>test</scope>
         </dependency>
     </dependencies>
 

Modified: servicemix/components/trunk/shared-libraries/servicemix-common/src/main/java/org/apache/servicemix/common/AbstractDeployer.java
URL: http://svn.apache.org/viewvc/servicemix/components/trunk/shared-libraries/servicemix-common/src/main/java/org/apache/servicemix/common/AbstractDeployer.java?rev=1067118&r1=1067117&r2=1067118&view=diff
==============================================================================
--- servicemix/components/trunk/shared-libraries/servicemix-common/src/main/java/org/apache/servicemix/common/AbstractDeployer.java (original)
+++ servicemix/components/trunk/shared-libraries/servicemix-common/src/main/java/org/apache/servicemix/common/AbstractDeployer.java Fri Feb  4 09:05:47 2011
@@ -16,7 +16,7 @@
  */
 package org.apache.servicemix.common;
 
-import org.apache.commons.logging.Log;
+import org.slf4j.Logger;
 
 import javax.jbi.JBIException;
 import javax.jbi.management.DeploymentException;
@@ -30,7 +30,7 @@ import javax.jbi.management.DeploymentEx
  */
 public abstract class AbstractDeployer implements Deployer {
 
-    protected final transient Log logger;
+    protected final transient Logger logger;
     
     protected ServiceMixComponent component;
     

Modified: servicemix/components/trunk/shared-libraries/servicemix-common/src/main/java/org/apache/servicemix/common/AsyncBaseLifeCycle.java
URL: http://svn.apache.org/viewvc/servicemix/components/trunk/shared-libraries/servicemix-common/src/main/java/org/apache/servicemix/common/AsyncBaseLifeCycle.java?rev=1067118&r1=1067117&r2=1067118&view=diff
==============================================================================
--- servicemix/components/trunk/shared-libraries/servicemix-common/src/main/java/org/apache/servicemix/common/AsyncBaseLifeCycle.java (original)
+++ servicemix/components/trunk/shared-libraries/servicemix-common/src/main/java/org/apache/servicemix/common/AsyncBaseLifeCycle.java Fri Feb  4 09:05:47 2011
@@ -40,14 +40,16 @@ import javax.transaction.Transaction;
 import javax.transaction.TransactionManager;
 import javax.xml.namespace.QName;
 
-import org.apache.commons.logging.Log;
 import org.apache.servicemix.executors.Executor;
 import org.apache.servicemix.executors.ExecutorFactory;
 import org.apache.servicemix.executors.impl.ExecutorFactoryImpl;
+import org.slf4j.Logger;
 
 /**
+ * <p>
  * Base class for life cycle management of components. This class may be used as
  * is.
+ * </p>
  *
  * @author Guillaume Nodet
  * @version $Revision: 399873 $
@@ -57,7 +59,7 @@ public class AsyncBaseLifeCycle implemen
 
     public static final String INITIALIZED = "Initialized";
 
-    protected transient Log logger;
+    protected transient Logger logger;
 
     protected ServiceMixComponent component;
 
@@ -188,9 +190,7 @@ public class AsyncBaseLifeCycle implemen
 
     public void init(ComponentContext context) throws JBIException {
         try {
-            if (logger.isDebugEnabled()) {
-                logger.debug("Initializing component");
-            }
+            logger.debug("Initializing component");
             Thread.currentThread().setContextClassLoader(component.getClass().getClassLoader());
             this.context = context;
             this.channel = context.getDeliveryChannel();
@@ -204,9 +204,7 @@ public class AsyncBaseLifeCycle implemen
             container = Container.detect(context);
             doInit();
             setCurrentState(INITIALIZED);
-            if (logger.isDebugEnabled()) {
-                logger.debug("Component initialized");
-            }
+            logger.debug("Component initialized");
         } catch (JBIException e) {
             throw e;
         } catch (Exception e) {
@@ -256,16 +254,12 @@ public class AsyncBaseLifeCycle implemen
 
     public void shutDown() throws JBIException {
         try {
-            if (logger.isDebugEnabled()) {
-                logger.debug("Shutting down component");
-            }
+            logger.debug("Shutting down component");
             Thread.currentThread().setContextClassLoader(component.getClass().getClassLoader());
             doShutDown();
             setCurrentState(LifeCycleMBean.SHUTDOWN);
             this.context = null;
-            if (logger.isDebugEnabled()) {
-                logger.debug("Component shut down");
-            }
+            logger.debug("Component shut down");
         } catch (JBIException e) {
             throw e;
         } catch (Exception e) {
@@ -299,17 +293,13 @@ public class AsyncBaseLifeCycle implemen
 
     public void start() throws JBIException {
         try {
-            if (logger.isDebugEnabled()) {
-                logger.debug("Starting component");
-            }
+            logger.debug("Starting component");
             Thread.currentThread().setContextClassLoader(component.getClass().getClassLoader());
             if (this.running.compareAndSet(false, true)) {
                 doStart();
                 setCurrentState(LifeCycleMBean.STARTED);
             }
-            if (logger.isDebugEnabled()) {
-                logger.debug("Component started");
-            }
+            logger.debug("Component started");
         } catch (JBIException e) {
             throw e;
         } catch (Exception e) {
@@ -374,9 +364,7 @@ public class AsyncBaseLifeCycle implemen
             } catch (Throwable t) {
                 if (running.get() == false) {
                     // Should have been interrupted, discard the throwable
-                    if (logger.isDebugEnabled()) {
-                        logger.debug("Polling thread will stop");
-                    }
+                    logger.debug("Polling thread will stop");
                 } else {
                     logger.error("Error polling delivery channel", t);
                 }
@@ -396,17 +384,13 @@ public class AsyncBaseLifeCycle implemen
 
     public void stop() throws JBIException {
         try {
-            if (logger.isDebugEnabled()) {
-                logger.debug("Stopping component");
-            }
+            logger.debug("Stopping component");
             Thread.currentThread().setContextClassLoader(component.getClass().getClassLoader());
             if (this.running.compareAndSet(true, false)) {
                 doStop();
                 setCurrentState(LifeCycleMBean.STOPPED);
             }
-            if (logger.isDebugEnabled()) {
-                logger.debug("Component stopped");
-            }
+            logger.debug("Component stopped");
         } catch (JBIException e) {
             throw e;
         } catch (Exception e) {
@@ -582,10 +566,8 @@ public class AsyncBaseLifeCycle implemen
     }
 
     protected void processExchange(MessageExchange exchange) throws Exception {
-        if (logger.isDebugEnabled()) {
-            logger.debug("Received exchange: status: " + exchange.getStatus() + ", role: "
+        logger.debug("Received exchange: status: " + exchange.getStatus() + ", role: "
                     + (exchange.getRole() == Role.CONSUMER ? "consumer" : "provider"));
-        }
         if (exchange.getRole() == Role.PROVIDER) {
             boolean dynamic = false;
             ServiceEndpoint endpoint = exchange.getEndpoint();
@@ -643,9 +625,7 @@ public class AsyncBaseLifeCycle implemen
                 // Set the id in threadlocal variable
                 correlationId.set(correlationID);
             }
-            if (logger.isDebugEnabled()) {
-                logger.debug("Retrieved correlation id: " + correlationID);
-            }
+            logger.debug("Retrieved correlation id: " + correlationID);
             EndpointDeliveryChannel.setEndpoint(ep);
             handleExchange(ep, exchange, exchange.getStatus() == ExchangeStatus.ACTIVE);
             ep.process(exchange);
@@ -673,15 +653,11 @@ public class AsyncBaseLifeCycle implemen
                     // to trace the process instance
                     correlationIDValue = exchange.getExchangeId();
                     exchange.setProperty(JbiConstants.CORRELATION_ID, exchange.getExchangeId());
-                    if (logger.isDebugEnabled()) {
-                        logger.debug("Created correlation id: " + correlationIDValue);
-                    }
+                    logger.debug("Created correlation id: " + correlationIDValue);
                 } else {
                     // Use correlation id retrieved from previous message exchange
                     exchange.setProperty(JbiConstants.CORRELATION_ID, correlationIDValue);
-                    if (logger.isDebugEnabled()) {
-                        logger.debug("Correlation id retrieved from ThreadLocal: " + correlationIDValue);
-                    }
+                    logger.debug("Correlation id retrieved from ThreadLocal: " + correlationIDValue);
                 }
             }
             // Set the sender endpoint property

Modified: servicemix/components/trunk/shared-libraries/servicemix-common/src/main/java/org/apache/servicemix/common/BaseBootstrap.java
URL: http://svn.apache.org/viewvc/servicemix/components/trunk/shared-libraries/servicemix-common/src/main/java/org/apache/servicemix/common/BaseBootstrap.java?rev=1067118&r1=1067117&r2=1067118&view=diff
==============================================================================
--- servicemix/components/trunk/shared-libraries/servicemix-common/src/main/java/org/apache/servicemix/common/BaseBootstrap.java (original)
+++ servicemix/components/trunk/shared-libraries/servicemix-common/src/main/java/org/apache/servicemix/common/BaseBootstrap.java Fri Feb  4 09:05:47 2011
@@ -16,8 +16,8 @@
  */
 package org.apache.servicemix.common;
 
-import org.apache.commons.logging.Log;
-import org.apache.commons.logging.LogFactory;
+import org.slf4j.Logger;
+import org.slf4j.LoggerFactory;
 
 import javax.jbi.JBIException;
 import javax.jbi.component.Bootstrap;
@@ -26,11 +26,13 @@ import javax.management.MBeanServer;
 import javax.management.ObjectName;
 
 /**
+ * <p>
  * Base class for components bootstrap.
  * Due to classloading mechanism in JBI, Shared Libraries are
  * not available at bootstrap time, so this class should be
  * copied in your own component and modified directly, instead
  * of inheriting it.
+ * </p>
  * 
  * @author Guillaume Nodet
  * @version $Revision$
@@ -40,7 +42,7 @@ import javax.management.ObjectName;
 @Deprecated
 public class BaseBootstrap implements Bootstrap {
 
-    protected final transient Log logger = LogFactory.getLog(getClass());
+    protected final transient Logger logger = LoggerFactory.getLogger(BaseBootstrap.class);
     
     protected InstallationContext context;
     protected ObjectName mbeanName;
@@ -65,14 +67,10 @@ public class BaseBootstrap implements Bo
      */
     public void init(InstallationContext installContext) throws JBIException {
         try {
-            if (logger.isDebugEnabled()) {
-                logger.debug("Initializing bootstrap");
-            }
+            logger.debug("Initializing bootstrap");
             this.context = installContext;
             doInit();
-            if (logger.isDebugEnabled()) {
-                logger.debug("Bootstrap initialized");
-            }
+            logger.debug("Bootstrap initialized");
         } catch (JBIException e) {
             throw e;
         } catch (Exception e) {
@@ -100,13 +98,9 @@ public class BaseBootstrap implements Bo
      */
     public void cleanUp() throws JBIException {
         try {
-            if (logger.isDebugEnabled()) {
-                logger.debug("Cleaning up bootstrap");
-            }
+            logger.debug("Cleaning up bootstrap");
             doCleanUp();
-            if (logger.isDebugEnabled()) {
-                logger.debug("Bootstrap cleaned up");
-            }
+            logger.debug("Bootstrap cleaned up");
         } catch (JBIException e) {
             throw e;
         } catch (Exception e) {
@@ -131,13 +125,9 @@ public class BaseBootstrap implements Bo
      */
     public void onInstall() throws JBIException {
         try {
-            if (logger.isDebugEnabled()) {
-                logger.debug("Bootstrap onInstall");
-            }
+            logger.debug("Bootstrap onInstall");
             doOnInstall();
-            if (logger.isDebugEnabled()) {
-                logger.debug("Bootstrap onInstall done");
-            }
+            logger.debug("Bootstrap onInstall done");
         } catch (JBIException e) {
             throw e;
         } catch (Exception e) {
@@ -153,13 +143,9 @@ public class BaseBootstrap implements Bo
      */
     public void onUninstall() throws JBIException {
         try {
-            if (logger.isDebugEnabled()) {
-                logger.debug("Bootstrap onUninstall");
-            }
+            logger.debug("Bootstrap onUninstall");
             doOnUninstall();
-            if (logger.isDebugEnabled()) {
-                logger.debug("Bootstrap onUninstall done");
-            }
+            logger.debug("Bootstrap onUninstall done");
         } catch (JBIException e) {
             throw e;
         } catch (Exception e) {

Modified: servicemix/components/trunk/shared-libraries/servicemix-common/src/main/java/org/apache/servicemix/common/BaseComponent.java
URL: http://svn.apache.org/viewvc/servicemix/components/trunk/shared-libraries/servicemix-common/src/main/java/org/apache/servicemix/common/BaseComponent.java?rev=1067118&r1=1067117&r2=1067118&view=diff
==============================================================================
--- servicemix/components/trunk/shared-libraries/servicemix-common/src/main/java/org/apache/servicemix/common/BaseComponent.java (original)
+++ servicemix/components/trunk/shared-libraries/servicemix-common/src/main/java/org/apache/servicemix/common/BaseComponent.java Fri Feb  4 09:05:47 2011
@@ -16,9 +16,9 @@
  */
 package org.apache.servicemix.common;
 
-import org.apache.commons.logging.Log;
-import org.apache.commons.logging.LogFactory;
 import org.apache.servicemix.executors.Executor;
+import org.slf4j.Logger;
+import org.slf4j.LoggerFactory;
 import org.w3c.dom.Document;
 import org.w3c.dom.DocumentFragment;
 
@@ -32,7 +32,9 @@ import javax.jbi.servicedesc.ServiceEndp
 import javax.xml.namespace.QName;
 
 /**
+ * <p>
  * Base class for a component.
+ * </p>
  * 
  * @author Guillaume Nodet
  * @version $Revision$
@@ -41,7 +43,7 @@ import javax.xml.namespace.QName;
 @Deprecated
 public abstract class BaseComponent implements ServiceMixComponent {
 
-	protected final transient Log logger = LogFactory.getLog(getClass());
+    protected final transient Logger logger = LoggerFactory.getLogger(BaseComponent.class);
     
     protected BaseLifeCycle lifeCycle;
     protected Registry registry;
@@ -71,23 +73,17 @@ public abstract class BaseComponent impl
      * @see javax.jbi.component.Component#getServiceDescription(javax.jbi.servicedesc.ServiceEndpoint)
      */
     public Document getServiceDescription(ServiceEndpoint endpoint) {
-        if (logger.isDebugEnabled()) {
-            logger.debug("Querying service description for " + endpoint);
-        }
+        logger.debug("Querying service description for " + endpoint);
         String key = EndpointSupport.getKey(endpoint);
         Endpoint ep = this.registry.getEndpoint(key);
         if (ep != null) {
             Document doc = ep.getDescription();
             if (doc == null) {
-                if (logger.isDebugEnabled()) {
-                    logger.debug("No description found for " + key);
-                }
+                logger.debug("No description found for " + key);
             }
             return doc;
         } else {
-            if (logger.isDebugEnabled()) {
-                logger.debug("No endpoint found for " + key);
-            }
+            logger.debug("No endpoint found for " + key);
             return null;
         }
     }
@@ -100,17 +96,13 @@ public abstract class BaseComponent impl
         Endpoint ep = this.registry.getEndpoint(key);
         if (ep != null) {
             if (ep.getRole() != Role.PROVIDER) {
-                if (logger.isDebugEnabled()) {
-                    logger.debug("Endpoint " + key + " is a consumer. Refusing exchange with consumer.");
-                }
+                logger.debug("Endpoint " + key + " is a consumer. Refusing exchange with consumer.");
                 return false;
             } else {
                 return ep.isExchangeOkay(exchange);
             }
         } else {
-            if (logger.isDebugEnabled()) {
-                logger.debug("No endpoint found for " + key + ". Refusing exchange with consumer.");
-            }
+            logger.debug("No endpoint found for " + key + ". Refusing exchange with consumer.");
             return false;
         }
     }
@@ -171,7 +163,7 @@ public abstract class BaseComponent impl
     /**
      * @return Returns the logger.
      */
-    public Log getLogger() {
+    public Logger getLogger() {
         return logger;
     }
 

Modified: servicemix/components/trunk/shared-libraries/servicemix-common/src/main/java/org/apache/servicemix/common/BaseLifeCycle.java
URL: http://svn.apache.org/viewvc/servicemix/components/trunk/shared-libraries/servicemix-common/src/main/java/org/apache/servicemix/common/BaseLifeCycle.java?rev=1067118&r1=1067117&r2=1067118&view=diff
==============================================================================
--- servicemix/components/trunk/shared-libraries/servicemix-common/src/main/java/org/apache/servicemix/common/BaseLifeCycle.java (original)
+++ servicemix/components/trunk/shared-libraries/servicemix-common/src/main/java/org/apache/servicemix/common/BaseLifeCycle.java Fri Feb  4 09:05:47 2011
@@ -22,8 +22,10 @@ import javax.transaction.Status;
 import org.apache.servicemix.MessageExchangeListener;
 
 /**
+ * <p>
  * Base class for life cycle management of components.
- * This lifecycle uses Push delivery by implementing MessageExchangeListerner interface
+ * This lifecycle uses Push delivery by implementing MessageExchangeListerner interface.
+ * </p>
  * 
  * @author Guillaume Nodet
  * @version $Revision$

Modified: servicemix/components/trunk/shared-libraries/servicemix-common/src/main/java/org/apache/servicemix/common/BaseServiceUnitManager.java
URL: http://svn.apache.org/viewvc/servicemix/components/trunk/shared-libraries/servicemix-common/src/main/java/org/apache/servicemix/common/BaseServiceUnitManager.java?rev=1067118&r1=1067117&r2=1067118&view=diff
==============================================================================
--- servicemix/components/trunk/shared-libraries/servicemix-common/src/main/java/org/apache/servicemix/common/BaseServiceUnitManager.java (original)
+++ servicemix/components/trunk/shared-libraries/servicemix-common/src/main/java/org/apache/servicemix/common/BaseServiceUnitManager.java Fri Feb  4 09:05:47 2011
@@ -16,24 +16,26 @@
  */
 package org.apache.servicemix.common;
 
-import org.apache.commons.logging.Log;
+import org.slf4j.Logger;
 
 import javax.jbi.component.ServiceUnitManager;
 import javax.jbi.management.DeploymentException;
 import javax.jbi.management.LifeCycleMBean;
 
 /**
+ * <p>
  * A simple service unit manager.
  * This service unit manager uses {@link Deployer} objects
  * to handle different type of service units.
- * 
+ * </p>
+ *
  * @author Guillaume Nodet
  * @version $Revision$
  * @since 3.0
  */
 public class BaseServiceUnitManager implements ServiceUnitManager {
 
-    protected final transient Log logger;
+    private final transient Logger logger;
     
     protected ServiceMixComponent component;
     
@@ -57,9 +59,7 @@ public class BaseServiceUnitManager impl
      */
     public synchronized String deploy(String serviceUnitName, String serviceUnitRootPath) throws DeploymentException {
         try {
-            if (logger.isDebugEnabled()) {
-                logger.debug("Deploying service unit");
-            }
+            logger.debug("Deploying service unit");
             if (serviceUnitName == null || serviceUnitName.length() == 0) {
                 throw new IllegalArgumentException("serviceUnitName should be non null and non empty");
             }
@@ -71,9 +71,7 @@ public class BaseServiceUnitManager impl
                 throw failure("deploy", "Unable to find suitable deployer for Service Unit '" + serviceUnitName + "'", null);
             }
             component.getRegistry().registerServiceUnit(su);
-            if (logger.isDebugEnabled()) {
-                logger.debug("Service unit deployed");
-            }
+            logger.debug("Service unit deployed");
             return createSuccessMessage("deploy");
         } catch (DeploymentException e) {
             throw e;
@@ -97,9 +95,7 @@ public class BaseServiceUnitManager impl
     public synchronized void init(String serviceUnitName, String serviceUnitRootPath) throws DeploymentException {
         ClassLoader cl = Thread.currentThread().getContextClassLoader();
         try {
-            if (logger.isDebugEnabled()) {
-                logger.debug("Initializing service unit");
-            }
+            logger.debug("Initializing service unit");
             if (serviceUnitName == null || serviceUnitName.length() == 0) {
                 throw new IllegalArgumentException("serviceUnitName should be non null and non empty");
             }
@@ -120,9 +116,7 @@ public class BaseServiceUnitManager impl
             }
             Thread.currentThread().setContextClassLoader(su.getConfigurationClassLoader());
             su.init();
-            if (logger.isDebugEnabled()) {
-                logger.debug("Service unit initialized");
-            }
+            logger.debug("Service unit initialized");
         } catch (DeploymentException e) {
             throw e;
         } catch (Exception e) {
@@ -138,9 +132,7 @@ public class BaseServiceUnitManager impl
     public synchronized void start(String serviceUnitName) throws DeploymentException {
         ClassLoader cl = Thread.currentThread().getContextClassLoader();
         try {
-            if (logger.isDebugEnabled()) {
-                logger.debug("Starting service unit");
-            }
+            logger.debug("Starting service unit");
             if (serviceUnitName == null || serviceUnitName.length() == 0) {
                 throw new IllegalArgumentException("serviceUnitName should be non null and non empty");
             }
@@ -153,9 +145,7 @@ public class BaseServiceUnitManager impl
             }
             Thread.currentThread().setContextClassLoader(su.getConfigurationClassLoader());
             su.start();
-            if (logger.isDebugEnabled()) {
-                logger.debug("Service unit started");
-            }
+            logger.debug("Service unit started");
         } catch (DeploymentException e) {
             throw e;
         } catch (Exception e) {
@@ -171,9 +161,7 @@ public class BaseServiceUnitManager impl
     public synchronized void stop(String serviceUnitName) throws DeploymentException {
         ClassLoader cl = Thread.currentThread().getContextClassLoader();
         try {
-            if (logger.isDebugEnabled()) {
-                logger.debug("Stopping service unit");
-            }
+            logger.debug("Stopping service unit");
             if (serviceUnitName == null || serviceUnitName.length() == 0) {
                 throw new IllegalArgumentException("serviceUnitName should be non null and non empty");
             }
@@ -186,9 +174,7 @@ public class BaseServiceUnitManager impl
             }
             Thread.currentThread().setContextClassLoader(su.getConfigurationClassLoader());
             su.stop();
-            if (logger.isDebugEnabled()) {
-                logger.debug("Service unit stopped");
-            }
+            logger.debug("Service unit stopped");
         } catch (DeploymentException e) {
             throw e;
         } catch (Exception e) {
@@ -204,9 +190,7 @@ public class BaseServiceUnitManager impl
     public synchronized void shutDown(String serviceUnitName) throws DeploymentException {
         ClassLoader cl = Thread.currentThread().getContextClassLoader();
         try {
-            if (logger.isDebugEnabled()) {
-                logger.debug("Shutting down service unit");
-            }
+            logger.debug("Shutting down service unit");
             if (serviceUnitName == null || serviceUnitName.length() == 0) {
                 throw new IllegalArgumentException("serviceUnitName should be non null and non empty");
             }
@@ -219,9 +203,7 @@ public class BaseServiceUnitManager impl
             }
             Thread.currentThread().setContextClassLoader(su.getConfigurationClassLoader());
             su.shutDown();
-            if (logger.isDebugEnabled()) {
-                logger.debug("Service unit shut down");
-            }
+            logger.debug("Service unit shut down");
         } catch (DeploymentException e) {
             throw e;
         } catch (Exception e) {
@@ -237,12 +219,8 @@ public class BaseServiceUnitManager impl
     public synchronized String undeploy(String serviceUnitName, String serviceUnitRootPath) throws DeploymentException {
         ClassLoader cl = Thread.currentThread().getContextClassLoader();
         try {
-            if (logger.isDebugEnabled()) {
-                logger.debug("Undeploying service unit");
-            }
-            if (logger.isDebugEnabled()) {
-                logger.debug("Shutting down service unit");
-            }
+            logger.debug("Undeploying service unit");
+            logger.debug("Shutting down service unit");
             if (serviceUnitName == null || serviceUnitName.length() == 0) {
                 throw new IllegalArgumentException("serviceUnitName should be non null and non empty");
             }
@@ -258,9 +236,7 @@ public class BaseServiceUnitManager impl
                 doUndeploy(su);
             }
             component.getRegistry().unregisterServiceUnit(su);
-            if (logger.isDebugEnabled()) {
-                logger.debug("Service unit undeployed");
-            }
+            logger.debug("Service unit undeployed");
             return createSuccessMessage("undeploy");
         } catch (DeploymentException e) {
             throw e;

Modified: servicemix/components/trunk/shared-libraries/servicemix-common/src/main/java/org/apache/servicemix/common/BasicWorkManager.java
URL: http://svn.apache.org/viewvc/servicemix/components/trunk/shared-libraries/servicemix-common/src/main/java/org/apache/servicemix/common/BasicWorkManager.java?rev=1067118&r1=1067117&r2=1067118&view=diff
==============================================================================
--- servicemix/components/trunk/shared-libraries/servicemix-common/src/main/java/org/apache/servicemix/common/BasicWorkManager.java (original)
+++ servicemix/components/trunk/shared-libraries/servicemix-common/src/main/java/org/apache/servicemix/common/BasicWorkManager.java Fri Feb  4 09:05:47 2011
@@ -27,7 +27,9 @@ import javax.resource.spi.work.WorkListe
 import javax.resource.spi.work.WorkManager;
 
 /**
+ * <p>
  * A simple WorkManager implementation on top of java.util.concurrent thread pool.
+ * </p>
  * 
  * @deprecated Components should use the executor on the ServiceMixComponent
  *      for thread pools

Modified: servicemix/components/trunk/shared-libraries/servicemix-common/src/main/java/org/apache/servicemix/common/DefaultBootstrap.java
URL: http://svn.apache.org/viewvc/servicemix/components/trunk/shared-libraries/servicemix-common/src/main/java/org/apache/servicemix/common/DefaultBootstrap.java?rev=1067118&r1=1067117&r2=1067118&view=diff
==============================================================================
--- servicemix/components/trunk/shared-libraries/servicemix-common/src/main/java/org/apache/servicemix/common/DefaultBootstrap.java (original)
+++ servicemix/components/trunk/shared-libraries/servicemix-common/src/main/java/org/apache/servicemix/common/DefaultBootstrap.java Fri Feb  4 09:05:47 2011
@@ -23,12 +23,14 @@ import javax.management.MBeanServer;
 import javax.management.ObjectName;
 
 /**
+ * <p>
  * Default Bootstrap class.
  * 
  * This is a default implementation of the Bootstrap,  it is used by the 
  * Maven JBI plugin to provide a standard implementation of a Bootstrap
  * when a component does not provide one, so even it is tagged as deprecated,
  * it should not be removed.
+ * </p>
  * 
  * @deprecated Due to JBI classloader mechanism, component should not
  *    use this class directly, but copy it, or rely on the maven-jbi-plugin

Modified: servicemix/components/trunk/shared-libraries/servicemix-common/src/main/java/org/apache/servicemix/common/DefaultComponent.java
URL: http://svn.apache.org/viewvc/servicemix/components/trunk/shared-libraries/servicemix-common/src/main/java/org/apache/servicemix/common/DefaultComponent.java?rev=1067118&r1=1067117&r2=1067118&view=diff
==============================================================================
--- servicemix/components/trunk/shared-libraries/servicemix-common/src/main/java/org/apache/servicemix/common/DefaultComponent.java (original)
+++ servicemix/components/trunk/shared-libraries/servicemix-common/src/main/java/org/apache/servicemix/common/DefaultComponent.java Fri Feb  4 09:05:47 2011
@@ -17,10 +17,10 @@
  */
 package org.apache.servicemix.common;
 
-import org.apache.commons.logging.Log;
-import org.apache.commons.logging.LogFactory;
 import org.apache.servicemix.common.xbean.XBeanServiceUnit;
 import org.apache.servicemix.common.xbean.BaseXBeanDeployer;
+import org.slf4j.Logger;
+import org.slf4j.LoggerFactory;
 import org.w3c.dom.Document;
 import org.w3c.dom.DocumentFragment;
 
@@ -38,14 +38,16 @@ import java.util.Iterator;
 import java.util.Collections;
 
 /**
+ * <p>
  * A useful base class for writing new JBI components which includes the {@link ComponentLifeCycle} interface methods so that
  * you can write a new component in a single class with minimal overloading.
+ * </p>
  *
  * @version $Revision$
  */
 public class DefaultComponent extends AsyncBaseLifeCycle implements ServiceMixComponent {
 
-    protected final transient Log logger = LogFactory.getLog(getClass());
+    protected final transient Logger logger = LoggerFactory.getLogger(DefaultComponent.class);
 
     protected Registry registry;
     protected BaseServiceUnitManager serviceUnitManager;
@@ -54,8 +56,11 @@ public class DefaultComponent extends As
 
     public DefaultComponent() {
         setComponent(this);
+        logger.debug("Create the registry");
         registry = createRegistry();
+        logger.debug("Create the SU manager");
         serviceUnitManager = createServiceUnitManager();
+        logger.debug("Create the XBean SU");
         XBeanServiceUnit su = new XBeanServiceUnit();
         su.setName("#default#");
         su.setComponent(this);
@@ -90,24 +95,18 @@ public class DefaultComponent extends As
      * @see javax.jbi.component.Component#getServiceDescription(javax.jbi.servicedesc.ServiceEndpoint)
      */
     public Document getServiceDescription(ServiceEndpoint endpoint) {
-        if (logger.isDebugEnabled()) {
-            logger.debug("Querying service description for " + endpoint);
-        }
+        logger.debug("Querying service description for " + endpoint);
         String key = EndpointSupport.getKey(endpoint);
         Endpoint ep = this.registry.getEndpoint(key);
         if (ep != null) {
             Document doc = ep.getDescription();
             if (doc == null) {
-                if (logger.isDebugEnabled()) {
-                    logger.debug("No description found for " + key);
-                }
+                logger.debug("No description found for " + key);
             }
             return doc;
         }
         else {
-            if (logger.isDebugEnabled()) {
-                logger.debug("No endpoint found for " + key);
-            }
+            logger.debug("No endpoint found for " + key);
             return null;
         }
     }
@@ -120,9 +119,7 @@ public class DefaultComponent extends As
         Endpoint ep = this.registry.getEndpoint(key);
         if (ep != null) {
             if (ep.getRole() != MessageExchange.Role.PROVIDER) {
-                if (logger.isDebugEnabled()) {
-                    logger.debug("Endpoint " + key + " is a consumer. Refusing exchange with consumer.");
-                }
+                logger.debug("Endpoint " + key + " is a consumer. Refusing exchange with consumer.");
                 return false;
             }
             else {
@@ -130,9 +127,7 @@ public class DefaultComponent extends As
             }
         }
         else {
-            if (logger.isDebugEnabled()) {
-                logger.debug("No endpoint found for " + key + ". Refusing exchange with consumer.");
-            }
+            logger.debug("No endpoint found for " + key + ". Refusing exchange with consumer.");
             return false;
         }
     }
@@ -237,7 +232,7 @@ public class DefaultComponent extends As
     /**
      * @return Returns the logger.
      */
-    public Log getLogger() {
+    public Logger getLogger() {
         return logger;
     }
 

Modified: servicemix/components/trunk/shared-libraries/servicemix-common/src/main/java/org/apache/servicemix/common/Deployer.java
URL: http://svn.apache.org/viewvc/servicemix/components/trunk/shared-libraries/servicemix-common/src/main/java/org/apache/servicemix/common/Deployer.java?rev=1067118&r1=1067117&r2=1067118&view=diff
==============================================================================
--- servicemix/components/trunk/shared-libraries/servicemix-common/src/main/java/org/apache/servicemix/common/Deployer.java (original)
+++ servicemix/components/trunk/shared-libraries/servicemix-common/src/main/java/org/apache/servicemix/common/Deployer.java Fri Feb  4 09:05:47 2011
@@ -19,7 +19,9 @@ package org.apache.servicemix.common;
 import javax.jbi.management.DeploymentException;
 
 /**
+ * <p>
  * A deployer is responsible for handling one type of artifact deployment.
+ * </p>
  * 
  * @author Guillaume Nodet
  * @version $Revision$

Modified: servicemix/components/trunk/shared-libraries/servicemix-common/src/main/java/org/apache/servicemix/common/Endpoint.java
URL: http://svn.apache.org/viewvc/servicemix/components/trunk/shared-libraries/servicemix-common/src/main/java/org/apache/servicemix/common/Endpoint.java?rev=1067118&r1=1067117&r2=1067118&view=diff
==============================================================================
--- servicemix/components/trunk/shared-libraries/servicemix-common/src/main/java/org/apache/servicemix/common/Endpoint.java (original)
+++ servicemix/components/trunk/shared-libraries/servicemix-common/src/main/java/org/apache/servicemix/common/Endpoint.java Fri Feb  4 09:05:47 2011
@@ -16,16 +16,11 @@
  */
 package org.apache.servicemix.common;
 
-import org.apache.commons.logging.Log;
-import org.apache.servicemix.common.xbean.XBeanServiceUnit;
-
 import org.w3c.dom.Document;
 
 import javax.jbi.management.DeploymentException;
 import javax.jbi.messaging.MessageExchange;
-import javax.jbi.messaging.MessagingException;
 import javax.jbi.messaging.MessageExchange.Role;
-import javax.wsdl.Definition;
 import javax.xml.namespace.QName;
 
 public interface Endpoint {

Modified: servicemix/components/trunk/shared-libraries/servicemix-common/src/main/java/org/apache/servicemix/common/EndpointDeliveryChannel.java
URL: http://svn.apache.org/viewvc/servicemix/components/trunk/shared-libraries/servicemix-common/src/main/java/org/apache/servicemix/common/EndpointDeliveryChannel.java?rev=1067118&r1=1067117&r2=1067118&view=diff
==============================================================================
--- servicemix/components/trunk/shared-libraries/servicemix-common/src/main/java/org/apache/servicemix/common/EndpointDeliveryChannel.java (original)
+++ servicemix/components/trunk/shared-libraries/servicemix-common/src/main/java/org/apache/servicemix/common/EndpointDeliveryChannel.java Fri Feb  4 09:05:47 2011
@@ -30,10 +30,12 @@ import javax.transaction.InvalidTransact
 import javax.transaction.SystemException;
 
 /**
+ * <p>
  * This class is a wrapper around an existing DeliveryChannel
  * that will be given to service engine endpoints so that
  * they are able to send messages and to interact with the
  * JBI container.
+ * </p>
  * 
  * @author gnodet
  */

Modified: servicemix/components/trunk/shared-libraries/servicemix-common/src/main/java/org/apache/servicemix/common/ManagementSupport.java
URL: http://svn.apache.org/viewvc/servicemix/components/trunk/shared-libraries/servicemix-common/src/main/java/org/apache/servicemix/common/ManagementSupport.java?rev=1067118&r1=1067117&r2=1067118&view=diff
==============================================================================
--- servicemix/components/trunk/shared-libraries/servicemix-common/src/main/java/org/apache/servicemix/common/ManagementSupport.java (original)
+++ servicemix/components/trunk/shared-libraries/servicemix-common/src/main/java/org/apache/servicemix/common/ManagementSupport.java Fri Feb  4 09:05:47 2011
@@ -16,8 +16,8 @@
  */
 package org.apache.servicemix.common;
 
-import org.apache.commons.logging.Log;
-import org.apache.commons.logging.LogFactory;
+import org.slf4j.Logger;
+import org.slf4j.LoggerFactory;
 
 import java.io.PrintWriter;
 import java.io.StringWriter;
@@ -29,7 +29,7 @@ import javax.jbi.management.DeploymentEx
  */
 public class ManagementSupport {
     
-    private static final Log logger = LogFactory.getLog(ManagementSupport.class);
+    private static final Logger logger = LoggerFactory.getLogger(ManagementSupport.class);
 
     public static DeploymentException failure(String task, String component, String info, Throwable e) {
         Message msg = new Message();

Modified: servicemix/components/trunk/shared-libraries/servicemix-common/src/main/java/org/apache/servicemix/common/PersistentConfiguration.java
URL: http://svn.apache.org/viewvc/servicemix/components/trunk/shared-libraries/servicemix-common/src/main/java/org/apache/servicemix/common/PersistentConfiguration.java?rev=1067118&r1=1067117&r2=1067118&view=diff
==============================================================================
--- servicemix/components/trunk/shared-libraries/servicemix-common/src/main/java/org/apache/servicemix/common/PersistentConfiguration.java (original)
+++ servicemix/components/trunk/shared-libraries/servicemix-common/src/main/java/org/apache/servicemix/common/PersistentConfiguration.java Fri Feb  4 09:05:47 2011
@@ -23,14 +23,16 @@ import java.io.IOException;
 import java.util.Properties;
 
 /**
+ * <p>
  * Base class for component configuration.
  * Due to classloading mechanism in JBI, Shared Libraries are
  * not available at bootstrap time, so this class should be
  * copied in your own component and modified directly, instead
  * of inheriting it.  This only apply if the bootstrap uses the
  * configuration.
+ * </p>
  * 
- * @author Guillaume Nodet
+ * @author gnodet
  * @since 3.0
  */
 @Deprecated

Modified: servicemix/components/trunk/shared-libraries/servicemix-common/src/main/java/org/apache/servicemix/common/Registry.java
URL: http://svn.apache.org/viewvc/servicemix/components/trunk/shared-libraries/servicemix-common/src/main/java/org/apache/servicemix/common/Registry.java?rev=1067118&r1=1067117&r2=1067118&view=diff
==============================================================================
--- servicemix/components/trunk/shared-libraries/servicemix-common/src/main/java/org/apache/servicemix/common/Registry.java (original)
+++ servicemix/components/trunk/shared-libraries/servicemix-common/src/main/java/org/apache/servicemix/common/Registry.java Fri Feb  4 09:05:47 2011
@@ -18,7 +18,6 @@ package org.apache.servicemix.common;
 
 import java.util.Collection;
 import java.util.HashMap;
-import java.util.Iterator;
 import java.util.Map;
 
 public class Registry {

Modified: servicemix/components/trunk/shared-libraries/servicemix-common/src/main/java/org/apache/servicemix/common/ResolvedEndpoint.java
URL: http://svn.apache.org/viewvc/servicemix/components/trunk/shared-libraries/servicemix-common/src/main/java/org/apache/servicemix/common/ResolvedEndpoint.java?rev=1067118&r1=1067117&r2=1067118&view=diff
==============================================================================
--- servicemix/components/trunk/shared-libraries/servicemix-common/src/main/java/org/apache/servicemix/common/ResolvedEndpoint.java (original)
+++ servicemix/components/trunk/shared-libraries/servicemix-common/src/main/java/org/apache/servicemix/common/ResolvedEndpoint.java Fri Feb  4 09:05:47 2011
@@ -29,7 +29,9 @@ import org.apache.servicemix.common.util
 import org.apache.servicemix.common.util.DOMUtil;
 
 /**
- * A default implementation of a resolved endpoint
+ * <p>
+ * A default implementation of a resolved endpoint.
+ * </p>
  */
 public class ResolvedEndpoint implements ServiceEndpoint {
 

Modified: servicemix/components/trunk/shared-libraries/servicemix-common/src/main/java/org/apache/servicemix/common/ServiceMixComponent.java
URL: http://svn.apache.org/viewvc/servicemix/components/trunk/shared-libraries/servicemix-common/src/main/java/org/apache/servicemix/common/ServiceMixComponent.java?rev=1067118&r1=1067117&r2=1067118&view=diff
==============================================================================
--- servicemix/components/trunk/shared-libraries/servicemix-common/src/main/java/org/apache/servicemix/common/ServiceMixComponent.java (original)
+++ servicemix/components/trunk/shared-libraries/servicemix-common/src/main/java/org/apache/servicemix/common/ServiceMixComponent.java Fri Feb  4 09:05:47 2011
@@ -17,8 +17,8 @@
  */
 package org.apache.servicemix.common;
 
-import org.apache.commons.logging.Log;
 import org.apache.servicemix.executors.Executor;
+import org.slf4j.Logger;
 
 import javax.jbi.component.Component;
 import javax.jbi.component.ComponentContext;
@@ -27,7 +27,9 @@ import javax.jbi.messaging.MessagingExce
 import javax.xml.namespace.QName;
 
 /**
- * Represents an extended JBI Component implementation which exposes some extra features
+ * <p>
+ * Represents an extended JBI Component implementation which exposes some extra features.
+ * </p>
  *
  * @version $Revision$
  */
@@ -36,7 +38,7 @@ public interface ServiceMixComponent ext
     /**
      * @return Returns the logger.
      */
-    public Log getLogger();
+    public Logger getLogger();
 
     /**
      * @return Returns the registry.

Modified: servicemix/components/trunk/shared-libraries/servicemix-common/src/main/java/org/apache/servicemix/common/ServiceUnit.java
URL: http://svn.apache.org/viewvc/servicemix/components/trunk/shared-libraries/servicemix-common/src/main/java/org/apache/servicemix/common/ServiceUnit.java?rev=1067118&r1=1067117&r2=1067118&view=diff
==============================================================================
--- servicemix/components/trunk/shared-libraries/servicemix-common/src/main/java/org/apache/servicemix/common/ServiceUnit.java (original)
+++ servicemix/components/trunk/shared-libraries/servicemix-common/src/main/java/org/apache/servicemix/common/ServiceUnit.java Fri Feb  4 09:05:47 2011
@@ -21,9 +21,11 @@ import java.util.Collection;
 import javax.jbi.management.DeploymentException;
 
 /**
+ * <p>
  * This interface defines the lifecycle and needed
  * methods to a collection of endpoints grouped into
  * a service unit.
+ * </p>
  */
 public interface ServiceUnit {
 

Modified: servicemix/components/trunk/shared-libraries/servicemix-common/src/main/java/org/apache/servicemix/common/SyncLifeCycleWrapper.java
URL: http://svn.apache.org/viewvc/servicemix/components/trunk/shared-libraries/servicemix-common/src/main/java/org/apache/servicemix/common/SyncLifeCycleWrapper.java?rev=1067118&r1=1067117&r2=1067118&view=diff
==============================================================================
--- servicemix/components/trunk/shared-libraries/servicemix-common/src/main/java/org/apache/servicemix/common/SyncLifeCycleWrapper.java (original)
+++ servicemix/components/trunk/shared-libraries/servicemix-common/src/main/java/org/apache/servicemix/common/SyncLifeCycleWrapper.java Fri Feb  4 09:05:47 2011
@@ -26,7 +26,9 @@ import javax.management.ObjectName;
 import org.apache.servicemix.MessageExchangeListener;
 
 /**
- * Wrap an AsyncBaseLifeCycle into a lifecycle implementing MessageExchangeListener
+ * <p>
+ * Wrap an AsyncBaseLifeCycle into a lifecycle implementing MessageExchangeListener.
+ * </p>
  */
 public class SyncLifeCycleWrapper implements ComponentLifeCycle, MessageExchangeListener {
 

Modified: servicemix/components/trunk/shared-libraries/servicemix-common/src/main/java/org/apache/servicemix/common/endpoints/AbstractEndpoint.java
URL: http://svn.apache.org/viewvc/servicemix/components/trunk/shared-libraries/servicemix-common/src/main/java/org/apache/servicemix/common/endpoints/AbstractEndpoint.java?rev=1067118&r1=1067117&r2=1067118&view=diff
==============================================================================
--- servicemix/components/trunk/shared-libraries/servicemix-common/src/main/java/org/apache/servicemix/common/endpoints/AbstractEndpoint.java (original)
+++ servicemix/components/trunk/shared-libraries/servicemix-common/src/main/java/org/apache/servicemix/common/endpoints/AbstractEndpoint.java Fri Feb  4 09:05:47 2011
@@ -16,11 +16,11 @@
  */
 package org.apache.servicemix.common.endpoints;
 
-import org.apache.commons.logging.Log;
 import org.apache.servicemix.common.ServiceUnit;
 import org.apache.servicemix.common.Endpoint;
 import org.apache.servicemix.common.EndpointSupport;
 
+import org.slf4j.Logger;
 import org.w3c.dom.Document;
 
 import javax.jbi.management.DeploymentException;
@@ -38,7 +38,7 @@ public abstract class AbstractEndpoint i
     protected Document description;
     protected Definition definition;
     protected ServiceUnit serviceUnit;
-    protected Log logger;
+    protected Logger logger;
     private String key;
 
     public AbstractEndpoint() {
@@ -52,6 +52,10 @@ public abstract class AbstractEndpoint i
     }
 
     /**
+     * <p>
+     * Get the endpoint implementation.
+     * </p>
+     *
      * @return Returns the endpoint.
      */
     public String getEndpoint() {
@@ -59,7 +63,9 @@ public abstract class AbstractEndpoint i
     }
 
     /**
+     * <p>
      * The name of the endpoint.
+     * </p>
      *
      * @param endpoint a string specifiying the name of the endpoint
      * @org.apache.xbean.Property
@@ -70,6 +76,10 @@ public abstract class AbstractEndpoint i
     }
 
     /**
+     * <p>
+     * Get the service qualified name of the endpoint.
+     * </p>
+     *
      * @return Returns the service.
      */
     public QName getService() {
@@ -77,7 +87,9 @@ public abstract class AbstractEndpoint i
     }
 
     /**
+     * <p>
      * The qualified name of the service the endpoint exposes.
+     * </p>
      *
      * @param service a QName specifiying the name of the service
      * @org.apache.xbean.Property
@@ -88,11 +100,19 @@ public abstract class AbstractEndpoint i
     }
 
     /**
+     * <p>
+     * Get the endpoint role.
+     * </p>
+     *
      * @return Returns the role.
      */
     public abstract Role getRole();
 
     /**
+     * <p>
+     * Get the endpoint description.
+     * </p>
+     *
      * @return Returns the description.
      */
     public Document getDescription() {
@@ -100,8 +120,10 @@ public abstract class AbstractEndpoint i
     }
 
     /**
+     * <p>
      * Associates an XML document with the endpoint. The XML document describes the endpoint and is typically found in the service
      * unit packaging.
+     * </p>
      *
      * @param description a <code>Document</code> describing the endpoint
      * @org.apache.xbean.Property description="an XML document describing the endpoint" hidden="true"
@@ -111,6 +133,10 @@ public abstract class AbstractEndpoint i
     }
 
     /**
+     * <p>
+     * Get the qualified name of the endpoint interface.
+     * </p>
+     *
      * @return Returns the interfaceName.
      */
     public QName getInterfaceName() {
@@ -118,7 +144,9 @@ public abstract class AbstractEndpoint i
     }
 
     /**
+     * <p>
      * The qualified name of the interface exposed by the endpoint.
+     * </p>
      *
      * @param interfaceName a QName specifiying the name of the interface
      * @org.apache.xbean.Property
@@ -128,6 +156,10 @@ public abstract class AbstractEndpoint i
     }
 
     /**
+     * <p>
+     * Get the service unit associated to the endpoint.
+     * </p>
+     *
      * @return Returns the serviceUnit.
      */
     public ServiceUnit getServiceUnit() {
@@ -135,7 +167,9 @@ public abstract class AbstractEndpoint i
     }
 
     /**
+     * <p>
      * Associates an endpoint with a service unit. The service unit is used by the container to manage the endpoint's lifecycle.
+     * </p>
      *
      * @param serviceUnit a <code>ServiceUnit</code> to which the endpoint will be associated
      * @org.apache.xbean.Property description="the service unit responsible for the endpoint" hidden="true

Modified: servicemix/components/trunk/shared-libraries/servicemix-common/src/main/java/org/apache/servicemix/common/endpoints/ConsumerEndpoint.java
URL: http://svn.apache.org/viewvc/servicemix/components/trunk/shared-libraries/servicemix-common/src/main/java/org/apache/servicemix/common/endpoints/ConsumerEndpoint.java?rev=1067118&r1=1067117&r2=1067118&view=diff
==============================================================================
--- servicemix/components/trunk/shared-libraries/servicemix-common/src/main/java/org/apache/servicemix/common/endpoints/ConsumerEndpoint.java (original)
+++ servicemix/components/trunk/shared-libraries/servicemix-common/src/main/java/org/apache/servicemix/common/endpoints/ConsumerEndpoint.java Fri Feb  4 09:05:47 2011
@@ -74,7 +74,9 @@ public abstract class ConsumerEndpoint e
     }
 
     /**
-     * Return the URI identifying this external endpoint. This must be overriden so that endpoint resolution can work correctly.
+     * <p>
+     * Gets the URI identifying this external endpoint. This must be overriden so that endpoint resolution can work correctly.
+     * </p>
      * 
      * @return the URI identifying this external endpoint
      */
@@ -83,6 +85,10 @@ public abstract class ConsumerEndpoint e
     }
 
     /**
+     * <p>
+     * Gets the target endpoint of the consumer one.
+     * </p>
+     *
      * @return the targetEndpoint
      */
     public String getTargetEndpoint() {
@@ -90,7 +96,9 @@ public abstract class ConsumerEndpoint e
     }
 
     /**
+     * <p>
      * Sets the endpoint name of the target endpoint.
+     * </p>
      * 
      * @param targetEndpoint a string specifiying the name of the target endpoint
      * @org.apache.xbean.Property description="the name of the endpoint to which requests are sent"
@@ -100,6 +108,10 @@ public abstract class ConsumerEndpoint e
     }
 
     /**
+     * <p>
+     * Gets the target interface qualified name of the endpoint.
+     * </p>
+     *
      * @return the targetInterface
      */
     public QName getTargetInterface() {
@@ -107,7 +119,9 @@ public abstract class ConsumerEndpoint e
     }
 
     /**
+     * <p>
      * Sets the name of the target interface.
+     * </p>
      * 
      * @param targetInterface a QName specifiying the name of the target interface
      * @org.apache.xbean.Property description="the QName of the interface to which requests are sent"
@@ -117,6 +131,10 @@ public abstract class ConsumerEndpoint e
     }
 
     /**
+     * <p>
+     * Gets the service qualified name of the endpoint.
+     * </p>
+     *
      * @return the targetService
      */
     public QName getTargetService() {
@@ -124,7 +142,9 @@ public abstract class ConsumerEndpoint e
     }
 
     /**
+     * <p>
      * Sets the name of the target service.
+     * </p>
      * 
      * @param targetService a QName specifiying the name of the target interface
      * @org.apache.xbean.Property description="the QName of the service to which requests are sent"
@@ -134,6 +154,10 @@ public abstract class ConsumerEndpoint e
     }
 
     /**
+     * <p>
+     * Gets the target operation name of the consumer endpoint.
+     * </p>
+     *
      * @return the targetOperation
      */
     public QName getTargetOperation() {
@@ -141,7 +165,9 @@ public abstract class ConsumerEndpoint e
     }
 
     /**
+     * <p>
      * Sets the name of the target operation.
+     * </p>
      * 
      * @param targetOperation a QName specifiying the name of the target operation
      * @org.apache.xbean.Property description="the QName of the operation to which requests are sent"
@@ -151,6 +177,10 @@ public abstract class ConsumerEndpoint e
     }
 
     /**
+     * <p>
+     * Gets the target URI of the consumer endpoint.
+     * </p>
+     *
      * @return the targetUri
      */
     public String getTargetUri() {
@@ -158,7 +188,9 @@ public abstract class ConsumerEndpoint e
     }
 
     /**
-     * Set the target service/endpoint/interface using a URI.
+     * <p>
+     * Sets the target service/endpoint/interface using a URI.
+     * </p>
      *
      * @param targetUri the targetUri to set
      */

Modified: servicemix/components/trunk/shared-libraries/servicemix-common/src/main/java/org/apache/servicemix/common/endpoints/PollingEndpoint.java
URL: http://svn.apache.org/viewvc/servicemix/components/trunk/shared-libraries/servicemix-common/src/main/java/org/apache/servicemix/common/endpoints/PollingEndpoint.java?rev=1067118&r1=1067117&r2=1067118&view=diff
==============================================================================
--- servicemix/components/trunk/shared-libraries/servicemix-common/src/main/java/org/apache/servicemix/common/endpoints/PollingEndpoint.java (original)
+++ servicemix/components/trunk/shared-libraries/servicemix-common/src/main/java/org/apache/servicemix/common/endpoints/PollingEndpoint.java Fri Feb  4 09:05:47 2011
@@ -31,8 +31,10 @@ import org.apache.servicemix.common.sche
 import org.apache.servicemix.executors.Executor;
 
 /**
+ * <p>
  * An implementation inheritance class for an endpoint which polls some resource
  * at periodic intervals to decide if there is an event to process.
+ * </p>
  *
  * @version $Revision: 464478 $
  */
@@ -62,7 +64,9 @@ public abstract class PollingEndpoint ex
     }
 
     /**
-     * Polls the underlying resource to see if some event is required
+     * <p>
+     * Polls the underlying resource to see if some event is required.
+     * </p>
      *
      * @throws JBIException
      */
@@ -77,9 +81,11 @@ public abstract class PollingEndpoint ex
 
 
     /**
+     * <p>
      * Sets the amount of time in milliseconds that the endpoint should wait before making the first poll.
+     * </p>
      *
-     * @param        delay   a long specifying the number of milliseconds to wait
+     * @param delay a long specifying the number of milliseconds to wait.
      */
     public void setDelay(long delay) {
         this.delay = delay;
@@ -91,12 +97,13 @@ public abstract class PollingEndpoint ex
 
 
     /**
+     * <p>
      * Sets the date on which the first poll will be executed. If a delay is 
      * also set using <code>setDelay</code>, the delay interval will be added 
      * after the date specified.
+     * </p>
      *
-     * @param        firstTime       a <code>Date</code> specifying when to make the 
-     *                               first polling attempt
+     * @param firstTime a <code>Date</code> specifying when to make the first polling attempt.
      */
     public void setFirstTime(Date firstTime) {
         this.firstTime = firstTime;
@@ -107,7 +114,9 @@ public abstract class PollingEndpoint ex
     }
 
     /**
+     * <p>
      * Sets whether more than one poll can be active at a time (true means yes). Default value is <code>false</code>.
+     * </p>
      * 
      * @param concurrentPolling The concurrentPolling to set.
      */
@@ -121,9 +130,11 @@ public abstract class PollingEndpoint ex
 
     
     /**
+     * <p>
      * Sets the number of milliseconds between polling attempts.
+     * </p>
      *
-     * @param        period  a long specifying the gap between polling attempts
+     * @param period a long specifying the gap between polling attempts.
      */
     public void setPeriod(long period) {
         this.period = period;
@@ -139,9 +150,11 @@ public abstract class PollingEndpoint ex
     }
 
     /**
-     * Set a custom Scheduler implementation if you need more fine-grained control over the polling schedule.
+     * <p>
+     * Sets a custom scheduler implementation if you need more fine-grained control over the polling schedule.
+     * </p>
      *
-     * @param scheduler
+     * @param scheduler the customer scheduler.
      */
     public void setScheduler(Scheduler scheduler) {
         this.scheduler = scheduler;

Modified: servicemix/components/trunk/shared-libraries/servicemix-common/src/main/java/org/apache/servicemix/common/endpoints/ProviderEndpoint.java
URL: http://svn.apache.org/viewvc/servicemix/components/trunk/shared-libraries/servicemix-common/src/main/java/org/apache/servicemix/common/endpoints/ProviderEndpoint.java?rev=1067118&r1=1067117&r2=1067118&view=diff
==============================================================================
--- servicemix/components/trunk/shared-libraries/servicemix-common/src/main/java/org/apache/servicemix/common/endpoints/ProviderEndpoint.java (original)
+++ servicemix/components/trunk/shared-libraries/servicemix-common/src/main/java/org/apache/servicemix/common/endpoints/ProviderEndpoint.java Fri Feb  4 09:05:47 2011
@@ -46,9 +46,6 @@ public abstract class ProviderEndpoint e
         super(component.getServiceUnit(), endpoint.getServiceName(), endpoint.getEndpointName());
     }
 
-    /* (non-Javadoc)
-     * @see org.apache.servicemix.common.Endpoint#getRole()
-     */
     public Role getRole() {
         return Role.PROVIDER;
     }
@@ -71,11 +68,13 @@ public abstract class ProviderEndpoint e
     }
 
     /**
+     * <p>
      * A default implementation of the message processor which checks the status of the exchange
      * and if its valid will dispatch to either {@link #processInOnly(MessageExchange,NormalizedMessage)} for
      * an {@link InOnly} or {@link RobustInOnly} message exchange otherwise the
      * {@link #processInOut(MessageExchange,NormalizedMessage,NormalizedMessage)}
-     * method will be invoked
+     * method will be invoked.
+     * </p>
      *
      * @param exchange the message exchange
      * @throws Exception

Modified: servicemix/components/trunk/shared-libraries/servicemix-common/src/main/java/org/apache/servicemix/common/endpoints/SimpleEndpoint.java
URL: http://svn.apache.org/viewvc/servicemix/components/trunk/shared-libraries/servicemix-common/src/main/java/org/apache/servicemix/common/endpoints/SimpleEndpoint.java?rev=1067118&r1=1067117&r2=1067118&view=diff
==============================================================================
--- servicemix/components/trunk/shared-libraries/servicemix-common/src/main/java/org/apache/servicemix/common/endpoints/SimpleEndpoint.java (original)
+++ servicemix/components/trunk/shared-libraries/servicemix-common/src/main/java/org/apache/servicemix/common/endpoints/SimpleEndpoint.java Fri Feb  4 09:05:47 2011
@@ -26,15 +26,14 @@ import javax.jbi.servicedesc.ServiceEndp
 import javax.xml.namespace.QName;
 
 import org.apache.servicemix.common.DefaultComponent;
-import org.apache.servicemix.common.Endpoint;
 import org.apache.servicemix.common.EndpointComponentContext;
 import org.apache.servicemix.common.ServiceUnit;
-import org.apache.commons.logging.Log;
-import org.apache.commons.logging.LogFactory;
+import org.slf4j.Logger;
+import org.slf4j.LoggerFactory;
 
 public abstract class SimpleEndpoint extends AbstractEndpoint {
 
-    private static final Log LOG = LogFactory.getLog(SimpleEndpoint.class);
+    protected static Logger logger = LoggerFactory.getLogger(SimpleEndpoint.class);
 
     private DeliveryChannel channel;
     private MessageExchangeFactory exchangeFactory;
@@ -77,18 +76,14 @@ public abstract class SimpleEndpoint ext
     }
     
     protected void done(MessageExchange me) throws MessagingException {
-        if (LOG.isDebugEnabled()) {
-            LOG.debug("SimpleEndpoint.done called: ");
-        }
+        logger.debug("SimpleEndpoint.done called: ");
 
         me.setStatus(ExchangeStatus.DONE);
         send(me);
     }
     
     protected void fail(MessageExchange me, Exception error) throws MessagingException {
-        if (LOG.isWarnEnabled()) {
-            LOG.warn("SimpleEndpoint.fail called: ", error);
-        }
+        logger.warn("SimpleEndpoint.fail called: ", error);
 
         me.setError(error);
         send(me);

Modified: servicemix/components/trunk/shared-libraries/servicemix-common/src/main/java/org/apache/servicemix/common/osgi/Configuration.java
URL: http://svn.apache.org/viewvc/servicemix/components/trunk/shared-libraries/servicemix-common/src/main/java/org/apache/servicemix/common/osgi/Configuration.java?rev=1067118&r1=1067117&r2=1067118&view=diff
==============================================================================
--- servicemix/components/trunk/shared-libraries/servicemix-common/src/main/java/org/apache/servicemix/common/osgi/Configuration.java (original)
+++ servicemix/components/trunk/shared-libraries/servicemix-common/src/main/java/org/apache/servicemix/common/osgi/Configuration.java Fri Feb  4 09:05:47 2011
@@ -16,17 +16,19 @@
  */
 package org.apache.servicemix.common.osgi;
 
-import org.apache.commons.logging.Log;
-import org.apache.commons.logging.LogFactory;
 import org.apache.servicemix.executors.impl.ExecutorConfig;
+import org.slf4j.Logger;
+import org.slf4j.LoggerFactory;
 
 /**
+ * <p>
  * Represents the configuration for the components that can be created from
- * information in the OSGi ConfigAdmin
+ * information in the OSGi ConfigAdmin.
+ * </p>
  */
 public class Configuration {
 
-    private static final Log LOG = LogFactory.getLog(Configuration.class);
+    private final Logger logger = LoggerFactory.getLogger(Configuration.class);
     private static final Configuration INSTANCE = new Configuration();
 
     private final ExecutorConfig executorConfig = new ExecutorConfig();
@@ -36,7 +38,7 @@ public class Configuration {
      */
     private Configuration() {
         super();
-        LOG.debug("Configuring JBI components using OSGi ConfigAdmin");
+        logger.debug("Configuring JBI components using OSGi ConfigAdmin");
     }
 
     /**
@@ -51,7 +53,7 @@ public class Configuration {
      * @see org.apache.servicemix.executors.impl.ExecutorConfig#setCorePoolSize(int)
      */
     public void setCorePoolSize(int size) {
-        LOG.debug("Setting core thread pool size: " + size);
+        logger.debug("Setting core thread pool size: " + size);
         executorConfig.setCorePoolSize(size);
     }
 
@@ -60,7 +62,7 @@ public class Configuration {
      * @see org.apache.servicemix.executors.impl.ExecutorConfig#setMaximumPoolSize(int)
      */
     public void setMaximumPoolSize(int size) {
-        LOG.debug("Setting maximum thread pool size: " + size);
+        logger.debug("Setting maximum thread pool size: " + size);
         executorConfig.setMaximumPoolSize(size);
     }
 
@@ -69,7 +71,7 @@ public class Configuration {
      * @see org.apache.servicemix.executors.impl.ExecutorConfig#setQueueSize(int)
      */
     public void setQueueSize(int size) {
-        LOG.debug("Setting executor queue size: " + size);
+        logger.debug("Setting executor queue size: " + size);
         executorConfig.setQueueSize(size);        
     }
 
@@ -78,7 +80,7 @@ public class Configuration {
      * @see org.apache.servicemix.executors.impl.ExecutorConfig#setAllowCoreThreadsTimeout(boolean)  
      */
     public void setAllowCoreThreadTimeout(boolean timeout) {
-        LOG.debug("Setting core thread timeout allow: " + timeout);
+        logger.debug("Setting core thread timeout allow: " + timeout);
         executorConfig.setAllowCoreThreadsTimeout(timeout);
     }
 
@@ -87,7 +89,7 @@ public class Configuration {
      * @see org.apache.servicemix.executors.impl.ExecutorConfig#setKeepAliveTime(long) 
      */
     public void setKeepAliveTime(int time) {
-        LOG.debug("Setting thread keep-alive time: " + time);
+        logger.debug("Setting thread keep-alive time: " + time);
         executorConfig.setKeepAliveTime(time);
     }
 

Modified: servicemix/components/trunk/shared-libraries/servicemix-common/src/main/java/org/apache/servicemix/common/osgi/DeployedAssembly.java
URL: http://svn.apache.org/viewvc/servicemix/components/trunk/shared-libraries/servicemix-common/src/main/java/org/apache/servicemix/common/osgi/DeployedAssembly.java?rev=1067118&r1=1067117&r2=1067118&view=diff
==============================================================================
--- servicemix/components/trunk/shared-libraries/servicemix-common/src/main/java/org/apache/servicemix/common/osgi/DeployedAssembly.java (original)
+++ servicemix/components/trunk/shared-libraries/servicemix-common/src/main/java/org/apache/servicemix/common/osgi/DeployedAssembly.java Fri Feb  4 09:05:47 2011
@@ -19,13 +19,14 @@ package org.apache.servicemix.common.osg
 import java.util.Map;
 
 /**
+ * <p>
  * This interface should be used by service assemblies deployed using another packaging
  * than the JBI packaging to be able to leverage the JBI life cycle.
  *
  * This file is a copy of the file from the ServiceMix 4 NMR project and can be removed
  * once this project has been released.  The package is not exported from this OSGi bundle
  * and it should be imported from the NMR project.
- *
+ * </p>
  */
 public interface DeployedAssembly {
 

Modified: servicemix/components/trunk/shared-libraries/servicemix-common/src/main/java/org/apache/servicemix/common/osgi/EndpointExporter.java
URL: http://svn.apache.org/viewvc/servicemix/components/trunk/shared-libraries/servicemix-common/src/main/java/org/apache/servicemix/common/osgi/EndpointExporter.java?rev=1067118&r1=1067117&r2=1067118&view=diff
==============================================================================
--- servicemix/components/trunk/shared-libraries/servicemix-common/src/main/java/org/apache/servicemix/common/osgi/EndpointExporter.java (original)
+++ servicemix/components/trunk/shared-libraries/servicemix-common/src/main/java/org/apache/servicemix/common/osgi/EndpointExporter.java Fri Feb  4 09:05:47 2011
@@ -28,11 +28,10 @@ import java.util.Timer;
 import java.util.TimerTask;
 
 import org.apache.servicemix.common.Endpoint;
-import org.apache.servicemix.common.osgi.DeployedAssembly;
-import org.apache.commons.logging.Log;
-import org.apache.commons.logging.LogFactory;
 import org.osgi.framework.BundleContext;
 import org.osgi.framework.ServiceRegistration;
+import org.slf4j.Logger;
+import org.slf4j.LoggerFactory;
 import org.springframework.osgi.context.BundleContextAware;
 import org.springframework.beans.factory.InitializingBean;
 import org.springframework.beans.factory.DisposableBean;
@@ -41,7 +40,7 @@ import org.springframework.context.Appli
 
 public class EndpointExporter implements BundleContextAware, ApplicationContextAware, InitializingBean, DisposableBean, DeployedAssembly {
 
-    private static final Log LOG = LogFactory.getLog(EndpointExporter.class);
+    private final Logger logger = LoggerFactory.getLogger(EndpointExporter.class);
 
     private BundleContext bundleContext;
     private ApplicationContext applicationContext;
@@ -124,7 +123,7 @@ public class EndpointExporter implements
             }
         }
         if (assemblyRegistration == null) {
-            LOG.info("Waiting for all endpoints to be deployed before registering service assembly");
+            logger.info("Waiting for all endpoints to be deployed before registering service assembly");
         }
     }
 
@@ -134,7 +133,7 @@ public class EndpointExporter implements
         }
         if (ep != null && (ep.getServiceUnit() == null 
             || !ep.getServiceUnit().getComponent().getRegistry().isRegistered(ep.getServiceUnit()))) {
-            LOG.info("something wrong during register endpoint " + ep.getKey());
+            logger.info("something wrong during register endpoint " + ep.getKey());
             //get chance to unregister all endpoints with this EndpointExporter
             for (Endpoint e : deployed) {
                 e.getServiceUnit().getComponent().getRegistry().unregisterServiceUnit(e.getServiceUnit());
@@ -157,7 +156,7 @@ public class EndpointExporter implements
                 // Create the timer if not already done
                 if (timer == null) {
                     timer = new Timer();
-                    LOG.info("All endpoints have been deployed but waiting for components initialization");
+                    logger.info("All endpoints have been deployed but waiting for components initialization");
                 }
                 // Retry a bit later to allow some time for the components to be initialized
                 // by the JBI container
@@ -175,7 +174,7 @@ public class EndpointExporter implements
                     timer = null;
                 }
                 // ... and register the SA in OSGi
-                LOG.info("All endpoints have been deployed and components initialized. Registering service assembly.");
+                logger.info("All endpoints have been deployed and components initialized. Registering service assembly.");
                 assemblyRegistration = bundleContext.registerService(DeployedAssembly.class.getName(), this, new Properties());
             }
         }