You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@camel.apache.org by ch...@apache.org on 2007/08/07 20:36:08 UTC

svn commit: r563607 [11/12] - in /activemq/camel/trunk/camel-core/src: main/java/org/apache/camel/ main/java/org/apache/camel/builder/ main/java/org/apache/camel/builder/xml/ main/java/org/apache/camel/component/bean/ main/java/org/apache/camel/compone...

Modified: activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/TestSupport.java
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/TestSupport.java?view=diff&rev=563607&r1=563606&r2=563607
==============================================================================
--- activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/TestSupport.java (original)
+++ activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/TestSupport.java Tue Aug  7 11:35:48 2007
@@ -1,5 +1,4 @@
 /**
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements.  See the NOTICE file distributed with
  * this work for additional information regarding copyright ownership.
@@ -7,7 +6,7 @@
  * (the "License"); you may not use this file except in compliance with
  * the License.  You may obtain a copy of the License at
  *
- * http://www.apache.org/licenses/LICENSE-2.0
+ *      http://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing, software
  * distributed under the License is distributed on an "AS IS" BASIS,
@@ -17,18 +16,19 @@
  */
 package org.apache.camel;
 
+import java.util.List;
+
 import junit.framework.TestCase;
+
 import org.apache.camel.builder.Builder;
 import org.apache.camel.builder.ValueBuilder;
 import org.apache.camel.impl.DefaultExchange;
 import org.apache.commons.logging.Log;
 import org.apache.commons.logging.LogFactory;
 
