You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@camel.apache.org by da...@apache.org on 2008/09/28 20:24:51 UTC

svn commit: r699876 - in /activemq/camel/trunk/camel-core/src: main/java/org/apache/camel/impl/ main/java/org/apache/camel/model/ main/java/org/apache/camel/processor/ main/java/org/apache/camel/processor/interceptor/ main/java/org/apache/camel/spi/ te...

Author: davsclaus
Date: Sun Sep 28 11:24:50 2008
New Revision: 699876

URL: http://svn.apache.org/viewvc?rev=699876&view=rev
Log:
CAMEL-944: tracer more easily configurable. new option to skip interceptors (default) to avoid tracing DeadLetterChannel interceptor that is just confusing

Modified:
    activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/impl/DefaultUnitOfWork.java
    activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/model/InterceptType.java
    activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/model/OptionalIdentifiedType.java
    activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/model/ProcessorRef.java
    activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/processor/UnitOfWorkProcessor.java
    activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/processor/interceptor/TraceFormatter.java
    activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/processor/interceptor/TraceInterceptor.java
    activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/processor/interceptor/Tracer.java
    activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/spi/Synchronization.java
    activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/model/ProcessorTypeConfigurationTest.java
    activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/processor/TraceInterceptorTest.java
    activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/processor/interceptor/TraceInterceptorTest.java

Modified: activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/impl/DefaultUnitOfWork.java
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/impl/DefaultUnitOfWork.java?rev=699876&r1=699875&r2=699876&view=diff
==============================================================================
--- activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/impl/DefaultUnitOfWork.java (original)
+++ activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/impl/DefaultUnitOfWork.java Sun Sep 28 11:24:50 2008
@@ -22,6 +22,7 @@
 
 import org.apache.camel.AsyncCallback;
 import org.apache.camel.Exchange;
+import org.apache.camel.Service;
 import org.apache.camel.spi.Synchronization;
 import org.apache.camel.spi.UnitOfWork;
 import org.apache.camel.util.UuidGenerator;
@@ -31,7 +32,7 @@
  *
  * @version $Revision$
  */
