You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@camel.apache.org by ni...@apache.org on 2008/09/16 05:52:01 UTC

svn commit: r695721 - in /activemq/camel/trunk: camel-core/src/main/java/org/apache/camel/impl/ camel-core/src/main/java/org/apache/camel/impl/converter/ camel-core/src/main/java/org/apache/camel/model/dataformat/ camel-core/src/main/java/org/apache/ca...

Author: ningjiang
Date: Mon Sep 15 20:51:58 2008
New Revision: 695721

URL: http://svn.apache.org/viewvc?rev=695721&view=rev
Log:
Fixed the CS errors

Modified:
    activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/impl/ProducerCache.java
    activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/impl/converter/DefaultTypeConverter.java
    activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/model/dataformat/DataFormatsType.java
    activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/processor/TryProcessor.java
    activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/util/concurrent/CountingLatch.java
    activemq/camel/trunk/components/camel-bam/src/main/java/org/apache/camel/bam/processor/BamProcessorSupport.java
    activemq/camel/trunk/components/camel-ftp/src/test/java/org/apache/camel/component/file/remote/FromFtpNonExclusiveReadTest.java
    activemq/camel/trunk/components/camel-jms/src/main/java/org/apache/camel/component/jms/EndpointMessageListener.java
    activemq/camel/trunk/components/camel-spring/src/main/java/org/apache/camel/component/event/EventEndpoint.java
    activemq/camel/trunk/components/camel-spring/src/main/java/org/apache/camel/spring/CamelContextFactoryBean.java
    activemq/camel/trunk/components/camel-spring/src/main/java/org/apache/camel/spring/SpringCamelContext.java
    activemq/camel/trunk/components/camel-spring/src/main/java/org/apache/camel/spring/spi/TransactionInterceptor.java
    activemq/camel/trunk/components/camel-spring/src/test/java/org/apache/camel/spring/dataformat/SpringDataFormatWithNonChildElementTest.java

Modified: activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/impl/ProducerCache.java
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/impl/ProducerCache.java?rev=695721&r1=695720&r2=695721&view=diff
==============================================================================
--- activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/impl/ProducerCache.java (original)
+++ activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/impl/ProducerCache.java Mon Sep 15 20:51:58 2008
@@ -27,11 +27,13 @@
 import org.apache.camel.Processor;
 import org.apache.camel.Producer;
 import org.apache.camel.impl.converter.AsyncProcessorTypeConverter;
-import static org.apache.camel.util.ObjectHelper.wrapRuntimeCamelException;
 import org.apache.camel.util.ServiceHelper;
 import org.apache.commons.logging.Log;
 import org.apache.commons.logging.LogFactory;
 