-import java.util.List;
-
 /**
  * A bunch of useful testing methods
- *
+ * 
  * @version $Revision$
  */
 public abstract class TestSupport extends TestCase {
@@ -36,7 +36,7 @@
     protected transient Log log = LogFactory.getLog(getClass());
 
     // Builder methods for expressions used when testing
-    //-------------------------------------------------------------------------
+    // -------------------------------------------------------------------------
 
     /**
      * Returns a value builder for the given header
@@ -55,7 +55,8 @@
     }
 
     /**
-     * Returns a predicate and value builder for the inbound message body as a specific type
+     * Returns a predicate and value builder for the inbound message body as a
+     * specific type
      */
 
     public <T> ValueBuilder bodyAs(Class<T> type) {
@@ -63,7 +64,8 @@
     }
 
     /**
-     * Returns a predicate and value builder for the outbound body on an exchange
+     * Returns a predicate and value builder for the outbound body on an
+     * exchange
      */
 
     public ValueBuilder outBody() {
@@ -71,7 +73,8 @@
     }
 
     /**
-     * Returns a predicate and value builder for the outbound message body as a specific type
+     * Returns a predicate and value builder for the outbound message body as a
+     * specific type
      */
 
     public <T> ValueBuilder outBody(Class<T> type) {
@@ -95,12 +98,12 @@
     }
 
     // Assertions
-    //-----------------------------------------------------------------------
+    // -----------------------------------------------------------------------
 
     protected <T> T assertIsInstanceOf(Class<T> expectedType, Object value) {
         assertNotNull("Expected an instance of type: " + expectedType.getName() + " but was null", value);
-        assertTrue("object should be a " + expectedType.getName() + " but was: " + value + " with type: " + value.getClass().getName(),
-                expectedType.isInstance(value));
+        assertTrue("object should be a " + expectedType.getName() + " but was: " + value + " with type: "
+                   + value.getClass().getName(), expectedType.isInstance(value));
         return expectedType.cast(value);
     }
 
@@ -154,8 +157,7 @@
     protected void assertPredicateDoesNotMatch(Predicate predicate, Exchange exchange) {
         try {
             predicate.assertMatches("Predicate should match", exchange);
-        }
-        catch (AssertionError e) {
+        } catch (AssertionError e) {
             log.debug("Caught expected assertion error: " + e);
         }
         assertPredicate(predicate, exchange, false);
@@ -190,7 +192,8 @@
     /**
      * Resolves an endpoint and asserts that it is found
      */
-    protected <T extends Endpoint> T resolveMandatoryEndpoint(CamelContext context, String uri, Class<T> endpointType) {
+    protected <T extends Endpoint> T resolveMandatoryEndpoint(CamelContext context, String uri,
+                                                              Class<T> endpointType) {
         T endpoint = context.getEndpoint(uri, endpointType);
 
         assertNotNull("No endpoint found for URI: " + uri, endpoint);

Modified: activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/builder/ErrorHandlerTest.java
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/builder/ErrorHandlerTest.java?view=diff&rev=563607&r1=563606&r2=563607
==============================================================================
--- activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/builder/ErrorHandlerTest.java (original)
+++ activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/builder/ErrorHandlerTest.java Tue Aug  7 11:35:48 2007
@@ -1,5 +1,4 @@
 /**
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements.  See the NOTICE file distributed with
  * this work for additional information regarding copyright ownership.
@@ -7,7 +6,7 @@
  * (the "License"); you may not use this file except in compliance with
  * the License.  You may obtain a copy of the License at
  *
- * http://www.apache.org/licenses/LICENSE-2.0
+ *      http://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing, software
  * distributed under the License is distributed on an "AS IS" BASIS,
@@ -34,123 +33,72 @@
  */
 public class ErrorHandlerTest extends TestSupport {
     /*
-    public void testOverloadingTheDefaultErrorHandler() throws Exception {
-
-        // START SNIPPET: e1
-        RouteBuilder<Exchange> builder = new RouteBuilder<Exchange>() {
-            public void configure() {
-                errorHandler(loggingErrorHandler("FOO.BAR"));
-
-                from("seda:a").to("seda:b");
-            }
-        };
-        // END SNIPPET: e1
-
-        Map<Endpoint<Exchange>, Processor> routeMap = builder.getRouteMap();
-        Set<Map.Entry<Endpoint<Exchange>, Processor>> routes = routeMap.entrySet();
-        assertEquals("Number routes created", 1, routes.size());
-        for (Map.Entry<Endpoint<Exchange>, Processor> route : routes) {
-            Endpoint<Exchange> key = route.getKey();
-            assertEquals("From endpoint", "seda:a", key.getEndpointUri());
-            Processor processor = route.getValue();
-
-            LoggingErrorHandler loggingProcessor = assertIsInstanceOf(LoggingErrorHandler.class, processor);
-        }
-    }
-
-    public void testOverloadingTheHandlerOnASingleRoute() throws Exception {
-
-        // START SNIPPET: e2
-        RouteBuilder<Exchange> builder = new RouteBuilder<Exchange>() {
-            public void configure() {
-                from("seda:a").errorHandler(loggingErrorHandler("FOO.BAR")).to("seda:b");
-
-                // this route will use the default error handler, DeadLetterChannel
-                from("seda:b").to("seda:c");
-            }
-        };
-        // END SNIPPET: e2
-
-        Map<Endpoint<Exchange>, Processor> routeMap = builder.getRouteMap();
-        log.debug(routeMap);
-
-        Set<Map.Entry<Endpoint<Exchange>, Processor>> routes = routeMap.entrySet();
-        assertEquals("Number routes created", 2, routes.size());
-        for (Map.Entry<Endpoint<Exchange>, Processor> route : routes) {
-            Endpoint<Exchange> key = route.getKey();
-            String endpointUri = key.getEndpointUri();
-            Processor processor = route.getValue();
-
-            if (endpointUri.equals("seda:a")) {
-                LoggingErrorHandler loggingProcessor = assertIsInstanceOf(LoggingErrorHandler.class, processor);
-
-                Processor outputProcessor = loggingProcessor.getOutput();
-                SendProcessor sendProcessor = assertIsInstanceOf(SendProcessor.class, outputProcessor);
-            }
-            else {
-                assertEquals("From endpoint", "seda:b", endpointUri);
-
-                DeadLetterChannel deadLetterChannel = assertIsInstanceOf(DeadLetterChannel.class, processor);
-                Processor outputProcessor = deadLetterChannel.getOutput();
-                SendProcessor sendProcessor = assertIsInstanceOf(SendProcessor.class, outputProcessor);
-            }
-        }
-    }
-
-    public void testConfigureDeadLetterChannel() throws Exception {
-
-        // START SNIPPET: e3
-        RouteBuilder<Exchange> builder = new RouteBuilder<Exchange>() {
-            public void configure() {
-                errorHandler(deadLetterChannel("seda:errors"));
-
-                from("seda:a").to("seda:b");
-            }
-        };
-        // END SNIPPET: e3
-
-        Map<Endpoint<Exchange>, Processor> routeMap = builder.getRouteMap();
-        Set<Map.Entry<Endpoint<Exchange>, Processor>> routes = routeMap.entrySet();
-        assertEquals("Number routes created", 1, routes.size());
-        for (Map.Entry<Endpoint<Exchange>, Processor> route : routes) {
-            Endpoint<Exchange> key = route.getKey();
-            assertEquals("From endpoint", "seda:a", key.getEndpointUri());
-            Processor processor = route.getValue();
-
-            DeadLetterChannel deadLetterChannel = assertIsInstanceOf(DeadLetterChannel.class, processor);
-            Endpoint deadLetterEndpoint = assertIsInstanceOf(Endpoint.class, deadLetterChannel.getDeadLetter());
-            assertEndpointUri(deadLetterEndpoint, "seda:errors");
-        }
-    }
-
-    public void testConfigureDeadLetterChannelWithCustomRedeliveryPolicy() throws Exception {
-
-        // START SNIPPET: e4
-        RouteBuilder<Exchange> builder = new RouteBuilder<Exchange>() {
-            public void configure() {
-                errorHandler(deadLetterChannel("seda:errors").maximumRedeliveries(2).useExponentialBackOff());
-
-                from("seda:a").to("seda:b");
-            }
-        };
-        // END SNIPPET: e4
-
-        Map<Endpoint<Exchange>, Processor> routeMap = builder.getRouteMap();
-        Set<Map.Entry<Endpoint<Exchange>, Processor>> routes = routeMap.entrySet();
-        assertEquals("Number routes created", 1, routes.size());
-        for (Map.Entry<Endpoint<Exchange>, Processor> route : routes) {
-            Endpoint<Exchange> key = route.getKey();
-            assertEquals("From endpoint", "seda:a", key.getEndpointUri());
-            Processor processor = route.getValue();
-
-            DeadLetterChannel deadLetterChannel = assertIsInstanceOf(DeadLetterChannel.class, processor);
-            Endpoint deadLetterEndpoint = assertIsInstanceOf(Endpoint.class, deadLetterChannel.getDeadLetter());
-            assertEndpointUri(deadLetterEndpoint, "seda:errors");
-            RedeliveryPolicy redeliveryPolicy = deadLetterChannel.getRedeliveryPolicy();
-            assertEquals("getMaximumRedeliveries()", 2, redeliveryPolicy.getMaximumRedeliveries());
-            assertEquals("isUseExponentialBackOff()", true, redeliveryPolicy.isUseExponentialBackOff());
-        }
-    }         */
+     * public void testOverloadingTheDefaultErrorHandler() throws Exception { //
+     * START SNIPPET: e1 RouteBuilder<Exchange> builder = new RouteBuilder<Exchange>() {
+     * public void configure() { errorHandler(loggingErrorHandler("FOO.BAR"));
+     * from("seda:a").to("seda:b"); } }; // END SNIPPET: e1 Map<Endpoint<Exchange>,
+     * Processor> routeMap = builder.getRouteMap(); Set<Map.Entry<Endpoint<Exchange>,
+     * Processor>> routes = routeMap.entrySet(); assertEquals("Number routes
+     * created", 1, routes.size()); for (Map.Entry<Endpoint<Exchange>,
+     * Processor> route : routes) { Endpoint<Exchange> key = route.getKey();
+     * assertEquals("From endpoint", "seda:a", key.getEndpointUri()); Processor
+     * processor = route.getValue(); LoggingErrorHandler loggingProcessor =
+     * assertIsInstanceOf(LoggingErrorHandler.class, processor); } } public void
+     * testOverloadingTheHandlerOnASingleRoute() throws Exception { // START
+     * SNIPPET: e2 RouteBuilder<Exchange> builder = new RouteBuilder<Exchange>() {
+     * public void configure() {
+     * from("seda:a").errorHandler(loggingErrorHandler("FOO.BAR")).to("seda:b"); //
+     * this route will use the default error handler, DeadLetterChannel
+     * from("seda:b").to("seda:c"); } }; // END SNIPPET: e2 Map<Endpoint<Exchange>,
+     * Processor> routeMap = builder.getRouteMap(); log.debug(routeMap); Set<Map.Entry<Endpoint<Exchange>,
+     * Processor>> routes = routeMap.entrySet(); assertEquals("Number routes
+     * created", 2, routes.size()); for (Map.Entry<Endpoint<Exchange>,
+     * Processor> route : routes) { Endpoint<Exchange> key = route.getKey();
+     * String endpointUri = key.getEndpointUri(); Processor processor =
+     * route.getValue(); if (endpointUri.equals("seda:a")) { LoggingErrorHandler
+     * loggingProcessor = assertIsInstanceOf(LoggingErrorHandler.class,
+     * processor); Processor outputProcessor = loggingProcessor.getOutput();
+     * SendProcessor sendProcessor = assertIsInstanceOf(SendProcessor.class,
+     * outputProcessor); } else { assertEquals("From endpoint", "seda:b",
+     * endpointUri); DeadLetterChannel deadLetterChannel =
+     * assertIsInstanceOf(DeadLetterChannel.class, processor); Processor
+     * outputProcessor = deadLetterChannel.getOutput(); SendProcessor
+     * sendProcessor = assertIsInstanceOf(SendProcessor.class, outputProcessor); } } }
+     * public void testConfigureDeadLetterChannel() throws Exception { // START
+     * SNIPPET: e3 RouteBuilder<Exchange> builder = new RouteBuilder<Exchange>() {
+     * public void configure() { errorHandler(deadLetterChannel("seda:errors"));
+     * from("seda:a").to("seda:b"); } }; // END SNIPPET: e3 Map<Endpoint<Exchange>,
+     * Processor> routeMap = builder.getRouteMap(); Set<Map.Entry<Endpoint<Exchange>,
+     * Processor>> routes = routeMap.entrySet(); assertEquals("Number routes
+     * created", 1, routes.size()); for (Map.Entry<Endpoint<Exchange>,
+     * Processor> route : routes) { Endpoint<Exchange> key = route.getKey();
+     * assertEquals("From endpoint", "seda:a", key.getEndpointUri()); Processor
+     * processor = route.getValue(); DeadLetterChannel deadLetterChannel =
+     * assertIsInstanceOf(DeadLetterChannel.class, processor); Endpoint
+     * deadLetterEndpoint = assertIsInstanceOf(Endpoint.class,
+     * deadLetterChannel.getDeadLetter()); assertEndpointUri(deadLetterEndpoint,
+     * "seda:errors"); } } public void
+     * testConfigureDeadLetterChannelWithCustomRedeliveryPolicy() throws
+     * Exception { // START SNIPPET: e4 RouteBuilder<Exchange> builder = new
+     * RouteBuilder<Exchange>() { public void configure() {
+     * errorHandler(deadLetterChannel("seda:errors").maximumRedeliveries(2).useExponentialBackOff());
+     * from("seda:a").to("seda:b"); } }; // END SNIPPET: e4 Map<Endpoint<Exchange>,
+     * Processor> routeMap = builder.getRouteMap(); Set<Map.Entry<Endpoint<Exchange>,
+     * Processor>> routes = routeMap.entrySet(); assertEquals("Number routes
+     * created", 1, routes.size()); for (Map.Entry<Endpoint<Exchange>,
+     * Processor> route : routes) { Endpoint<Exchange> key = route.getKey();
+     * assertEquals("From endpoint", "seda:a", key.getEndpointUri()); Processor
+     * processor = route.getValue(); DeadLetterChannel deadLetterChannel =
+     * assertIsInstanceOf(DeadLetterChannel.class, processor); Endpoint
+     * deadLetterEndpoint = assertIsInstanceOf(Endpoint.class,
+     * deadLetterChannel.getDeadLetter()); assertEndpointUri(deadLetterEndpoint,
+     * "seda:errors"); RedeliveryPolicy redeliveryPolicy =
+     * deadLetterChannel.getRedeliveryPolicy();
+     * assertEquals("getMaximumRedeliveries()", 2,
+     * redeliveryPolicy.getMaximumRedeliveries());
+     * assertEquals("isUseExponentialBackOff()", true,
+     * redeliveryPolicy.isUseExponentialBackOff()); } }
+     */
 
     public void testDisablingInheritenceOfErrorHandlers() throws Exception {
 
@@ -158,11 +106,7 @@
         RouteBuilder builder = new RouteBuilder() {
             public void configure() {
 
-                from("seda:a").
-                        errorHandler(loggingErrorHandler("FOO.BAR")).
-                        filter(body().isInstanceOf(String.class)).
-                        inheritErrorHandler(false).
-                        to("seda:b");
+                from("seda:a").errorHandler(loggingErrorHandler("FOO.BAR")).filter(body().isInstanceOf(String.class)).inheritErrorHandler(false).to("seda:b");
             }
         };
         // END SNIPPET: e5

Modified: activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/builder/ExpressionBuilderTest.java
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/builder/ExpressionBuilderTest.java?view=diff&rev=563607&r1=563606&r2=563607
==============================================================================
--- activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/builder/ExpressionBuilderTest.java (original)
+++ activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/builder/ExpressionBuilderTest.java Tue Aug  7 11:35:48 2007
@@ -1,5 +1,4 @@
 /**
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements.  See the NOTICE file distributed with
  * this work for additional information regarding copyright ownership.
@@ -7,7 +6,7 @@
  * (the "License"); you may not use this file except in compliance with
  * the License.  You may obtain a copy of the License at
  *
- * http://www.apache.org/licenses/LICENSE-2.0
+ *      http://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing, software
  * distributed under the License is distributed on an "AS IS" BASIS,
@@ -17,17 +16,21 @@
  */
 package org.apache.camel.builder;
 
+import java.util.Arrays;
+
 import org.apache.camel.Exchange;
 import org.apache.camel.Expression;
 import org.apache.camel.Message;
 import org.apache.camel.Predicate;
 import org.apache.camel.TestSupport;
-import static org.apache.camel.builder.ExpressionBuilder.*;
-import static org.apache.camel.builder.PredicateBuilder.contains;
 import org.apache.camel.impl.DefaultCamelContext;
 import org.apache.camel.impl.DefaultExchange;
 
-import java.util.Arrays;
+import static org.apache.camel.builder.ExpressionBuilder.constantExpression;
+import static org.apache.camel.builder.ExpressionBuilder.headerExpression;
+import static org.apache.camel.builder.ExpressionBuilder.regexReplaceAll;
+import static org.apache.camel.builder.ExpressionBuilder.regexTokenize;
+import static org.apache.camel.builder.PredicateBuilder.contains;
 
 /**
  * @version $Revision$
@@ -37,17 +40,20 @@
 
     public void testRegexTokenize() throws Exception {
         Expression<Exchange> expression = regexTokenize(headerExpression("location"), ",");
-        assertExpression(expression, exchange, Arrays.asList(new String[]{"Islington", "London", "UK"}));
+        assertExpression(expression, exchange, Arrays.asList(new String[] {"Islington", "London", "UK"}));
 
-        Predicate<Exchange> predicate = contains(regexTokenize(headerExpression("location"), ","), constantExpression("London"));
+        Predicate<Exchange> predicate = contains(regexTokenize(headerExpression("location"), ","),
+                                                 constantExpression("London"));
         assertPredicate(predicate, exchange, true);
 
-        predicate = contains(regexTokenize(headerExpression("location"), ","), constantExpression("Manchester"));
+        predicate = contains(regexTokenize(headerExpression("location"), ","),
+                             constantExpression("Manchester"));
         assertPredicate(predicate, exchange, false);
     }
 
     public void testRegexReplaceAll() throws Exception {
-        Expression<Exchange> expression = regexReplaceAll(headerExpression("location"), "London", "Westminster");
+        Expression<Exchange> expression = regexReplaceAll(headerExpression("location"), "London",
+                                                          "Westminster");
         assertExpression(expression, exchange, "Islington,Westminster,UK");
 
         expression = regexReplaceAll(headerExpression("location"), "London", headerExpression("name"));

Modified: activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/builder/InterceptorBuilderTest.java
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/builder/InterceptorBuilderTest.java?view=diff&rev=563607&r1=563606&r2=563607
==============================================================================
--- activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/builder/InterceptorBuilderTest.java (original)
+++ activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/builder/InterceptorBuilderTest.java Tue Aug  7 11:35:48 2007
@@ -1,4 +1,4 @@
-/*
+/**
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements.  See the NOTICE file distributed with
  * this work for additional information regarding copyright ownership.
@@ -31,9 +31,9 @@
  */
 public class InterceptorBuilderTest extends TestSupport {
 
-
     /**
      * Validates that interceptors are executed in the right order.
+     * 
      * @throws Exception
      */
     public void testRouteWithInterceptor() throws Exception {
@@ -42,55 +42,48 @@
         final ArrayList<String> order = new ArrayList<String>();
 
         final DelegateProcessor interceptor1 = new DelegateProcessor() {
-        	@Override
-        	public void process(Exchange exchange) throws Exception {
-        		order.add("START:1");
-        		super.process(exchange);
-        		order.add("END:1");
-        	}
+            @Override
+            public void process(Exchange exchange) throws Exception {
+                order.add("START:1");
+                super.process(exchange);
+                order.add("END:1");
+            }
         };
         final DelegateProcessor interceptor2 = new DelegateProcessor() {
-        	@Override
-        	public void process(Exchange exchange) throws Exception {
-        		order.add("START:2");
-        		super.process(exchange);
-        		order.add("END:2");
-        	}
+            @Override
+            public void process(Exchange exchange) throws Exception {
+                order.add("START:2");
+                super.process(exchange);
+                order.add("END:2");
+            }
         };
 
         RouteBuilder builder = new RouteBuilder() {
             public void configure() {
-                from("direct:a")
-                        .intercept(interceptor1)
-                        .intercept(interceptor2)
-                        .to("direct:d");
-/*
-    TODO keep old DSL?
-                        .intercept()
-                        .add(interceptor1)
-                        .add(interceptor2)
-                        .target().to("direct:d");
-*/
+                from("direct:a").intercept(interceptor1).intercept(interceptor2).to("direct:d");
+                /*
+                 * TODO keep old DSL? .intercept() .add(interceptor1)
+                 * .add(interceptor2) .target().to("direct:d");
+                 */
             }
-        };        
+        };
         container.addRoutes(builder);
-        container.start();                                                   
-        
+        container.start();
+
         Endpoint<Exchange> endpoint = container.getEndpoint("direct:a");
         Exchange exchange = endpoint.createExchange();
         Producer<Exchange> producer = endpoint.createProducer();
         producer.process(exchange);
-        
-        
+
         ArrayList<String> expected = new ArrayList<String>();
         expected.add("START:1");
         expected.add("START:2");
         expected.add("END:2");
         expected.add("END:1");
-        
-        log.debug("Interceptor invocation order:"+order);
+
+        log.debug("Interceptor invocation order:" + order);
         assertEquals(expected, order);
-        
+
     }
 
 }

Modified: activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/builder/MyInterceptorProcessor.java
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/builder/MyInterceptorProcessor.java?view=diff&rev=563607&r1=563606&r2=563607
==============================================================================
--- activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/builder/MyInterceptorProcessor.java (original)
+++ activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/builder/MyInterceptorProcessor.java Tue Aug  7 11:35:48 2007
@@ -1,4 +1,4 @@
-/*
+/**
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements.  See the NOTICE file distributed with
  * this work for additional information regarding copyright ownership.
@@ -22,11 +22,11 @@
 import org.apache.commons.logging.LogFactory;
 
 public class MyInterceptorProcessor extends DelegateProcessor {
-    private static final transient Log log = LogFactory.getLog(MyInterceptorProcessor.class);
+    private static final transient Log LOG = LogFactory.getLog(MyInterceptorProcessor.class);
 
     public void process(Exchange exchange) throws Exception {
-		log.debug("START of onExchange: "+exchange);
-		super.process(exchange);
-		log.debug("END of onExchange: "+exchange);
-	}
-}
\ No newline at end of file
+        LOG.debug("START of onExchange: " + exchange);
+        super.process(exchange);
+        LOG.debug("END of onExchange: " + exchange);
+    }
+}

Modified: activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/builder/MyProcessor.java
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/builder/MyProcessor.java?view=diff&rev=563607&r1=563606&r2=563607
==============================================================================
--- activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/builder/MyProcessor.java (original)
+++ activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/builder/MyProcessor.java Tue Aug  7 11:35:48 2007
@@ -1,4 +1,4 @@
-/*
+/**
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements.  See the NOTICE file distributed with
  * this work for additional information regarding copyright ownership.
@@ -22,10 +22,10 @@
 import org.apache.commons.logging.LogFactory;
 
 public class MyProcessor implements Processor {
-    private static final transient Log log = LogFactory.getLog(MyProcessor.class);
+    private static final transient Log LOG = LogFactory.getLog(MyProcessor.class);
     
     public void process(Exchange exchange) {
-        log.debug("Called with exchange: " + exchange);
+        LOG.debug("Called with exchange: " + exchange);
     }
 
     @Override

Modified: activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/builder/PredicateBuilderTest.java
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/builder/PredicateBuilderTest.java?view=diff&rev=563607&r1=563606&r2=563607
==============================================================================
--- activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/builder/PredicateBuilderTest.java (original)
+++ activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/builder/PredicateBuilderTest.java Tue Aug  7 11:35:48 2007
@@ -1,5 +1,4 @@
 /**
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements.  See the NOTICE file distributed with
  * this work for additional information regarding copyright ownership.
@@ -7,7 +6,7 @@
  * (the "License"); you may not use this file except in compliance with
  * the License.  You may obtain a copy of the License at
  *
- * http://www.apache.org/licenses/LICENSE-2.0
+ *      http://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing, software
  * distributed under the License is distributed on an "AS IS" BASIS,
@@ -21,9 +20,10 @@
 import org.apache.camel.Message;
 import org.apache.camel.Predicate;
 import org.apache.camel.TestSupport;
-import static org.apache.camel.builder.Builder.*;
 import org.apache.camel.impl.DefaultCamelContext;
 import org.apache.camel.impl.DefaultExchange;
+
+import static org.apache.camel.builder.Builder.constant;
 
 /**
  * @version $Revision$

Modified: activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/builder/RouteBuilderTest.java
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/builder/RouteBuilderTest.java?view=diff&rev=563607&r1=563606&r2=563607
==============================================================================
--- activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/builder/RouteBuilderTest.java (original)
+++ activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/builder/RouteBuilderTest.java Tue Aug  7 11:35:48 2007
@@ -1,4 +1,4 @@
-/*
+/**
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements.  See the NOTICE file distributed with
  * this work for additional information regarding copyright ownership.
@@ -16,17 +16,15 @@
  */
 package org.apache.camel.builder;
 
-import static org.apache.camel.processor.idempotent.MemoryMessageIdRepository.memoryMessageIdRepository;
-
 import java.util.ArrayList;
 import java.util.List;
 
 import org.apache.camel.Endpoint;
 import org.apache.camel.Exchange;
 import org.apache.camel.Processor;
+import org.apache.camel.Producer;
 import org.apache.camel.Route;
 import org.apache.camel.TestSupport;
-import org.apache.camel.Producer;
 import org.apache.camel.impl.EventDrivenConsumerRoute;
 import org.apache.camel.processor.ChoiceProcessor;
 import org.apache.camel.processor.DeadLetterChannel;
@@ -39,6 +37,8 @@
 import org.apache.camel.processor.idempotent.IdempotentConsumer;
 import org.apache.camel.processor.idempotent.MemoryMessageIdRepository;
 
+import static org.apache.camel.processor.idempotent.MemoryMessageIdRepository.memoryMessageIdRepository;
+
 /**
  * @version $Revision$
  */
@@ -95,7 +95,9 @@
             Processor processor = getProcessorWithoutErrorHandler(route);
 
             FilterProcessor filterProcessor = assertIsInstanceOf(FilterProcessor.class, processor);
-            SendProcessor sendProcessor = assertIsInstanceOf(SendProcessor.class, unwrapErrorHandler(filterProcessor.getProcessor()));
+            SendProcessor sendProcessor = assertIsInstanceOf(SendProcessor.class,
+                                                             unwrapErrorHandler(filterProcessor
+                                                                 .getProcessor()));
             assertEquals("Endpoint URI", "seda:b", sendProcessor.getDestination().getEndpointUri());
         }
     }
@@ -104,10 +106,8 @@
         // START SNIPPET: e3
         RouteBuilder builder = new RouteBuilder() {
             public void configure() {
-                from("seda:a").choice()
-                        .when(header("foo").isEqualTo("bar")).to("seda:b")
-                        .when(header("foo").isEqualTo("cheese")).to("seda:c")
-                        .otherwise().to("seda:d");
+                from("seda:a").choice().when(header("foo").isEqualTo("bar")).to("seda:b")
+                    .when(header("foo").isEqualTo("cheese")).to("seda:c").otherwise().to("seda:d");
             }
         };
         // END SNIPPET: e3
@@ -192,7 +192,8 @@
             Processor processor = getProcessorWithoutErrorHandler(route);
 
             FilterProcessor filterProcessor = assertIsInstanceOf(FilterProcessor.class, processor);
-            assertEquals("Should be called with my processor", myProcessor, unwrapErrorHandler(filterProcessor.getProcessor()));
+            assertEquals("Should be called with my processor", myProcessor,
+                         unwrapErrorHandler(filterProcessor.getProcessor()));
         }
     }
 
@@ -231,23 +232,17 @@
         interceptor1 = new DelegateProcessor() {
         };
 
-        // START SNIPPET: e7        
+        // START SNIPPET: e7
         interceptor2 = new MyInterceptorProcessor();
 
         RouteBuilder builder = new RouteBuilder() {
             public void configure() {
-                from("seda:a")
-                        .intercept(interceptor1)
-                        .intercept(interceptor2)
-                        .to("seda:d");
-/*
-
-    TODO keep old DSL?
-                        .intercept()
-                        .add(interceptor1)
-                        .add(interceptor2)
-                        .target().to("seda:d");
-*/
+                from("seda:a").intercept(interceptor1).intercept(interceptor2).to("seda:d");
+                /*
+                 * 
+                 * TODO keep old DSL? .intercept() .add(interceptor1)
+                 * .add(interceptor2) .target().to("seda:d");
+                 */
             }
         };
         // END SNIPPET: e7
@@ -295,12 +290,15 @@
             Processor processor = getProcessorWithoutErrorHandler(route);
 
             log.debug("processor: " + processor);
-            /* TODO
-            FilterProcessor filterProcessor = assertIsInstanceOf(FilterProcessor.class, processor);
-
-            SendProcessor sendProcessor = assertIsInstanceOf(SendProcessor.class, filterProcessor.getProcessor());
-            assertEquals("Endpoint URI", "seda:b", sendProcessor.getDestination().getEndpointUri());
-            */
+            /*
+             * TODO FilterProcessor filterProcessor =
+             * assertIsInstanceOf(FilterProcessor.class, processor);
+             * 
+             * SendProcessor sendProcessor =
+             * assertIsInstanceOf(SendProcessor.class,
+             * filterProcessor.getProcessor()); assertEquals("Endpoint URI",
+             * "seda:b", sendProcessor.getDestination().getEndpointUri());
+             */
         }
     }
 
