You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@camel.apache.org by ha...@apache.org on 2008/12/03 06:48:12 UTC

svn commit: r722785 - in /activemq/camel/trunk: ./ components/ components/camel-cometd/ components/camel-cometd/src/ components/camel-cometd/src/main/ components/camel-cometd/src/main/java/ components/camel-cometd/src/main/java/org/ components/camel-co...

Author: hadrian
Date: Tue Dec  2 21:48:10 2008
New Revision: 722785

URL: http://svn.apache.org/viewvc?rev=722785&view=rev
Log:
CAMEL-982.  Patch applied with many thanks!

Added:
    activemq/camel/trunk/components/camel-cometd/
    activemq/camel/trunk/components/camel-cometd/README.txt
    activemq/camel/trunk/components/camel-cometd/pom.xml
    activemq/camel/trunk/components/camel-cometd/src/
    activemq/camel/trunk/components/camel-cometd/src/main/
    activemq/camel/trunk/components/camel-cometd/src/main/java/
    activemq/camel/trunk/components/camel-cometd/src/main/java/org/
    activemq/camel/trunk/components/camel-cometd/src/main/java/org/apache/
    activemq/camel/trunk/components/camel-cometd/src/main/java/org/apache/camel/
    activemq/camel/trunk/components/camel-cometd/src/main/java/org/apache/camel/component/
    activemq/camel/trunk/components/camel-cometd/src/main/java/org/apache/camel/component/cometd/
    activemq/camel/trunk/components/camel-cometd/src/main/java/org/apache/camel/component/cometd/CometdComponent.java
    activemq/camel/trunk/components/camel-cometd/src/main/java/org/apache/camel/component/cometd/CometdConsumer.java
    activemq/camel/trunk/components/camel-cometd/src/main/java/org/apache/camel/component/cometd/CometdConverters.java
    activemq/camel/trunk/components/camel-cometd/src/main/java/org/apache/camel/component/cometd/CometdEndpoint.java
    activemq/camel/trunk/components/camel-cometd/src/main/java/org/apache/camel/component/cometd/CometdProducer.java
    activemq/camel/trunk/components/camel-cometd/src/main/java/org/apache/camel/component/cometd/CometdProducerConsumer.java
    activemq/camel/trunk/components/camel-cometd/src/main/java/org/apache/camel/component/cometd/CometdProducerConsumerInteractiveTest.java
    activemq/camel/trunk/components/camel-cometd/src/main/resources/
    activemq/camel/trunk/components/camel-cometd/src/main/resources/META-INF/
    activemq/camel/trunk/components/camel-cometd/src/main/resources/META-INF/services/
    activemq/camel/trunk/components/camel-cometd/src/main/resources/META-INF/services/org/
    activemq/camel/trunk/components/camel-cometd/src/main/resources/META-INF/services/org/apache/
    activemq/camel/trunk/components/camel-cometd/src/main/resources/META-INF/services/org/apache/camel/
    activemq/camel/trunk/components/camel-cometd/src/main/resources/META-INF/services/org/apache/camel/component/
    activemq/camel/trunk/components/camel-cometd/src/main/resources/META-INF/services/org/apache/camel/component/cometd
    activemq/camel/trunk/components/camel-cometd/src/main/resources/META-INF/services/org/apache/camel/component/cometds
    activemq/camel/trunk/components/camel-cometd/src/test/
    activemq/camel/trunk/components/camel-cometd/src/test/java/
    activemq/camel/trunk/components/camel-cometd/src/test/java/org/
    activemq/camel/trunk/components/camel-cometd/src/test/java/org/apache/
    activemq/camel/trunk/components/camel-cometd/src/test/java/org/apache/camel/
    activemq/camel/trunk/components/camel-cometd/src/test/java/org/apache/camel/component/
    activemq/camel/trunk/components/camel-cometd/src/test/java/org/apache/camel/component/cometd/
    activemq/camel/trunk/components/camel-cometd/src/test/java/org/apache/camel/component/cometd/CometdProducerConsumerTest.java
    activemq/camel/trunk/components/camel-cometd/src/test/java/org/apache/camel/component/cometd/SslCometdProducerConsumerTest.java
    activemq/camel/trunk/components/camel-cometd/src/test/resources/
    activemq/camel/trunk/components/camel-cometd/src/test/resources/jsse/
    activemq/camel/trunk/components/camel-cometd/src/test/resources/jsse/localhost.ks   (with props)
    activemq/camel/trunk/components/camel-cometd/src/test/resources/log4j.properties
Modified:
    activemq/camel/trunk/components/pom.xml
    activemq/camel/trunk/pom.xml

Added: activemq/camel/trunk/components/camel-cometd/README.txt
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/components/camel-cometd/README.txt?rev=722785&view=auto
==============================================================================
--- activemq/camel/trunk/components/camel-cometd/README.txt (added)
+++ activemq/camel/trunk/components/camel-cometd/README.txt Tue Dec  2 21:48:10 2008
@@ -0,0 +1,6 @@
+There is a simple demo showing the usage of this component:
+1) Under the shell just type: mvn exec:java
+2) Point your browser to http://localhost:8080
+
+then under the shell console start type something followed by <enter>, you'll see what you are typing into the browser.
+This simple demo is under: src/main/java/org/apache/camel/component/cometd/CometdProducerConsumerInteractiveTest.java