-public class DefaultUnitOfWork implements UnitOfWork {
+public class DefaultUnitOfWork implements UnitOfWork, Service {
     private static final UuidGenerator DEFAULT_ID_GENERATOR = new UuidGenerator();
 
     private String id;
@@ -42,6 +43,19 @@
     public DefaultUnitOfWork() {
     }
 
+    public void start() throws Exception {
+    }
+
+    public void stop() throws Exception {
+        // need to clean up when we are stopping to not leak memory
+        if (synchronizations != null) {
+            synchronizations.clear();
+        }
+        if (asyncCallbacks != null) {
+            asyncCallbacks.clear();
+        }
+    }
+
     public synchronized void addSynchronization(Synchronization synchronization) {
         if (synchronizations == null) {
             synchronizations = new ArrayList<Synchronization>();
@@ -55,6 +69,9 @@
         }
     }
 
+    /**
+     * @deprecated will be removed in Camel 2.0
+     */
     public void reset() {
     }
 

Modified: activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/model/InterceptType.java
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/model/InterceptType.java?rev=699876&r1=699875&r2=699876&view=diff
==============================================================================
--- activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/model/InterceptType.java (original)
+++ activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/model/InterceptType.java Sun Sep 28 11:24:50 2008
@@ -61,6 +61,11 @@
     }
 
     @Override
+    public String getLabel() {
+        return "intercept";
+    }
+
+    @Override
     public Processor createProcessor(RouteContext routeContext) throws Exception {
         Interceptor interceptor = new Interceptor();
         routeContext.intercept(interceptor);

Modified: activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/model/OptionalIdentifiedType.java
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/model/OptionalIdentifiedType.java?rev=699876&r1=699875&r2=699876&view=diff
==============================================================================
--- activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/model/OptionalIdentifiedType.java (original)
+++ activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/model/OptionalIdentifiedType.java Sun Sep 28 11:24:50 2008
@@ -50,9 +50,6 @@
 
     /**
      * Gets the value of the id property.
-     *
-     * @return possible object is
-     *         {@link String }
      */
     public String getId() {
         return id;
@@ -60,9 +57,6 @@
 
     /**
      * Sets the value of the id property.
-     *
-     * @param value allowed object is
-     *              {@link String }
      */
     public void setId(String value) {
         this.id = value;

Modified: activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/model/ProcessorRef.java
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/model/ProcessorRef.java?rev=699876&r1=699875&r2=699876&view=diff
==============================================================================
--- activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/model/ProcessorRef.java (original)
+++ activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/model/ProcessorRef.java Sun Sep 28 11:24:50 2008
@@ -47,20 +47,20 @@
 
     @Override
     public String getShortName() {
-        return "processor";
+        return "process";
     }
 
     @Override
     public String toString() {
-        return "Processor["
-                + ((ref != null) ? "ref:  " + ref : processor)
+        return "process["
+                + ((ref != null) ? "ref: " + ref : processor)
                 + "]";
     }
 
     @Override
     public String getLabel() {
         if (ref != null) {
-            return "ref:  " + ref;
+            return "ref: " + ref;
         } else if (processor != null) {
             return processor.toString();
         } else {

Modified: activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/processor/UnitOfWorkProcessor.java
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/processor/UnitOfWorkProcessor.java?rev=699876&r1=699875&r2=699876&view=diff
==============================================================================
--- activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/processor/UnitOfWorkProcessor.java (original)
+++ activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/processor/UnitOfWorkProcessor.java Sun Sep 28 11:24:50 2008
@@ -20,6 +20,7 @@
 import org.apache.camel.AsyncProcessor;
 import org.apache.camel.Exchange;
 import org.apache.camel.impl.DefaultUnitOfWork;
+import static org.apache.camel.util.ObjectHelper.wrapRuntimeCamelException;
 
 /** 
  * Handles calling the UnitOfWork.done() method when processing of an exchange
@@ -35,7 +36,14 @@
         if (exchange.getUnitOfWork() == null) {
             // If there is no existing UoW, then we should start one and
             // terminate it once processing is completed for the exchange.
-            exchange.setUnitOfWork(new DefaultUnitOfWork());
+            final DefaultUnitOfWork uow = new DefaultUnitOfWork();
+            exchange.setUnitOfWork(uow);
+            try {
+                uow.start();
+            } catch (Exception e) {
+                throw wrapRuntimeCamelException(e);
+            }
+            // return the process code where we do stop and cleanup
             return processor.process(exchange, new AsyncCallback() {
                 public void done(boolean sync) {
                     // Order here matters. We need to complete the callbacks
@@ -43,6 +51,11 @@
                     // some final results.
                     callback.done(sync);
                     exchange.getUnitOfWork().done(exchange);
+                    try {
+                        uow.stop();
+                    } catch (Exception e) {
+                        throw wrapRuntimeCamelException(e);
+                    }
                     exchange.setUnitOfWork(null);
                 }
             });

Modified: activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/processor/interceptor/TraceFormatter.java
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/processor/interceptor/TraceFormatter.java?rev=699876&r1=699875&r2=699876&view=diff
==============================================================================
--- activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/processor/interceptor/TraceFormatter.java (original)
+++ activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/processor/interceptor/TraceFormatter.java Sun Sep 28 11:24:50 2008
@@ -16,13 +16,10 @@
  */
 package org.apache.camel.processor.interceptor;
 
-import java.io.InputStream;
-
 import org.apache.camel.Exchange;
 import org.apache.camel.Message;
 import org.apache.camel.NoTypeConversionAvailableException;
 import org.apache.camel.converter.stream.StreamCache;
-import org.apache.camel.converter.stream.StreamCacheConverter;
 import org.apache.camel.spi.UnitOfWork;
 import org.apache.camel.util.ObjectHelper;
 
@@ -33,24 +30,45 @@
     private boolean showBreadCrumb = true;
     private boolean showNode = true;
     private boolean showExchangeId;
+    private boolean showExchangePattern = true;
     private boolean showProperties = true;
     private boolean showHeaders = true;
     private boolean showBody = true;
     private boolean showBodyType = true;
+    private boolean showException = true;
 
     public Object format(TraceInterceptor interceptor, Exchange exchange) {
         Message in = exchange.getIn();
         Throwable exception = exchange.getException();
-        return (showBreadCrumb ? getBreadCrumbID(exchange) + " " : "")
-                + "-> " + getNodeMessage(interceptor) + " "
-                + (showNode ? interceptor.getNode() + " " : "")
-                + exchange.getPattern()
-                + (showExchangeId ? " Id: " + exchange.getExchangeId() : "")
-                + (showProperties ? " Properties:" + exchange.getProperties() : "")
-                + (showHeaders ? " Headers:" + in.getHeaders() : "")
-                + (showBodyType ? " BodyType:" + getBodyTypeAsString(in) : "")
-                + (showBody ? " Body:" + getBodyAsString(in) : "")
-                + (exception != null ? " Exception: " + exception : "");
+        StringBuilder sb = new StringBuilder();
+        if (showBreadCrumb || showExchangeId) {
+            sb.append(getBreadCrumbID(exchange)).append(" ");
+        }
+        if (showNode) {
+            sb.append("-> ").append(getNodeMessage(interceptor)).append(" ");
+        }
+        if (showExchangePattern) {
+            sb.append(", Pattern:").append(exchange.getPattern()).append(" ");
+        }
+        // only show properties if we have any
+        if (showProperties && !exchange.getProperties().isEmpty()) {
+            sb.append(", Properties:").append(exchange.getProperties()).append(" ");
+        }
+        // only show headers if we have any
+        if (showHeaders && !in.getHeaders().isEmpty()) {
+            sb.append(", Headers:").append(in.getHeaders()).append(" ");
+        }
+        if (showBodyType) {
+            sb.append(", BodyType:").append(getBodyTypeAsString(in)).append(" ");
+        }
+        if (showBody) {
+            sb.append(", Body:").append(getBodyAsString(in)).append(" ");
+        }
+        if (showException && exception != null) {
+            sb.append(", Exception:").append(exception);
+        }
+
+        return sb.toString();
     }
 
     public boolean isShowBody() {
@@ -109,6 +127,22 @@
         this.showNode = showNode;
     }
 
+    public boolean isShowExchangePattern() {
+        return showExchangePattern;
+    }
+
+    public void setShowExchangePattern(boolean showExchangePattern) {
+        this.showExchangePattern = showExchangePattern;
+    }
+
+    public boolean isShowException() {
+        return showException;
+    }
+
+    public void setShowException(boolean showException) {
+        this.showException = showException;
+    }
+
     // Implementation methods
     //-------------------------------------------------------------------------
     protected Object getBreadCrumbID(Exchange exchange) {
@@ -150,6 +184,8 @@
     }
 
     protected String getNodeMessage(TraceInterceptor interceptor) {
-        return interceptor.getNode().idOrCreate();
+        String message = interceptor.getNode().getShortName() + "(" + interceptor.getNode().getLabel() + ")";
+        return String.format("%1$-25s", message);
     }
+
 }

Modified: activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/processor/interceptor/TraceInterceptor.java
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/processor/interceptor/TraceInterceptor.java?rev=699876&r1=699875&r2=699876&view=diff
==============================================================================
--- activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/processor/interceptor/TraceInterceptor.java (original)
+++ activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/processor/interceptor/TraceInterceptor.java Sun Sep 28 11:24:50 2008
@@ -17,13 +17,12 @@
 package org.apache.camel.processor.interceptor;
 
 import org.apache.camel.Exchange;
-import org.apache.camel.Predicate;
 import org.apache.camel.Processor;
+import org.apache.camel.model.InterceptorRef;
 import org.apache.camel.model.ProcessorType;
 import org.apache.camel.processor.DelegateProcessor;
 import org.apache.camel.processor.Logger;
-import org.apache.camel.processor.LoggingLevel;
-import org.apache.commons.logging.Log;
+import org.apache.camel.spi.InterceptStrategy;
 import org.apache.commons.logging.LogFactory;
 
 /**
@@ -32,22 +31,31 @@
  * @version $Revision$
  */
 public class TraceInterceptor extends DelegateProcessor implements ExchangeFormatter {
+    private final Logger logger = new Logger(LogFactory.getLog(TraceInterceptor.class), this);
     private final ProcessorType node;
-    private Predicate<Exchange> traceFilter;
-    private boolean traceExceptions = true;
-    private Logger logger = new Logger(LogFactory.getLog(TraceInterceptor.class), this);
+    private final Tracer tracer;
     private TraceFormatter formatter;
-    private Tracer tracer;
 
     public TraceInterceptor(ProcessorType node, Processor target, TraceFormatter formatter, Tracer tracer) {
         super(target);
         this.tracer = tracer;
         this.node = node;
         this.formatter = formatter;
+
+        // set logging level
+        if (tracer.getLevel() != null) {
+            logger.setLevel(tracer.getLevel());
+        }
+        if (tracer.getFormatter() != null) {
+            this.formatter = tracer.getFormatter();
+        }
     }
 
+    /**
+     * @deprecated will be removed in Camel 2.0
+     */
     public TraceInterceptor(ProcessorType node, Processor target, TraceFormatter formatter) {
-        this(node, target, formatter, null);
+        this(node, target, formatter, new Tracer());
     }
 
     public TraceInterceptor(ProcessorType node, Processor target, Tracer tracer) {
@@ -59,30 +67,22 @@
         return "TraceInterceptor[" + node + "]";
     }
 
-    public void process(Exchange exchange) throws Exception {
+    public void process(final Exchange exchange) throws Exception {
         try {
-            if (shouldLogExchange(exchange)) {
+            if (shouldLogNode(node) && shouldLogExchange(exchange)) {
                 logExchange(exchange);
             }
             super.proceed(exchange);
         } catch (Exception e) {
-            logException(exchange, e);
-            throw e;
-        } catch (Error e) {
-            logException(exchange, e);
+            if (shouldLogException(exchange)) {
+                logException(exchange, e);
+            }
             throw e;
         }
     }
 
     public Object format(Exchange exchange) {
-        TraceFormatter traceFormatter = null;
-        if (formatter != null) {
-            traceFormatter = formatter;
-        } else {
-            assert tracer != null;
-            traceFormatter = tracer.getFormatter();
-        }
-        return traceFormatter.format(this, exchange);
+        return formatter.format(this, exchange);
     }
 
     // Properties
@@ -91,22 +91,6 @@
         return node;
     }
 
-    public Predicate getTraceFilter() {
-        return traceFilter;
-    }
-
-    public void setTraceFilter(Predicate traceFilter) {
-        this.traceFilter = traceFilter;
-    }
-
-    public boolean isTraceExceptions() {
-        return traceExceptions;
-    }
-
-    public void setTraceExceptions(boolean traceExceptions) {
-        this.traceExceptions = traceExceptions;
-    }
-
     public Logger getLogger() {
         return logger;
     }
@@ -115,26 +99,6 @@
         return formatter;
     }
 
-    public void setFormatter(TraceFormatter formatter) {
-        this.formatter = formatter;
-    }
-
-    public LoggingLevel getLevel() {
-        return getLogger().getLevel();
-    }
-
-    public Log getLog() {
-        return getLogger().getLog();
-    }
-
-    public void setLog(Log log) {
-        getLogger().setLog(log);
-    }
-
-    public void setLevel(LoggingLevel level) {
-        getLogger().setLevel(level);
-    }
-
     // Implementation methods
     //-------------------------------------------------------------------------
     protected void logExchange(Exchange exchange) {
@@ -142,7 +106,9 @@
     }
 
     protected void logException(Exchange exchange, Throwable throwable) {
-        logger.process(exchange, throwable);
+        if (tracer.isTraceExceptions()) {
+            logger.process(exchange, throwable);
+        }
     }
 
     /**
@@ -150,7 +116,28 @@
      */
     protected boolean shouldLogExchange(Exchange exchange) {
         return (tracer == null || tracer.isEnabled())
-            && (traceFilter == null || traceFilter.matches(exchange));
+            && (tracer.getTraceFilter() == null || tracer.getTraceFilter().matches(exchange));
+    }
+
+    /**
+     * Returns true if the given exchange should be logged when an exception was thrown
+     */
+    protected boolean shouldLogException(Exchange exchange) {
+        return tracer.isTraceExceptions();
+    }
+
+
+    /**
+     * Returns true if the given node should be logged in the trace list
+     */
+    protected boolean shouldLogNode(ProcessorType node) {
+        if (node == null) {
+            return false;
+        }
+        if (!tracer.isTraceInterceptors() && (node instanceof InterceptStrategy || node instanceof InterceptorRef)) {
+            return false;
+        }
+        return true;
     }
 
 }
\ No newline at end of file

Modified: activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/processor/interceptor/Tracer.java
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/processor/interceptor/Tracer.java?rev=699876&r1=699875&r2=699876&view=diff
==============================================================================
--- activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/processor/interceptor/Tracer.java (original)
+++ activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/processor/interceptor/Tracer.java Sun Sep 28 11:24:50 2008
@@ -19,9 +19,12 @@
 import java.util.List;
 
 import org.apache.camel.CamelContext;
+import org.apache.camel.Exchange;
+import org.apache.camel.Predicate;
 import org.apache.camel.Processor;
 import org.apache.camel.impl.DefaultCamelContext;
 import org.apache.camel.model.ProcessorType;
+import org.apache.camel.processor.LoggingLevel;
 import org.apache.camel.spi.InterceptStrategy;
 
 /**
@@ -33,6 +36,10 @@
 
     private TraceFormatter formatter = new TraceFormatter();
     private boolean enabled = true;
+    private LoggingLevel level;
+    private Predicate<Exchange> traceFilter;
+    private boolean traceInterceptors;
+    private boolean traceExceptions = true;
 
     /**
      * A helper method to return the Tracer instance for a given {@link CamelContext} if one is enabled
@@ -75,4 +82,48 @@
     public boolean isEnabled() {
         return enabled;
     }
+
+    public boolean isTraceInterceptors() {
+        return traceInterceptors;
+    }
+
+    /**
+     * Sets wether interceptors should be traced or not
+     */
+    public void setTraceInterceptors(boolean traceInterceptors) {
+        this.traceInterceptors = traceInterceptors;
+    }
+
+    public Predicate getTraceFilter() {
+        return traceFilter;
+    }
+
+    /**
+     * Sets a predicate to be used as filter when tracing
+     */
+    public void setTraceFilter(Predicate traceFilter) {
+        this.traceFilter = traceFilter;
+    }
+
+    public LoggingLevel getLevel() {
+        return level;
+    }
+
+    /**
+     * Sets the logging level to ouput tracing. Will default use <tt>INFO</tt> level.
+     */
+    public void setLevel(LoggingLevel level) {
+        this.level = level;
+    }
+
+    public boolean isTraceExceptions() {
+        return traceExceptions;
+    }
+
+    /**
+     * Sets wether thrown exceptions should be traced
+     */
+    public void setTraceExceptions(boolean traceExceptions) {
+        this.traceExceptions = traceExceptions;
+    }
 }
\ No newline at end of file

Modified: activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/spi/Synchronization.java
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/spi/Synchronization.java?rev=699876&r1=699875&r2=699876&view=diff
==============================================================================
--- activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/spi/Synchronization.java (original)
+++ activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/spi/Synchronization.java Sun Sep 28 11:24:50 2008
@@ -33,7 +33,7 @@
     /**
      * Called when the processing of the message exchange is complete
      *
-     * @param exchange the excahnge being processed
+     * @param exchange the exchange being processed
      */
     void onComplete(Exchange exchange);
 
@@ -42,7 +42,7 @@
      * The exception which caused the problem is in {@link Exchange#getException()} and
      * there could be a fault message via {@link Exchange#getFault()}
      *
-     * @param exchange the excahnge being processed
+     * @param exchange the exchange being processed
      */
     void onFailure(Exchange exchange);
 }

Modified: activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/model/ProcessorTypeConfigurationTest.java
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/model/ProcessorTypeConfigurationTest.java?rev=699876&r1=699875&r2=699876&view=diff
==============================================================================
--- activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/model/ProcessorTypeConfigurationTest.java (original)
+++ activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/model/ProcessorTypeConfigurationTest.java Sun Sep 28 11:24:50 2008
@@ -17,7 +17,6 @@
 package org.apache.camel.model;
 
 import org.apache.camel.ContextTestSupport;
-import org.apache.camel.RuntimeCamelException;
 import org.apache.camel.builder.RouteBuilder;
 
 /**
@@ -34,7 +33,7 @@
             });
             fail("Should have thrown RuntimeCamelException");
         } catch (IllegalArgumentException e) {
-            assertEquals("target not provided on node: Processor[ref:  hello]", e.getMessage());
+            assertEquals("target not provided on node: process[ref: hello]", e.getMessage());
         }
     }
 

Modified: activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/processor/TraceInterceptorTest.java
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/processor/TraceInterceptorTest.java?rev=699876&r1=699875&r2=699876&view=diff
==============================================================================
--- activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/processor/TraceInterceptorTest.java (original)
+++ activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/processor/TraceInterceptorTest.java Sun Sep 28 11:24:50 2008
@@ -20,7 +20,6 @@
 import org.apache.camel.Exchange;
 import org.apache.camel.Processor;
 import org.apache.camel.builder.RouteBuilder;
-import org.apache.camel.processor.interceptor.Debugger;
 import org.apache.camel.processor.interceptor.Tracer;
 
 /**

Modified: activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/processor/interceptor/TraceInterceptorTest.java
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/processor/interceptor/TraceInterceptorTest.java?rev=699876&r1=699875&r2=699876&view=diff
==============================================================================
--- activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/processor/interceptor/TraceInterceptorTest.java (original)
+++ activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/processor/interceptor/TraceInterceptorTest.java Sun Sep 28 11:24:50 2008
@@ -14,7 +14,6 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-
 package org.apache.camel.processor.interceptor;
 
 import org.apache.camel.ContextTestSupport;
@@ -23,8 +22,9 @@
 import org.easymock.classextension.EasyMock;
 
 public class TraceInterceptorTest extends ContextTestSupport {
-    TraceFormatter formatter;
-    Tracer tracer;
+    private TraceFormatter formatter;
+    private Tracer tracer;
+
     @Override
     protected void setUp() throws Exception {
         formatter = EasyMock.createMock(TraceFormatter.class);