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/04/14 18:38:43 UTC

svn commit: r647890 [1/3] - in /activemq/camel/trunk/camel-core/src: main/java/org/apache/camel/component/dataset/ main/java/org/apache/camel/component/file/strategy/ main/java/org/apache/camel/component/log/ main/java/org/apache/camel/converter/stream...

Author: ningjiang
Date: Mon Apr 14 09:38:25 2008
New Revision: 647890

URL: http://svn.apache.org/viewvc?rev=647890&view=rev
Log:
Fixed the svn property issues of the camel-core

Modified:
    activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/component/dataset/DataSet.java   (contents, props changed)
    activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/component/dataset/DataSetConsumer.java   (contents, props changed)
    activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/component/dataset/DataSetEndpoint.java   (contents, props changed)
    activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/component/dataset/DataSetSupport.java   (contents, props changed)
    activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/component/dataset/SimpleDataSet.java   (contents, props changed)
    activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/component/dataset/package.html   (props changed)
    activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/component/file/strategy/package.html   (contents, props changed)
    activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/component/log/package.html   (contents, props changed)
    activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/converter/stream/StreamCache.java   (props changed)
    activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/converter/stream/StreamCacheConverter.java   (props changed)
    activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/converter/stream/package.html   (props changed)
    activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/language/bean/package.html   (contents, props changed)
    activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/language/package.html   (contents, props changed)
    activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/language/simple/package.html   (contents, props changed)
    activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/management/package.html   (contents, props changed)
    activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/model/ConvertBodyType.java   (contents, props changed)
    activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/model/RoutingSlipType.java   (props changed)
    activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/model/SetHeaderType.java   (contents, props changed)
    activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/processor/ConvertBodyProcessor.java   (contents, props changed)
    activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/processor/RoutingSlip.java   (props changed)
    activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/processor/SetHeaderProcessor.java   (contents, props changed)
    activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/processor/ThroughputLogger.java   (contents, props changed)
    activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/processor/exceptionpolicy/DefaultExceptionPolicyStrategy.java   (contents, props changed)
    activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/processor/exceptionpolicy/ExceptionPolicyStrategy.java   (contents, props changed)
    activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/processor/exceptionpolicy/package.html   (contents, props changed)
    activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/processor/interceptor/StreamCachingInterceptor.java   (props changed)
    activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/processor/interceptor/package.html   (contents, props changed)
    activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/processor/resequencer/package.html   (contents, props changed)
    activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/builder/ExceptionBuilderTest.java   (contents, props changed)
    activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/component/dataset/CustomDataSetTest.java   (contents, props changed)
    activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/component/dataset/DataSetConsumeTest.java   (contents, props changed)
    activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/component/dataset/DataSetTest.java   (contents, props changed)
    activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/component/file/FileFilterOnNameRouteTest.java   (props changed)
    activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/component/file/ToFileRouteTest.java   (contents, props changed)
    activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/converter/IOConverterTest.java   (props changed)
    activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/converter/stream/StreamCacheConverterTest.java   (props changed)
    activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/impl/StringDataFormatTest.java   (contents, props changed)
    activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/issues/InterceptorLogTest.java   (contents, props changed)
    activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/processor/ConvertBodyTest.java   (contents, props changed)
    activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/processor/ErrorHandlerSupportTest.java   (contents, props changed)
    activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/processor/ExpressionAdapter.java   (contents, props changed)
    activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/processor/InterceptorSimpleRouteTest.java   (contents, props changed)
    activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/processor/MulticastStreamCachingTest.java   (contents, props changed)
    activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/processor/StaticRecipientListTest.java   (props changed)
    activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/processor/ValidationWithErrorInHandleAndFinallyBlockTest.java   (props changed)
    activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/processor/ValidationWithFinallyBlockPipelineTest.java   (props changed)
    activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/processor/ValidationWithHandlePipelineAndExceptionTest.java   (props changed)
    activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/processor/ValidationWithInFlowExceptionTest.java   (contents, props changed)
    activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/processor/ValidationWithMultipleHandlesTest.java   (props changed)
    activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/processor/ValidationWithNestedFinallyBlockPipelineTest.java   (props changed)
    activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/processor/exceptionpolicy/CustomExceptionPolicyStrategyTest.java   (contents, props changed)
    activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/processor/exceptionpolicy/DefaultExceptionPolicyStrategyTest.java   (contents, props changed)
    activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/processor/interceptor/StreamCachingInterceptorTest.java   (props changed)
    activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/processor/routingslip/RoutingSlipDataModificationTest.java   (props changed)
    activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/processor/routingslip/RoutingSlipTest.java   (props changed)
    activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/processor/routingslip/RoutingSlipWithExceptionTest.java   (props changed)
    activemq/camel/trunk/camel-core/src/test/resources/org/apache/camel/converter/stream/test.xml   (props changed)
    activemq/camel/trunk/camel-core/src/test/resources/org/apache/camel/model/convertBody.xml   (contents, props changed)
    activemq/camel/trunk/camel-core/src/test/resources/org/apache/camel/model/routingSlip.xml   (props changed)
    activemq/camel/trunk/camel-core/src/test/resources/org/apache/camel/model/routingSlipHeaderAndDelimiterSet.xml   (props changed)
    activemq/camel/trunk/camel-core/src/test/resources/org/apache/camel/model/routingSlipHeaderSet.xml   (props changed)
    activemq/camel/trunk/camel-core/src/test/resources/org/apache/camel/model/setHeader.xml   (contents, props changed)
    activemq/camel/trunk/camel-core/src/test/resources/org/apache/camel/model/setHeaderToConstant.xml   (contents, props changed)
    activemq/camel/trunk/camel-core/src/test/resources/org/apache/camel/model/setHeaderWithChildProcessor.xml   (contents, props changed)