Added: activemq/camel/trunk/components/camel-cometd/pom.xml
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/components/camel-cometd/pom.xml?rev=722785&view=auto
==============================================================================
--- activemq/camel/trunk/components/camel-cometd/pom.xml (added)
+++ activemq/camel/trunk/components/camel-cometd/pom.xml Tue Dec  2 21:48:10 2008
@@ -0,0 +1,85 @@
+<?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>
+        <groupId>org.apache.camel</groupId>
+        <artifactId>camel-parent</artifactId>
+        <version>2.0-SNAPSHOT</version>
+    </parent>
+
+    <artifactId>camel-cometd</artifactId>
+    <packaging>bundle</packaging>
+    <name>Camel :: Cometd</name>
+    <description>Camel Cometd support</description>
+
+    <properties>
+        <camel.osgi.export.pkg>org.apache.camel.component.cometd.*</camel.osgi.export.pkg>
+    </properties>
+
+    <dependencies>
+        <dependency>
+            <groupId>org.apache.camel</groupId>
+            <artifactId>camel-core</artifactId>
+        </dependency>
+        <dependency>
+            <groupId>org.apache.camel</groupId>
+            <artifactId>camel-stream</artifactId>
+        </dependency>
+        <dependency>
+            <groupId>org.mortbay.jetty</groupId>
+            <artifactId>jetty</artifactId>
+        </dependency>
+        <dependency>
+            <groupId>org.mortbay.jetty</groupId>
+            <artifactId>cometd-bayeux</artifactId>
+            <version>${cometd-bayeux-version}</version>
+        </dependency>
+
+        <!-- Test Dependencies -->
+        <dependency>
+            <groupId>org.apache.camel</groupId>
+            <artifactId>camel-core</artifactId>
+            <type>test-jar</type>
+            <scope>test</scope>
+        </dependency>
+        <dependency>
+            <groupId>junit</groupId>
+            <artifactId>junit</artifactId>
+            <scope>test</scope>
+        </dependency>
+    </dependencies>
+
+    <build>
+        <defaultGoal>install</defaultGoal>
+
+        <plugins>
+            <plugin>
+                <groupId>org.codehaus.mojo</groupId>
+                <artifactId>exec-maven-plugin</artifactId>
+                <configuration>
+                    <mainClass>org.apache.camel.component.cometd.CometdProducerConsumerInteractiveTest</mainClass>
+                    <includePluginDependencies>false</includePluginDependencies>
+                </configuration>
+            </plugin>
+        </plugins>
+    </build>
+</project>