@@ -373,9 +371,8 @@
         // START SNIPPET: idempotent
         RouteBuilder builder = new RouteBuilder() {
             public void configure() {
-                from("seda:a").idempotentConsumer(
-                        header("myMessageId"), memoryMessageIdRepository(200)
-                ).to("seda:b");
+                from("seda:a").idempotentConsumer(header("myMessageId"), memoryMessageIdRepository(200))
+                    .to("seda:b");
             }
         };
         // END SNIPPET: idempotent
@@ -396,39 +393,42 @@
 
             IdempotentConsumer idempotentConsumer = assertIsInstanceOf(IdempotentConsumer.class, processor);
 
-            assertEquals("messageIdExpression", "header(myMessageId)", idempotentConsumer.getMessageIdExpression().toString());
+            assertEquals("messageIdExpression", "header(myMessageId)", idempotentConsumer
+                .getMessageIdExpression().toString());
 
             assertIsInstanceOf(MemoryMessageIdRepository.class, idempotentConsumer.getMessageIdRepository());
 
-            SendProcessor sendProcessor = assertIsInstanceOf(SendProcessor.class, unwrapErrorHandler(idempotentConsumer.getNextProcessor()));
+            SendProcessor sendProcessor = assertIsInstanceOf(SendProcessor.class,
+                                                             unwrapErrorHandler(idempotentConsumer
+                                                                 .getNextProcessor()));
             assertEquals("Endpoint URI", "seda:b", sendProcessor.getDestination().getEndpointUri());
         }
     }
 
     protected void assertSendTo(Processor processor, String uri) {
-    	if (!(processor instanceof SendProcessor)) {
-    		processor = unwrapErrorHandler(processor);
-    	}
+        if (!(processor instanceof SendProcessor)) {
+            processor = unwrapErrorHandler(processor);
+        }
 
         SendProcessor sendProcessor = assertIsInstanceOf(SendProcessor.class, processor);
         assertEquals("Endpoint URI", uri, sendProcessor.getDestination().getEndpointUri());
     }
 
     protected void assertSendToProcessor(Processor processor, String uri) {
-    	if (!(processor instanceof Producer)) {
-    		processor = unwrapErrorHandler(processor);
-    	}
-    	if (processor instanceof SendProcessor) {
-    		assertSendTo(processor, uri);
-    	}
-    	else {
-	        Producer producer = assertIsInstanceOf(Producer.class, processor);
-	        assertEquals("Endpoint URI", uri, producer.getEndpoint().getEndpointUri());
-    	}
+        if (!(processor instanceof Producer)) {
+            processor = unwrapErrorHandler(processor);
+        }
+        if (processor instanceof SendProcessor) {
+            assertSendTo(processor, uri);
+        } else {
+            Producer producer = assertIsInstanceOf(Producer.class, processor);
+            assertEquals("Endpoint URI", uri, producer.getEndpoint().getEndpointUri());
+        }
     }
 
     /**
-     * By default routes should be wrapped in the {@link DeadLetterChannel} so lets unwrap that and return the actual processor
+     * By default routes should be wrapped in the {@link DeadLetterChannel} so
+     * lets unwrap that and return the actual processor
      */
     protected Processor getProcessorWithoutErrorHandler(Route route) {
         EventDrivenConsumerRoute consumerRoute = assertIsInstanceOf(EventDrivenConsumerRoute.class, route);
@@ -437,14 +437,11 @@
     }
 
     protected Processor unwrapErrorHandler(Processor processor) {
-    	if (processor instanceof DeadLetterChannel) {
-    		DeadLetterChannel deadLetter = (DeadLetterChannel) processor;
-    		return deadLetter.getOutput();
-    	}
-    	else {
-    		return processor;
-    	}
+        if (processor instanceof DeadLetterChannel) {
+            DeadLetterChannel deadLetter = (DeadLetterChannel)processor;
+            return deadLetter.getOutput();
+        } else {
+            return processor;
+        }
     }
 }
