You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@camel.apache.org by dk...@apache.org on 2011/12/02 18:03:50 UTC

svn commit: r1209585 [15/22] - in /camel/trunk: ./ apache-camel/ buildingtools/ camel-core/ camel-core/src/main/java/org/apache/camel/ camel-core/src/main/java/org/apache/camel/api/management/ camel-core/src/main/java/org/apache/camel/builder/ camel-co...

Modified: camel/trunk/components/camel-quickfix/src/test/java/org/apache/camel/component/quickfixj/examples/SimpleMessagingExample.java
URL: http://svn.apache.org/viewvc/camel/trunk/components/camel-quickfix/src/test/java/org/apache/camel/component/quickfixj/examples/SimpleMessagingExample.java?rev=1209585&r1=1209584&r2=1209585&view=diff
==============================================================================
--- camel/trunk/components/camel-quickfix/src/test/java/org/apache/camel/component/quickfixj/examples/SimpleMessagingExample.java (original)
+++ camel/trunk/components/camel-quickfix/src/test/java/org/apache/camel/component/quickfixj/examples/SimpleMessagingExample.java Fri Dec  2 17:03:07 2011
@@ -1,107 +1,107 @@
-/**
- * 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.component.quickfixj.examples;
-
-import java.util.concurrent.CountDownLatch;
-import java.util.concurrent.TimeUnit;
-
-import org.apache.camel.Exchange;
-import org.apache.camel.ExchangePattern;
-import org.apache.camel.Producer;
-import org.apache.camel.builder.PredicateBuilder;
-import org.apache.camel.builder.RouteBuilder;
-import org.apache.camel.component.quickfixj.QuickfixjEndpoint;
-import org.apache.camel.component.quickfixj.QuickfixjEventCategory;
-import org.apache.camel.component.quickfixj.TestSupport;
-import org.apache.camel.component.quickfixj.examples.transform.QuickfixjMessageJsonPrinter;
-import org.apache.camel.component.quickfixj.examples.util.CountDownLatchDecrementer;
-import org.apache.camel.impl.DefaultCamelContext;
-import org.slf4j.Logger;
-import org.slf4j.LoggerFactory;
-
-import quickfix.field.MsgType;
-import quickfix.fix42.Email;
-
-/**
- * This example demonstrates several features of the QuickFIX/J component. It uses
- * QFJ session events to synchronize application behavior (e.g., Session logon).
- * 
- */
-public class SimpleMessagingExample {
-    private static final Logger LOG = LoggerFactory.getLogger(SimpleMessagingExample.class);
-
-    public static void main(String[] args) throws Exception {
-        new SimpleMessagingExample().sendMessage();
-    }
-    
-    public void sendMessage() throws Exception {        
-        DefaultCamelContext context = new DefaultCamelContext();
-        
-        final CountDownLatch logonLatch = new CountDownLatch(2);
-        final CountDownLatch receivedMessageLatch = new CountDownLatch(1);
-        
-        RouteBuilder routes = new RouteBuilder() {
-            @Override
-            public void configure() throws Exception {
-                // Release latch when session logon events are received
-                // We expect two events, one for the trader session and one for the market session
-                from("quickfix:examples/inprocess.cfg").
-                    filter(header(QuickfixjEndpoint.EVENT_CATEGORY_KEY).isEqualTo(QuickfixjEventCategory.SessionLogon)).
-                    bean(new CountDownLatchDecrementer("logon", logonLatch));
-
-                // For all received messages, print the JSON-formatted message to stdout
-                from("quickfix:examples/inprocess.cfg").
-                    filter(PredicateBuilder.or(
-                            header(QuickfixjEndpoint.EVENT_CATEGORY_KEY).isEqualTo(QuickfixjEventCategory.AdminMessageReceived),
-                            header(QuickfixjEndpoint.EVENT_CATEGORY_KEY).isEqualTo(QuickfixjEventCategory.AppMessageReceived))).
-                    bean(new QuickfixjMessageJsonPrinter());
-
-                // If the market session receives an email then release the latch
-                from("quickfix:examples/inprocess.cfg?sessionID=FIX.4.2:MARKET->TRADER").
-                    filter(header(QuickfixjEndpoint.MESSAGE_TYPE_KEY).isEqualTo(MsgType.EMAIL)).
-                    bean(new CountDownLatchDecrementer("message", receivedMessageLatch));
-            }
-        };
-        
-        context.addRoutes(routes);
-        
-        LOG.info("Starting Camel context");
-        context.start();
-        
-        if (!logonLatch.await(5L, TimeUnit.SECONDS)) {
-            throw new IllegalStateException("Logon did not succeed");
-        }
-        
-        String marketUri = "quickfix:examples/inprocess.cfg?sessionID=FIX.4.2:TRADER->MARKET";
-        Producer producer = context.getEndpoint(marketUri).createProducer();
-        
-        Email email = TestSupport.createEmailMessage("Example");
-        Exchange exchange = producer.createExchange(ExchangePattern.InOnly);
-        exchange.getIn().setBody(email);
-        producer.process(exchange);            
-
-        if (!receivedMessageLatch.await(5L, TimeUnit.SECONDS)) {
-            throw new IllegalStateException("Message did not reach market");
-        }
-        
-        LOG.info("Message received, shutting down Camel context");
-        
-        context.stop();
-        
-        LOG.info("Example complete");
-    }
-}
+/**
+ * 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.component.quickfixj.examples;
+
+import java.util.concurrent.CountDownLatch;
+import java.util.concurrent.TimeUnit;
+
+import org.apache.camel.Exchange;
+import org.apache.camel.ExchangePattern;
+import org.apache.camel.Producer;
+import org.apache.camel.builder.PredicateBuilder;
+import org.apache.camel.builder.RouteBuilder;
+import org.apache.camel.component.quickfixj.QuickfixjEndpoint;
+import org.apache.camel.component.quickfixj.QuickfixjEventCategory;
+import org.apache.camel.component.quickfixj.TestSupport;
+import org.apache.camel.component.quickfixj.examples.transform.QuickfixjMessageJsonPrinter;
+import org.apache.camel.component.quickfixj.examples.util.CountDownLatchDecrementer;
+import org.apache.camel.impl.DefaultCamelContext;
+import org.slf4j.Logger;
+import org.slf4j.LoggerFactory;
+
+import quickfix.field.MsgType;
+import quickfix.fix42.Email;
+
+/**
+ * This example demonstrates several features of the QuickFIX/J component. It uses
+ * QFJ session events to synchronize application behavior (e.g., Session logon).
+ * 
+ */
+public class SimpleMessagingExample {
+    private static final Logger LOG = LoggerFactory.getLogger(SimpleMessagingExample.class);
+
+    public static void main(String[] args) throws Exception {
+        new SimpleMessagingExample().sendMessage();
+    }
+    
+    public void sendMessage() throws Exception {        
+        DefaultCamelContext context = new DefaultCamelContext();
+        
+        final CountDownLatch logonLatch = new CountDownLatch(2);
+        final CountDownLatch receivedMessageLatch = new CountDownLatch(1);
+        
+        RouteBuilder routes = new RouteBuilder() {
+            @Override
+            public void configure() throws Exception {
+                // Release latch when session logon events are received
+                // We expect two events, one for the trader session and one for the market session
+                from("quickfix:examples/inprocess.cfg").
+                    filter(header(QuickfixjEndpoint.EVENT_CATEGORY_KEY).isEqualTo(QuickfixjEventCategory.SessionLogon)).
+                    bean(new CountDownLatchDecrementer("logon", logonLatch));
+
+                // For all received messages, print the JSON-formatted message to stdout
+                from("quickfix:examples/inprocess.cfg").
+                    filter(PredicateBuilder.or(
+                            header(QuickfixjEndpoint.EVENT_CATEGORY_KEY).isEqualTo(QuickfixjEventCategory.AdminMessageReceived),
+                            header(QuickfixjEndpoint.EVENT_CATEGORY_KEY).isEqualTo(QuickfixjEventCategory.AppMessageReceived))).
+                    bean(new QuickfixjMessageJsonPrinter());
+
+                // If the market session receives an email then release the latch
+                from("quickfix:examples/inprocess.cfg?sessionID=FIX.4.2:MARKET->TRADER").
+                    filter(header(QuickfixjEndpoint.MESSAGE_TYPE_KEY).isEqualTo(MsgType.EMAIL)).
+                    bean(new CountDownLatchDecrementer("message", receivedMessageLatch));
+            }
+        };
+        
+        context.addRoutes(routes);
+        
+        LOG.info("Starting Camel context");
+        context.start();
+        
+        if (!logonLatch.await(5L, TimeUnit.SECONDS)) {
+            throw new IllegalStateException("Logon did not succeed");
+        }
+        
+        String marketUri = "quickfix:examples/inprocess.cfg?sessionID=FIX.4.2:TRADER->MARKET";
+        Producer producer = context.getEndpoint(marketUri).createProducer();
+        
+        Email email = TestSupport.createEmailMessage("Example");
+        Exchange exchange = producer.createExchange(ExchangePattern.InOnly);
+        exchange.getIn().setBody(email);
+        producer.process(exchange);            
+
+        if (!receivedMessageLatch.await(5L, TimeUnit.SECONDS)) {
+            throw new IllegalStateException("Message did not reach market");
+        }
+        
+        LOG.info("Message received, shutting down Camel context");
+        
+        context.stop();
+        
+        LOG.info("Example complete");
+    }
+}