Added: activemq/camel/trunk/components/camel-cometd/src/main/java/org/apache/camel/component/cometd/CometdComponent.java
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/components/camel-cometd/src/main/java/org/apache/camel/component/cometd/CometdComponent.java?rev=722785&view=auto
==============================================================================
--- activemq/camel/trunk/components/camel-cometd/src/main/java/org/apache/camel/component/cometd/CometdComponent.java (added)
+++ activemq/camel/trunk/components/camel-cometd/src/main/java/org/apache/camel/component/cometd/CometdComponent.java Tue Dec  2 21:48:10 2008
@@ -0,0 +1,253 @@
+/**
+ * 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.cometd;
+
+import java.util.HashMap;
+import java.util.Map;
+
+import org.apache.camel.Endpoint;
+import org.apache.camel.impl.DefaultComponent;
+import org.apache.commons.logging.Log;
+import org.apache.commons.logging.LogFactory;
+import org.mortbay.cometd.AbstractBayeux;
+import org.mortbay.cometd.continuation.ContinuationCometdServlet;
+import org.mortbay.jetty.Connector;
+import org.mortbay.jetty.Server;
+import org.mortbay.jetty.handler.ContextHandlerCollection;
+import org.mortbay.jetty.nio.SelectChannelConnector;
+import org.mortbay.jetty.security.SslSocketConnector;
+import org.mortbay.jetty.servlet.Context;
+import org.mortbay.jetty.servlet.ServletHolder;
+
+/**
+ * Component for Jetty Cometd
+ * 
+ * @version $Revision:520964 $
+ */
+public class CometdComponent extends DefaultComponent {
+    private static final transient Log LOG = LogFactory.getLog(CometdComponent.class);
+
+    private HashMap<String, ConnectorRef> connectors = new HashMap<String, ConnectorRef>();
+
+    private Server server;
+    private String sslKeyPassword;
+    private String sslPassword;
+    private String sslKeystore;
+    private SslSocketConnector sslSocketConnector;
+
+    class ConnectorRef {
+        Connector connector;
+        ContinuationCometdServlet servlet;
+        int refCount;
+
+        public ConnectorRef(Connector connector,
+                ContinuationCometdServlet servlet) {
+            this.connector = connector;
+            this.servlet = servlet;
+            increment();
+        }
+
+        public int increment() {
+            return ++refCount;
+        }
+
+        public int decrement() {
+            return --refCount;
+        }
+    }
+
+    public CometdComponent() {
+    }
+
+    @SuppressWarnings("unchecked")
+    @Override
+    protected Endpoint createEndpoint(String uri, String remaining,
+            Map parameters) throws Exception {
+        setProperties(this, parameters);
+        CometdEndpoint endpoint = new CometdEndpoint(this, uri, remaining,
+                parameters);
+        return endpoint;
+    }
+
+    /**
+     * Connects the URL specified on the endpoint to the specified processor.
+     * 
+     * @throws Exception
+     */
+    public void connect(CometdProducerConsumer prodcon) throws Exception {
+        // Make sure that there is a connector for the requested endpoint.
+        CometdEndpoint endpoint = (CometdEndpoint) prodcon.getEndpoint();
+        String connectorKey = endpoint.getProtocol() + ":" + endpoint.getUri().getHost() + ":" + endpoint.getPort();
+
+        synchronized (connectors) {
+            ConnectorRef connectorRef = connectors.get(connectorKey);
+            if (connectorRef == null) {
+                Connector connector;
+                if ("cometds".equals(endpoint.getProtocol())) {
+                    connector = getSslSocketConnector();
+                } else {
+                    connector = new SelectChannelConnector();
+                }
+                connector.setPort(endpoint.getPort());
+                connector.setHost(endpoint.getUri().getHost());
+                if ("localhost".equalsIgnoreCase(endpoint.getUri().getHost())) {
+                    LOG.warn("You use localhost interface! It means that no external connections will be available." + 
+                            " Don't you want to use 0.0.0.0 instead (all network interfaces)?");
+                }
+                getServer().addConnector(connector);
+
+                ContinuationCometdServlet servlet = createServletForConnector(connector, endpoint);
+                connectorRef = new ConnectorRef(connector, servlet);
+                connector.start();
+
+                connectors.put(connectorKey, connectorRef);
+            } else {
+                connectorRef.increment();
+            }
+            AbstractBayeux bayeux = connectorRef.servlet.getBayeux();
+            bayeux.setJSONCommented(endpoint.isJsonCommented());
+            prodcon.setBayeux(bayeux);
+        }
+    }
+
+    /**
+     * Disconnects the URL specified on the endpoint from the specified
+     * processor.
+     */
+    public void disconnect(CometdProducerConsumer prodcon) throws Exception {
+        CometdEndpoint endpoint = (CometdEndpoint) prodcon.getEndpoint();
+
+        String connectorKey = endpoint.getProtocol() + ":" + endpoint.getUri().getHost() + ":" + endpoint.getPort();
+
+        synchronized (connectors) {
+            ConnectorRef connectorRef = connectors.get(connectorKey);
+            if (connectorRef != null) {
+                if (connectorRef.decrement() == 0) {
+                    getServer().removeConnector(connectorRef.connector);
+                    connectorRef.connector.stop();
+                    connectors.remove(connectorKey);
+                }
+            }
+        }
+    }
+
+    protected ContinuationCometdServlet createServletForConnector(
+            Connector connector, CometdEndpoint endpoint) throws Exception {
+        ContinuationCometdServlet servlet = new ContinuationCometdServlet();
+
+        Context context = new Context(server, "/", Context.NO_SECURITY | Context.NO_SESSIONS);
+        context.setConnectorNames(new String[] {connector.getName()});
+
+        ServletHolder holder = new ServletHolder();
+        holder.setServlet(servlet);
+        context.setResourceBase(endpoint.getResourceBase());
+        context.addServlet(holder, "/cometd/*");
+        context.addServlet("org.mortbay.jetty.servlet.DefaultServlet", "/");
+        connector.start();
+        context.start();
+        holder.setInitParameter("timeout", Integer.toString(endpoint
+                .getTimeout()));
+        holder.setInitParameter("interval", Integer.toString(endpoint
+                .getInterval()));
+        holder.setInitParameter("maxInterval", Integer.toString(endpoint
+                .getMaxInterval()));
+        holder.setInitParameter("multiFrameInterval", Integer.toString(endpoint
+                .getMultiFrameInterval()));
+        holder.setInitParameter("JSONCommented", Boolean.toString(endpoint
+                .isJsonCommented()));
+        holder.setInitParameter("logLevel", Integer.toString(endpoint
+                .getLogLevel()));
+        return servlet;
+    }
+
+    public synchronized SslSocketConnector getSslSocketConnector() {
+        if (sslSocketConnector == null) {
+            sslSocketConnector = new SslSocketConnector();
+            // with default null values, jetty ssl system properties
+            // and console will be read by jetty implementation
+            sslSocketConnector.setPassword(sslPassword);
+            sslSocketConnector.setKeyPassword(sslKeyPassword);
+            if (sslKeystore != null) {
+                sslSocketConnector.setKeystore(sslKeystore);
+            }
+        }
+        return sslSocketConnector;
+    }
+
+    public Server getServer() throws Exception {
+        if (server == null) {
+            server = createServer();
+        }
+        return server;
+    }
+
+    public void setServer(Server server) {
+        this.server = server;
+    }
+
+    public String getSslKeyPassword() {
+        return sslKeyPassword;
+    }
+
+    public String getSslPassword() {
+        return sslPassword;
+    }
+
+    public String getSslKeystore() {
+        return sslKeystore;
+    }
+
+    public void setSslKeyPassword(String sslKeyPassword) {
+        this.sslKeyPassword = sslKeyPassword;
+    }
+
+    public void setSslPassword(String sslPassword) {
+        this.sslPassword = sslPassword;
+    }
+
+    public void setSslKeystore(String sslKeystore) {
+        this.sslKeystore = sslKeystore;
+    }
+
+    protected Server createServer() throws Exception {
+        Server server = new Server();
+        ContextHandlerCollection collection = new ContextHandlerCollection();
+        collection.setServer(server);
+        server.addHandler(collection);
+        server.start();
+
+        return server;
+    }
+
+    @Override
+    protected void doStop() throws Exception {
+        for (ConnectorRef connectorRef : connectors.values()) {
+            connectorRef.connector.stop();
+        }
+        connectors.clear();
+
+        if (server != null) {
+            server.stop();
+        }
+        super.doStop();
+    }
+
+    @Override
+    protected void doStart() throws Exception {
+        super.doStart();
+    }
+}