-
-    
\ No newline at end of file

Modified: activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/builder/xml/XPathTest.java
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/builder/xml/XPathTest.java?view=diff&rev=563607&r1=563606&r2=563607
==============================================================================
--- activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/builder/xml/XPathTest.java (original)
+++ activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/builder/xml/XPathTest.java Tue Aug  7 11:35:48 2007
@@ -1,5 +1,4 @@
 /**
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements.  See the NOTICE file distributed with
  * this work for additional information regarding copyright ownership.
@@ -7,7 +6,7 @@
  * (the "License"); you may not use this file except in compliance with
  * the License.  You may obtain a copy of the License at
  *
- * http://www.apache.org/licenses/LICENSE-2.0
+ *      http://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing, software
  * distributed under the License is distributed on an "AS IS" BASIS,
@@ -17,18 +16,18 @@
  */
 package org.apache.camel.builder.xml;
 
+import javax.xml.xpath.XPathFunctionResolver;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.Exchange;
 import org.apache.camel.Expression;
 import org.apache.camel.Message;
 import org.apache.camel.Predicate;
 import org.apache.camel.TestSupport;
-import static org.apache.camel.builder.xml.XPathBuilder.*;
-import org.apache.camel.builder.xml.XPathBuilder;
 import org.apache.camel.impl.DefaultCamelContext;
 import org.apache.camel.impl.DefaultExchange;
 