Propchange: camel/trunk/components/camel-quickfix/src/test/java/org/apache/camel/component/quickfixj/examples/SimpleMessagingExample.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/trunk/components/camel-quickfix/src/test/java/org/apache/camel/component/quickfixj/examples/routing/FixMessageRouter.java
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: camel/trunk/components/camel-quickfix/src/test/java/org/apache/camel/component/quickfixj/examples/trading/MarketQuoteProvider.java
URL: http://svn.apache.org/viewvc/camel/trunk/components/camel-quickfix/src/test/java/org/apache/camel/component/quickfixj/examples/trading/MarketQuoteProvider.java?rev=1209585&r1=1209584&r2=1209585&view=diff
==============================================================================
--- camel/trunk/components/camel-quickfix/src/test/java/org/apache/camel/component/quickfixj/examples/trading/MarketQuoteProvider.java (original)
+++ camel/trunk/components/camel-quickfix/src/test/java/org/apache/camel/component/quickfixj/examples/trading/MarketQuoteProvider.java Fri Dec  2 17:03:07 2011
@@ -1,27 +1,27 @@
-/**
- * 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.component.quickfixj.examples.trading;
-
-/**
- * Trivial market data provider interface to allow plugins for
- * alternative market data sources.
- *
- */
-public interface MarketQuoteProvider {
-    double getBid(String symbol);
-    double getAsk(String symbol);
-}
+/**
+ * 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.component.quickfixj.examples.trading;
+
+/**
+ * Trivial market data provider interface to allow plugins for
+ * alternative market data sources.
+ *
+ */
+public interface MarketQuoteProvider {
+    double getBid(String symbol);
+    double getAsk(String symbol);
+}

Propchange: camel/trunk/components/camel-quickfix/src/test/java/org/apache/camel/component/quickfixj/examples/trading/MarketQuoteProvider.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/trunk/components/camel-quickfix/src/test/java/org/apache/camel/component/quickfixj/examples/trading/QuickfixjMessageListener.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/trunk/components/camel-quickfix/src/test/java/org/apache/camel/component/quickfixj/examples/trading/TradeExecutor.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/trunk/components/camel-quickfix/src/test/java/org/apache/camel/component/quickfixj/examples/trading/TradeExecutorComponent.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/trunk/components/camel-quickfix/src/test/java/org/apache/camel/component/quickfixj/examples/trading/TradeExecutorExample.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/trunk/components/camel-quickfix/src/test/java/org/apache/camel/component/quickfixj/examples/transform/QuickfixjEventJsonTransformer.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/trunk/components/camel-quickfix/src/test/java/org/apache/camel/component/quickfixj/examples/transform/QuickfixjMessageJsonPrinter.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/trunk/components/camel-quickfix/src/test/java/org/apache/camel/component/quickfixj/examples/transform/QuickfixjMessageJsonTransformer.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/trunk/components/camel-quickfix/src/test/java/org/apache/camel/component/quickfixj/examples/util/CountDownLatchDecrementer.java
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: camel/trunk/components/camel-quickfix/src/test/resources/log4j.properties
URL: http://svn.apache.org/viewvc/camel/trunk/components/camel-quickfix/src/test/resources/log4j.properties?rev=1209585&r1=1209584&r2=1209585&view=diff
==============================================================================
--- camel/trunk/components/camel-quickfix/src/test/resources/log4j.properties (original)
+++ camel/trunk/components/camel-quickfix/src/test/resources/log4j.properties Fri Dec  2 17:03:07 2011
@@ -1,37 +1,37 @@
-## ------------------------------------------------------------------------
-## 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.
-## ------------------------------------------------------------------------
-
-#
-# The logging properties used for eclipse testing, We want to see debug output on the console.
-#
-log4j.rootLogger=INFO, file
-
-# uncomment the following to enable camel debugging
-#log4j.logger.org.apache.camel=DEBUG
-#log4j.logger.org.apache.camel.component.quickfixj=DEBUG
-
-# CONSOLE appender not used by default
-log4j.appender.out=org.apache.log4j.ConsoleAppender
-log4j.appender.out.layout=org.apache.log4j.PatternLayout
-#log4j.appender.out.layout.ConversionPattern=[%30.30t] %-30.30c{1} %-5p %m%n
-log4j.appender.out.layout.ConversionPattern=%d [%-15.15t] %-5p %-30.30c{1} - %m%n
-
-# File appender
-log4j.appender.file=org.apache.log4j.FileAppender
-log4j.appender.file.layout=org.apache.log4j.PatternLayout
-log4j.appender.file.layout.ConversionPattern=%d [%-15.15t] %-5p %-30.30c{1} - %m%n
+## ------------------------------------------------------------------------
+## 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.
+## ------------------------------------------------------------------------
+
+#
+# The logging properties used for eclipse testing, We want to see debug output on the console.
+#
+log4j.rootLogger=INFO, file
+
+# uncomment the following to enable camel debugging
+#log4j.logger.org.apache.camel=DEBUG
+#log4j.logger.org.apache.camel.component.quickfixj=DEBUG
+
+# CONSOLE appender not used by default
+log4j.appender.out=org.apache.log4j.ConsoleAppender
+log4j.appender.out.layout=org.apache.log4j.PatternLayout
+#log4j.appender.out.layout.ConversionPattern=[%30.30t] %-30.30c{1} %-5p %m%n
+log4j.appender.out.layout.ConversionPattern=%d [%-15.15t] %-5p %-30.30c{1} - %m%n
+
+# File appender
+log4j.appender.file=org.apache.log4j.FileAppender
+log4j.appender.file.layout=org.apache.log4j.PatternLayout
+log4j.appender.file.layout.ConversionPattern=%d [%-15.15t] %-5p %-30.30c{1} - %m%n
 log4j.appender.file.file=target/camel-quickfix-test.log
\ No newline at end of file

Propchange: camel/trunk/components/camel-quickfix/src/test/resources/log4j.properties
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/trunk/components/camel-quickfix/src/test/resources/log4j.properties
------------------------------------------------------------------------------
    svn:mime-type = text/plain

Propchange: camel/trunk/components/camel-quickfix/src/test/resources/org/apache/camel/component/quickfixj/QuickfixjSpringTest-context.xml
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/trunk/components/camel-quickfix/src/test/resources/org/apache/camel/component/quickfixj/QuickfixjSpringTest-context.xml
------------------------------------------------------------------------------
    svn:mime-type = text/xml

Propchange: camel/trunk/components/camel-restlet/
------------------------------------------------------------------------------
--- svn:ignore (original)
+++ svn:ignore Fri Dec  2 17:03:07 2011
@@ -1,8 +1,13 @@
-.project
 .pmd
 .checkstyle
-.classpath
+.ruleset
 target
 .settings
+.classpath
+.project
+.wtpmodules
+prj.el
+.jdee_classpath
+.jdee_sources
+velocity.log
 eclipse-classes
-*.i??