Added: activemq/camel/trunk/components/camel-cometd/src/main/java/org/apache/camel/component/cometd/CometdConsumer.java
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/components/camel-cometd/src/main/java/org/apache/camel/component/cometd/CometdConsumer.java?rev=722785&view=auto
==============================================================================
--- activemq/camel/trunk/components/camel-cometd/src/main/java/org/apache/camel/component/cometd/CometdConsumer.java (added)
+++ activemq/camel/trunk/components/camel-cometd/src/main/java/org/apache/camel/component/cometd/CometdConsumer.java Tue Dec  2 21:48:10 2008
@@ -0,0 +1,89 @@
+/**
+ * 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.cometd;
+
+import dojox.cometd.Bayeux;
+import dojox.cometd.Client;
+
+import org.apache.camel.Exchange;
+import org.apache.camel.Message;
+import org.apache.camel.Processor;
+import org.apache.camel.impl.DefaultConsumer;
+import org.apache.camel.impl.DefaultMessage;
+import org.mortbay.cometd.AbstractBayeux;
+import org.mortbay.cometd.BayeuxService;
+
+/**
+ * A Consumer for receving messages using Cometd and Bayeux protocol.
+ * 
+ * @version $Revision: 712626 $
+ */
+public class CometdConsumer extends DefaultConsumer implements CometdProducerConsumer {
+
+    private AbstractBayeux bayeux;
+    private final CometdEndpoint endpoint;
+    @SuppressWarnings("unused")
+    private ConsumerService service;
+
+    public CometdConsumer(CometdEndpoint endpoint, Processor processor) {
+        super(endpoint, processor);
+        this.endpoint = endpoint;
+    }
+
+    @Override
+    public void start() throws Exception {
+        super.start();
+        endpoint.connect(this);
+        service = new ConsumerService(endpoint.getPath(), bayeux, this);
+    }
+
+    @Override
+    public void stop() throws Exception {
+        super.stop();
+        endpoint.disconnect(this);
+    }
+
+    public void setBayeux(AbstractBayeux bayeux) {
+        this.bayeux = bayeux;
+    }
+
+    public CometdEndpoint getEndpoint() {
+        return endpoint;
+    }
+
+    public static class ConsumerService extends BayeuxService {
+
+        private final CometdEndpoint endpoint;
+        private final CometdConsumer consumer;
+
+        public ConsumerService(String channel, Bayeux bayeux,
+                CometdConsumer consumer) {
+            super(bayeux, channel);
+            this.consumer = consumer;
+            this.endpoint = consumer.getEndpoint();
+            subscribe(channel, "push");
+        }
+
+        public void push(Client client, Object data) throws Exception {
+            Message message = new DefaultMessage();
+            Exchange exchange = endpoint.createExchange();
+            message.setBody(data);
+            exchange.setIn(message);
+            consumer.getAsyncProcessor().process(exchange);
+        }
+    }
+}

Added: activemq/camel/trunk/components/camel-cometd/src/main/java/org/apache/camel/component/cometd/CometdConverters.java
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/components/camel-cometd/src/main/java/org/apache/camel/component/cometd/CometdConverters.java?rev=722785&view=auto
==============================================================================
--- activemq/camel/trunk/components/camel-cometd/src/main/java/org/apache/camel/component/cometd/CometdConverters.java (added)
+++ activemq/camel/trunk/components/camel-cometd/src/main/java/org/apache/camel/component/cometd/CometdConverters.java Tue Dec  2 21:48:10 2008
@@ -0,0 +1,54 @@
+/**
+ * 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.cometd;
+
+import org.apache.camel.Converter;
+
+/**
+ * Cometd specific converters.
+ *
+ * @version $Revision: 705131 $
+ */
+@Converter
+public final class CometdConverters {
+    
+    private CometdConverters() {
+        //Utility Class
+    }
+
+    /**
+     * Converts the given JavaMail message to a String body.
+     * Can return null.
+     */
+/*    
+    @Converter
+    public static String toString(Message message) throws MessagingException, IOException {
+        Object content = message.getContent();
+        if (content instanceof MimeMultipart) {
+            MimeMultipart multipart = (MimeMultipart) content;
+            if (multipart.getCount() > 0) {
+                BodyPart part = multipart.getBodyPart(0);
+                content = part.getContent();
+            }
+        }
+        if (content != null) {
+            return content.toString();
+        }
+        return null;
+    }
+*/
+}