-import javax.xml.xpath.XPathFunctionResolver;
+import static org.apache.camel.builder.xml.XPathBuilder.xpath;
 
 /**
  * @version $Revision$
@@ -59,18 +58,14 @@
         // we may not have Xalan on the classpath
         try {
             instance = Class.forName("org.apache.xalan.extensions.XPathFunctionResolverImpl").newInstance();
-        }
-        catch (Throwable e) {
+        } catch (Throwable e) {
             log.debug("Could not find Xalan on the classpath so ignoring this test case: " + e);
         }
-        
+
         if (instance instanceof XPathFunctionResolver) {
-            XPathFunctionResolver functionResolver = (XPathFunctionResolver) instance;
+            XPathFunctionResolver functionResolver = (XPathFunctionResolver)instance;
 
-            XPathBuilder builder = xpath("java:"
-                    + getClass().getName() + ".func(string(/header/value))")
-                    .namespace("java", "http://xml.apache.org/xalan/java")
-                    .functionResolver(functionResolver);
+            XPathBuilder builder = xpath("java:" + getClass().getName() + ".func(string(/header/value))").namespace("java", "http://xml.apache.org/xalan/java").functionResolver(functionResolver);
 
             String xml = "<header><value>12</value></header>";
             Object value = assertExpression(builder, xml, "modified12");

Modified: activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/builder/xml/XPathWithNamespacesFromDomTest.java
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/builder/xml/XPathWithNamespacesFromDomTest.java?view=diff&rev=563607&r1=563606&r2=563607
==============================================================================
--- activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/builder/xml/XPathWithNamespacesFromDomTest.java (original)
+++ activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/builder/xml/XPathWithNamespacesFromDomTest.java Tue Aug  7 11:35:48 2007
@@ -1,5 +1,4 @@
 /**
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements.  See the NOTICE file distributed with
  * this work for additional information regarding copyright ownership.
@@ -7,7 +6,7 @@
  * (the "License"); you may not use this file except in compliance with
  * the License.  You may obtain a copy of the License at
  *
- * http://www.apache.org/licenses/LICENSE-2.0
+ *      http://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing, software
  * distributed under the License is distributed on an "AS IS" BASIS,
@@ -17,19 +16,10 @@
  */
 package org.apache.camel.builder.xml;
 
-import org.apache.camel.TestSupport;
-import org.apache.camel.Expression;
-import org.apache.camel.Predicate;
-import org.apache.camel.Exchange;
-import org.apache.camel.CamelContext;
-import org.apache.camel.Message;
-import org.apache.camel.ContextTestSupport;
-import org.apache.camel.impl.DefaultCamelContext;
-import org.apache.camel.impl.DefaultExchange;
 import org.w3c.dom.Document;
 import org.w3c.dom.Element;
 
-import javax.xml.xpath.XPathFunctionResolver;
+import org.apache.camel.ContextTestSupport;
 
 /**
  * @version $Revision: 534495 $
@@ -37,8 +27,9 @@
 public class XPathWithNamespacesFromDomTest extends ContextTestSupport {
 
     public void testXPathUsingDomForNamespaces() throws Exception {
-        Document document = context.getTypeConverter().convertTo(Document.class, "<x:foo xmlns:x='n1' xmlns:y='n2'><bar id='a' xmlns:y='n3'/></x:foo>");
-        Element element = (Element) document.getElementsByTagName("bar").item(0);
+        Document document = context.getTypeConverter()
+            .convertTo(Document.class, "<x:foo xmlns:x='n1' xmlns:y='n2'><bar id='a' xmlns:y='n3'/></x:foo>");
+        Element element = (Element)document.getElementsByTagName("bar").item(0);
         assertNotNull("Could not find element for id 'a'", element);
 
         XPathBuilder builder = XPathBuilder.xpath("//y:foo[@id='z']");

Modified: activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/builder/xml/XsltTest.java
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/builder/xml/XsltTest.java?view=diff&rev=563607&r1=563606&r2=563607
==============================================================================
--- activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/builder/xml/XsltTest.java (original)
+++ activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/builder/xml/XsltTest.java Tue Aug  7 11:35:48 2007
@@ -1,5 +1,4 @@
 /**
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements.  See the NOTICE file distributed with
  * this work for additional information regarding copyright ownership.
@@ -7,7 +6,7 @@
  * (the "License"); you may not use this file except in compliance with
  * the License.  You may obtain a copy of the License at
  *
- * http://www.apache.org/licenses/LICENSE-2.0
+ *      http://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing, software
  * distributed under the License is distributed on an "AS IS" BASIS,
@@ -17,21 +16,23 @@
  */
 package org.apache.camel.builder.xml;
 
+import java.net.URL;
+
 import org.apache.camel.ContextTestSupport;
 import org.apache.camel.builder.RouteBuilder;
-import static org.apache.camel.builder.xml.XsltBuilder.xslt;
 import org.apache.camel.component.mock.MockEndpoint;
 