Propchange: camel/trunk/components/camel-restlet/src/main/java/org/apache/camel/component/restlet/RestletOperationException.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/trunk/components/camel-restlet/src/test/java/org/apache/camel/component/restlet/RestletPostXmlRouteAndJSONAsReturnTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/trunk/components/camel-restlet/src/test/java/org/apache/camel/component/restlet/RestletProducerGet2Test.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/trunk/components/camel-restlet/src/test/java/org/apache/camel/component/restlet/RestletProducerGetResponseCodeTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/trunk/components/camel-restlet/src/test/java/org/apache/camel/component/restlet/RestletProducerGetTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/trunk/components/camel-restlet/src/test/java/org/apache/camel/component/restlet/RestletRecipientListTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/trunk/components/camel-restlet/src/test/java/org/apache/camel/component/restlet/RestletRequestAndResponseAPITest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/trunk/components/camel-restlet/src/test/java/org/apache/camel/component/restlet/RestletThrowExceptionOnFailureTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/trunk/components/camel-restlet/src/test/java/org/apache/camel/component/restlet/RestletTwoEndpointsTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/trunk/components/camel-restlet/src/test/java/org/apache/camel/component/restlet/RestletValidUriQueryTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/trunk/components/camel-rmi/
------------------------------------------------------------------------------
--- svn:ignore (original)
+++ svn:ignore Fri Dec  2 17:03:07 2011
@@ -1,8 +1,13 @@
-target
 .pmd
 .checkstyle
+.ruleset
+target
+.settings
 .classpath
 .project
+.wtpmodules
+prj.el
+.jdee_classpath
+.jdee_sources
+velocity.log
 eclipse-classes
-.settings
-*.i??

Propchange: camel/trunk/components/camel-routebox/
------------------------------------------------------------------------------
--- svn:ignore (original)
+++ svn:ignore Fri Dec  2 17:03:07 2011
@@ -1,9 +1,13 @@
-.project
-.checkstyle
 .pmd
-.classpath
+.checkstyle
+.ruleset
 target
 .settings
+.classpath
+.project
+.wtpmodules
+prj.el
+.jdee_classpath
+.jdee_sources
+velocity.log
 eclipse-classes
-*.i??
-classes

Propchange: camel/trunk/components/camel-routebox/pom.xml
------------------------------------------------------------------------------
    svn:mime-type = text/xml

Propchange: camel/trunk/components/camel-rss/
------------------------------------------------------------------------------
--- svn:ignore (original)
+++ svn:ignore Fri Dec  2 17:03:07 2011
@@ -1,9 +1,13 @@
-.project
-.checkstyle
 .pmd
-.classpath
+.checkstyle
+.ruleset
 target
 .settings
+.classpath
+.project
+.wtpmodules
+prj.el
+.jdee_classpath
+.jdee_sources
+velocity.log
 eclipse-classes
-*.i??
-classes

Propchange: camel/trunk/components/camel-rss/src/test/java/org/apache/camel/component/rss/RssUriEncodingIssueTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/trunk/components/camel-ruby/
------------------------------------------------------------------------------
--- svn:ignore (original)
+++ svn:ignore Fri Dec  2 17:03:07 2011
@@ -1,8 +1,13 @@
-.project
-.checkstyle
 .pmd
-.classpath
+.checkstyle
+.ruleset
 target
 .settings
+.classpath
+.project
+.wtpmodules
+prj.el
+.jdee_classpath
+.jdee_sources
+velocity.log
 eclipse-classes
-*.i??

Propchange: camel/trunk/components/camel-saxon/
------------------------------------------------------------------------------
--- svn:ignore (original)
+++ svn:ignore Fri Dec  2 17:03:07 2011
@@ -1,8 +1,13 @@
-eclipse-classes
 .pmd
 .checkstyle
+.ruleset
 target
+.settings
 .classpath
 .project
-.settings
-*.i??
+.wtpmodules
+prj.el
+.jdee_classpath
+.jdee_sources
+velocity.log
+eclipse-classes

Modified: camel/trunk/components/camel-saxon/src/main/java/org/apache/camel/component/xquery/XQueryModuleURIResolver.java
URL: http://svn.apache.org/viewvc/camel/trunk/components/camel-saxon/src/main/java/org/apache/camel/component/xquery/XQueryModuleURIResolver.java?rev=1209585&r1=1209584&r2=1209585&view=diff
==============================================================================
--- camel/trunk/components/camel-saxon/src/main/java/org/apache/camel/component/xquery/XQueryModuleURIResolver.java (original)
+++ camel/trunk/components/camel-saxon/src/main/java/org/apache/camel/component/xquery/XQueryModuleURIResolver.java Fri Dec  2 17:03:07 2011
@@ -1,46 +1,46 @@
-/**
- * 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.component.xquery;
-
-import javax.xml.transform.stream.StreamSource;
-
-import net.sf.saxon.query.ModuleURIResolver;
-import net.sf.saxon.trans.XPathException;
-
-/**
- * Resolves XQuery file imports
- */
-public class XQueryModuleURIResolver implements ModuleURIResolver {
-    private final XQueryComponent xqueryComponent;
-
-    public XQueryModuleURIResolver(XQueryComponent xqueryComponent) {
-        this.xqueryComponent = xqueryComponent;
-    }
-
-    public StreamSource[] resolve(String moduleURI, String baseURI, String[] locations) throws XPathException {
-        StreamSource[] ss = new StreamSource[locations.length];
-        try {
-            for (int i = 0; i < locations.length; i++) {
-                ss[i] = new StreamSource(xqueryComponent.resolveModuleResource(locations[i]).openStream());
-            }
-        } catch (Exception e) {
-            throw new XPathException("Error resolving resource: " + locations, e);
-        }
-        return ss;
-    }
-
-}
+/**
+ * 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.component.xquery;
+
+import javax.xml.transform.stream.StreamSource;
+
+import net.sf.saxon.query.ModuleURIResolver;
+import net.sf.saxon.trans.XPathException;
+
+/**
+ * Resolves XQuery file imports
+ */
+public class XQueryModuleURIResolver implements ModuleURIResolver {
+    private final XQueryComponent xqueryComponent;
+
+    public XQueryModuleURIResolver(XQueryComponent xqueryComponent) {
+        this.xqueryComponent = xqueryComponent;
+    }
+
+    public StreamSource[] resolve(String moduleURI, String baseURI, String[] locations) throws XPathException {
+        StreamSource[] ss = new StreamSource[locations.length];
+        try {
+            for (int i = 0; i < locations.length; i++) {
+                ss[i] = new StreamSource(xqueryComponent.resolveModuleResource(locations[i]).openStream());
+            }
+        } catch (Exception e) {
+            throw new XPathException("Error resolving resource: " + locations, e);
+        }
+        return ss;
+    }
+
+}