Added: activemq/camel/trunk/components/camel-cometd/src/main/java/org/apache/camel/component/cometd/CometdEndpoint.java
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/components/camel-cometd/src/main/java/org/apache/camel/component/cometd/CometdEndpoint.java?rev=722785&view=auto
==============================================================================
--- activemq/camel/trunk/components/camel-cometd/src/main/java/org/apache/camel/component/cometd/CometdEndpoint.java (added)
+++ activemq/camel/trunk/components/camel-cometd/src/main/java/org/apache/camel/component/cometd/CometdEndpoint.java Tue Dec  2 21:48:10 2008
@@ -0,0 +1,162 @@
+/**
+ * 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.cometd;
+
+import java.net.URI;
+import java.net.URISyntaxException;
+import java.util.Map;
+
+import org.apache.camel.Consumer;
+import org.apache.camel.Processor;
+import org.apache.camel.Producer;
+import org.apache.camel.impl.DefaultEndpoint;
+
+/**
+ * Endpoint for Camel Cometd.
+ *
+ * @version $Revision:520964 $
+ */
+public class CometdEndpoint extends DefaultEndpoint {
+   
+    private String          resourceBase;
+    private int             timeout = 240000;
+    private int             interval;
+    private int             maxInterval = 30000;
+    private int             multiFrameInterval = 1500;
+    private boolean         jsonCommented = true;
+    private int             logLevel = 1;
+    private URI             uri;
+    private CometdComponent component;
+    
+    @SuppressWarnings("unchecked")
+    public CometdEndpoint(CometdComponent component, String uri, String remaining, Map parameters) {
+        super(uri);
+        this.component = component;
+        try {
+            this.uri = new URI(uri);
+        } catch (URISyntaxException e) {
+            e.printStackTrace();
+        }
+    }
+
+    public Producer createProducer() throws Exception {
+        CometdProducer producer = new CometdProducer(this);
+        return producer;
+    }
+
+    public Consumer createConsumer(Processor processor) throws Exception {
+        CometdConsumer consumer =  new CometdConsumer(this, processor);
+        return consumer;
+    }
+
+    
+    public void connect(CometdProducerConsumer prodcons) throws Exception {
+        component.connect(prodcons);
+    }
+    
+    public void disconnect(CometdProducerConsumer prodcons) throws Exception {
+        component.disconnect(prodcons);
+    }
+    
+    public CometdComponent getComponent() {
+        return component;
+    }
+
+    public boolean isSingleton() {
+        return false;
+    }
+    
+    public String getPath() {
+        return uri.getPath();
+    }
+
+    public int getPort() {
+        if (uri.getPort() == -1) {
+            if ("cometds".equals(getProtocol())) {
+                return 443;
+            } else {
+                return 80;
+            }
+        }
+        return uri.getPort();
+    }
+
+    public String getProtocol() {
+        return uri.getScheme();
+    }
+
+    public URI getUri() {
+        return uri;
+    }
+    
+    
+    public String getResourceBase() {
+        return resourceBase;
+    }
+
+    public void setResourceBase(String resourceBase) {
+        this.resourceBase = resourceBase;
+    }
+   
+    public int getTimeout() {
+        return timeout;
+    }
+
+    public void setTimeout(int timeout) {
+        this.timeout = timeout;
+    }
+
+    public int getInterval() {
+        return interval;
+    }
+
+    public void setInterval(int interval) {
+        this.interval = interval;
+    }
+
+    public int getMaxInterval() {
+        return maxInterval;
+    }
+
+    public void setMaxInterval(int maxInterval) {
+        this.maxInterval = maxInterval;
+    }
+
+    public int getMultiFrameInterval() {
+        return multiFrameInterval;
+    }
+
+    public void setMultiFrameInterval(int multiFrameInterval) {
+        this.multiFrameInterval = multiFrameInterval;
+    }
+
+    public boolean isJsonCommented() {
+        return jsonCommented;
+    }
+
+    public void setJsonCommented(boolean commented) {
+        jsonCommented = commented;
+    }
+
+    public int getLogLevel() {
+        return logLevel;
+    }
+
+    public void setLogLevel(int logLevel) {
+        this.logLevel = logLevel;
+    }
+}