-import java.net.URL;
+import static org.apache.camel.builder.xml.XsltBuilder.xslt;
 
 /**
  * @version $Revision: 1.1 $
  */
 public class XsltTest extends ContextTestSupport {
-    
+
     public void testXslt() throws Exception {
-        MockEndpoint resultEndpoint = (MockEndpoint) resolveMandatoryEndpoint("mock:result");
-        resultEndpoint.expectedBodiesReceived("<?xml version=\"1.0\" encoding=\"UTF-8\"?><goodbye>world!</goodbye>");
+        MockEndpoint resultEndpoint = (MockEndpoint)resolveMandatoryEndpoint("mock:result");
+        resultEndpoint
+            .expectedBodiesReceived("<?xml version=\"1.0\" encoding=\"UTF-8\"?><goodbye>world!</goodbye>");
 
         sendBody("direct:start", "<hello>world!</hello>");
 

Modified: activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/component/direct/DirectRouteTest.java
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/component/direct/DirectRouteTest.java?view=diff&rev=563607&r1=563606&r2=563607
==============================================================================
--- activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/component/direct/DirectRouteTest.java (original)
+++ activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/component/direct/DirectRouteTest.java Tue Aug  7 11:35:48 2007
@@ -1,5 +1,4 @@
 /**
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements.  See the NOTICE file distributed with
  * this work for additional information regarding copyright ownership.
@@ -7,7 +6,7 @@
  * (the "License"); you may not use this file except in compliance with
  * the License.  You may obtain a copy of the License at
  *
- * http://www.apache.org/licenses/LICENSE-2.0
+ *      http://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing, software
  * distributed under the License is distributed on an "AS IS" BASIS,
@@ -34,27 +33,25 @@
  */
 public class DirectRouteTest extends TestCase {
 
-	
     public void testSedaQueue() throws Exception {
         CamelContext container = new DefaultCamelContext();
 
         final AtomicBoolean invoked = new AtomicBoolean();
-        
+
         // lets add some routes
         container.addRoutes(new RouteBuilder() {
             public void configure() {
                 from("direct:test.a").to("direct:test.b");
                 from("direct:test.b").process(new Processor() {
                     public void process(Exchange e) {
-                    	invoked.set(true);
+                        invoked.set(true);
                     }
                 });
             }
         });
 
-        
         container.start();
-        
+
         // now lets fire in a message
         Endpoint<Exchange> endpoint = container.getEndpoint("direct:test.a");
         Exchange exchange = endpoint.createExchange();

Modified: activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/component/file/FileConfigureTest.java
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/component/file/FileConfigureTest.java?view=diff&rev=563607&r1=563606&r2=563607
==============================================================================
--- activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/component/file/FileConfigureTest.java (original)
+++ activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/component/file/FileConfigureTest.java Tue Aug  7 11:35:48 2007
@@ -1,5 +1,4 @@
 /**
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements.  See the NOTICE file distributed with
  * this work for additional information regarding copyright ownership.
@@ -7,7 +6,7 @@
  * (the "License"); you may not use this file except in compliance with
  * the License.  You may obtain a copy of the License at
  *
- * http://www.apache.org/licenses/LICENSE-2.0
+ *      http://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing, software
  * distributed under the License is distributed on an "AS IS" BASIS,
@@ -17,15 +16,15 @@
  */
 package org.apache.camel.component.file;
 
-import org.apache.camel.ContextTestSupport;
-
 import java.io.File;
 
+import org.apache.camel.ContextTestSupport;
+
 /**
  * @version $Revision: 1.1 $
  */
 public class FileConfigureTest extends ContextTestSupport {
-	private static final String EXPECT_PATH = "target" + File.separator + "foo" + File.separator + "bar";
+    private static final String EXPECT_PATH = "target" + File.separator + "foo" + File.separator + "bar";
 
     public void testUriConfigurations() throws Exception {
         assertFileEndpoint("file://target/foo/bar", EXPECT_PATH);
@@ -39,7 +38,7 @@
         assertNotNull("Could not find endpoint: " + endpointUri, endpoint);
 
         File file = endpoint.getFile();
-        String path = file.getPath();        
+        String path = file.getPath();
         assertEquals("For uri: " + endpointUri + " the file is not equal", expectedPath, path);
     }
 }

Modified: activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/component/file/FileDeleteRouteTest.java
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/component/file/FileDeleteRouteTest.java?view=diff&rev=563607&r1=563606&r2=563607
==============================================================================
--- activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/component/file/FileDeleteRouteTest.java (original)
+++ activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/component/file/FileDeleteRouteTest.java Tue Aug  7 11:35:48 2007
@@ -1,5 +1,4 @@
 /**
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements.  See the NOTICE file distributed with
  * this work for additional information regarding copyright ownership.
@@ -7,7 +6,7 @@
  * (the "License"); you may not use this file except in compliance with
  * the License.  You may obtain a copy of the License at
  *
- * http://www.apache.org/licenses/LICENSE-2.0
+ *      http://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing, software
  * distributed under the License is distributed on an "AS IS" BASIS,

Modified: activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/component/file/FileNoOpRouteTest.java
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/component/file/FileNoOpRouteTest.java?view=diff&rev=563607&r1=563606&r2=563607
==============================================================================
--- activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/component/file/FileNoOpRouteTest.java (original)
+++ activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/component/file/FileNoOpRouteTest.java Tue Aug  7 11:35:48 2007
@@ -1,5 +1,4 @@
 /**
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements.  See the NOTICE file distributed with
  * this work for additional information regarding copyright ownership.
@@ -7,7 +6,7 @@
  * (the "License"); you may not use this file except in compliance with
  * the License.  You may obtain a copy of the License at
  *
- * http://www.apache.org/licenses/LICENSE-2.0
+ *      http://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing, software
  * distributed under the License is distributed on an "AS IS" BASIS,

Modified: activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/component/file/FileRenameRouteTest.java
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/component/file/FileRenameRouteTest.java?view=diff&rev=563607&r1=563606&r2=563607
==============================================================================
--- activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/component/file/FileRenameRouteTest.java (original)
+++ activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/component/file/FileRenameRouteTest.java Tue Aug  7 11:35:48 2007
@@ -1,5 +1,4 @@
 /**
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements.  See the NOTICE file distributed with
  * this work for additional information regarding copyright ownership.
@@ -7,7 +6,7 @@
  * (the "License"); you may not use this file except in compliance with
  * the License.  You may obtain a copy of the License at
  *
- * http://www.apache.org/licenses/LICENSE-2.0
+ *      http://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing, software
  * distributed under the License is distributed on an "AS IS" BASIS,

Modified: activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/component/file/FileRouteTest.java
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/component/file/FileRouteTest.java?view=diff&rev=563607&r1=563606&r2=563607
==============================================================================
--- activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/component/file/FileRouteTest.java (original)
+++ activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/component/file/FileRouteTest.java Tue Aug  7 11:35:48 2007
@@ -1,5 +1,4 @@
 /**
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements.  See the NOTICE file distributed with
  * this work for additional information regarding copyright ownership.
@@ -7,7 +6,7 @@
  * (the "License"); you may not use this file except in compliance with
  * the License.  You may obtain a copy of the License at
  *
- * http://www.apache.org/licenses/LICENSE-2.0
+ *      http://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing, software
  * distributed under the License is distributed on an "AS IS" BASIS,

Modified: activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/component/log/LogRouteTest.java
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/component/log/LogRouteTest.java?view=diff&rev=563607&r1=563606&r2=563607
==============================================================================
--- activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/component/log/LogRouteTest.java (original)
+++ activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/component/log/LogRouteTest.java Tue Aug  7 11:35:48 2007
@@ -1,5 +1,4 @@
 /**
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements.  See the NOTICE file distributed with
  * this work for additional information regarding copyright ownership.
@@ -7,7 +6,7 @@
  * (the "License"); you may not use this file except in compliance with
  * the License.  You may obtain a copy of the License at
  *
- * http://www.apache.org/licenses/LICENSE-2.0
+ *      http://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing, software
  * distributed under the License is distributed on an "AS IS" BASIS,
@@ -24,8 +23,8 @@
 /**
  * @version $Revision: 520220 $
  */
-public class LogRouteTest  extends ContextTestSupport {
-    private static final Log log = LogFactory.getLog(LogRouteTest.class);
+public class LogRouteTest extends ContextTestSupport {
+    private static final Log LOG = LogFactory.getLog(LogRouteTest.class);
 
     public void testSendMessageToLog() throws Exception {
         template.sendBody("log:org.apache.camel.TEST", "<level>default</level>");
@@ -43,10 +42,9 @@
         try {
             template.sendBody("log:org.apache.camel.TEST?level=noSuchLevel", "<level>noSuchLevel</level>");
             fail("Shoudl have failed!");
-        }
-        catch (Exception e) {
-            log.debug("Caught expected exception: " + e, e);
+        } catch (Exception e) {
+            LOG.debug("Caught expected exception: " + e, e);
         }
     }
 
-}
\ No newline at end of file
+}

Modified: activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/component/mock/MockEndpointTest.java
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/component/mock/MockEndpointTest.java?view=diff&rev=563607&r1=563606&r2=563607
==============================================================================
--- activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/component/mock/MockEndpointTest.java (original)
+++ activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/component/mock/MockEndpointTest.java Tue Aug  7 11:35:48 2007
@@ -1,4 +1,4 @@
-/*
+/**
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements.  See the NOTICE file distributed with
  * this work for additional information regarding copyright ownership.

Modified: activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/component/pojo/ISay.java
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/component/pojo/ISay.java?view=diff&rev=563607&r1=563606&r2=563607
==============================================================================
--- activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/component/pojo/ISay.java (original)
+++ activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/component/pojo/ISay.java Tue Aug  7 11:35:48 2007
@@ -1,4 +1,4 @@
-/*
+/**
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements.  See the NOTICE file distributed with
  * this work for additional information regarding copyright ownership.
@@ -17,5 +17,5 @@
 package org.apache.camel.component.pojo;
 
 public interface ISay {
-	public String say();
+    String say();
 }

Modified: activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/component/pojo/PojoRouteTest.java
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/component/pojo/PojoRouteTest.java?view=diff&rev=563607&r1=563606&r2=563607
==============================================================================
--- activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/component/pojo/PojoRouteTest.java (original)
+++ activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/component/pojo/PojoRouteTest.java Tue Aug  7 11:35:48 2007
@@ -1,5 +1,4 @@
 /**
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements.  See the NOTICE file distributed with
  * this work for additional information regarding copyright ownership.
@@ -7,7 +6,7 @@
  * (the "License"); you may not use this file except in compliance with
  * the License.  You may obtain a copy of the License at
  *
- * http://www.apache.org/licenses/LICENSE-2.0
+ *      http://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing, software
  * distributed under the License is distributed on an "AS IS" BASIS,
@@ -21,16 +20,16 @@
 
 import org.apache.camel.CamelContext;
 import org.apache.camel.Endpoint;
-import org.apache.camel.component.bean.ProxyHelper;
-import org.apache.camel.util.jndi.JndiContext;
 import org.apache.camel.builder.RouteBuilder;
+import org.apache.camel.component.bean.ProxyHelper;
 import org.apache.camel.impl.DefaultCamelContext;
+import org.apache.camel.util.jndi.JndiContext;
 
 /**
  * @version $Revision: 520220 $
  */
 public class PojoRouteTest extends TestCase {
-	
+
     public void testPojoRoutes() throws Exception {
         // START SNIPPET: register
         // lets populate the context with the services we need
@@ -51,14 +50,14 @@
         // END SNIPPET: route
 
         camelContext.start();
-        
+
         // START SNIPPET: invoke
         Endpoint endpoint = camelContext.getEndpoint("direct:hello");
         ISay proxy = ProxyHelper.createProxy(endpoint, ISay.class);
         String rc = proxy.say();
         assertEquals("Good Bye!", rc);
         // END SNIPPET: invoke
-        
+
         camelContext.stop();
     }
 }

Modified: activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/component/pojo/SayService.java
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/component/pojo/SayService.java?view=diff&rev=563607&r1=563606&r2=563607
==============================================================================
--- activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/component/pojo/SayService.java (original)
+++ activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/component/pojo/SayService.java Tue Aug  7 11:35:48 2007
@@ -1,4 +1,4 @@
-/*
+/**
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements.  See the NOTICE file distributed with
  * this work for additional information regarding copyright ownership.
@@ -17,24 +17,25 @@
 package org.apache.camel.component.pojo;
 
 public class SayService implements ISay {
-	String message = "Hello";
-	
-	public SayService() {
-	}
-	public SayService(String message) {
-		this.message = message;
-	}
-
-	public String say() {
-		return message;
-	}
-
-	public String getMessage() {
-		return message;
-	}
-
-	public void setMessage(String message) {
-		this.message = message;
-	}
+    String message = "Hello";
+
+    public SayService() {
+    }
+
+    public SayService(String message) {
+        this.message = message;
+    }
+
+    public String say() {
+        return message;
+    }
+
+    public String getMessage() {
+        return message;
+    }
+
+    public void setMessage(String message) {
+        this.message = message;
+    }
 
 }

Modified: activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/component/seda/SedaRouteTest.java
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/component/seda/SedaRouteTest.java?view=diff&rev=563607&r1=563606&r2=563607
==============================================================================
--- activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/component/seda/SedaRouteTest.java (original)
+++ activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/component/seda/SedaRouteTest.java Tue Aug  7 11:35:48 2007
@@ -1,5 +1,4 @@
 /**
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements.  See the NOTICE file distributed with
  * this work for additional information regarding copyright ownership.
@@ -7,7 +6,7 @@
  * (the "License"); you may not use this file except in compliance with
  * the License.  You may obtain a copy of the License at
  *
- * http://www.apache.org/licenses/LICENSE-2.0
+ *      http://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing, software
  * distributed under the License is distributed on an "AS IS" BASIS,
@@ -17,9 +16,10 @@
  */
 package org.apache.camel.component.seda;
 
-import junit.framework.TestCase;
+import java.util.concurrent.CountDownLatch;
+import java.util.concurrent.TimeUnit;
+
 import org.apache.camel.CamelContext;
-import org.apache.camel.Component;
 import org.apache.camel.Endpoint;
 import org.apache.camel.Exchange;
 import org.apache.camel.Processor;
@@ -27,9 +27,6 @@
 import org.apache.camel.TestSupport;
 import org.apache.camel.builder.RouteBuilder;
 import org.apache.camel.impl.DefaultCamelContext;
-
-import java.util.concurrent.CountDownLatch;
-import java.util.concurrent.TimeUnit;
 
 /**
  * @version $Revision: 520220 $

Modified: activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/component/timer/TimerRouteTest.java
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/component/timer/TimerRouteTest.java?view=diff&rev=563607&r1=563606&r2=563607
==============================================================================
--- activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/component/timer/TimerRouteTest.java (original)
+++ activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/component/timer/TimerRouteTest.java Tue Aug  7 11:35:48 2007
@@ -1,5 +1,4 @@
 /**
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements.  See the NOTICE file distributed with
  * this work for additional information regarding copyright ownership.
@@ -7,7 +6,7 @@
  * (the "License"); you may not use this file except in compliance with
  * the License.  You may obtain a copy of the License at
  *
- * http://www.apache.org/licenses/LICENSE-2.0
+ *      http://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing, software
  * distributed under the License is distributed on an "AS IS" BASIS,
@@ -17,7 +16,10 @@
  */
 package org.apache.camel.component.timer;
 
+import java.util.concurrent.atomic.AtomicInteger;
+
 import junit.framework.TestCase;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.builder.RouteBuilder;
 import org.apache.camel.impl.DefaultCamelContext;
@@ -25,13 +27,11 @@
 import org.apache.commons.logging.Log;
 import org.apache.commons.logging.LogFactory;
 
-import java.util.concurrent.atomic.AtomicInteger;
-
 /**
  * @version $Revision: 520220 $
  */
 public class TimerRouteTest extends TestCase {
-    private static final transient Log log = LogFactory.getLog(TimerRouteTest.class);
+    private static final transient Log LOG = LogFactory.getLog(TimerRouteTest.class);
 
     public void testPojoRoutes() throws Exception {
         final AtomicInteger hitCount = new AtomicInteger();
@@ -39,7 +39,7 @@
         JndiContext context = new JndiContext();
         context.bind("bar", new Runnable() {
             public void run() {
-                log.debug("hit");
+                LOG.debug("hit");
                 hitCount.incrementAndGet();
             }
         });

Modified: activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/component/vm/VmRouteTest.java
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/component/vm/VmRouteTest.java?view=diff&rev=563607&r1=563606&r2=563607
==============================================================================
--- activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/component/vm/VmRouteTest.java (original)
+++ activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/component/vm/VmRouteTest.java Tue Aug  7 11:35:48 2007
@@ -1,5 +1,4 @@
 /**
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements.  See the NOTICE file distributed with
  * this work for additional information regarding copyright ownership.
@@ -7,7 +6,7 @@
  * (the "License"); you may not use this file except in compliance with
  * the License.  You may obtain a copy of the License at
  *
- * http://www.apache.org/licenses/LICENSE-2.0
+ *      http://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing, software
  * distributed under the License is distributed on an "AS IS" BASIS,

Modified: activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/converter/ConverterTest.java
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/converter/ConverterTest.java?view=diff&rev=563607&r1=563606&r2=563607
==============================================================================
--- activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/converter/ConverterTest.java (original)
+++ activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/converter/ConverterTest.java Tue Aug  7 11:35:48 2007
@@ -1,5 +1,4 @@
 /**
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements.  See the NOTICE file distributed with
  * this work for additional information regarding copyright ownership.
@@ -7,7 +6,7 @@
  * (the "License"); you may not use this file except in compliance with
  * the License.  You may obtain a copy of the License at
  *
- * http://www.apache.org/licenses/LICENSE-2.0
+ *      http://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing, software
  * distributed under the License is distributed on an "AS IS" BASIS,
@@ -17,13 +16,6 @@
  */
 package org.apache.camel.converter;
 
-import junit.framework.TestCase;
-import org.apache.camel.TypeConverter;
-import org.apache.camel.impl.ReflectionInjector;
-import org.apache.camel.impl.converter.DefaultTypeConverter;
-import org.apache.commons.logging.Log;
-import org.apache.commons.logging.LogFactory;
-
 import java.beans.PropertyEditorManager;
 import java.beans.PropertyEditorSupport;
 import java.io.File;
@@ -33,11 +25,19 @@
 import java.util.List;
 import java.util.Set;
 
+import junit.framework.TestCase;
+
+import org.apache.camel.TypeConverter;
+import org.apache.camel.impl.ReflectionInjector;
+import org.apache.camel.impl.converter.DefaultTypeConverter;
+import org.apache.commons.logging.Log;
+import org.apache.commons.logging.LogFactory;
+
 /**
  * @version $Revision$
  */
 public class ConverterTest extends TestCase {
-    private static final transient Log log = LogFactory.getLog(ConverterTest.class);
+    private static final transient Log LOG = LogFactory.getLog(ConverterTest.class);
 
     protected TypeConverter converter = new DefaultTypeConverter(new ReflectionInjector());
 
@@ -48,7 +48,7 @@
 
         public String getAsText() {
             Integer value = (Integer) getValue();
-            return (value != null ? value.toString() : "");
+            return value != null ? value.toString() : "";
         }
     }
 
@@ -71,7 +71,7 @@
         byte[] array = converter.convertTo(byte[].class, "foo");
         assertNotNull(array);
 
-        log.debug("Found array of size: " + array.length);
+        LOG.debug("Found array of size: " + array.length);
 
         String text = converter.convertTo(String.class, array);
         assertEquals("Converted to String", "foo", text);
@@ -131,7 +131,7 @@
         // now lets go back to a List again
         List resultList = converter.convertTo(List.class, intArray);
         assertEquals("List size", 2, resultList.size());
-        log.debug("From primitive type array we've created the list: " + resultList);
+        LOG.debug("From primitive type array we've created the list: " + resultList);
     }
 
     public void testStringToFile() throws Exception {

Modified: activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/converter/JaxpTest.java
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/converter/JaxpTest.java?view=diff&rev=563607&r1=563606&r2=563607
==============================================================================
--- activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/converter/JaxpTest.java (original)
+++ activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/converter/JaxpTest.java Tue Aug  7 11:35:48 2007
@@ -1,5 +1,4 @@
 /**
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements.  See the NOTICE file distributed with
  * this work for additional information regarding copyright ownership.
@@ -7,7 +6,7 @@
  * (the "License"); you may not use this file except in compliance with
  * the License.  You may obtain a copy of the License at
  *
- * http://www.apache.org/licenses/LICENSE-2.0
+ *      http://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing, software
  * distributed under the License is distributed on an "AS IS" BASIS,
@@ -17,41 +16,46 @@
  */
 package org.apache.camel.converter;
 
+import javax.xml.transform.Source;
+
+import org.w3c.dom.Document;
+
 import junit.framework.TestCase;
-import org.apache.commons.logging.Log;
-import org.apache.commons.logging.LogFactory;
+
 import org.apache.camel.TypeConverter;
 import org.apache.camel.impl.ReflectionInjector;
 import org.apache.camel.impl.converter.DefaultTypeConverter;
-import org.w3c.dom.Document;
-
-import javax.xml.transform.Source;
+import org.apache.commons.logging.Log;
+import org.apache.commons.logging.LogFactory;
 
 /**
  * @version $Revision$
  */
 public class JaxpTest extends TestCase {
-    private static final transient Log log = LogFactory.getLog(JaxpTest.class);
+    private static final transient Log LOG = LogFactory.getLog(JaxpTest.class);
 
     protected TypeConverter converter = new DefaultTypeConverter(new ReflectionInjector());
 
     public void testConvertToDocument() throws Exception {
-        Document document = converter.convertTo(Document.class, "<?xml version=\"1.0\" encoding=\"UTF-8\"?><hello>world!</hello>");
+        Document document = converter
+            .convertTo(Document.class, "<?xml version=\"1.0\" encoding=\"UTF-8\"?><hello>world!</hello>");
         assertNotNull(document);
 
-        log.debug("Found document: " + document);
+        LOG.debug("Found document: " + document);
 
         // lets now convert back again
 
         String text = converter.convertTo(String.class, document);
-        // The preamble changes a little under Java 1.6 it adds a standalone="no" attribute.
+        // The preamble changes a little under Java 1.6 it adds a
+        // standalone="no" attribute.
         assertTrue("Converted to String", text.endsWith("?><hello>world!</hello>"));
     }
 
     public void testConvertToSource() throws Exception {
-        Source source = converter.convertTo(Source.class, "<?xml version=\"1.0\" encoding=\"UTF-8\"?><hello>world!</hello>");
+        Source source = converter
+            .convertTo(Source.class, "<?xml version=\"1.0\" encoding=\"UTF-8\"?><hello>world!</hello>");
         assertNotNull(source);
 
-        log.debug("Found document: " + source);
+        LOG.debug("Found document: " + source);
     }
 }

Modified: activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/impl/DefaultCamelContextTest.java
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/impl/DefaultCamelContextTest.java?view=diff&rev=563607&r1=563606&r2=563607
==============================================================================
--- activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/impl/DefaultCamelContextTest.java (original)
+++ activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/impl/DefaultCamelContextTest.java Tue Aug  7 11:35:48 2007
@@ -1,5 +1,4 @@
 /**
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements.  See the NOTICE file distributed with
  * this work for additional information regarding copyright ownership.
@@ -7,7 +6,7 @@
  * (the "License"); you may not use this file except in compliance with
  * the License.  You may obtain a copy of the License at
  *
- * http://www.apache.org/licenses/LICENSE-2.0
+ *      http://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing, software
  * distributed under the License is distributed on an "AS IS" BASIS,
@@ -26,18 +25,18 @@
  */
 public class DefaultCamelContextTest extends TestCase {
 
-	public void testAutoCreateComponentsOn() {
-		DefaultCamelContext ctx = new DefaultCamelContext();
-		Component component = ctx.getComponent("bean");
-		assertNotNull(component);
-		assertEquals(component.getClass(), BeanComponent.class);
-	}
-	
-	public void testAutoCreateComponentsOff() {
-		DefaultCamelContext ctx = new DefaultCamelContext();
-		ctx.setAutoCreateComponents(false);
-		Component component = ctx.getComponent("bean");
-		assertNull(component);		
-	}
-	
+    public void testAutoCreateComponentsOn() {
+        DefaultCamelContext ctx = new DefaultCamelContext();
+        Component component = ctx.getComponent("bean");
+        assertNotNull(component);
+        assertEquals(component.getClass(), BeanComponent.class);
+    }
+
+    public void testAutoCreateComponentsOff() {
+        DefaultCamelContext ctx = new DefaultCamelContext();
+        ctx.setAutoCreateComponents(false);
+        Component component = ctx.getComponent("bean");
+        assertNull(component);
+    }
+
 }

Modified: activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/impl/MyExchange.java
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/impl/MyExchange.java?view=diff&rev=563607&r1=563606&r2=563607
==============================================================================
--- activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/impl/MyExchange.java (original)
+++ activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/impl/MyExchange.java Tue Aug  7 11:35:48 2007
@@ -1,5 +1,4 @@
 /**
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements.  See the NOTICE file distributed with
  * this work for additional information regarding copyright ownership.
@@ -7,7 +6,7 @@
  * (the "License"); you may not use this file except in compliance with
  * the License.  You may obtain a copy of the License at
  *
- * http://www.apache.org/licenses/LICENSE-2.0
+ *      http://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing, software
  * distributed under the License is distributed on an "AS IS" BASIS,

Modified: activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/impl/ProducerTest.java
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/impl/ProducerTest.java?view=diff&rev=563607&r1=563606&r2=563607
==============================================================================
--- activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/impl/ProducerTest.java (original)
+++ activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/impl/ProducerTest.java Tue Aug  7 11:35:48 2007
@@ -1,5 +1,4 @@
 /**
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements.  See the NOTICE file distributed with
  * this work for additional information regarding copyright ownership.
@@ -7,7 +6,7 @@
  * (the "License"); you may not use this file except in compliance with
  * the License.  You may obtain a copy of the License at
  *
- * http://www.apache.org/licenses/LICENSE-2.0
+ *      http://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing, software
  * distributed under the License is distributed on an "AS IS" BASIS,
@@ -34,13 +33,13 @@
     private CamelContext context = new DefaultCamelContext();
 
     public void testUsingADerivedExchange() throws Exception {
-        DefaultEndpoint<MyExchange> endpoint = new DefaultEndpoint<MyExchange>("foo", new DefaultComponent(){
-			@Override
-			protected Endpoint createEndpoint(String uri, String remaining, Map parameters) throws Exception {
-				return null;
-			}
-        	
-        } ) {
+        DefaultEndpoint<MyExchange> endpoint = new DefaultEndpoint<MyExchange>("foo", new DefaultComponent() {
+            @Override
+            protected Endpoint createEndpoint(String uri, String remaining, Map parameters) throws Exception {
+                return null;
+            }
+
+        }) {
             public Consumer<MyExchange> createConsumer(Processor processor) throws Exception {
                 return null;
             }
@@ -48,7 +47,7 @@
             public MyExchange createExchange() {
                 return new MyExchange(getContext());
             }
- 
+
             public Producer<MyExchange> createProducer() throws Exception {
                 return null;
             }
@@ -56,7 +55,7 @@
             public boolean isSingleton() {
                 return false;
             }
-            
+
         };
 
         DefaultProducer producer = new DefaultProducer(endpoint) {
@@ -75,7 +74,6 @@
         MyExchange actual = endpoint.toExchangeType(exchange);
         assertNotNull(actual);
         assertTrue("Not same exchange", actual != exchange);
-
 
         MyExchange expected = new MyExchange(context);
         actual = endpoint.toExchangeType(expected);

Modified: activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/impl/RegistryTest.java
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/impl/RegistryTest.java?view=diff&rev=563607&r1=563606&r2=563607
==============================================================================
--- activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/impl/RegistryTest.java (original)
+++ activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/impl/RegistryTest.java Tue Aug  7 11:35:48 2007
@@ -1,4 +1,4 @@
-/*
+/**
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements.  See the NOTICE file distributed with
  * this work for additional information regarding copyright ownership.
@@ -16,11 +16,12 @@
  */
 package org.apache.camel.impl;
 
-import junit.framework.TestCase;
-import org.apache.camel.util.jndi.JndiTest;
-
 import java.util.Arrays;
 import java.util.List;
+
+import junit.framework.TestCase;
+
+import org.apache.camel.util.jndi.JndiTest;
 
 /**
  * @version $Revision: $

Modified: activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/issues/Issue3Test.java
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/issues/Issue3Test.java?view=diff&rev=563607&r1=563606&r2=563607
==============================================================================
--- activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/issues/Issue3Test.java (original)
+++ activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/issues/Issue3Test.java Tue Aug  7 11:35:48 2007
@@ -1,5 +1,4 @@
 /**
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements.  See the NOTICE file distributed with
  * this work for additional information regarding copyright ownership.
@@ -7,7 +6,7 @@
  * (the "License"); you may not use this file except in compliance with
  * the License.  You may obtain a copy of the License at
  *
- * http://www.apache.org/licenses/LICENSE-2.0
+ *      http://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing, software
  * distributed under the License is distributed on an "AS IS" BASIS,

Modified: activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/language/SimpleTest.java
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/language/SimpleTest.java?view=diff&rev=563607&r1=563606&r2=563607
==============================================================================
--- activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/language/SimpleTest.java (original)
+++ activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/language/SimpleTest.java Tue Aug  7 11:35:48 2007
@@ -1,4 +1,4 @@
-/*
+/**
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements.  See the NOTICE file distributed with
  * this work for additional information regarding copyright ownership.

Modified: activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/language/XPathTest.java
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/language/XPathTest.java?view=diff&rev=563607&r1=563606&r2=563607
==============================================================================
--- activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/language/XPathTest.java (original)
+++ activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/language/XPathTest.java Tue Aug  7 11:35:48 2007
@@ -1,4 +1,4 @@
-/*
+/**
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements.  See the NOTICE file distributed with
  * this work for additional information regarding copyright ownership.

Modified: activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/model/GenerateXmlTest.java
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/model/GenerateXmlTest.java?view=diff&rev=563607&r1=563606&r2=563607
==============================================================================
--- activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/model/GenerateXmlTest.java (original)
+++ activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/model/GenerateXmlTest.java Tue Aug  7 11:35:48 2007
@@ -1,5 +1,4 @@
 /**
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements.  See the NOTICE file distributed with
  * this work for additional information regarding copyright ownership.
@@ -7,7 +6,7 @@
  * (the "License"); you may not use this file except in compliance with
  * the License.  You may obtain a copy of the License at
  *
- * http://www.apache.org/licenses/LICENSE-2.0
+ *      http://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing, software
  * distributed under the License is distributed on an "AS IS" BASIS,
@@ -17,11 +16,12 @@
  */
 package org.apache.camel.model;
 
-import org.apache.camel.model.language.GroovyExpression;
-
-import javax.xml.bind.Marshaller;
 import java.io.StringWriter;
 import java.util.List;
+
+import javax.xml.bind.Marshaller;
+
+import org.apache.camel.model.language.GroovyExpression;
 
 /**
  * @version $Revision: 1.1 $