Propchange: camel/trunk/components/camel-saxon/src/main/java/org/apache/camel/component/xquery/XQueryModuleURIResolver.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/trunk/components/camel-saxon/src/test/java/org/apache/camel/builder/saxon/SaxonXPathSplitTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/trunk/components/camel-saxon/src/test/java/org/apache/camel/builder/saxon/SaxonXPathTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: camel/trunk/components/camel-saxon/src/test/java/org/apache/camel/builder/saxon/XPathAnnotationResultTypeTest.java
URL: http://svn.apache.org/viewvc/camel/trunk/components/camel-saxon/src/test/java/org/apache/camel/builder/saxon/XPathAnnotationResultTypeTest.java?rev=1209585&r1=1209584&r2=1209585&view=diff
==============================================================================
--- camel/trunk/components/camel-saxon/src/test/java/org/apache/camel/builder/saxon/XPathAnnotationResultTypeTest.java (original)
+++ camel/trunk/components/camel-saxon/src/test/java/org/apache/camel/builder/saxon/XPathAnnotationResultTypeTest.java Fri Dec  2 17:03:07 2011
@@ -1,73 +1,73 @@
-/**
- * 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.builder.saxon;
-
-import javax.naming.Context;
-import javax.xml.xpath.XPathFactory;
-
-import org.apache.camel.builder.RouteBuilder;
-import org.apache.camel.language.XPath;
-import org.apache.camel.test.junit4.CamelTestSupport;
-import org.apache.camel.util.jndi.JndiContext;
-
-import org.junit.Test;
-
-/**
- * @version 
- */
-public class XPathAnnotationResultTypeTest extends CamelTestSupport {
-    protected MyBean myBean = new MyBean();
-
-    @Test
-    public void testSendMessage() throws Exception {
-
-        String response = (String) template.requestBody("direct:in1", "<a><b>hello</b></a>");
-        assertEquals("HELLO", response);
-        
-        response = (String) template.requestBody("direct:in2", "<a><b>hello</b></a>");
-        assertEquals("HELLO", response);
-    }
-
-    @Override
-    protected Context createJndiContext() throws Exception {
-        JndiContext answer = new JndiContext();
-        answer.bind("myBean", myBean);
-        return answer;
-    }
-
-    protected RouteBuilder createRouteBuilder() {
-        return new RouteBuilder() {
-            public void configure() {
-                System.setProperty(XPathFactory.DEFAULT_PROPERTY_NAME + ":" + "http://saxon.sf.net/jaxp/xpath/om", "net.sf.saxon.xpath.XPathFactoryImpl");
-                from("direct:in1").beanRef("myBean", "readImplicit");
-                from("direct:in2").beanRef("myBean", "readExplicit");
-            }
-        };
-    }
-
-    public static class MyBean {
-        public String abText;
-
-        public String readImplicit(@XPath("upper-case(//a/b/text())") String abText) {
-            return abText;
-        }
-
-        public String readExplicit(@XPath(value = "upper-case(//a/b/text())", resultType = String.class) String abText) {
-            return abText;
-        }
-    }
-}
+/**
+ * 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.builder.saxon;
+
+import javax.naming.Context;
+import javax.xml.xpath.XPathFactory;
+
+import org.apache.camel.builder.RouteBuilder;
+import org.apache.camel.language.XPath;
+import org.apache.camel.test.junit4.CamelTestSupport;
+import org.apache.camel.util.jndi.JndiContext;
+
+import org.junit.Test;
+
+/**
+ * @version 
+ */
+public class XPathAnnotationResultTypeTest extends CamelTestSupport {
+    protected MyBean myBean = new MyBean();
+
+    @Test
+    public void testSendMessage() throws Exception {
+
+        String response = (String) template.requestBody("direct:in1", "<a><b>hello</b></a>");
+        assertEquals("HELLO", response);
+        
+        response = (String) template.requestBody("direct:in2", "<a><b>hello</b></a>");
+        assertEquals("HELLO", response);
+    }
+
+    @Override
+    protected Context createJndiContext() throws Exception {
+        JndiContext answer = new JndiContext();
+        answer.bind("myBean", myBean);
+        return answer;
+    }
+
+    protected RouteBuilder createRouteBuilder() {
+        return new RouteBuilder() {
+            public void configure() {
+                System.setProperty(XPathFactory.DEFAULT_PROPERTY_NAME + ":" + "http://saxon.sf.net/jaxp/xpath/om", "net.sf.saxon.xpath.XPathFactoryImpl");
+                from("direct:in1").beanRef("myBean", "readImplicit");
+                from("direct:in2").beanRef("myBean", "readExplicit");
+            }
+        };
+    }
+
+    public static class MyBean {
+        public String abText;
+
+        public String readImplicit(@XPath("upper-case(//a/b/text())") String abText) {
+            return abText;
+        }
+
+        public String readExplicit(@XPath(value = "upper-case(//a/b/text())", resultType = String.class) String abText) {
+            return abText;
+        }
+    }
+}

Propchange: camel/trunk/components/camel-saxon/src/test/java/org/apache/camel/builder/saxon/XPathAnnotationResultTypeTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/trunk/components/camel-saxon/src/test/java/org/apache/camel/component/xquery/SoapPayloadBean.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/trunk/components/camel-saxon/src/test/java/org/apache/camel/component/xquery/SoapPayloadBeanTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/trunk/components/camel-saxon/src/test/java/org/apache/camel/component/xquery/XQueryFromFileExceptionTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/trunk/components/camel-saxon/src/test/java/org/apache/camel/component/xquery/XQueryFromFileTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/trunk/components/camel-saxon/src/test/java/org/apache/camel/component/xquery/XQueryLanguageFromFileTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/trunk/components/camel-saxon/src/test/java/org/apache/camel/component/xquery/XQueryStripWhitespaceTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/trunk/components/camel-saxon/src/test/resources/payload.xml
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/trunk/components/camel-saxon/src/test/resources/payload.xml
------------------------------------------------------------------------------
    svn:mime-type = text/xml

Propchange: camel/trunk/components/camel-scala/
------------------------------------------------------------------------------
--- svn:ignore (original)
+++ svn:ignore Fri Dec  2 17:03:07 2011
@@ -1,10 +1,13 @@
-.project
 .pmd
 .checkstyle
-.classpath
+.ruleset
 target
 .settings
-eclipse-classes
-.manager
+.classpath
+.project
+.wtpmodules
+prj.el
+.jdee_classpath
+.jdee_sources
 velocity.log
-*.i??
+eclipse-classes

Propchange: camel/trunk/components/camel-script/
------------------------------------------------------------------------------
--- svn:ignore (original)
+++ svn:ignore Fri Dec  2 17:03:07 2011
@@ -1,8 +1,13 @@
-eclipse-classes
 .pmd
 .checkstyle
+.ruleset
 target
+.settings
 .classpath
 .project
-.settings
-*.i??
+.wtpmodules
+prj.el
+.jdee_classpath
+.jdee_sources
+velocity.log
+eclipse-classes

Propchange: camel/trunk/components/camel-script/src/main/java/org/apache/camel/builder/script/PropertiesFunction.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/trunk/components/camel-script/src/main/java/org/apache/camel/builder/script/ScriptPropertiesFunction.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/trunk/components/camel-script/src/test/java/org/apache/camel/builder/script/GroovyExpressionListMapTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/trunk/components/camel-script/src/test/java/org/apache/camel/builder/script/GroovyPropertiesFunctionTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/trunk/components/camel-script/src/test/java/org/apache/camel/builder/script/GroovySetHeaderPropertyComponentTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/trunk/components/camel-script/src/test/java/org/apache/camel/builder/script/JavaScriptPropertiesFunctionTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/trunk/components/camel-script/src/test/java/org/apache/camel/builder/script/ScriptBuilderTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/trunk/components/camel-script/src/test/java/org/apache/camel/builder/script/example/XPathFilterTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/trunk/components/camel-script/src/test/resources/org/apache/camel/builder/script/example/mygroovy.txt
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/trunk/components/camel-script/src/test/resources/org/apache/camel/builder/script/example/mygroovy.txt
------------------------------------------------------------------------------
    svn:mime-type = text/plain

Propchange: camel/trunk/components/camel-script/src/test/resources/org/apache/camel/builder/script/myproperties.properties
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/trunk/components/camel-script/src/test/resources/org/apache/camel/builder/script/myproperties.properties
------------------------------------------------------------------------------
    svn:mime-type = text/plain

Propchange: camel/trunk/components/camel-servlet/
------------------------------------------------------------------------------
--- svn:ignore (original)
+++ svn:ignore Fri Dec  2 17:03:07 2011
@@ -1,10 +1,13 @@
-.project
-.checkstyle
 .pmd
-.classpath
+.checkstyle
+.ruleset
 target
 .settings
+.classpath
+.project
+.wtpmodules
+prj.el
+.jdee_classpath
+.jdee_sources
+velocity.log
 eclipse-classes
-*.i??
-
-.springBeans