Added: activemq/camel/trunk/components/camel-cometd/src/main/java/org/apache/camel/component/cometd/CometdProducer.java
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/components/camel-cometd/src/main/java/org/apache/camel/component/cometd/CometdProducer.java?rev=722785&view=auto
==============================================================================
--- activemq/camel/trunk/components/camel-cometd/src/main/java/org/apache/camel/component/cometd/CometdProducer.java (added)
+++ activemq/camel/trunk/components/camel-cometd/src/main/java/org/apache/camel/component/cometd/CometdProducer.java Tue Dec  2 21:48:10 2008
@@ -0,0 +1,79 @@
+/**
+ * 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.cometd;
+
+import java.util.Collection;
+import java.util.Iterator;
+
+import dojox.cometd.Client;
+
+import org.apache.camel.Exchange;
+import org.apache.camel.impl.DefaultProducer;
+import org.apache.commons.logging.Log;
+import org.apache.commons.logging.LogFactory;
+import org.mortbay.cometd.AbstractBayeux;
+
+/**
+ * A Producer to send messages using Cometd and Bayeux protocol.
+ * 
+ * @version $Revision: 712626 $
+ */
+public class CometdProducer extends DefaultProducer implements CometdProducerConsumer {
+
+    @SuppressWarnings("unused")
+    private static final transient Log LOG = LogFactory.getLog(CometdProducer.class);
+    
+    private AbstractBayeux       bayeux;  
+    private final CometdEndpoint endpoint;
+
+    public CometdProducer(CometdEndpoint endpoint) {
+        super(endpoint);
+        this.endpoint = endpoint;
+    }
+
+    @Override
+    public void start() throws Exception {
+        super.start();
+        endpoint.connect(this);
+    }
+
+    @Override
+    public void stop() throws Exception {
+        super.stop();
+        endpoint.disconnect(this);
+    }
+
+    public void process(final Exchange exchange) {
+        Collection<Client> clients = bayeux.getClients();
+        for (Iterator<Client> iterator = clients.iterator(); iterator.hasNext();) {
+            Client client = (Client) iterator.next();
+            client.deliver(client, endpoint.getPath(), exchange.getIn().getBody(), null);
+        }
+    }
+
+    public CometdEndpoint getEndpoint() {
+        return endpoint;
+    }
+    
+    public AbstractBayeux getBayeux() {
+        return bayeux;
+    }
+
+    public void setBayeux(AbstractBayeux bayeux) {
+        this.bayeux = bayeux;
+    }
+}

Added: activemq/camel/trunk/components/camel-cometd/src/main/java/org/apache/camel/component/cometd/CometdProducerConsumer.java
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/components/camel-cometd/src/main/java/org/apache/camel/component/cometd/CometdProducerConsumer.java?rev=722785&view=auto
==============================================================================
--- activemq/camel/trunk/components/camel-cometd/src/main/java/org/apache/camel/component/cometd/CometdProducerConsumer.java (added)
+++ activemq/camel/trunk/components/camel-cometd/src/main/java/org/apache/camel/component/cometd/CometdProducerConsumer.java Tue Dec  2 21:48:10 2008
@@ -0,0 +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.
+ */
+package org.apache.camel.component.cometd;
+
+import org.mortbay.cometd.AbstractBayeux;
+
+public interface CometdProducerConsumer {
+    
+    CometdEndpoint getEndpoint();
+    void           setBayeux(AbstractBayeux bayeux);
+    
+}