+import static org.apache.camel.util.ObjectHelper.wrapRuntimeCamelException;
+
+
 /**
  * Cache containing created {@link Producer}.
  *

Modified: activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/impl/converter/DefaultTypeConverter.java
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/impl/converter/DefaultTypeConverter.java?rev=695721&r1=695720&r2=695721&view=diff
==============================================================================
--- activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/impl/converter/DefaultTypeConverter.java (original)
+++ activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/impl/converter/DefaultTypeConverter.java Mon Sep 15 20:51:58 2008
@@ -30,10 +30,12 @@
 import org.apache.camel.util.FactoryFinder;
 import org.apache.camel.util.NoFactoryAvailableException;
 import org.apache.camel.util.ObjectHelper;
-import static org.apache.camel.util.ObjectHelper.wrapRuntimeCamelException;
 import org.apache.commons.logging.Log;
 import org.apache.commons.logging.LogFactory;
 
+import static org.apache.camel.util.ObjectHelper.wrapRuntimeCamelException;
+
+
 /**
  * Default implementation of a type converter registry used for
  * <a href="http://activemq.apache.org/camel/type-converter.html">type converters</a> in Camel.
@@ -106,7 +108,7 @@
 
         boolean camelType = type.getCanonicalName().startsWith("org.apache.camel");
         if (!camelType && value != null) {
-            // only log WARN level for non internal Camel convertions 
+            // only log WARN level for non internal Camel convertions
             LOG.warn("Could not find a type converter for converting "
                 + value.getClass().getCanonicalName() + " -> "
                 + type.getCanonicalName() + " with value: " + value);

Modified: activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/model/dataformat/DataFormatsType.java
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/model/dataformat/DataFormatsType.java?rev=695721&r1=695720&r2=695721&view=diff
==============================================================================
--- activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/model/dataformat/DataFormatsType.java (original)
+++ activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/model/dataformat/DataFormatsType.java Mon Sep 15 20:51:58 2008
@@ -1,3 +1,19 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *      http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
 package org.apache.camel.model.dataformat;
 
 import java.util.ArrayList;
@@ -21,7 +37,7 @@
 public class DataFormatsType {
 
     // TODO cannot use @XmlElementRef as it doesn't allow optional properties
-    // @XmlElementRef    
+    // @XmlElementRef
     @XmlElements({
         @XmlElement(required = false, name = "artixDS", type = ArtixDSDataFormat.class),
         @XmlElement(required = false, name = "csv", type = CsvDataFormat.class),
@@ -35,7 +51,7 @@
         )
     private List<DataFormatType> dataFormats;
 
-    
+
     public void setDataFormats(List<DataFormatType> dataFormats) {
         this.dataFormats = dataFormats;
     }
@@ -53,5 +69,5 @@
             dataFormatsAsMap.put(dataFormatType.getId(), dataFormatType);
         }
         return dataFormatsAsMap;
-    }     
+    }
 }

Modified: activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/processor/TryProcessor.java
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/processor/TryProcessor.java?rev=695721&r1=695720&r2=695721&view=diff
==============================================================================
--- activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/processor/TryProcessor.java (original)
+++ activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/processor/TryProcessor.java Mon Sep 15 20:51:58 2008
@@ -23,10 +23,11 @@
 import org.apache.camel.impl.ServiceSupport;
 import org.apache.camel.util.ExchangeHelper;
 import org.apache.camel.util.ServiceHelper;
-import static org.apache.camel.util.ObjectHelper.wrapRuntimeCamelException;
 import org.apache.commons.logging.Log;
 import org.apache.commons.logging.LogFactory;
 
+import static org.apache.camel.util.ObjectHelper.wrapRuntimeCamelException;
+
 /**
  * Implements try/catch/finally type processing
  *

Modified: activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/util/concurrent/CountingLatch.java
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/util/concurrent/CountingLatch.java?rev=695721&r1=695720&r2=695721&view=diff
==============================================================================
--- activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/util/concurrent/CountingLatch.java (original)
+++ activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/util/concurrent/CountingLatch.java Mon Sep 15 20:51:58 2008
@@ -25,35 +25,36 @@
  * the latch count while counting down.  It can also be used to count up to 0 from a negative integer.
  */
 public class CountingLatch {
-    
+
     @SuppressWarnings("serial")
     private final class Sync extends AbstractQueuedSynchronizer {
-        
+
         private Sync() {
             super();
         }
-        
+
         int getCount() {
             return getState();
         }
 
         public int tryAcquireShared(int acquires) {
-            return getState() == 0? 1 : -1;
+            return getState() == 0 ? 1 : -1;
         }
-        
+
         public boolean tryReleaseShared(int delta) {
             // Decrement count; signal when transition to zero
             for (;;) {
                 int c = getState();
                 int nextc = c + delta;
-                if (compareAndSetState(c, nextc))
+                if (compareAndSetState(c, nextc)) {
                     return nextc == 0;
+                }
             }
         }
     }
-    
+
     private final Sync sync;
-    
+
     /**
      * Create a new counting latch (starting count is 0)
      */
@@ -68,14 +69,14 @@
     public int getCount() {
         return sync.getCount();
     }
-    
+
     /**
      * Increment the count with 1
      */
     public void increment() {
         sync.releaseShared(+1);
     }
-    
+
     /**
      * Decrement the count with 1
      */
@@ -85,7 +86,7 @@
 
     /**
      * Await the latch reaching the count of 0
-     * 
+     *
      * @throws InterruptedException if the threads gets interrupted while waiting
      */
     public void await() throws InterruptedException {
@@ -93,8 +94,8 @@
     }
 
     /**
-     * Wait for a given timeout while checking if the latch reached the count of 0  
-     * 
+     * Wait for a given timeout while checking if the latch reached the count of 0
+     *
      * @param timeout the value of the timeout
      * @param unit the unit in which the timeout is expressed
      * @return <code>true</code> if the latch has reached the count of 0 in the given time

Modified: activemq/camel/trunk/components/camel-bam/src/main/java/org/apache/camel/bam/processor/BamProcessorSupport.java
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/components/camel-bam/src/main/java/org/apache/camel/bam/processor/BamProcessorSupport.java?rev=695721&r1=695720&r2=695721&view=diff
==============================================================================
--- activemq/camel/trunk/components/camel-bam/src/main/java/org/apache/camel/bam/processor/BamProcessorSupport.java (original)
+++ activemq/camel/trunk/components/camel-bam/src/main/java/org/apache/camel/bam/processor/BamProcessorSupport.java Mon Sep 15 20:51:58 2008
@@ -23,13 +23,14 @@
 import org.apache.camel.Expression;
 import org.apache.camel.Processor;
 import org.apache.camel.util.ExchangeHelper;
-import static org.apache.camel.util.ObjectHelper.wrapRuntimeCamelException;
 import org.apache.commons.logging.Log;
 import org.apache.commons.logging.LogFactory;
 import org.springframework.transaction.TransactionStatus;
 import org.springframework.transaction.support.TransactionCallback;
 import org.springframework.transaction.support.TransactionTemplate;
 
+import static org.apache.camel.util.ObjectHelper.wrapRuntimeCamelException;
+
 /**
  * A base {@link Processor} for working on <a
  * href="http://activemq.apache.org/camel/bam.html">BAM</a> which a derived

Modified: activemq/camel/trunk/components/camel-ftp/src/test/java/org/apache/camel/component/file/remote/FromFtpNonExclusiveReadTest.java
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/components/camel-ftp/src/test/java/org/apache/camel/component/file/remote/FromFtpNonExclusiveReadTest.java?rev=695721&r1=695720&r2=695721&view=diff
==============================================================================
--- activemq/camel/trunk/components/camel-ftp/src/test/java/org/apache/camel/component/file/remote/FromFtpNonExclusiveReadTest.java (original)
+++ activemq/camel/trunk/components/camel-ftp/src/test/java/org/apache/camel/component/file/remote/FromFtpNonExclusiveReadTest.java Mon Sep 15 20:51:58 2008
@@ -32,8 +32,8 @@
     private static final Log LOG = LogFactory.getLog(FromFtpExclusiveReadTest.class);
 
     private int port = 20027;
-    private String ftpUrl = "ftp://admin@localhost:" + port + "/slowfile?password=admin" +
-            "&consumer.exclusiveReadLock=false&consumer.delay=500&consumer.timestamp=true";
+    private String ftpUrl = "ftp://admin@localhost:" + port + "/slowfile?password=admin"
+            + "&consumer.exclusiveReadLock=false&consumer.delay=500&consumer.timestamp=true";
 
     public int getPort() {
         return port;

Modified: activemq/camel/trunk/components/camel-jms/src/main/java/org/apache/camel/component/jms/EndpointMessageListener.java
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/components/camel-jms/src/main/java/org/apache/camel/component/jms/EndpointMessageListener.java?rev=695721&r1=695720&r2=695721&view=diff
==============================================================================
--- activemq/camel/trunk/components/camel-jms/src/main/java/org/apache/camel/component/jms/EndpointMessageListener.java (original)
+++ activemq/camel/trunk/components/camel-jms/src/main/java/org/apache/camel/component/jms/EndpointMessageListener.java Mon Sep 15 20:51:58 2008
@@ -25,18 +25,19 @@
 import org.apache.camel.ExchangePattern;
 import org.apache.camel.Processor;
 import org.apache.camel.RuntimeCamelException;
-import static org.apache.camel.util.ObjectHelper.wrapRuntimeCamelException;
 import org.apache.commons.logging.Log;
 import org.apache.commons.logging.LogFactory;
 import org.springframework.jms.core.JmsOperations;
 import org.springframework.jms.core.MessageCreator;
 
+import static org.apache.camel.util.ObjectHelper.wrapRuntimeCamelException;
+
 /**
  * A JMS {@link MessageListener} which can be used to delegate processing to a
  * Camel endpoint.
  *
  * Note that instance of this object has to be thread safe (reentrant)
- * 
+ *
  * @version $Revision$
  */
 public class EndpointMessageListener implements MessageListener {

Modified: activemq/camel/trunk/components/camel-spring/src/main/java/org/apache/camel/component/event/EventEndpoint.java
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/components/camel-spring/src/main/java/org/apache/camel/component/event/EventEndpoint.java?rev=695721&r1=695720&r2=695721&view=diff
==============================================================================
--- activemq/camel/trunk/components/camel-spring/src/main/java/org/apache/camel/component/event/EventEndpoint.java (original)
+++ activemq/camel/trunk/components/camel-spring/src/main/java/org/apache/camel/component/event/EventEndpoint.java Mon Sep 15 20:51:58 2008
@@ -23,12 +23,12 @@
 import org.apache.camel.impl.DefaultProducer;
 import org.apache.camel.processor.loadbalancer.LoadBalancer;
 import org.apache.camel.processor.loadbalancer.TopicLoadBalancer;
-import static org.apache.camel.util.ObjectHelper.wrapRuntimeCamelException;
 import org.springframework.beans.BeansException;
 import org.springframework.context.ApplicationContext;
 import org.springframework.context.ApplicationContextAware;
 import org.springframework.context.ApplicationEvent;
 
+import static org.apache.camel.util.ObjectHelper.wrapRuntimeCamelException;
 /**
  * An <a href="http://activemq.apache.org/camel/event.html">Event Endpoint</a>
  * for working with Spring ApplicationEvents

Modified: activemq/camel/trunk/components/camel-spring/src/main/java/org/apache/camel/spring/CamelContextFactoryBean.java
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/components/camel-spring/src/main/java/org/apache/camel/spring/CamelContextFactoryBean.java?rev=695721&r1=695720&r2=695721&view=diff
==============================================================================
--- activemq/camel/trunk/components/camel-spring/src/main/java/org/apache/camel/spring/CamelContextFactoryBean.java (original)
+++ activemq/camel/trunk/components/camel-spring/src/main/java/org/apache/camel/spring/CamelContextFactoryBean.java Mon Sep 15 20:51:58 2008
@@ -17,7 +17,6 @@
 package org.apache.camel.spring;
 
 import java.util.ArrayList;
-import java.util.HashMap;
 import java.util.List;
 import java.util.Map;
 
@@ -25,7 +24,6 @@
 import javax.xml.bind.annotation.XmlAccessorType;
 import javax.xml.bind.annotation.XmlAttribute;
 import javax.xml.bind.annotation.XmlElement;
-import javax.xml.bind.annotation.XmlElementRef;
 import javax.xml.bind.annotation.XmlElements;
 import javax.xml.bind.annotation.XmlRootElement;
 import javax.xml.bind.annotation.XmlTransient;
@@ -44,28 +42,26 @@
 import org.apache.camel.model.RouteContainer;
 import org.apache.camel.model.RouteType;
 import org.apache.camel.model.dataformat.DataFormatsType;
-import org.apache.camel.model.dataformat.DataFormatType;
 import org.apache.camel.processor.interceptor.Debugger;
 import org.apache.camel.processor.interceptor.TraceFormatter;
 import org.apache.camel.processor.interceptor.Tracer;
-import org.apache.camel.spi.DataFormat;
 import org.apache.camel.spi.LifecycleStrategy;
 import org.apache.camel.spi.Registry;
-import static org.apache.camel.util.ObjectHelper.wrapRuntimeCamelException;
 import org.apache.commons.logging.Log;
 import org.apache.commons.logging.LogFactory;
 import org.springframework.beans.factory.DisposableBean;
 import org.springframework.beans.factory.FactoryBean;
 import org.springframework.beans.factory.InitializingBean;
-import org.springframework.beans.factory.config.BeanDefinition;
 import org.springframework.beans.factory.config.BeanPostProcessor;
-import org.springframework.beans.factory.support.RootBeanDefinition;
 import org.springframework.context.ApplicationContext;
 import org.springframework.context.ApplicationContextAware;
 import org.springframework.context.ApplicationEvent;
 import org.springframework.context.ApplicationListener;
 import org.springframework.context.event.ContextRefreshedEvent;
 
+import static org.apache.camel.util.ObjectHelper.wrapRuntimeCamelException;
+
+
 /**
  * A Spring {@link FactoryBean} to create and initialize a
  * {@link SpringCamelContext} and install routes either explicitly configured in
@@ -174,8 +170,8 @@
             if (beanPostProcessor instanceof CamelBeanPostProcessor) {
                 ((CamelBeanPostProcessor)beanPostProcessor).setCamelContext(getContext());
             }
-        }       
-        
+        }
+
         // setup the intercepts
         for (RouteType route : routes) {
 
@@ -205,17 +201,17 @@
                 if (outputsSize > 0) {
                     ProcessorType<?> processorType = proxy.getOutputs().get(outputsSize - 1);
                     if (processorType instanceof ProceedType) {
-                        route.getOutputs().addAll(outputs);                        
+                        route.getOutputs().addAll(outputs);
                     }
-                }                
+                }
             }
 
-        }        
-        
+        }
+
         if (dataFormats != null) {
             getContext().setDataFormats(dataFormats.asMap());
         }
-        
+
         // lets force any lazy creation
         getContext().addRouteDefinitions(routes);
 

Modified: activemq/camel/trunk/components/camel-spring/src/main/java/org/apache/camel/spring/SpringCamelContext.java
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/components/camel-spring/src/main/java/org/apache/camel/spring/SpringCamelContext.java?rev=695721&r1=695720&r2=695721&view=diff
==============================================================================
--- activemq/camel/trunk/components/camel-spring/src/main/java/org/apache/camel/spring/SpringCamelContext.java (original)
+++ activemq/camel/trunk/components/camel-spring/src/main/java/org/apache/camel/spring/SpringCamelContext.java Mon Sep 15 20:51:58 2008
@@ -28,7 +28,6 @@
 import org.apache.camel.spring.spi.ApplicationContextRegistry;
 import org.apache.camel.spring.spi.SpringInjector;
 import org.apache.camel.util.ObjectHelper;
-import static org.apache.camel.util.ObjectHelper.wrapRuntimeCamelException;
 import org.apache.commons.logging.Log;
 import org.apache.commons.logging.LogFactory;
 import org.springframework.beans.BeansException;
@@ -42,6 +41,8 @@
 import org.springframework.context.event.ContextRefreshedEvent;
 import org.springframework.context.support.ClassPathXmlApplicationContext;
 
+import static org.apache.camel.util.ObjectHelper.wrapRuntimeCamelException;
+
 /**
  * A Spring aware implementation of {@link org.apache.camel.CamelContext} which
  * will automatically register itself with Springs lifecycle methods plus allows
@@ -57,8 +58,8 @@
     private static final transient Log LOG = LogFactory.getLog(SpringCamelContext.class);
     private ApplicationContext applicationContext;
     private EventEndpoint eventEndpoint;
-    private boolean shouldStartContext = 
-        ObjectHelper.getSystemProperty("shouldStartContext", Boolean.TRUE); // start context by default 
+    private boolean shouldStartContext =
+        ObjectHelper.getSystemProperty("shouldStartContext", Boolean.TRUE); // start context by default
 
     public SpringCamelContext() {
     }
@@ -79,7 +80,7 @@
         answer.afterPropertiesSet();
         return answer;
     }
-        
+
 
     public static SpringCamelContext springCamelContext(String configLocations) throws Exception {
         return springCamelContext(new ClassPathXmlApplicationContext(configLocations));
@@ -90,7 +91,7 @@
     }
 
     private void maybeStart() throws Exception {
-        if (getShouldStartContext()) {     
+        if (getShouldStartContext()) {
             LOG.debug("Starting the CamelContext now that the ApplicationContext has started");
             start();
         } else {
@@ -167,8 +168,8 @@
                 eventEndpoint = createEventEndpoint();
             }
         }
-    }   
-    
+    }
+
     @Override
     protected Injector createInjector() {
         if (applicationContext instanceof ConfigurableApplicationContext) {

Modified: activemq/camel/trunk/components/camel-spring/src/main/java/org/apache/camel/spring/spi/TransactionInterceptor.java
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/components/camel-spring/src/main/java/org/apache/camel/spring/spi/TransactionInterceptor.java?rev=695721&r1=695720&r2=695721&view=diff
==============================================================================
--- activemq/camel/trunk/components/camel-spring/src/main/java/org/apache/camel/spring/spi/TransactionInterceptor.java (original)
+++ activemq/camel/trunk/components/camel-spring/src/main/java/org/apache/camel/spring/spi/TransactionInterceptor.java Mon Sep 15 20:51:58 2008
@@ -23,7 +23,6 @@
 import org.apache.camel.processor.DelayPolicy;
 import org.apache.camel.processor.DelegateProcessor;
 import org.apache.camel.processor.RedeliveryPolicy;
-import static org.apache.camel.util.ObjectHelper.wrapRuntimeCamelException;
 import org.apache.commons.logging.Log;
 import org.apache.commons.logging.LogFactory;
 import org.springframework.transaction.TransactionDefinition;
@@ -33,6 +32,8 @@
 import org.springframework.transaction.support.TransactionSynchronizationManager;
 import org.springframework.transaction.support.TransactionTemplate;
 
+import static org.apache.camel.util.ObjectHelper.wrapRuntimeCamelException;
+
 /**
  * The <a href="http://activemq.apache.org/camel/transactional-client.html">Transactional Client</a>
  * EIP pattern.

Modified: activemq/camel/trunk/components/camel-spring/src/test/java/org/apache/camel/spring/dataformat/SpringDataFormatWithNonChildElementTest.java
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/components/camel-spring/src/test/java/org/apache/camel/spring/dataformat/SpringDataFormatWithNonChildElementTest.java?rev=695721&r1=695720&r2=695721&view=diff
==============================================================================
--- activemq/camel/trunk/components/camel-spring/src/test/java/org/apache/camel/spring/dataformat/SpringDataFormatWithNonChildElementTest.java (original)
+++ activemq/camel/trunk/components/camel-spring/src/test/java/org/apache/camel/spring/dataformat/SpringDataFormatWithNonChildElementTest.java Mon Sep 15 20:51:58 2008
@@ -1,3 +1,19 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *      http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
 package org.apache.camel.spring.dataformat;
 
 import org.springframework.context.support.AbstractXmlApplicationContext;
@@ -10,5 +26,5 @@
 
     protected AbstractXmlApplicationContext createApplicationContext() {
         return new ClassPathXmlApplicationContext("org/apache/camel/spring/dataformat/dataFormatWithNonChildElementTest.xml");
-    }    
+    }
 }