Modified: camel/trunk/components/camel-servlet/src/main/java/org/apache/camel/component/servlet/DefaultHttpRegistry.java
URL: http://svn.apache.org/viewvc/camel/trunk/components/camel-servlet/src/main/java/org/apache/camel/component/servlet/DefaultHttpRegistry.java?rev=1209585&r1=1209584&r2=1209585&view=diff
==============================================================================
--- camel/trunk/components/camel-servlet/src/main/java/org/apache/camel/component/servlet/DefaultHttpRegistry.java (original)
+++ camel/trunk/components/camel-servlet/src/main/java/org/apache/camel/component/servlet/DefaultHttpRegistry.java Fri Dec  2 17:03:07 2011
@@ -1,109 +1,109 @@
-/**
- * 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.component.servlet;
-
-import java.util.HashSet;
-import java.util.List;
-import java.util.Map;
-import java.util.Set;
-
-import javax.servlet.Servlet;
-
-import org.apache.camel.component.http.CamelServlet;
-import org.apache.camel.component.http.HttpConsumer;
-import org.slf4j.Logger;
-import org.slf4j.LoggerFactory;
-
-public class DefaultHttpRegistry implements HttpRegistry {
-    private static final transient Logger LOG = LoggerFactory.getLogger(DefaultHttpRegistry.class);
-
-    private static HttpRegistry singleton;
-    
-    private final Set<HttpConsumer> consumers;
-    private final Set<CamelServlet> providers;
-    
-    public DefaultHttpRegistry() {
-        consumers = new HashSet<HttpConsumer>();
-        providers = new HashSet<CamelServlet>();
-    }
-    
-    /**
-     * Lookup or create a HttpRegistry
-     */
-    public static synchronized HttpRegistry getSingletonHttpRegistry() {
-        if (singleton == null) {
-            singleton = new DefaultHttpRegistry();
-        }
-        return singleton;
-    }
-    
-    @Override
-    public void register(HttpConsumer consumer) {
-        LOG.debug("Registering consumer for path {} providers present: {}",
-                consumer.getPath(), providers.size());
-        consumers.add(consumer);
-        for (CamelServlet provider : providers) {
-            provider.connect(consumer);
-        }
-    }
-    
-    @Override
-    public void unregister(HttpConsumer consumer) {
-        LOG.debug("Unregistering consumer for path {} ", consumer.getPath());
-        consumers.remove(consumer);
-        for (CamelServlet provider : providers) {
-            provider.disconnect(consumer);
-        }
-    }
-    
-    @SuppressWarnings("rawtypes")
-    public void register(CamelServlet provider, Map properties) {
-        LOG.debug("Registering provider through OSGi service listener {}", properties);
-        CamelServlet camelServlet = (CamelServlet)provider;
-        camelServlet.setServletName((String) properties.get("servlet-name"));
-        register(camelServlet);
-    }
-
-    public void unregister(CamelServlet provider, Map<String, Object> properties) {
-        unregister((CamelServlet)provider);
-    }
-    
-    @Override
-    public void register(CamelServlet provider) {
-        LOG.debug("Registering CamelServlet with name {} consumers present: {}", 
-                provider.getServletName(), consumers.size());
-        providers.add(provider);
-        for (HttpConsumer consumer : consumers) {
-            provider.connect(consumer);
-        }
-    }
-
-    @Override
-    public void unregister(CamelServlet provider) {
-        providers.remove(provider);
-    }
-    
-    public void setServlets(List<Servlet> servlets) {
-        providers.clear();
-        for (Servlet servlet : servlets) {
-            if (servlet instanceof CamelServlet) {
-                providers.add((CamelServlet) servlet);
-            }
-        }
-    }
-
-}
+/**
+ * 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.component.servlet;
+
+import java.util.HashSet;
+import java.util.List;
+import java.util.Map;
+import java.util.Set;
+
+import javax.servlet.Servlet;
+
+import org.apache.camel.component.http.CamelServlet;
+import org.apache.camel.component.http.HttpConsumer;
+import org.slf4j.Logger;
+import org.slf4j.LoggerFactory;
+
+public class DefaultHttpRegistry implements HttpRegistry {
+    private static final transient Logger LOG = LoggerFactory.getLogger(DefaultHttpRegistry.class);
+
+    private static HttpRegistry singleton;
+    
+    private final Set<HttpConsumer> consumers;
+    private final Set<CamelServlet> providers;
+    
+    public DefaultHttpRegistry() {
+        consumers = new HashSet<HttpConsumer>();
+        providers = new HashSet<CamelServlet>();
+    }
+    
+    /**
+     * Lookup or create a HttpRegistry
+     */
+    public static synchronized HttpRegistry getSingletonHttpRegistry() {
+        if (singleton == null) {
+            singleton = new DefaultHttpRegistry();
+        }
+        return singleton;
+    }
+    
+    @Override
+    public void register(HttpConsumer consumer) {
+        LOG.debug("Registering consumer for path {} providers present: {}",
+                consumer.getPath(), providers.size());
+        consumers.add(consumer);
+        for (CamelServlet provider : providers) {
+            provider.connect(consumer);
+        }
+    }
+    
+    @Override
+    public void unregister(HttpConsumer consumer) {
+        LOG.debug("Unregistering consumer for path {} ", consumer.getPath());
+        consumers.remove(consumer);
+        for (CamelServlet provider : providers) {
+            provider.disconnect(consumer);
+        }
+    }
+    
+    @SuppressWarnings("rawtypes")
+    public void register(CamelServlet provider, Map properties) {
+        LOG.debug("Registering provider through OSGi service listener {}", properties);
+        CamelServlet camelServlet = (CamelServlet)provider;
+        camelServlet.setServletName((String) properties.get("servlet-name"));
+        register(camelServlet);
+    }
+
+    public void unregister(CamelServlet provider, Map<String, Object> properties) {
+        unregister((CamelServlet)provider);
+    }
+    
+    @Override
+    public void register(CamelServlet provider) {
+        LOG.debug("Registering CamelServlet with name {} consumers present: {}", 
+                provider.getServletName(), consumers.size());
+        providers.add(provider);
+        for (HttpConsumer consumer : consumers) {
+            provider.connect(consumer);
+        }
+    }
+
+    @Override
+    public void unregister(CamelServlet provider) {
+        providers.remove(provider);
+    }
+    
+    public void setServlets(List<Servlet> servlets) {
+        providers.clear();
+        for (Servlet servlet : servlets) {
+            if (servlet instanceof CamelServlet) {
+                providers.add((CamelServlet) servlet);
+            }
+        }
+    }
+
+}