Added: activemq/camel/trunk/components/camel-cometd/src/main/java/org/apache/camel/component/cometd/CometdProducerConsumerInteractiveTest.java
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/components/camel-cometd/src/main/java/org/apache/camel/component/cometd/CometdProducerConsumerInteractiveTest.java?rev=722785&view=auto
==============================================================================
--- activemq/camel/trunk/components/camel-cometd/src/main/java/org/apache/camel/component/cometd/CometdProducerConsumerInteractiveTest.java (added)
+++ activemq/camel/trunk/components/camel-cometd/src/main/java/org/apache/camel/component/cometd/CometdProducerConsumerInteractiveTest.java Tue Dec  2 21:48:10 2008
@@ -0,0 +1,67 @@
+/**
+ * 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.cometd;
+
+import java.io.File;
+import java.net.URI;
+import java.net.URISyntaxException;
+import java.net.URL;
+
+import org.apache.camel.CamelContext;
+import org.apache.camel.builder.RouteBuilder;
+import org.apache.camel.impl.DefaultCamelContext;
+
+public class CometdProducerConsumerInteractiveTest {
+
+    private static final String URI = "cometd://localhost:8080/service/test?resourceBase=./src/test/resources/webapp&"
+            + "timeout=240000&interval=0&maxInterval=30000&multiFrameInterval=1500&jsonCommented=true&logLevel=2";
+
+    private static final String URIS = "cometds://localhost:8443/service/test?resourceBase=./src/test/resources/webapp&"
+        + "timeout=240000&interval=0&maxInterval=30000&multiFrameInterval=1500&jsonCommented=true&logLevel=2";
+
+    private CamelContext context;
+
+    private String pwd = "changeit";
+    
+    public static void main(String[] args) throws Exception {
+        CometdProducerConsumerInteractiveTest me = new CometdProducerConsumerInteractiveTest();
+        me.testCometdProducerConsumerInteractive();
+    }
+
+    public void testCometdProducerConsumerInteractive() throws Exception {
+        context = new DefaultCamelContext();
+        context.addRoutes(createRouteBuilder());
+        context.start();
+    }
+
+    private RouteBuilder createRouteBuilder() {
+        return new RouteBuilder() {
+            public void configure() {
+                CometdComponent component = (CometdComponent) context.getComponent("cometds");
+                component.setSslPassword(pwd);
+                component.setSslKeyPassword(pwd);
+                URI keyStoreUrl = null;
+                File file = new File("./src/test/resources/jsse/localhost.ks");
+                keyStoreUrl = file.toURI();
+                component.setSslKeystore(keyStoreUrl.getPath());
+                                
+                from("stream:in").to(URI).to(URIS);
+            }
+        };
+    }
+
+}

Added: activemq/camel/trunk/components/camel-cometd/src/main/resources/META-INF/services/org/apache/camel/component/cometd
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/components/camel-cometd/src/main/resources/META-INF/services/org/apache/camel/component/cometd?rev=722785&view=auto
==============================================================================
--- activemq/camel/trunk/components/camel-cometd/src/main/resources/META-INF/services/org/apache/camel/component/cometd (added)
+++ activemq/camel/trunk/components/camel-cometd/src/main/resources/META-INF/services/org/apache/camel/component/cometd Tue Dec  2 21:48:10 2008
@@ -0,0 +1,17 @@
+#
+# 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.
+#
+class=org.apache.camel.component.cometd.CometdComponent

Added: activemq/camel/trunk/components/camel-cometd/src/main/resources/META-INF/services/org/apache/camel/component/cometds
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/components/camel-cometd/src/main/resources/META-INF/services/org/apache/camel/component/cometds?rev=722785&view=auto
==============================================================================
--- activemq/camel/trunk/components/camel-cometd/src/main/resources/META-INF/services/org/apache/camel/component/cometds (added)
+++ activemq/camel/trunk/components/camel-cometd/src/main/resources/META-INF/services/org/apache/camel/component/cometds Tue Dec  2 21:48:10 2008
@@ -0,0 +1,17 @@
+#
+# 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.
+#
+class=org.apache.camel.component.cometd.CometdComponent

Added: activemq/camel/trunk/components/camel-cometd/src/test/java/org/apache/camel/component/cometd/CometdProducerConsumerTest.java
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/components/camel-cometd/src/test/java/org/apache/camel/component/cometd/CometdProducerConsumerTest.java?rev=722785&view=auto
==============================================================================
--- activemq/camel/trunk/components/camel-cometd/src/test/java/org/apache/camel/component/cometd/CometdProducerConsumerTest.java (added)
+++ activemq/camel/trunk/components/camel-cometd/src/test/java/org/apache/camel/component/cometd/CometdProducerConsumerTest.java Tue Dec  2 21:48:10 2008
@@ -0,0 +1,86 @@
+/**
+ * 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.cometd;
+
+import java.util.List;
+
+import org.apache.camel.ContextTestSupport;
+import org.apache.camel.Exchange;
+import org.apache.camel.builder.RouteBuilder;
+import org.apache.camel.component.mock.MockEndpoint;
+
+/**
+ * Unit testing for using a CometdProducer and a CometdConsumer
+ */
+public class CometdProducerConsumerTest extends ContextTestSupport {
+
+    private static final String URI = "cometd://localhost:8080/service/test?resourceBase=./target/test-classes/webapp&"
+            + "timeout=240000&interval=0&maxInterval=30000&multiFrameInterval=1500&jsonCommented=true&logLevel=2";
+
+    public void testProducer() throws Exception {
+        Person person = new Person("David", "Greco");
+        template.requestBody("direct:input", person);
+        MockEndpoint ep = (MockEndpoint) context.getEndpoint("mock:test");
+        List<Exchange> exchanges = ep.getReceivedExchanges();
+        for (Exchange exchange : exchanges) {
+            Person person1 = (Person) exchange.getIn().getBody();
+            assertEquals("David", person1.getName());
+            assertEquals("Greco", person1.getSurname());
+        }
+    }
+
+    @Override
+    protected void tearDown() throws Exception {
+        super.tearDown();
+        stopCamelContext();
+    }
+
+    @Override
+    protected RouteBuilder createRouteBuilder() throws Exception {
+        return new RouteBuilder() {
+            @Override
+            public void configure() throws Exception {
+                from("direct:input").to(URI);
+                from(URI).to("mock:test");
+            }
+        };
+    }
+
+    public static class Person {
+
+        private String name;
+        private String surname;
+        
+        Person(String name, String surname) {
+            this.name = name;
+            this.surname = surname;
+        }
+        
+        public String getName() {
+            return name;
+        }
+        public String getSurname() {
+            return surname;
+        }
+        public void setName(String name) {
+            this.name = name;
+        }
+        public void setSurname(String surname) {
+            this.surname = surname;
+        }
+    }
+}