Modified: activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/component/dataset/DataSet.java
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/component/dataset/DataSet.java?rev=647890&r1=647889&r2=647890&view=diff
==============================================================================
--- activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/component/dataset/DataSet.java (original)
+++ activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/component/dataset/DataSet.java Mon Apr 14 09:38:25 2008
@@ -21,7 +21,7 @@
 /**
  * Represents a strategy for testing endpoints with canned data.
  *
- * @version $Revision: 1.1 $
+ * @version $Revision$
  */
 public interface DataSet {
     String INDEX_HEADER = "camelDataSetIndex";

Propchange: activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/component/dataset/DataSet.java
------------------------------------------------------------------------------
    svn:keywords = Rev Date

Modified: activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/component/dataset/DataSetConsumer.java
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/component/dataset/DataSetConsumer.java?rev=647890&r1=647889&r2=647890&view=diff
==============================================================================
--- activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/component/dataset/DataSetConsumer.java (original)
+++ activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/component/dataset/DataSetConsumer.java Mon Apr 14 09:38:25 2008
@@ -24,7 +24,7 @@
 import org.apache.commons.logging.LogFactory;
 
 /**
- * @version $Revision: 1.1 $
+ * @version $Revision$
  */
 public class DataSetConsumer extends DefaultConsumer<Exchange> {
     private static final transient Log LOG = LogFactory.getLog(DataSetConsumer.class);

Propchange: activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/component/dataset/DataSetConsumer.java
------------------------------------------------------------------------------
    svn:keywords = Rev Date

Modified: activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/component/dataset/DataSetEndpoint.java
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/component/dataset/DataSetEndpoint.java?rev=647890&r1=647889&r2=647890&view=diff
==============================================================================
--- activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/component/dataset/DataSetEndpoint.java (original)
+++ activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/component/dataset/DataSetEndpoint.java Mon Apr 14 09:38:25 2008
@@ -33,7 +33,7 @@
 import org.apache.commons.logging.LogFactory;
 
 /**
- * @version $Revision: 1.1 $
+ * @version $Revision$
  */
 public class DataSetEndpoint extends MockEndpoint implements Service {
     private static final transient Log LOG = LogFactory.getLog(DataSetEndpoint.class);

Propchange: activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/component/dataset/DataSetEndpoint.java
------------------------------------------------------------------------------
    svn:keywords = Rev Date

Modified: activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/component/dataset/DataSetSupport.java
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/component/dataset/DataSetSupport.java?rev=647890&r1=647889&r2=647890&view=diff
==============================================================================
--- activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/component/dataset/DataSetSupport.java (original)
+++ activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/component/dataset/DataSetSupport.java Mon Apr 14 09:38:25 2008
@@ -25,7 +25,7 @@
 import org.apache.camel.util.ExchangeHelper;
 
 /**
- * @version $Revision: 1.1 $
+ * @version $Revision$
  */
 public abstract class DataSetSupport implements DataSet {
     private Map<String, Object> defaultHeaders;

Propchange: activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/component/dataset/DataSetSupport.java
------------------------------------------------------------------------------
    svn:keywords = Rev Date

Modified: activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/component/dataset/SimpleDataSet.java
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/component/dataset/SimpleDataSet.java?rev=647890&r1=647889&r2=647890&view=diff
==============================================================================
--- activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/component/dataset/SimpleDataSet.java (original)
+++ activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/component/dataset/SimpleDataSet.java Mon Apr 14 09:38:25 2008
@@ -22,7 +22,7 @@
  * A simple DataSet that allows a static payload to be used to create each message exchange
  * along with using a pluggable transformer to randomize the message.
  *
- * @version $Revision: 1.1 $
+ * @version $Revision$
  */
 public class SimpleDataSet extends DataSetSupport {
     private Object defaultBody = "<hello>world!</hello>";

Propchange: activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/component/dataset/SimpleDataSet.java
------------------------------------------------------------------------------
    svn:keywords = Rev Date

Propchange: activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/component/dataset/package.html
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/component/dataset/package.html
------------------------------------------------------------------------------
    svn:keywords = Rev Date

Modified: activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/component/file/strategy/package.html
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/component/file/strategy/package.html?rev=647890&r1=647889&r2=647890&view=diff
==============================================================================
--- activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/component/file/strategy/package.html (original)
+++ activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/component/file/strategy/package.html Mon Apr 14 09:38:25 2008
@@ -1,25 +1,25 @@
-<!--
-    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.
--->
-<html>
-<head>
-</head>
-<body>
-
-Strategies for the File Component.
-
-</body>
-</html>
+<!--
+    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.
+-->
+<html>
+<head>
+</head>
+<body>
+
+Strategies for the File Component.
+
+</body>
+</html>

Propchange: activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/component/file/strategy/package.html
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/component/file/strategy/package.html
------------------------------------------------------------------------------
    svn:keywords = Rev Date

Propchange: activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/component/file/strategy/package.html
------------------------------------------------------------------------------
    svn:mime-type = text/html

Modified: activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/component/log/package.html
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/component/log/package.html?rev=647890&r1=647889&r2=647890&view=diff
==============================================================================
--- activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/component/log/package.html (original)
+++ activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/component/log/package.html Mon Apr 14 09:38:25 2008
@@ -1,26 +1,26 @@
-<!--
-    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.
--->
-<html>
-<head>
-</head>
-<body>
-
-The <a href="http://activemq.apache.org/camel/log.html">Log Component</a> uses Jakarta Commons Logging to log message exchanges.
-
-
-</body>
-</html>
+<!--
+    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.
+-->
+<html>
+<head>
+</head>
+<body>
+
+The <a href="http://activemq.apache.org/camel/log.html">Log Component</a> uses Jakarta Commons Logging to log message exchanges.
+
+
+</body>
+</html>

Propchange: activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/component/log/package.html
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/component/log/package.html
------------------------------------------------------------------------------
    svn:keywords = Rev Date

Propchange: activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/component/log/package.html
------------------------------------------------------------------------------
    svn:mime-type = text/html

Propchange: activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/converter/stream/StreamCache.java
------------------------------------------------------------------------------
    svn:keywords = Rev Date

Propchange: activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/converter/stream/StreamCacheConverter.java
------------------------------------------------------------------------------
    svn:keywords = Rev Date

Propchange: activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/converter/stream/package.html
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/converter/stream/package.html
------------------------------------------------------------------------------
    svn:keywords = Rev Date

Modified: activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/language/bean/package.html
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/language/bean/package.html?rev=647890&r1=647889&r2=647890&view=diff
==============================================================================
--- activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/language/bean/package.html (original)
+++ activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/language/bean/package.html Mon Apr 14 09:38:25 2008
@@ -1,25 +1,25 @@
-<!--
-    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.
--->
-<html>
-<head>
-</head>
-<body>
-
-Camel <a href="http://activemq.apache.org/camel/bean-language.html">Bean</a> language.
-
-</body>
-</html>
+<!--
+    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.
+-->
+<html>
+<head>
+</head>
+<body>
+
+Camel <a href="http://activemq.apache.org/camel/bean-language.html">Bean</a> language.
+
+</body>
+</html>

Propchange: activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/language/bean/package.html
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/language/bean/package.html
------------------------------------------------------------------------------
    svn:keywords = Rev Date

Propchange: activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/language/bean/package.html
------------------------------------------------------------------------------
    svn:mime-type = text/html

Modified: activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/language/package.html
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/language/package.html?rev=647890&r1=647889&r2=647890&view=diff
==============================================================================
--- activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/language/package.html (original)
+++ activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/language/package.html Mon Apr 14 09:38:25 2008
@@ -1,26 +1,26 @@
-<!--
-    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.
--->
-<html>
-<head>
-</head>
-<body>
-
-Camel language support such as <a href="http://activemq.apache.org/camel/bean-language.html">Bean</a>
-and <a href="http://activemq.apache.org/camel/simple.html">Simple</a> language.
-
-</body>
-</html>
+<!--
+    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.
+-->
+<html>
+<head>
+</head>
+<body>
+
+Camel language support such as <a href="http://activemq.apache.org/camel/bean-language.html">Bean</a>
+and <a href="http://activemq.apache.org/camel/simple.html">Simple</a> language.
+
+</body>
+</html>

Propchange: activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/language/package.html
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/language/package.html
------------------------------------------------------------------------------
    svn:keywords = Rev Date

Propchange: activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/language/package.html
------------------------------------------------------------------------------
    svn:mime-type = text/html

Modified: activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/language/simple/package.html
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/language/simple/package.html?rev=647890&r1=647889&r2=647890&view=diff
==============================================================================
--- activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/language/simple/package.html (original)
+++ activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/language/simple/package.html Mon Apr 14 09:38:25 2008
@@ -1,25 +1,25 @@
-<!--
-    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.
--->
-<html>
-<head>
-</head>
-<body>
-
-Camel <a href="http://activemq.apache.org/camel/simple.html">Simple</a> language.
-
-</body>
-</html>
+<!--
+    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.
+-->
+<html>
+<head>
+</head>
+<body>
+
+Camel <a href="http://activemq.apache.org/camel/simple.html">Simple</a> language.
+
+</body>
+</html>

Propchange: activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/language/simple/package.html
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/language/simple/package.html
------------------------------------------------------------------------------
    svn:keywords = Rev Date

Propchange: activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/language/simple/package.html
------------------------------------------------------------------------------
    svn:mime-type = text/html

Modified: activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/management/package.html
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/management/package.html?rev=647890&r1=647889&r2=647890&view=diff
==============================================================================
--- activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/management/package.html (original)
+++ activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/management/package.html Mon Apr 14 09:38:25 2008
@@ -1,25 +1,25 @@
-<!--
-    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.
--->
-<html>
-<head>
-</head>
-<body>
-
-Camel JMX export services.
-
-</body>
-</html>
+<!--
+    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.
+-->
+<html>
+<head>
+</head>
+<body>
+
+Camel JMX export services.
+
+</body>
+</html>

Propchange: activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/management/package.html
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/management/package.html
------------------------------------------------------------------------------
    svn:keywords = Rev Date

Propchange: activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/management/package.html
------------------------------------------------------------------------------
    svn:mime-type = text/html

Modified: activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/model/ConvertBodyType.java
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/model/ConvertBodyType.java?rev=647890&r1=647889&r2=647890&view=diff
==============================================================================
--- activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/model/ConvertBodyType.java (original)
+++ activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/model/ConvertBodyType.java Mon Apr 14 09:38:25 2008
@@ -1,91 +1,91 @@
-/**
- * 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;
-
-import java.util.ArrayList;
-import java.util.Collection;
-import java.util.Collections;
-import java.util.List;
-
-import javax.xml.bind.annotation.XmlAccessType;
-import javax.xml.bind.annotation.XmlAccessorType;
-import javax.xml.bind.annotation.XmlAttribute;
-import javax.xml.bind.annotation.XmlRootElement;
-import javax.xml.bind.annotation.XmlTransient;
-
-import org.apache.camel.Processor;
-import org.apache.camel.impl.RouteContext;
-import org.apache.camel.processor.ConvertBodyProcessor;
-import org.apache.camel.util.ObjectHelper;
-
-@XmlRootElement(name = "convertBodyTo")
-@XmlAccessorType(XmlAccessType.FIELD)
-public class ConvertBodyType extends ProcessorType<ProcessorType> {
-    @XmlAttribute
-    private String type;
-    @XmlTransient
-    private Class typeClass;
-
-    public ConvertBodyType() {
-    }
-
-    public ConvertBodyType(String type) {
-        setType(type);
-    }
-
-    public ConvertBodyType(Class typeClass) {
-        setTypeClass(typeClass);
-    }
-
-    @Override
-    public String toString() {
-        return "convertBodyTo[ " + getType() + "]";
-    }
-
-    @Override
-    public Processor createProcessor(RouteContext routeContext) throws Exception {
-        return new ConvertBodyProcessor(getTypeClass());
-    }
-
-    @Override
-    public List<ProcessorType<?>> getOutputs() {
-        return Collections.EMPTY_LIST;
-    }    
-    
-    protected Class createTypeClass() {
-        return ObjectHelper.loadClass(getType(), getClass().getClassLoader());
-    }
-
-    public void setType(String type) {
-        this.type = type;
-    }
-
-    public String getType() {
-        return type;
-    }
-
-    public void setTypeClass(Class typeClass) {
-        this.typeClass = typeClass;
-    }
-
-    public Class getTypeClass() {
-        if (typeClass == null) {
-            setTypeClass(createTypeClass());
-        }
-        return typeClass;
-    }
-}
+/**
+ * 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;
+
+import java.util.ArrayList;
+import java.util.Collection;
+import java.util.Collections;
+import java.util.List;
+
+import javax.xml.bind.annotation.XmlAccessType;
+import javax.xml.bind.annotation.XmlAccessorType;
+import javax.xml.bind.annotation.XmlAttribute;
+import javax.xml.bind.annotation.XmlRootElement;
+import javax.xml.bind.annotation.XmlTransient;
+
+import org.apache.camel.Processor;
+import org.apache.camel.impl.RouteContext;
+import org.apache.camel.processor.ConvertBodyProcessor;
+import org.apache.camel.util.ObjectHelper;
+
+@XmlRootElement(name = "convertBodyTo")
+@XmlAccessorType(XmlAccessType.FIELD)
+public class ConvertBodyType extends ProcessorType<ProcessorType> {
+    @XmlAttribute
+    private String type;
+    @XmlTransient
+    private Class typeClass;
+
+    public ConvertBodyType() {
+    }
+
+    public ConvertBodyType(String type) {
+        setType(type);
+    }
+
+    public ConvertBodyType(Class typeClass) {
+        setTypeClass(typeClass);
+    }
+
+    @Override
+    public String toString() {
+        return "convertBodyTo[ " + getType() + "]";
+    }
+
+    @Override
+    public Processor createProcessor(RouteContext routeContext) throws Exception {
+        return new ConvertBodyProcessor(getTypeClass());
+    }
+
+    @Override
+    public List<ProcessorType<?>> getOutputs() {
+        return Collections.EMPTY_LIST;
+    }    
+    
+    protected Class createTypeClass() {
+        return ObjectHelper.loadClass(getType(), getClass().getClassLoader());
+    }
+
+    public void setType(String type) {
+        this.type = type;
+    }
+
+    public String getType() {
+        return type;
+    }
+
+    public void setTypeClass(Class typeClass) {
+        this.typeClass = typeClass;
+    }
+
+    public Class getTypeClass() {
+        if (typeClass == null) {
+            setTypeClass(createTypeClass());
+        }
+        return typeClass;
+    }
+}

Propchange: activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/model/ConvertBodyType.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/model/ConvertBodyType.java
------------------------------------------------------------------------------
    svn:keywords = Rev Date

Propchange: activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/model/RoutingSlipType.java
------------------------------------------------------------------------------
    svn:keywords = Rev Date

Modified: activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/model/SetHeaderType.java
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/model/SetHeaderType.java?rev=647890&r1=647889&r2=647890&view=diff
==============================================================================
--- activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/model/SetHeaderType.java (original)
+++ activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/model/SetHeaderType.java Mon Apr 14 09:38:25 2008
@@ -1,93 +1,93 @@
-/**
- * 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;
-
-import javax.xml.bind.annotation.XmlAccessType;
-import javax.xml.bind.annotation.XmlAccessorType;
-import javax.xml.bind.annotation.XmlAttribute;
-import javax.xml.bind.annotation.XmlRootElement;
-
-import org.apache.camel.Expression;
-import org.apache.camel.Processor;
-import org.apache.camel.builder.ExpressionBuilder;
-import org.apache.camel.impl.RouteContext;
-import org.apache.camel.model.language.ExpressionType;
-import org.apache.camel.processor.Delayer;
-import org.apache.camel.processor.SetHeaderProcessor;
-
-@XmlRootElement(name = "setHeader")
-@XmlAccessorType(XmlAccessType.FIELD)
-public class SetHeaderType extends ExpressionNode {
-    @XmlAttribute
-    private String headerName;
-    @XmlAttribute(required = false)
-    private String value;
-    
-    public SetHeaderType() {
-    }
-
-    public SetHeaderType(String headerName, ExpressionType expression) {
-        super(expression);
-        setHeaderName(headerName);
-    }
-
-    public SetHeaderType(String headerName, Expression expression) {
-        super(expression);
-        setHeaderName(headerName);        
-    }
-
-    public SetHeaderType(String headerName, String value) {
-        super(ExpressionBuilder.constantExpression(value));
-        setHeaderName(headerName);        
-    }   
-    
-    @Override
-    public String toString() {
-        return "SetHeader[ " + getHeaderName() + ", " + getExpression() + "]";
-    }
-
-    @Override
-    public Processor createProcessor(RouteContext routeContext) throws Exception {
-        Expression expr;
-
-        if (getValue() == null) {
-            expr = getExpression().createExpression(routeContext);
-        } else {
-            expr = ExpressionBuilder.constantExpression(getValue());
-        }
-
-        Processor childProcessor = routeContext.createProcessor(this);
-        
-        return new SetHeaderProcessor(getHeaderName(), expr, childProcessor);
-    }
-
-    public void setHeaderName(String headerName) {
-        this.headerName = headerName;
-    }
-
-    public String getHeaderName() {
-        return headerName;
-    }
-
-    public void setValue(String value) {
-        this.value = value;
-    }
-
-    public String getValue() {
-        return value;
-    }
-}
+/**
+ * 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;
+
+import javax.xml.bind.annotation.XmlAccessType;
+import javax.xml.bind.annotation.XmlAccessorType;
+import javax.xml.bind.annotation.XmlAttribute;
+import javax.xml.bind.annotation.XmlRootElement;
+
+import org.apache.camel.Expression;
+import org.apache.camel.Processor;
+import org.apache.camel.builder.ExpressionBuilder;
+import org.apache.camel.impl.RouteContext;
+import org.apache.camel.model.language.ExpressionType;
+import org.apache.camel.processor.Delayer;
+import org.apache.camel.processor.SetHeaderProcessor;
+
+@XmlRootElement(name = "setHeader")
+@XmlAccessorType(XmlAccessType.FIELD)
+public class SetHeaderType extends ExpressionNode {
+    @XmlAttribute
+    private String headerName;
+    @XmlAttribute(required = false)
+    private String value;
+    
+    public SetHeaderType() {
+    }
+
+    public SetHeaderType(String headerName, ExpressionType expression) {
+        super(expression);
+        setHeaderName(headerName);
+    }
+
+    public SetHeaderType(String headerName, Expression expression) {
+        super(expression);
+        setHeaderName(headerName);        
+    }
+
+    public SetHeaderType(String headerName, String value) {
+        super(ExpressionBuilder.constantExpression(value));
+        setHeaderName(headerName);        
+    }   
+    
+    @Override
+    public String toString() {
+        return "SetHeader[ " + getHeaderName() + ", " + getExpression() + "]";
+    }
+
+    @Override
+    public Processor createProcessor(RouteContext routeContext) throws Exception {
+        Expression expr;
+
+        if (getValue() == null) {
+            expr = getExpression().createExpression(routeContext);
+        } else {
+            expr = ExpressionBuilder.constantExpression(getValue());
+        }
+
+        Processor childProcessor = routeContext.createProcessor(this);
+        
+        return new SetHeaderProcessor(getHeaderName(), expr, childProcessor);
+    }
+
+    public void setHeaderName(String headerName) {
+        this.headerName = headerName;
+    }
+
+    public String getHeaderName() {
+        return headerName;
+    }
+
+    public void setValue(String value) {
+        this.value = value;
+    }
+
+    public String getValue() {
+        return value;
+    }
+}

Propchange: activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/model/SetHeaderType.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/model/SetHeaderType.java
------------------------------------------------------------------------------
    svn:keywords = Rev Date

Modified: activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/processor/ConvertBodyProcessor.java
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/processor/ConvertBodyProcessor.java?rev=647890&r1=647889&r2=647890&view=diff
==============================================================================
--- activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/processor/ConvertBodyProcessor.java (original)
+++ activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/processor/ConvertBodyProcessor.java Mon Apr 14 09:38:25 2008
@@ -25,7 +25,7 @@
 /**
  * A processor which converts the payload of the input message to be of the given type
  *
- * @version $Revision: 1.1 $
+ * @version $Revision$
  */
 public class ConvertBodyProcessor implements Processor {
     private static final transient Log LOG = LogFactory.getLog(ConvertBodyProcessor.class);

Propchange: activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/processor/ConvertBodyProcessor.java
------------------------------------------------------------------------------
    svn:keywords = Rev Date

Propchange: activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/processor/RoutingSlip.java
------------------------------------------------------------------------------
    svn:keywords = Rev Date

Modified: activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/processor/SetHeaderProcessor.java
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/processor/SetHeaderProcessor.java?rev=647890&r1=647889&r2=647890&view=diff
==============================================================================
--- activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/processor/SetHeaderProcessor.java (original)
+++ activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/processor/SetHeaderProcessor.java Mon Apr 14 09:38:25 2008
@@ -1,59 +1,59 @@
-/**
- * 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.processor;
-
-import org.apache.camel.Exchange;
-import org.apache.camel.Expression;
-import org.apache.camel.Processor;
-import org.apache.commons.logging.Log;
-import org.apache.commons.logging.LogFactory;
-
-/**
- * A processor which sets the header on the IN message
- */
-public class SetHeaderProcessor extends DelegateProcessor implements Processor {
-    private static final transient Log LOG = LogFactory.getLog(SetHeaderProcessor.class);
-    private String name;
-    private Expression expression;
-
-    public SetHeaderProcessor(String name, Expression expression) {
-        this.name = name;
-        this.expression = expression;
-    }
-
-    public SetHeaderProcessor(String name, Expression expression,
-            Processor childProcessor) {
-        super(childProcessor);
-        this.name = name;
-        this.expression = expression;
-    }
-
-    public void process(Exchange exchange) throws Exception {
-        Object value = expression.evaluate(exchange);
-        if (value == null) {
-            LOG.warn("Expression: " + expression
-                    + " on exchange: " + exchange + " evaluated to null.");
-        }
-        exchange.getIn().setHeader(name, value);
-        super.process(exchange);
-    }
-
-    @Override
-    public String toString() {
-        return "setHeader(" + name + ", " + expression + ")";
-    }
-}
+/**
+ * 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.processor;
+
+import org.apache.camel.Exchange;
+import org.apache.camel.Expression;
+import org.apache.camel.Processor;
+import org.apache.commons.logging.Log;
+import org.apache.commons.logging.LogFactory;
+
+/**
+ * A processor which sets the header on the IN message
+ */
+public class SetHeaderProcessor extends DelegateProcessor implements Processor {
+    private static final transient Log LOG = LogFactory.getLog(SetHeaderProcessor.class);
+    private String name;
+    private Expression expression;
+
+    public SetHeaderProcessor(String name, Expression expression) {
+        this.name = name;
+        this.expression = expression;
+    }
+
+    public SetHeaderProcessor(String name, Expression expression,
+            Processor childProcessor) {
+        super(childProcessor);
+        this.name = name;
+        this.expression = expression;
+    }
+
+    public void process(Exchange exchange) throws Exception {
+        Object value = expression.evaluate(exchange);
+        if (value == null) {
+            LOG.warn("Expression: " + expression
+                    + " on exchange: " + exchange + " evaluated to null.");
+        }
+        exchange.getIn().setHeader(name, value);
+        super.process(exchange);
+    }
+
+    @Override
+    public String toString() {
+        return "setHeader(" + name + ", " + expression + ")";
+    }
+}

Propchange: activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/processor/SetHeaderProcessor.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/processor/SetHeaderProcessor.java
------------------------------------------------------------------------------
    svn:keywords = Rev Date

Modified: activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/processor/ThroughputLogger.java
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/processor/ThroughputLogger.java?rev=647890&r1=647889&r2=647890&view=diff
==============================================================================
--- activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/processor/ThroughputLogger.java (original)
+++ activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/processor/ThroughputLogger.java Mon Apr 14 09:38:25 2008
@@ -23,7 +23,7 @@
 import org.apache.commons.logging.Log;
 
 /**
- * @version $Revision: 1.1 $
+ * @version $Revision$
  */
 public class ThroughputLogger extends Logger {
     private int groupSize = 100;

Propchange: activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/processor/ThroughputLogger.java
------------------------------------------------------------------------------
    svn:keywords = Rev Date

Modified: activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/processor/exceptionpolicy/DefaultExceptionPolicyStrategy.java
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/processor/exceptionpolicy/DefaultExceptionPolicyStrategy.java?rev=647890&r1=647889&r2=647890&view=diff
==============================================================================
--- activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/processor/exceptionpolicy/DefaultExceptionPolicyStrategy.java (original)
+++ activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/processor/exceptionpolicy/DefaultExceptionPolicyStrategy.java Mon Apr 14 09:38:25 2008
@@ -1,93 +1,93 @@
-/**
- * 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.processor.exceptionpolicy;
-
-import java.util.Map;
-import java.util.Set;
-
-import org.apache.camel.Exchange;
-import org.apache.camel.model.ExceptionType;
-import org.apache.commons.logging.Log;
-import org.apache.commons.logging.LogFactory;
-
-/**
- * The default strategy used in Camel to resolve the {@link org.apache.camel.model.ExceptionType} that should
- * handle the thrown exception.
- * <p/>
- * This strategy applies the following rules:
- * <ul>
- *   <li>The exception type must be configured with an Exception that is an instance of the thrown exception</li>
- *   <li>If the exception type has exactly the thrown exception then its selected</li>
- *   <li>Otherwise the type that has an exception that is super of the thrown exception is selected
- *       (recurring up the exception hierarchy)
- *  </ul>
- */
-public class DefaultExceptionPolicyStrategy implements ExceptionPolicyStrategy {
-
-    private static final transient Log LOG = LogFactory.getLog(DefaultExceptionPolicyStrategy.class);
-
-    public ExceptionType getExceptionPolicy(Map<Class, ExceptionType> exceptionPolicices, Exchange exchange,
-                                            Throwable exception) {
-        // the goal is to find the exception with the same/closet inheritance level as the target exception being thrown
-        int targetLevel = getInheritanceLevel(exception.getClass());
-        // candidate is the best candidate found so far to return
-        ExceptionType candidate = null;
-        // difference in inheritance level between the current candidate and the thrown exception (target level)
-        int candidateDiff = Integer.MAX_VALUE;
-
-        // loop through all the entries and find the best candidates to use
-        Set<Map.Entry<Class, ExceptionType>> entries = exceptionPolicices.entrySet();
-        for (Map.Entry<Class, ExceptionType> entry : entries) {
-            Class clazz = entry.getKey();
-            ExceptionType type = entry.getValue();
-
-            // must be instance of check to ensure that the clazz is one type of the thrown exception
-            if (clazz.isInstance(exception)) {
-
-                // exact match
-                if (clazz.equals(exception.getClass())) {
-                    candidate = type;
-                    break;
-                }
-
-                // not an exact match so find the best candidate
-                int level = getInheritanceLevel(clazz);
-                int diff = targetLevel - level;
-
-                if (diff < candidateDiff) {
-                    // replace with a much better candidate
-                    candidate = type;
-                    candidateDiff = diff;
-                }
-            }
-        }
-
-        if (LOG.isDebugEnabled()) {
-            LOG.debug("Using " + candidate + " as the exception policy");
-        }
-        return candidate;
-
-    }
-
-    private static int getInheritanceLevel(Class clazz) {
-        if (clazz == null || "java.lang.Object".equals(clazz.getName())) {
-            return 0;
-        }
-        return 1 + getInheritanceLevel(clazz.getSuperclass());
-    }
-
-}
+/**
+ * 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.processor.exceptionpolicy;
+
+import java.util.Map;
+import java.util.Set;
+
+import org.apache.camel.Exchange;
+import org.apache.camel.model.ExceptionType;
+import org.apache.commons.logging.Log;
+import org.apache.commons.logging.LogFactory;
+
+/**
+ * The default strategy used in Camel to resolve the {@link org.apache.camel.model.ExceptionType} that should
+ * handle the thrown exception.
+ * <p/>
+ * This strategy applies the following rules:
+ * <ul>
+ *   <li>The exception type must be configured with an Exception that is an instance of the thrown exception</li>
+ *   <li>If the exception type has exactly the thrown exception then its selected</li>
+ *   <li>Otherwise the type that has an exception that is super of the thrown exception is selected
+ *       (recurring up the exception hierarchy)
+ *  </ul>
+ */
+public class DefaultExceptionPolicyStrategy implements ExceptionPolicyStrategy {
+
+    private static final transient Log LOG = LogFactory.getLog(DefaultExceptionPolicyStrategy.class);
+
+    public ExceptionType getExceptionPolicy(Map<Class, ExceptionType> exceptionPolicices, Exchange exchange,
+                                            Throwable exception) {
+        // the goal is to find the exception with the same/closet inheritance level as the target exception being thrown
+        int targetLevel = getInheritanceLevel(exception.getClass());
+        // candidate is the best candidate found so far to return
+        ExceptionType candidate = null;
+        // difference in inheritance level between the current candidate and the thrown exception (target level)
+        int candidateDiff = Integer.MAX_VALUE;
+
+        // loop through all the entries and find the best candidates to use
+        Set<Map.Entry<Class, ExceptionType>> entries = exceptionPolicices.entrySet();
+        for (Map.Entry<Class, ExceptionType> entry : entries) {
+            Class clazz = entry.getKey();
+            ExceptionType type = entry.getValue();
+
+            // must be instance of check to ensure that the clazz is one type of the thrown exception
+            if (clazz.isInstance(exception)) {
+
+                // exact match
+                if (clazz.equals(exception.getClass())) {
+                    candidate = type;
+                    break;
+                }
+
+                // not an exact match so find the best candidate
+                int level = getInheritanceLevel(clazz);
+                int diff = targetLevel - level;
+
+                if (diff < candidateDiff) {
+                    // replace with a much better candidate
+                    candidate = type;
+                    candidateDiff = diff;
+                }
+            }
+        }
+
+        if (LOG.isDebugEnabled()) {
+            LOG.debug("Using " + candidate + " as the exception policy");
+        }
+        return candidate;
+
+    }
+
+    private static int getInheritanceLevel(Class clazz) {
+        if (clazz == null || "java.lang.Object".equals(clazz.getName())) {
+            return 0;
+        }
+        return 1 + getInheritanceLevel(clazz.getSuperclass());
+    }
+
+}

Propchange: activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/processor/exceptionpolicy/DefaultExceptionPolicyStrategy.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/processor/exceptionpolicy/DefaultExceptionPolicyStrategy.java
------------------------------------------------------------------------------
    svn:keywords = Rev Date

Modified: activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/processor/exceptionpolicy/ExceptionPolicyStrategy.java
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/processor/exceptionpolicy/ExceptionPolicyStrategy.java?rev=647890&r1=647889&r2=647890&view=diff
==============================================================================
--- activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/processor/exceptionpolicy/ExceptionPolicyStrategy.java (original)
+++ activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/processor/exceptionpolicy/ExceptionPolicyStrategy.java Mon Apr 14 09:38:25 2008
@@ -1,43 +1,43 @@
-/**
- * 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.processor.exceptionpolicy;
-
-import java.util.Map;
-
-import org.apache.camel.Exchange;
-import org.apache.camel.model.ExceptionType;
-
-/**
- * A strategy to determine witch {@link org.apache.camel.model.ExceptionType} should handle the thrown
- * exception.
- *
- * @see org.apache.camel.processor.exceptionpolicy.DefaultExceptionPolicyStrategy DefaultExceptionPolicy
- */
-public interface ExceptionPolicyStrategy {
-
-    /**
-     * Resolves the {@link org.apache.camel.model.ExceptionType} that should handle the thrown exception.
-     *
-     * @param exceptionPolicices the configured exception policies to resolve from
-     * @param exchange           the exchange
-     * @param exception          the exception that was thrown
-     * @return the resolved exception type to handle this exception, <tt>null</tt> if none found.
-     */
-    ExceptionType getExceptionPolicy(Map<Class, ExceptionType> exceptionPolicices, Exchange exchange,
-                                            Throwable exception);
-
-}
+/**
+ * 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.processor.exceptionpolicy;
+
+import java.util.Map;
+
+import org.apache.camel.Exchange;
+import org.apache.camel.model.ExceptionType;
+
+/**
+ * A strategy to determine witch {@link org.apache.camel.model.ExceptionType} should handle the thrown
+ * exception.
+ *
+ * @see org.apache.camel.processor.exceptionpolicy.DefaultExceptionPolicyStrategy DefaultExceptionPolicy
+ */
+public interface ExceptionPolicyStrategy {
+
+    /**
+     * Resolves the {@link org.apache.camel.model.ExceptionType} that should handle the thrown exception.
+     *
+     * @param exceptionPolicices the configured exception policies to resolve from
+     * @param exchange           the exchange
+     * @param exception          the exception that was thrown
+     * @return the resolved exception type to handle this exception, <tt>null</tt> if none found.
+     */
+    ExceptionType getExceptionPolicy(Map<Class, ExceptionType> exceptionPolicices, Exchange exchange,
+                                            Throwable exception);
+
+}

Propchange: activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/processor/exceptionpolicy/ExceptionPolicyStrategy.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/processor/exceptionpolicy/ExceptionPolicyStrategy.java
------------------------------------------------------------------------------
    svn:keywords = Rev Date

Modified: activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/processor/exceptionpolicy/package.html
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/processor/exceptionpolicy/package.html?rev=647890&r1=647889&r2=647890&view=diff
==============================================================================
--- activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/processor/exceptionpolicy/package.html (original)
+++ activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/processor/exceptionpolicy/package.html Mon Apr 14 09:38:25 2008
@@ -1,25 +1,25 @@
-<!--
-    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.
--->
-<html>
-<head>
-</head>
-<body>
-
-Exception policy startegies for <a href="http://activemq.apache.org/camel/dead-letter-channel.html">Dead Letter Channel</a> pattern.
-
-</body>
-</html>
+<!--
+    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.
+-->
+<html>
+<head>
+</head>
+<body>
+
+Exception policy startegies for <a href="http://activemq.apache.org/camel/dead-letter-channel.html">Dead Letter Channel</a> pattern.
+
+</body>
+</html>

Propchange: activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/processor/exceptionpolicy/package.html
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/processor/exceptionpolicy/package.html
------------------------------------------------------------------------------
    svn:keywords = Rev Date

Propchange: activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/processor/exceptionpolicy/package.html
------------------------------------------------------------------------------
    svn:mime-type = text/html

Propchange: activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/processor/interceptor/StreamCachingInterceptor.java
------------------------------------------------------------------------------
    svn:keywords = Rev Date

Modified: activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/processor/interceptor/package.html
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/processor/interceptor/package.html?rev=647890&r1=647889&r2=647890&view=diff
==============================================================================
--- activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/processor/interceptor/package.html (original)
+++ activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/processor/interceptor/package.html Mon Apr 14 09:38:25 2008
@@ -1,25 +1,25 @@
-<!--
-    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.
--->
-<html>
-<head>
-</head>
-<body>
-
-Helper classes for interceptors.
-
-</body>
-</html>
+<!--
+    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.
+-->
+<html>
+<head>
+</head>
+<body>
+
+Helper classes for interceptors.
+
+</body>
+</html>

Propchange: activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/processor/interceptor/package.html
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/processor/interceptor/package.html
------------------------------------------------------------------------------
    svn:keywords = Rev Date

Propchange: activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/processor/interceptor/package.html
------------------------------------------------------------------------------
    svn:mime-type = text/html

Modified: activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/processor/resequencer/package.html
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/processor/resequencer/package.html?rev=647890&r1=647889&r2=647890&view=diff
==============================================================================
--- activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/processor/resequencer/package.html (original)
+++ activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/processor/resequencer/package.html Mon Apr 14 09:38:25 2008
@@ -1,25 +1,25 @@
-<!--
-    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.
--->
-<html>
-<head>
-</head>
-<body>
-
-Helper classes for the <a href="http://activemq.apache.org/camel/resequencer.html">Resequencer</a> pattern.
-
-</body>
-</html>
+<!--
+    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.
+-->
+<html>
+<head>
+</head>
+<body>
+
+Helper classes for the <a href="http://activemq.apache.org/camel/resequencer.html">Resequencer</a> pattern.
+
+</body>
+</html>

Propchange: activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/processor/resequencer/package.html
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/processor/resequencer/package.html
------------------------------------------------------------------------------
    svn:keywords = Rev Date

Propchange: activemq/camel/trunk/camel-core/src/main/java/org/apache/camel/processor/resequencer/package.html
------------------------------------------------------------------------------
    svn:mime-type = text/html