Propchange: camel/trunk/components/camel-servlet/src/main/java/org/apache/camel/component/servlet/DefaultHttpRegistry.java
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: camel/trunk/components/camel-servlet/src/main/java/org/apache/camel/component/servlet/HttpRegistry.java
URL: http://svn.apache.org/viewvc/camel/trunk/components/camel-servlet/src/main/java/org/apache/camel/component/servlet/HttpRegistry.java?rev=1209585&r1=1209584&r2=1209585&view=diff
==============================================================================
--- camel/trunk/components/camel-servlet/src/main/java/org/apache/camel/component/servlet/HttpRegistry.java (original)
+++ camel/trunk/components/camel-servlet/src/main/java/org/apache/camel/component/servlet/HttpRegistry.java Fri Dec  2 17:03:07 2011
@@ -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.component.servlet;
-
-import org.apache.camel.component.http.CamelServlet;
-import org.apache.camel.component.http.HttpConsumer;
-
-/**
- * Keeps track of HttpConsumers and CamelServlets and 
- * connects them to each other. In OSGi there should
- * be one HttpRegistry per bundle.
- * 
- * A CamelServlet that should serve more than one
- * bundle should be registered as an OSGi service.
- * The HttpRegistryImpl can then be configured to listen
- * to service changes. See /tests/camel-itest-osgi/../servlet
- * for an example how to use this.
- */
-public interface HttpRegistry {
-
-    void register(HttpConsumer consumer);
-
-    void unregister(HttpConsumer consumer);
-
-    void register(CamelServlet provider);
-
-    void unregister(CamelServlet provider);
-
+/**
+ * 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.component.servlet;
+
+import org.apache.camel.component.http.CamelServlet;
+import org.apache.camel.component.http.HttpConsumer;
+
+/**
+ * Keeps track of HttpConsumers and CamelServlets and 
+ * connects them to each other. In OSGi there should
+ * be one HttpRegistry per bundle.
+ * 
+ * A CamelServlet that should serve more than one
+ * bundle should be registered as an OSGi service.
+ * The HttpRegistryImpl can then be configured to listen
+ * to service changes. See /tests/camel-itest-osgi/../servlet
+ * for an example how to use this.
+ */
+public interface HttpRegistry {
+
+    void register(HttpConsumer consumer);
+
+    void unregister(HttpConsumer consumer);
+
+    void register(CamelServlet provider);
+
+    void unregister(CamelServlet provider);
+
 }
\ No newline at end of file

Propchange: camel/trunk/components/camel-servlet/src/main/java/org/apache/camel/component/servlet/HttpRegistry.java
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: camel/trunk/components/camel-servlet/src/main/java/org/apache/camel/component/servlet/osgi/OsgiServletRegisterer.java
URL: http://svn.apache.org/viewvc/camel/trunk/components/camel-servlet/src/main/java/org/apache/camel/component/servlet/osgi/OsgiServletRegisterer.java?rev=1209585&r1=1209584&r2=1209585&view=diff
==============================================================================
--- camel/trunk/components/camel-servlet/src/main/java/org/apache/camel/component/servlet/osgi/OsgiServletRegisterer.java (original)
+++ camel/trunk/components/camel-servlet/src/main/java/org/apache/camel/component/servlet/osgi/OsgiServletRegisterer.java Fri Dec  2 17:03:07 2011
@@ -1,96 +1,96 @@
-/**
- * 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.component.servlet.osgi;
-
-import java.util.Dictionary;
-import java.util.Hashtable;
-import javax.servlet.http.HttpServlet;
-
-import org.osgi.service.http.HttpContext;
-import org.osgi.service.http.HttpService;
-
-/**
- * Register the given (CamelHttpTransport) Servlet with the OSGI 
- * <a href="http://www.osgi.org/javadoc/r4v42/org/osgi/service/http/HttpService.html">
- * HttpService</a>
- * 
- * See src/test/resources/osgiservletregisterer.xml
- */
-public class OsgiServletRegisterer {
-
-    /**
-     * The alias is the name in the URI namespace of the Http Service at which the registration will be mapped
-     * An alias must begin with slash ('/') and must not end with slash ('/'), with the exception that an alias 
-     * of the form "/" is used to denote the root alias.
-     */
-    private String alias;
-    
-    private String servletName;
-
-    /**
-     * Servlet to be registered
-     */
-    private HttpServlet servlet;
-    
-    /**
-     * HttpService to register with. Get this with osgi:reference in the spring
-     * context
-     */
-    private HttpService httpService;
-    
-    private HttpContext httpContext;
-    
-    private boolean alreadyRegistered;
-    
-    public void setHttpService(HttpService httpService) {
-        this.httpService = httpService;
-    }
-    public void setAlias(String alias) {
-        this.alias = alias;
-    }
-
-    public void setServletName(String servletName) {
-        this.servletName = servletName;
-    }
-    public void setServlet(HttpServlet servlet) {
-        this.servlet = servlet;
-    }
-    
-    public void setHttpContext(HttpContext httpContext) {
-        this.httpContext = httpContext;
-    }
- 
-    public void register() throws Exception {
-        HttpContext actualHttpContext = (httpContext == null) 
-            ? httpService.createDefaultHttpContext()
-            : httpContext;
-        final Dictionary<String, String> initParams = new Hashtable<String, String>();
-        // The servlet will always have to match on uri prefix as some endpoints may do so
-        initParams.put("matchOnUriPrefix", "true");
-        initParams.put("servlet-name", servletName);
-        httpService.registerServlet(alias, servlet, initParams, actualHttpContext);
-        alreadyRegistered = true;
-    }
- 
-    public void unregister() {
-        if (alreadyRegistered) {
-            httpService.unregister(alias);
-            alreadyRegistered = false;
-        }
-    }
-
-}
+/**
+ * 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.component.servlet.osgi;
+
+import java.util.Dictionary;
+import java.util.Hashtable;
+import javax.servlet.http.HttpServlet;
+
+import org.osgi.service.http.HttpContext;
+import org.osgi.service.http.HttpService;
+
+/**
+ * Register the given (CamelHttpTransport) Servlet with the OSGI 
+ * <a href="http://www.osgi.org/javadoc/r4v42/org/osgi/service/http/HttpService.html">
+ * HttpService</a>
+ * 
+ * See src/test/resources/osgiservletregisterer.xml
+ */
+public class OsgiServletRegisterer {
+
+    /**
+     * The alias is the name in the URI namespace of the Http Service at which the registration will be mapped
+     * An alias must begin with slash ('/') and must not end with slash ('/'), with the exception that an alias 
+     * of the form "/" is used to denote the root alias.
+     */
+    private String alias;
+    
+    private String servletName;
+
+    /**
+     * Servlet to be registered
+     */
+    private HttpServlet servlet;
+    
+    /**
+     * HttpService to register with. Get this with osgi:reference in the spring
+     * context
+     */
+    private HttpService httpService;
+    
+    private HttpContext httpContext;
+    
+    private boolean alreadyRegistered;
+    
+    public void setHttpService(HttpService httpService) {
+        this.httpService = httpService;
+    }
+    public void setAlias(String alias) {
+        this.alias = alias;
+    }
+
+    public void setServletName(String servletName) {
+        this.servletName = servletName;
+    }
+    public void setServlet(HttpServlet servlet) {
+        this.servlet = servlet;
+    }
+    
+    public void setHttpContext(HttpContext httpContext) {
+        this.httpContext = httpContext;
+    }
+ 
+    public void register() throws Exception {
+        HttpContext actualHttpContext = (httpContext == null) 
+            ? httpService.createDefaultHttpContext()
+            : httpContext;
+        final Dictionary<String, String> initParams = new Hashtable<String, String>();
+        // The servlet will always have to match on uri prefix as some endpoints may do so
+        initParams.put("matchOnUriPrefix", "true");
+        initParams.put("servlet-name", servletName);
+        httpService.registerServlet(alias, servlet, initParams, actualHttpContext);
+        alreadyRegistered = true;
+    }
+ 
+    public void unregister() {
+        if (alreadyRegistered) {
+            httpService.unregister(alias);
+            alreadyRegistered = false;
+        }
+    }
+
+}

Propchange: camel/trunk/components/camel-servlet/src/main/java/org/apache/camel/component/servlet/osgi/OsgiServletRegisterer.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/trunk/components/camel-servlet/src/test/java/org/apache/camel/component/servlet/ServletTransferExceptionTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: camel/trunk/components/camel-servlet/src/test/resources/org/apache/camel/component/servlet/osgiservletregisterer.xml
URL: http://svn.apache.org/viewvc/camel/trunk/components/camel-servlet/src/test/resources/org/apache/camel/component/servlet/osgiservletregisterer.xml?rev=1209585&r1=1209584&r2=1209585&view=diff
==============================================================================
--- camel/trunk/components/camel-servlet/src/test/resources/org/apache/camel/component/servlet/osgiservletregisterer.xml (original)
+++ camel/trunk/components/camel-servlet/src/test/resources/org/apache/camel/component/servlet/osgiservletregisterer.xml Fri Dec  2 17:03:07 2011
@@ -1,36 +1,36 @@
-<!--
-  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.
--->
-<!-- Example how to configure a CamelServlet in OSGi without using an Activator -->
-<beans xmlns="http://www.springframework.org/schema/beans"
-	xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xmlns:camel="http://camel.apache.org/schema/spring"
-	xmlns:osgi="http://www.springframework.org/schema/osgi"
-	xsi:schemaLocation="http://www.springframework.org/schema/beans http://www.springframework.org/schema/beans/spring-beans.xsd http://camel.apache.org/schema/spring http://camel.apache.org/schema/spring/camel-spring.xsd ">
-
-	<osgi:reference id="httpService" interface="org.osgi.service.http.HttpService" />
-	
-	<bean id="camelServlet" class="org.apache.camel.component.servlet.CamelHttpTransportServlet"/>
-
-	<bean class="org.apache.camel.component.servlet.osgi.OsgiServletRegisterer"
-		init-method="register"
-		destroy-method="unregister">
-		<property name="alias" value="alias" />
-		<property name="httpService" ref="httpService" />
-		<property name="servlet" ref="camelServlet" />
-	</bean>
-</beans>
+<!--
+  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.
+-->
+<!-- Example how to configure a CamelServlet in OSGi without using an Activator -->
+<beans xmlns="http://www.springframework.org/schema/beans"
+	xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xmlns:camel="http://camel.apache.org/schema/spring"
+	xmlns:osgi="http://www.springframework.org/schema/osgi"
+	xsi:schemaLocation="http://www.springframework.org/schema/beans http://www.springframework.org/schema/beans/spring-beans.xsd http://camel.apache.org/schema/spring http://camel.apache.org/schema/spring/camel-spring.xsd ">
+
+	<osgi:reference id="httpService" interface="org.osgi.service.http.HttpService" />
+	
+	<bean id="camelServlet" class="org.apache.camel.component.servlet.CamelHttpTransportServlet"/>
+
+	<bean class="org.apache.camel.component.servlet.osgi.OsgiServletRegisterer"
+		init-method="register"
+		destroy-method="unregister">
+		<property name="alias" value="alias" />
+		<property name="httpService" ref="httpService" />
+		<property name="servlet" ref="camelServlet" />
+	</bean>
+</beans>

Propchange: camel/trunk/components/camel-servlet/src/test/resources/org/apache/camel/component/servlet/osgiservletregisterer.xml
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/trunk/components/camel-servlet/src/test/resources/org/apache/camel/component/servlet/osgiservletregisterer.xml
------------------------------------------------------------------------------
    svn:mime-type = text/xml

Propchange: camel/trunk/components/camel-shiro/
------------------------------------------------------------------------------
--- svn:ignore (original)
+++ svn:ignore Fri Dec  2 17:03:07 2011
@@ -1,9 +1,13 @@
-.project
-.checkstyle
 .pmd
-.classpath
+.checkstyle
+.ruleset
 target
 .settings
+.classpath
+.project
+.wtpmodules
+prj.el
+.jdee_classpath
+.jdee_sources
+velocity.log
 eclipse-classes
-*.i??
-classes

Propchange: camel/trunk/components/camel-shiro/pom.xml
------------------------------------------------------------------------------
    svn:mime-type = text/xml

Propchange: camel/trunk/components/camel-shiro/src/main/resources/META-INF/LICENSE.txt
------------------------------------------------------------------------------
    svn:mime-type = text/plain

Propchange: camel/trunk/components/camel-shiro/src/main/resources/META-INF/NOTICE.txt
------------------------------------------------------------------------------
    svn:mime-type = text/plain

Propchange: camel/trunk/components/camel-shiro/src/test/resources/log4j.properties
------------------------------------------------------------------------------
    svn:mime-type = text/plain

Propchange: camel/trunk/components/camel-sip/
------------------------------------------------------------------------------
--- svn:ignore (original)
+++ svn:ignore Fri Dec  2 17:03:07 2011
@@ -1,9 +1,13 @@
-.project
-.checkstyle
 .pmd
-.classpath
+.checkstyle
+.ruleset
 target
 .settings
+.classpath
+.project
+.wtpmodules
+prj.el
+.jdee_classpath
+.jdee_sources
+velocity.log
 eclipse-classes
-*.i??
-classes

Propchange: camel/trunk/components/camel-sip/pom.xml
------------------------------------------------------------------------------
    svn:mime-type = text/xml

Propchange: camel/trunk/components/camel-smpp/
------------------------------------------------------------------------------
--- svn:ignore (original)
+++ svn:ignore Fri Dec  2 17:03:07 2011
@@ -1,9 +1,13 @@
-.project
-.checkstyle
 .pmd
-.classpath
+.checkstyle
+.ruleset
 target
 .settings
+.classpath
+.project
+.wtpmodules
+prj.el
+.jdee_classpath
+.jdee_sources
+velocity.log
 eclipse-classes
-*.i??
-

Propchange: camel/trunk/components/camel-smpp/src/main/java/org/apache/camel/component/smpp/AbstractSmppCommand.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/trunk/components/camel-smpp/src/main/java/org/apache/camel/component/smpp/MessageReceiverListenerImpl.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/trunk/components/camel-smpp/src/main/java/org/apache/camel/component/smpp/Smpp8BitSplitter.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/trunk/components/camel-smpp/src/main/java/org/apache/camel/component/smpp/SmppCancelSmCommand.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/trunk/components/camel-smpp/src/main/java/org/apache/camel/component/smpp/SmppCommand.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/trunk/components/camel-smpp/src/main/java/org/apache/camel/component/smpp/SmppCommandType.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/trunk/components/camel-smpp/src/main/java/org/apache/camel/component/smpp/SmppConstants.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/trunk/components/camel-smpp/src/main/java/org/apache/camel/component/smpp/SmppDataSmCommand.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/trunk/components/camel-smpp/src/main/java/org/apache/camel/component/smpp/SmppDefaultSplitter.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/trunk/components/camel-smpp/src/main/java/org/apache/camel/component/smpp/SmppException.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/trunk/components/camel-smpp/src/main/java/org/apache/camel/component/smpp/SmppMessageType.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/trunk/components/camel-smpp/src/main/java/org/apache/camel/component/smpp/SmppQuerySmCommand.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/trunk/components/camel-smpp/src/main/java/org/apache/camel/component/smpp/SmppReplaceSmCommand.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/trunk/components/camel-smpp/src/main/java/org/apache/camel/component/smpp/SmppSmCommand.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/trunk/components/camel-smpp/src/main/java/org/apache/camel/component/smpp/SmppSplitter.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/trunk/components/camel-smpp/src/main/java/org/apache/camel/component/smpp/SmppSubmitMultiCommand.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/trunk/components/camel-smpp/src/main/java/org/apache/camel/component/smpp/SmppSubmitSmCommand.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/trunk/components/camel-smpp/src/main/java/org/apache/camel/component/smpp/SmppUcs2Splitter.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/trunk/components/camel-smpp/src/main/java/org/apache/camel/component/smpp/SmppUtils.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/trunk/components/camel-smpp/src/test/java/org/apache/camel/component/smpp/AbstractSmppCommandTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/trunk/components/camel-smpp/src/test/java/org/apache/camel/component/smpp/MessageReceiverListenerImplTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/trunk/components/camel-smpp/src/test/java/org/apache/camel/component/smpp/Smpp8BitSplitterTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/trunk/components/camel-smpp/src/test/java/org/apache/camel/component/smpp/SmppCancelSmCommandTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/trunk/components/camel-smpp/src/test/java/org/apache/camel/component/smpp/SmppCommandTypeTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/trunk/components/camel-smpp/src/test/java/org/apache/camel/component/smpp/SmppDefaultSplitterTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/trunk/components/camel-smpp/src/test/java/org/apache/camel/component/smpp/SmppProducerLazySessionCreationTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/trunk/components/camel-smpp/src/test/java/org/apache/camel/component/smpp/SmppQuerySmCommandTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/trunk/components/camel-smpp/src/test/java/org/apache/camel/component/smpp/SmppReplaceSmCommandTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/trunk/components/camel-smpp/src/test/java/org/apache/camel/component/smpp/SmppSplitterTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/trunk/components/camel-smpp/src/test/java/org/apache/camel/component/smpp/SmppSubmitMultiCommandTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/trunk/components/camel-smpp/src/test/java/org/apache/camel/component/smpp/SmppSubmitSmCommandTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/trunk/components/camel-smpp/src/test/java/org/apache/camel/component/smpp/SmppUcs2SplitterTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/trunk/components/camel-smpp/src/test/java/org/apache/camel/component/smpp/SmppUtilsTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/trunk/components/camel-snmp/
------------------------------------------------------------------------------
--- svn:ignore (original)
+++ svn:ignore Fri Dec  2 17:03:07 2011
@@ -1,9 +1,13 @@
-.project
-.checkstyle
 .pmd
-.classpath
+.checkstyle
+.ruleset
 target
 .settings
+.classpath
+.project
+.wtpmodules
+prj.el
+.jdee_classpath
+.jdee_sources
+velocity.log
 eclipse-classes
-*.i??
-classes

Propchange: camel/trunk/components/camel-soap/
------------------------------------------------------------------------------
--- svn:ignore (original)
+++ svn:ignore Fri Dec  2 17:03:07 2011
@@ -1,8 +1,13 @@
-target
 .pmd
 .checkstyle
+.ruleset
+target
+.settings
 .classpath
 .project
+.wtpmodules
+prj.el
+.jdee_classpath
+.jdee_sources
+velocity.log
 eclipse-classes
-.settings
-*.i??

Propchange: camel/trunk/components/camel-solr/
------------------------------------------------------------------------------
--- svn:ignore (original)
+++ svn:ignore Fri Dec  2 17:03:07 2011
@@ -1,9 +1,13 @@
-.project
-.checkstyle
 .pmd
-.classpath
+.checkstyle
+.ruleset
 target
 .settings
+.classpath
+.project
+.wtpmodules
+prj.el
+.jdee_classpath
+.jdee_sources
+velocity.log
 eclipse-classes
-*.i??
-classes

Modified: camel/trunk/components/camel-solr/pom.xml
URL: http://svn.apache.org/viewvc/camel/trunk/components/camel-solr/pom.xml?rev=1209585&r1=1209584&r2=1209585&view=diff
==============================================================================
--- camel/trunk/components/camel-solr/pom.xml (original)
+++ camel/trunk/components/camel-solr/pom.xml Fri Dec  2 17:03:07 2011
@@ -1,130 +1,130 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<!--
-
-    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.
-
--->
-<project xmlns="http://maven.apache.org/POM/4.0.0"
-         xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
-         xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/maven-v4_0_0.xsd">
-
-    <modelVersion>4.0.0</modelVersion>
-
-  <parent>
-    <artifactId>components</artifactId>
-    <groupId>org.apache.camel</groupId>
-    <version>2.9-SNAPSHOT</version>
-  </parent>
-
-  <groupId>org.apache.camel</groupId>
-  <artifactId>camel-solr</artifactId>
-  <packaging>bundle</packaging>
-  <name>Camel :: Solr</name>
-  <description>Camel Solr Support</description>
-
-    <properties>
-        <camel.osgi.export.pkg>
-            org.apache.camel.component.solr.*;${camel.osgi.version}
-        </camel.osgi.export.pkg>
-    </properties>
-
-    <dependencies>
-        <dependency>
-            <groupId>org.apache.camel</groupId>
-            <artifactId>camel-core</artifactId>
-        </dependency>
-
-        <dependency>
-            <groupId>org.apache.solr</groupId>
-            <artifactId>solr-solrj</artifactId>
-            <version>${solr-version}</version>
-        </dependency>
-
-        <!-- testing -->
-        <dependency>
-            <groupId>org.apache.camel</groupId>
-            <artifactId>camel-test</artifactId>
-            <scope>test</scope>
-        </dependency>
-
-        <dependency>
-            <groupId>org.apache.solr</groupId>
-            <artifactId>solr-core</artifactId>
-            <version>${solr-version}</version>
-            <scope>test</scope>
-          <exclusions>
-            <!-- exclude jdk14 as we want to use log4j -->
-            <exclusion>
-              <groupId>org.slf4j</groupId>
-              <artifactId>slf4j-jdk14</artifactId>
-            </exclusion>
-          </exclusions>
-        </dependency>
-
-        <dependency>
-            <groupId>org.apache.solr</groupId>
-            <artifactId>solr-cell</artifactId>
-            <version>${solr-version}</version>
-            <scope>test</scope>
-            <exclusions>
-              <!-- exclude netcdf as it has a slf4j binding -->
-              <exclusion>
-                <groupId>edu.ucar</groupId>
-                <artifactId>netcdf</artifactId>
-              </exclusion>
-            </exclusions>
-        </dependency>
-
-        <dependency>
-            <groupId>org.mortbay.jetty</groupId>
-            <artifactId>jetty</artifactId>
-            <version>6.1.24</version>
-            <scope>test</scope>
-        </dependency>
-
-        <dependency>
-            <groupId>org.springframework</groupId>
-            <artifactId>spring-test</artifactId>
-            <scope>test</scope>
-        </dependency>
-
-        <dependency>
-            <groupId>org.apache.camel</groupId>
-            <artifactId>camel-jms</artifactId>
-            <scope>test</scope>
-        </dependency>
-
-        <dependency>
-            <groupId>org.apache.camel</groupId>
-            <artifactId>camel-script</artifactId>
-            <scope>test</scope>
-        </dependency>
-
-        <dependency>
-            <groupId>org.codehaus.groovy</groupId>
-            <artifactId>groovy-all</artifactId>
-            <scope>test</scope>
-        </dependency>
-
-        <!-- logging -->
-        <dependency>
-          <groupId>org.slf4j</groupId>
-          <artifactId>slf4j-log4j12</artifactId>
-          <scope>test</scope>
-        </dependency>
-
-    </dependencies>
-</project>
+<?xml version="1.0" encoding="UTF-8"?>
+<!--
+
+    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.
+
+-->
+<project xmlns="http://maven.apache.org/POM/4.0.0"
+         xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
+         xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/maven-v4_0_0.xsd">
+
+    <modelVersion>4.0.0</modelVersion>
+
+  <parent>
+    <artifactId>components</artifactId>
+    <groupId>org.apache.camel</groupId>
+    <version>2.9-SNAPSHOT</version>
+  </parent>
+
+  <groupId>org.apache.camel</groupId>
+  <artifactId>camel-solr</artifactId>
+  <packaging>bundle</packaging>
+  <name>Camel :: Solr</name>
+  <description>Camel Solr Support</description>
+
+    <properties>
+        <camel.osgi.export.pkg>
+            org.apache.camel.component.solr.*;${camel.osgi.version}
+        </camel.osgi.export.pkg>
+    </properties>
+
+    <dependencies>
+        <dependency>
+            <groupId>org.apache.camel</groupId>
+            <artifactId>camel-core</artifactId>
+        </dependency>
+
+        <dependency>
+            <groupId>org.apache.solr</groupId>
+            <artifactId>solr-solrj</artifactId>
+            <version>${solr-version}</version>
+        </dependency>
+
+        <!-- testing -->
+        <dependency>
+            <groupId>org.apache.camel</groupId>
+            <artifactId>camel-test</artifactId>
+            <scope>test</scope>
+        </dependency>
+
+        <dependency>
+            <groupId>org.apache.solr</groupId>
+            <artifactId>solr-core</artifactId>
+            <version>${solr-version}</version>
+            <scope>test</scope>
+          <exclusions>
+            <!-- exclude jdk14 as we want to use log4j -->
+            <exclusion>
+              <groupId>org.slf4j</groupId>
+              <artifactId>slf4j-jdk14</artifactId>
+            </exclusion>
+          </exclusions>
+        </dependency>
+
+        <dependency>
+            <groupId>org.apache.solr</groupId>
+            <artifactId>solr-cell</artifactId>
+            <version>${solr-version}</version>
+            <scope>test</scope>
+            <exclusions>
+              <!-- exclude netcdf as it has a slf4j binding -->
+              <exclusion>
+                <groupId>edu.ucar</groupId>
+                <artifactId>netcdf</artifactId>
+              </exclusion>
+            </exclusions>
+        </dependency>
+
+        <dependency>
+            <groupId>org.mortbay.jetty</groupId>
+            <artifactId>jetty</artifactId>
+            <version>6.1.24</version>
+            <scope>test</scope>
+        </dependency>
+
+        <dependency>
+            <groupId>org.springframework</groupId>
+            <artifactId>spring-test</artifactId>
+            <scope>test</scope>
+        </dependency>
+
+        <dependency>
+            <groupId>org.apache.camel</groupId>
+            <artifactId>camel-jms</artifactId>
+            <scope>test</scope>
+        </dependency>
+
+        <dependency>
+            <groupId>org.apache.camel</groupId>
+            <artifactId>camel-script</artifactId>
+            <scope>test</scope>
+        </dependency>
+
+        <dependency>
+            <groupId>org.codehaus.groovy</groupId>
+            <artifactId>groovy-all</artifactId>
+            <scope>test</scope>
+        </dependency>
+
+        <!-- logging -->
+        <dependency>
+          <groupId>org.slf4j</groupId>
+          <artifactId>slf4j-log4j12</artifactId>
+          <scope>test</scope>
+        </dependency>
+
+    </dependencies>
+</project>

Propchange: camel/trunk/components/camel-solr/pom.xml
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/trunk/components/camel-solr/pom.xml
------------------------------------------------------------------------------
    svn:mime-type = text/xml