Added: activemq/camel/trunk/components/camel-cometd/src/test/java/org/apache/camel/component/cometd/SslCometdProducerConsumerTest.java
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/components/camel-cometd/src/test/java/org/apache/camel/component/cometd/SslCometdProducerConsumerTest.java?rev=722785&view=auto
==============================================================================
--- activemq/camel/trunk/components/camel-cometd/src/test/java/org/apache/camel/component/cometd/SslCometdProducerConsumerTest.java (added)
+++ activemq/camel/trunk/components/camel-cometd/src/test/java/org/apache/camel/component/cometd/SslCometdProducerConsumerTest.java Tue Dec  2 21:48:10 2008
@@ -0,0 +1,95 @@
+/**
+ * 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.cometd;
+
+import java.net.URL;
+import java.util.List;
+
+import org.apache.camel.ContextTestSupport;
+import org.apache.camel.Exchange;
+import org.apache.camel.builder.RouteBuilder;
+import org.apache.camel.component.mock.MockEndpoint;
+
+/**
+ * Unit testing for using a CometdProducer and a CometdConsumer
+ */
+public class SslCometdProducerConsumerTest extends ContextTestSupport {
+
+    private static final String URI = "cometds://localhost:8080/service/test?resourceBase=./target/test-classes/webapp&"
+            + "timeout=240000&interval=0&maxInterval=30000&multiFrameInterval=1500&jsonCommented=true&logLevel=2";
+
+    protected String pwd = "changeit";
+    
+    public void testProducer() throws Exception {
+        Person person = new Person("David", "Greco");
+        template.requestBody("direct:input", person);
+        MockEndpoint ep = (MockEndpoint) context.getEndpoint("mock:test");
+        List<Exchange> exchanges = ep.getReceivedExchanges();
+        for (Exchange exchange : exchanges) {
+            Person person1 = (Person) exchange.getIn().getBody();
+            assertEquals("David", person1.getName());
+            assertEquals("Greco", person1.getSurname());
+        }
+    }
+
+    @Override
+    protected void tearDown() throws Exception {
+        super.tearDown();
+        stopCamelContext();
+    }
+
+    @Override
+    protected RouteBuilder createRouteBuilder() throws Exception {
+        return new RouteBuilder() {
+            @Override
+            public void configure() throws Exception {
+                CometdComponent component = (CometdComponent) context.getComponent("cometds");
+                component.setSslPassword(pwd);
+                component.setSslKeyPassword(pwd);
+                URL keyStoreUrl = this.getClass().getClassLoader().getResource("jsse/localhost.ks");
+                component.setSslKeystore(keyStoreUrl.getPath());
+
+                from("direct:input").to(URI);
+                from(URI).to("mock:test");
+            }
+        };
+    }
+    
+    public static class Person {
+
+        private String name;
+        private String surname;
+        
+        Person(String name, String surname) {
+            this.name = name;
+            this.surname = surname;
+        }
+        
+        public String getName() {
+            return name;
+        }
+        public String getSurname() {
+            return surname;
+        }
+        public void setName(String name) {
+            this.name = name;
+        }
+        public void setSurname(String surname) {
+            this.surname = surname;
+        }
+    }
+}

Added: activemq/camel/trunk/components/camel-cometd/src/test/resources/jsse/localhost.ks
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/components/camel-cometd/src/test/resources/jsse/localhost.ks?rev=722785&view=auto
==============================================================================
Binary file - no diff available.

Propchange: activemq/camel/trunk/components/camel-cometd/src/test/resources/jsse/localhost.ks
------------------------------------------------------------------------------
    svn:mime-type = application/octet-stream

Added: activemq/camel/trunk/components/camel-cometd/src/test/resources/log4j.properties
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/components/camel-cometd/src/test/resources/log4j.properties?rev=722785&view=auto
==============================================================================
--- activemq/camel/trunk/components/camel-cometd/src/test/resources/log4j.properties (added)
+++ activemq/camel/trunk/components/camel-cometd/src/test/resources/log4j.properties Tue Dec  2 21:48:10 2008
@@ -0,0 +1,35 @@
+## ---------------------------------------------------------------------------
+## 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 during tests..
+#
+log4j.rootLogger=INFO, file
+
+# CONSOLE appender not used by default
+log4j.appender.console=org.apache.log4j.ConsoleAppender
+log4j.appender.console.layout=org.apache.log4j.PatternLayout
+log4j.appender.console.layout.ConversionPattern=%d %-5p %c{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 %-5p %c{1} - %m %n
+log4j.appender.file.file=target/camel-jetty-test.log
+
+# debug loging for Camel
+#log4j.logger.org.apache.camel.component.cometd=DEBUG

Modified: activemq/camel/trunk/components/pom.xml
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/components/pom.xml?rev=722785&r1=722784&r2=722785&view=diff
==============================================================================
--- activemq/camel/trunk/components/pom.xml (original)
+++ activemq/camel/trunk/components/pom.xml Tue Dec  2 21:48:10 2008
@@ -37,6 +37,7 @@
     <module>camel-amqp</module>
     <module>camel-atom</module>
     <module>camel-bam</module>
+    <module>camel-cometd</module>
     <module>camel-csv</module>
     <module>camel-cxf</module>
     <module>camel-flatpack</module>

Modified: activemq/camel/trunk/pom.xml
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/pom.xml?rev=722785&r1=722784&r2=722785&view=diff
==============================================================================
--- activemq/camel/trunk/pom.xml (original)
+++ activemq/camel/trunk/pom.xml Tue Dec  2 21:48:10 2008
@@ -59,6 +59,7 @@
     <jaxb-api-version>2.1</jaxb-api-version>
     <stax-api-version>1.0.1</stax-api-version>
     <log4j-version>1.2.14</log4j-version>
+    <cometd-bayeux-version>6.1.11</cometd-bayeux-version>
     <commons-io-version>1.3.2</commons-io-version>
     <commons-logging-version>1.1.1</commons-logging-version>
     <commons-logging-api-version>1.1</commons-logging-api-version>