You are viewing a plain text version of this content. The canonical link for it is here.
Posted to dev@camel.apache.org by Andrea Cosentino <an...@yahoo.com.INVALID> on 2016/12/19 09:55:26 UTC

Re: camel git commit: Fix CS violations

It looks like the build deleted the components list from readme.
 --
Andrea Cosentino 
----------------------------------
Apache Camel PMC Member
Apache Karaf Committer
Apache Servicemix Committer
Email: ancosen1985@yahoo.com
Twitter: @oscerd2
Github: oscerd



On Sunday, December 18, 2016 6:27 PM, "bvahdat@apache.org" <bv...@apache.org> wrote:
Repository: camel
Updated Branches:
  refs/heads/master 079b5f9e6 -> 490a76f17


Fix CS violations

Project: http://git-wip-us.apache.org/repos/asf/camel/repo
Commit: http://git-wip-us.apache.org/repos/asf/camel/commit/490a76f1
Tree: http://git-wip-us.apache.org/repos/asf/camel/tree/490a76f1
Diff: http://git-wip-us.apache.org/repos/asf/camel/diff/490a76f1

Branch: refs/heads/master
Commit: 490a76f17a1cb96a08009607a7aa972e7bc0372d
Parents: 079b5f9
Author: Babak Vahdat <bv...@apache.org>
Authored: Sun Dec 18 18:26:52 2016 +0100
Committer: Babak Vahdat <bv...@apache.org>
Committed: Sun Dec 18 18:26:52 2016 +0100

----------------------------------------------------------------------
.../component/bonita/BonitaConfiguration.java   |   6 +-
.../core/xml/CamelProxyFactoryDefinition.java   |   2 +-
.../camel/component/gridfs/GridFsEndpoint.java  |   1 -
.../openstack/nova/KeypairProducerTest.java     |   2 +-
.../processor/RibbonServiceCallProcessor.java   |  19 +-
.../component/servicenow/ServiceNowClient.java  |   2 +-
components/readme.adoc                          | 402 -------------------
7 files changed, 15 insertions(+), 419 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/camel/blob/490a76f1/components/camel-bonita/src/main/java/org/apache/camel/component/bonita/BonitaConfiguration.java
----------------------------------------------------------------------
diff --git a/components/camel-bonita/src/main/java/org/apache/camel/component/bonita/BonitaConfiguration.java b/components/camel-bonita/src/main/java/org/apache/camel/component/bonita/BonitaConfiguration.java
index 7343e2c..b992682 100644
--- a/components/camel-bonita/src/main/java/org/apache/camel/component/bonita/BonitaConfiguration.java
+++ b/components/camel-bonita/src/main/java/org/apache/camel/component/bonita/BonitaConfiguration.java
@@ -5,9 +5,9 @@
  * 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
- * <p>
- * http://www.apache.org/licenses/LICENSE-2.0
- * <p>
+ *
+ *      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.

http://git-wip-us.apache.org/repos/asf/camel/blob/490a76f1/components/camel-core-xml/src/main/java/org/apache/camel/core/xml/CamelProxyFactoryDefinition.java
----------------------------------------------------------------------
diff --git a/components/camel-core-xml/src/main/java/org/apache/camel/core/xml/CamelProxyFactoryDefinition.java b/components/camel-core-xml/src/main/java/org/apache/camel/core/xml/CamelProxyFactoryDefinition.java
index 6f160ce..5c78b93 100644
--- a/components/camel-core-xml/src/main/java/org/apache/camel/core/xml/CamelProxyFactoryDefinition.java
+++ b/components/camel-core-xml/src/main/java/org/apache/camel/core/xml/CamelProxyFactoryDefinition.java
@@ -63,7 +63,7 @@ public class CamelProxyFactoryDefinition extends IdentifiedType {
      * @deprecated use serviceUrl instead with the ref endpoint.
      */
     @Deprecated
-    public void setServiceRef(String serviceRef) {
+    public void setServiceRef(String serviceRef) {
         this.serviceRef = serviceRef;
     }


http://git-wip-us.apache.org/repos/asf/camel/blob/490a76f1/components/camel-mongodb-gridfs/src/main/java/org/apache/camel/component/gridfs/GridFsEndpoint.java
----------------------------------------------------------------------
diff --git a/components/camel-mongodb-gridfs/src/main/java/org/apache/camel/component/gridfs/GridFsEndpoint.java b/components/camel-mongodb-gridfs/src/main/java/org/apache/camel/component/gridfs/GridFsEndpoint.java
index cb8f686..f4d5d65 100644
--- a/components/camel-mongodb-gridfs/src/main/java/org/apache/camel/component/gridfs/GridFsEndpoint.java
+++ b/components/camel-mongodb-gridfs/src/main/java/org/apache/camel/component/gridfs/GridFsEndpoint.java
@@ -39,7 +39,6 @@ import org.slf4j.LoggerFactory;
@UriEndpoint(scheme = "gridfs", title = "MongoDBGridFS", syntax = "gridfs:connectionBean", label = "database,nosql")
public class GridFsEndpoint extends DefaultEndpoint {

-    ;
     public static final String GRIDFS_OPERATION = "gridfs.operation";
     public static final String GRIDFS_METADATA = "gridfs.metadata";
     public static final String GRIDFS_CHUNKSIZE = "gridfs.chunksize";

http://git-wip-us.apache.org/repos/asf/camel/blob/490a76f1/components/camel-openstack/src/test/java/org/apache/camel/component/openstack/nova/KeypairProducerTest.java
----------------------------------------------------------------------
diff --git a/components/camel-openstack/src/test/java/org/apache/camel/component/openstack/nova/KeypairProducerTest.java b/components/camel-openstack/src/test/java/org/apache/camel/component/openstack/nova/KeypairProducerTest.java
index c851a40..ba4813e 100644
--- a/components/camel-openstack/src/test/java/org/apache/camel/component/openstack/nova/KeypairProducerTest.java
+++ b/components/camel-openstack/src/test/java/org/apache/camel/component/openstack/nova/KeypairProducerTest.java
@@ -114,6 +114,6 @@ public class KeypairProducerTest extends NovaProducerTestSupport {
     }

     private Keypair createDummyKeypair() {
-        return NovaKeypair.create(KEYPAIR_NAME, "string contains private key");
+        return NovaKeypair.create(KEYPAIR_NAME, "string contains private key");
     }
}

http://git-wip-us.apache.org/repos/asf/camel/blob/490a76f1/components/camel-ribbon/src/main/java/org/apache/camel/component/ribbon/processor/RibbonServiceCallProcessor.java
----------------------------------------------------------------------
diff --git a/components/camel-ribbon/src/main/java/org/apache/camel/component/ribbon/processor/RibbonServiceCallProcessor.java b/components/camel-ribbon/src/main/java/org/apache/camel/component/ribbon/processor/RibbonServiceCallProcessor.java
index f9151ce..f701ba0 100644
--- a/components/camel-ribbon/src/main/java/org/apache/camel/component/ribbon/processor/RibbonServiceCallProcessor.java
+++ b/components/camel-ribbon/src/main/java/org/apache/camel/component/ribbon/processor/RibbonServiceCallProcessor.java
@@ -19,7 +19,6 @@ package org.apache.camel.component.ribbon.processor;
import java.util.Map;
import java.util.concurrent.RejectedExecutionException;

-import com.netflix.client.config.CommonClientConfigKey;
import com.netflix.client.config.IClientConfig;
import com.netflix.client.config.IClientConfigKey;
import com.netflix.loadbalancer.DummyPing;
@@ -46,8 +45,8 @@ import org.apache.camel.spi.IdAware;
import org.apache.camel.spi.ServiceCallServerListStrategy;
import org.apache.camel.support.ServiceSupport;
import org.apache.camel.util.AsyncProcessorHelper;
-import org.apache.camel.util.ObjectHelper;
import org.apache.camel.util.ServiceHelper;
+import org.apache.camel.util.StringHelper;
import org.slf4j.Logger;
import org.slf4j.LoggerFactory;

@@ -78,18 +77,18 @@ public class RibbonServiceCallProcessor extends ServiceSupport implements AsyncP
         // setup from the provided name which can contain scheme and context-path information as well
         String serviceName;
         if (name.contains("/")) {
-            serviceName = ObjectHelper.before(name, "/");
-            this.contextPath = ObjectHelper.after(name, "/");
+            serviceName = StringHelper.before(name, "/");
+            this.contextPath = StringHelper.after(name, "/");
         } else if (name.contains("?")) {
-            serviceName = ObjectHelper.before(name, "?");
-            this.contextPath = ObjectHelper.after(name, "?");
+            serviceName = StringHelper.before(name, "?");
+            this.contextPath = StringHelper.after(name, "?");
         } else {
             serviceName = name;
             this.contextPath = null;
         }
         if (serviceName.contains(":")) {
-            this.scheme = ObjectHelper.before(serviceName, ":");
-            this.name = ObjectHelper.after(serviceName, ":");
+            this.scheme = StringHelper.before(serviceName, ":");
+            this.name = StringHelper.after(serviceName, ":");
         } else {
             this.scheme = scheme;
             this.name = serviceName;
@@ -199,7 +198,7 @@ public class RibbonServiceCallProcessor extends ServiceSupport implements AsyncP
     @Override
     @SuppressWarnings("unchecked")
     protected void doStart() throws Exception {
-        ObjectHelper.notEmpty(name, "name", this);
+        StringHelper.notEmpty(name, "name", this);

         if (serverListStrategy == null) {
             serverListStrategy = new RibbonServiceCallStaticServerListStrategy();
@@ -222,7 +221,7 @@ public class RibbonServiceCallProcessor extends ServiceSupport implements AsyncP
         IClientConfig config = IClientConfig.Builder.newBuilder(name).build();
         if (ribbonClientConfig != null) {
             for (Map.Entry<String, String> entry : ribbonClientConfig.entrySet()) {
-                IClientConfigKey key = CommonClientConfigKey.valueOf(entry.getKey());
+                IClientConfigKey key = IClientConfigKey.Keys.valueOf(entry.getKey());
                 String value = entry.getValue();
                 LOG.debug("RibbonClientConfig: {}={}", key.key(), value);
                 config.set(key, entry.getValue());

http://git-wip-us.apache.org/repos/asf/camel/blob/490a76f1/components/camel-servicenow/src/main/java/org/apache/camel/component/servicenow/ServiceNowClient.java
----------------------------------------------------------------------
diff --git a/components/camel-servicenow/src/main/java/org/apache/camel/component/servicenow/ServiceNowClient.java b/components/camel-servicenow/src/main/java/org/apache/camel/component/servicenow/ServiceNowClient.java
index 2bdd86a..fa33607 100644
--- a/components/camel-servicenow/src/main/java/org/apache/camel/component/servicenow/ServiceNowClient.java
+++ b/components/camel-servicenow/src/main/java/org/apache/camel/component/servicenow/ServiceNowClient.java
@@ -162,7 +162,7 @@ public final class ServiceNowClient {
     }

     private static void configureTls(
-        CamelContext camelContext, ServiceNowConfiguration configuration, WebClient client) throws Exception{
+        CamelContext camelContext, ServiceNowConfiguration configuration, WebClient client) throws Exception {

         SSLContextParameters sslContextParams = configuration.getSslContextParameters();
         if (sslContextParams != null) {

http://git-wip-us.apache.org/repos/asf/camel/blob/490a76f1/components/readme.adoc
----------------------------------------------------------------------
diff --git a/components/readme.adoc b/components/readme.adoc
index 6d1eb1a..81b3828 100644
--- a/components/readme.adoc
+++ b/components/readme.adoc
@@ -15,12 +15,6 @@ Components
| link:camel-amqp/src/main/docs/amqp-component.adoc[AMQP] (camel-amqp) +
`amqp:destinationType:destinationName` | Messaging with AMQP protocol using Apache QPid Client.

-| link:camel-flink/src/main/docs/flink-component.adoc[Apache Flink] (camel-flink) +
-`flink:endpointType` | The flink component can be used to send DataSet jobs to Apache Flink cluster.
-
-| link:camel-spark/src/main/docs/spark-component.adoc[Apache Spark] (camel-spark) +
-`spark:endpointType` | The spark component can be used to send RDD or DataFrame jobs to Apache Spark cluster.
-
| link:camel-apns/src/main/docs/apns-component.adoc[APNS] (camel-apns) +
`apns:name` | For sending notifications to Apple iOS devices.

@@ -141,249 +135,60 @@ Components
| link:camel-drill/src/main/docs/drill-component.adoc[Drill] (camel-drill) +
`drill:host` | The drill component gives you the ability to quering into apache drill cluster.

-| link:camel-dropbox/src/main/docs/dropbox-component.adoc[Dropbox] (camel-dropbox) +
-`dropbox:operation` | For uploading downloading and managing files folders groups collaborations etc on dropbox DOT com.
-
| link:camel-cache/src/main/docs/cache-component.adoc[EHCache] (camel-cache) +
`cache:cacheName` | *deprecated* The cache component enables you to perform caching operations using EHCache as the Cache Implementation.

-| link:camel-ehcache/src/main/docs/ehcache-component.adoc[Ehcache] (camel-ehcache) +
-`ehcache:cacheName` | The ehcache component enables you to perform caching operations using Ehcache as cache implementation.
-
-| link:camel-ejb/src/main/docs/ejb-component.adoc[EJB] (camel-ejb) +
-`ejb:beanName` | The ejb component is for invoking EJB Java beans from Camel.
-
-| link:camel-elasticsearch/src/main/docs/elasticsearch-component.adoc[Elasticsearch] (camel-elasticsearch) +
-`elasticsearch:clusterName` | The elasticsearch component is used for interfacing with ElasticSearch server.
-
-| link:camel-elsql/src/main/docs/elsql-component.adoc[ElSQL] (camel-elsql) +
-`elsql:elsqlName:resourceUri` | The elsql component is an extension to the existing SQL Component that uses ElSql to define the SQL queries.
-
-| link:camel-etcd/src/main/docs/etcd-component.adoc[etcd] (camel-etcd) +
-`etcd:namespace/path` | The camel etcd component allows you to work with Etcd a distributed A distributed reliable key-value store.
-
-| link:camel-exec/src/main/docs/exec-component.adoc[Exec] (camel-exec) +
-`exec:executable` | The exec component can be used to execute OS system commands.
-
-| link:camel-facebook/src/main/docs/facebook-component.adoc[Facebook] (camel-facebook) +
-`facebook:methodName` | The Facebook component provides access to all of the Facebook APIs accessible using Facebook4J.
-
-| link:camel-flatpack/src/main/docs/flatpack-component.adoc[Flatpack] (camel-flatpack) +
-`flatpack:type:resourceUri` | The flatpack component supports fixed width and delimited file parsing via the FlatPack library.
-
-| link:camel-fop/src/main/docs/fop-component.adoc[FOP] (camel-fop) +
-`fop:outputType` | The fop component allows you to render a message into different output formats using Apache FOP.
-
-| link:camel-freemarker/src/main/docs/freemarker-component.adoc[Freemarker] (camel-freemarker) +
-`freemarker:resourceUri` | Transforms the message using a FreeMarker template.
-
-| link:camel-ftp/src/main/docs/ftp-component.adoc[FTP] (camel-ftp) +
-`ftp:host:port/directoryName` | The ftp component is used for uploading or downloading files from FTP servers.
-
-| link:camel-ftp/src/main/docs/ftps-component.adoc[FTPS] (camel-ftp) +
-`ftps:host:port/directoryName` | The ftps (FTP secure SSL/TLS) component is used for uploading or downloading files from FTP servers.
-
-| link:camel-ganglia/src/main/docs/ganglia-component.adoc[Ganglia] (camel-ganglia) +
-`ganglia:host:port` | The ganglia component is used for sending metrics to the Ganglia monitoring system.
-
-| link:camel-geocoder/src/main/docs/geocoder-component.adoc[Geocoder] (camel-geocoder) +
-`geocoder:address:latlng` | The geocoder component is used for looking up geocodes (latitude and longitude) for a given address or reverse lookup.
-
-| link:camel-git/src/main/docs/git-component.adoc[Git] (camel-git) +
-`git:localPath` | The git component is used for working with git repositories.
-
-| link:camel-github/src/main/docs/github-component.adoc[GitHub] (camel-github) +
-`github:type/branchName` | The github component is used for integrating Camel with github.
-
| link:camel-google-calendar/src/main/docs/google-calendar-component.adoc[Google Calendar] (camel-google-calendar) +
`google-calendar:apiName/methodName` | The google-calendar component provides access to Google Calendar.

-| link:camel-google-drive/src/main/docs/google-drive-component.adoc[Google Drive] (camel-google-drive) +
-`google-drive:apiName/methodName` | The google-drive component provides access to Google Drive file storage service.
-
-| link:camel-google-mail/src/main/docs/google-mail-component.adoc[Google Mail] (camel-google-mail) +
-`google-mail:apiName/methodName` | The google-mail component provides access to Google Mail.
-
| link:camel-google-pubsub/src/main/docs/google-pubsub-component.adoc[Google Pubsub] (camel-google-pubsub) +
`google-pubsub:projectId:destinationName` | Messaging client for Google Cloud Platform PubSub Service: https://cloud.google.com/pubsub/

-| link:camel-gora/src/main/docs/gora-component.adoc[Gora] (camel-gora) +
-`gora:name` | The gora component allows you to work with NoSQL databases using the Apache Gora framework.
-
| link:camel-grape/src/main/docs/grape-component.adoc[Grape] (camel-grape) +
`grape:defaultCoordinates` | Grape component allows you to fetch, load and manage additional jars when CamelContext is running.

-| link:camel-guava-eventbus/src/main/docs/guava-eventbus-component.adoc[Guava EventBus] (camel-guava-eventbus) +
-`guava-eventbus:eventBusRef` | The guava-eventbus component provides integration bridge between Camel and Google Guava EventBus.
-
-| link:camel-hazelcast/src/main/docs/hazelcast-component.adoc[Hazelcast] (camel-hazelcast) +
-`hazelcast:command:cacheName` | The hazelcast component allows you to work with the Hazelcast distributed data grid / cache.
-
-| link:camel-hbase/src/main/docs/hbase-component.adoc[HBase] (camel-hbase) +
-`hbase:tableName` | For reading/writing from/to an HBase store (Hadoop database).
-
-| link:camel-hdfs/src/main/docs/hdfs-component.adoc[HDFS] (camel-hdfs) +
-`hdfs:hostName:port/path` | *deprecated* For reading/writing from/to an HDFS filesystem using Hadoop 1.x.
-
-| link:camel-hdfs2/src/main/docs/hdfs2-component.adoc[HDFS2] (camel-hdfs2) +
-`hdfs2:hostName:port/path` | For reading/writing from/to an HDFS filesystem using Hadoop 2.x.
-
-| link:camel-hipchat/src/main/docs/hipchat-component.adoc[Hipchat] (camel-hipchat) +
-`hipchat:protocol:host:port` | The hipchat component supports producing and consuming messages from/to Hipchat service.
-
| link:camel-http/src/main/docs/http-component.adoc[HTTP] (camel-http) +
`http:httpUri` | For calling out to external HTTP servers using Apache HTTP Client 3.x.

| link:camel-http4/src/main/docs/http4-component.adoc[HTTP4] (camel-http4) +
`http4:httpUri` | For calling out to external HTTP servers using Apache HTTP Client 4.x.

-| link:camel-ibatis/src/main/docs/ibatis-component.adoc[iBatis] (camel-ibatis) +
-`ibatis:statement` | *deprecated* Performs a query poll insert update or delete in a relational database using Apache iBATIS.
-
-| link:camel-mail/src/main/docs/imap-component.adoc[IMAP] (camel-mail) +
-`imap:host:port` | To send or receive emails using imap/pop3 or stmp protocols.
-
| link:camel-infinispan/src/main/docs/infinispan-component.adoc[Infinispan] (camel-infinispan) +
`infinispan:host` | For reading/writing from/to Infinispan distributed key/value store and data grid.

-| link:camel-influxdb/src/main/docs/influxdb-component.adoc[InfluxDB] (camel-influxdb) +
-`influxdb:connectionBean` | The influxdb component allows you to interact with InfluxDB a time series database.
-
-| link:camel-irc/src/main/docs/irc-component.adoc[IRC] (camel-irc) +
-`irc:hostname:port` | The irc component implements an IRC (Internet Relay Chat) transport.
-
| link:camel-ironmq/src/main/docs/ironmq-component.adoc[ironmq] (camel-ironmq) +
`ironmq:queueName` | The ironmq provides integration with IronMQ an elastic and durable hosted message queue as a service.

-| link:camel-javaspace/src/main/docs/javaspace-component.adoc[JavaSpace] (camel-javaspace) +
-`javaspace:url` | *deprecated* Sending and receiving messages through JavaSpace.
-
-| link:camel-jbpm/src/main/docs/jbpm-component.adoc[JBPM] (camel-jbpm) +
-`jbpm:connectionURL` | The jbpm component provides integration with jBPM (Business Process Management).
-
| link:camel-jcache/src/main/docs/jcache-component.adoc[JCache] (camel-jcache) +
`jcache:cacheName` | The jcache component enables you to perform caching operations using JSR107/JCache as cache implementation.

-| link:camel-jclouds/src/main/docs/jclouds-component.adoc[JClouds] (camel-jclouds) +
-`jclouds:command:providerId` | For interacting with cloud compute & blobstore service via jclouds.
-
-| link:camel-jcr/src/main/docs/jcr-component.adoc[JCR] (camel-jcr) +
-`jcr:host/base` | The jcr component allows you to add/read nodes to/from a JCR compliant content repository.
-
-| link:camel-jdbc/src/main/docs/jdbc-component.adoc[JDBC] (camel-jdbc) +
-`jdbc:dataSourceName` | The jdbc component enables you to access databases through JDBC where SQL queries are sent in the message body.
-
| link:camel-jetty9/src/main/docs/jetty-component.adoc[Jetty 9] (camel-jetty9) +
`jetty:httpUri` | The jetty component provides HTTP-based endpoints for consuming and producing HTTP requests.

| link:camel-websocket/src/main/docs/websocket-component.adoc[Jetty Websocket] (camel-websocket) +
`websocket:host:port/resourceUri` | The websocket component provides websocket endpoints for communicating with clients using websocket.

-| link:camel-jgroups/src/main/docs/jgroups-component.adoc[JGroups] (camel-jgroups) +
-`jgroups:clusterName` | The jgroups component provides exchange of messages between Camel and JGroups clusters.
-
-| link:camel-jing/src/main/docs/jing-component.adoc[Jing] (camel-jing) +
-`jing:resourceUri` | Validates the payload of a message using RelaxNG Syntax using Jing library.
-
-| link:camel-jira/src/main/docs/jira-component.adoc[JIRA] (camel-jira) +
-`jira:type` | The jira component interacts with the JIRA issue tracker.
-
| link:camel-jms/src/main/docs/jms-component.adoc[JMS] (camel-jms) +
`jms:destinationType:destinationName` | The jms component allows messages to be sent to (or consumed from) a JMS Queue or Topic.

-| link:camel-jmx/src/main/docs/jmx-component.adoc[JMX] (camel-jmx) +
-`jmx:serverURL` | The jmx component allows to receive JMX notifications.
-
-| link:camel-jolt/src/main/docs/jolt-component.adoc[JOLT] (camel-jolt) +
-`jolt:resourceUri` | The jolt component allows you to process a JSON messages using an JOLT specification (such as JSON-JSON transformation).
-
-| link:camel-jpa/src/main/docs/jpa-component.adoc[JPA] (camel-jpa) +
-`jpa:entityType` | The jpa component enables you to store and retrieve Java objects from databases using JPA.
-
-| link:camel-jt400/src/main/docs/jt400-component.adoc[JT400] (camel-jt400) +
-`jt400:userID:password/systemName/objectPath.type` | The jt400 component allows you to exchanges messages with an AS/400 system using data queues or program call.
-
| link:camel-kafka/src/main/docs/kafka-component.adoc[Kafka] (camel-kafka) +
`kafka:brokers` | The kafka component allows messages to be sent to (or consumed from) Apache Kafka brokers.

-| link:camel-kestrel/src/main/docs/kestrel-component.adoc[Kestrel] (camel-kestrel) +
-`kestrel:addresses/queue` | *deprecated* The kestrel component allows messages to be sent to (or consumed from) Kestrel brokers.
-
-| link:camel-krati/src/main/docs/krati-component.adoc[Krati] (camel-krati) +
-`krati:path` | The krati allows the use krati datastores and datasets inside Camel.
-
-| link:camel-kubernetes/src/main/docs/kubernetes-component.adoc[Kubernetes] (camel-kubernetes) +
-`kubernetes:masterUrl` | The kubernetes component allows to work with Kubernetes PaaS.
-
-| link:camel-ldap/src/main/docs/ldap-component.adoc[LDAP] (camel-ldap) +
-`ldap:dirContextName` | The ldap component allows you to perform searches in LDAP servers using filters as the message payload.
-
-| link:camel-linkedin/src/main/docs/linkedin-component.adoc[Linkedin] (camel-linkedin) +
-`linkedin:apiName/methodName` | The linkedin component is uses for retrieving LinkedIn user profiles connections companies groups posts etc.
-
-| link:camel-lucene/src/main/docs/lucene-component.adoc[Lucene] (camel-lucene) +
-`lucene:host:operation` | To insert or query from Apache Lucene databases.
-
-| link:camel-lumberjack/src/main/docs/lumberjack-component.adoc[Lumberjack] (camel-lumberjack) +
-`lumberjack:host:port` | The lumberjack retrieves logs sent over the network using the Lumberjack protocol.
-
| link:camel-metrics/src/main/docs/metrics-component.adoc[Metrics] (camel-metrics) +
`metrics:metricsType:metricsName` | To collect various metrics directly from Camel routes using the DropWizard metrics library.

-| link:camel-mina/src/main/docs/mina-component.adoc[Mina] (camel-mina) +
-`mina:protocol:host:port` | *deprecated* Socket level networking using TCP or UDP with the Apache Mina 1.x library.
-
-| link:camel-mina2/src/main/docs/mina2-component.adoc[Mina2] (camel-mina2) +
-`mina2:protocol:host:port` | Socket level networking using TCP or UDP with the Apache Mina 2.x library.
-
| link:camel-mllp/src/main/docs/mllp-component.adoc[MLLP] (camel-mllp) +
`mllp:hostname:port` | The MLLP component is designed to handle the MLLP protocol and provide the functionality required by Healthcare providers to communicate with other systems using the MLLP protocol.

| link:camel-mongodb/src/main/docs/mongodb-component.adoc[MongoDB] (camel-mongodb) +
`mongodb:connectionBean` | Component for working with documents stored in MongoDB database.

-| link:camel-mongodb3/src/main/docs/mongodb3-component.adoc[MongoDB] (camel-mongodb3) +
-`mongodb3:connectionBean` | Component for working with documents stored in MongoDB database.
-
-| link:camel-mongodb-gridfs/src/main/docs/gridfs-component.adoc[MongoDBGridFS] (camel-mongodb-gridfs) +
-`gridfs:connectionBean` | Component for working with MongoDB GridFS.
-
-| link:camel-mqtt/src/main/docs/mqtt-component.adoc[MQTT] (camel-mqtt) +
-`mqtt:name` | Component for communicating with MQTT M2M message brokers using FuseSource MQTT Client.
-
-| link:camel-msv/src/main/docs/msv-component.adoc[MSV] (camel-msv) +
-`msv:resourceUri` | Validates the payload of a message using the MSV Library.
-
-| link:camel-mustache/src/main/docs/mustache-component.adoc[Mustache] (camel-mustache) +
-`mustache:resourceUri` | Transforms the message using a Mustache template.
-
-| link:camel-mvel/src/main/docs/mvel-component.adoc[MVEL] (camel-mvel) +
-`mvel:resourceUri` | Transforms the message using a MVEL template.
-
-| link:camel-mybatis/src/main/docs/mybatis-component.adoc[MyBatis] (camel-mybatis) +
-`mybatis:statement` | Performs a query poll insert update or delete in a relational database using MyBatis.
-
-| link:camel-nagios/src/main/docs/nagios-component.adoc[Nagios] (camel-nagios) +
-`nagios:host:port` | To send passive checks to Nagios using JSendNSCA.
-
-| link:camel-nats/src/main/docs/nats-component.adoc[Nats] (camel-nats) +
-`nats:servers` | The nats component allows you produce and consume messages from NATS.
-
-| link:camel-netty/src/main/docs/netty-component.adoc[Netty] (camel-netty) +
-`netty:protocol:host:port` | *deprecated* Socket level networking using TCP or UDP with the Netty 3.x library.
-
-| link:camel-netty-http/src/main/docs/netty-http-component.adoc[Netty HTTP] (camel-netty-http) +
-`netty-http:protocol:host:port/path` | *deprecated* Netty HTTP server and client using the Netty 3.x library.
-
| link:camel-netty4/src/main/docs/netty4-component.adoc[Netty4] (camel-netty4) +
`netty4:protocol:host:port` | Socket level networking using TCP or UDP with the Netty 4.x library.

| link:camel-netty4-http/src/main/docs/netty4-http-component.adoc[Netty4 HTTP] (camel-netty4-http) +
`netty4-http:protocol:host:port/path` | Netty HTTP server and client using the Netty 4.x library.

-| link:camel-openshift/src/main/docs/openshift-component.adoc[OpenShift] (camel-openshift) +
-`openshift:clientId` | *deprecated* To manage your Openshift 2.x applications.
-
| link:camel-openstack/src/main/docs/openstack-cinder-component.adoc[OpenStack-Cinder] (camel-openstack) +
`openstack-cinder:host` | Camel Components

@@ -402,174 +207,33 @@ Components
| link:camel-openstack/src/main/docs/openstack-swift-component.adoc[OpenStack-Swift] (camel-openstack) +
`openstack-swift:host` | Camel Components

-| link:camel-optaplanner/src/main/docs/optaplanner-component.adoc[OptaPlanner] (camel-optaplanner) +
-`optaplanner:configFile` | Solves the planning problem contained in a message with OptaPlanner.
-
-| link:camel-eventadmin/src/main/docs/eventadmin-component.adoc[OSGi EventAdmin] (camel-eventadmin) +
-`eventadmin:topic` | The eventadmin component can be used in an OSGi environment to receive OSGi EventAdmin events and process them.
-
-| link:camel-paxlogging/src/main/docs/paxlogging-component.adoc[OSGi PAX Logging] (camel-paxlogging) +
-`paxlogging:appender` | The paxlogging component can be used in an OSGi environment to receive PaxLogging events and process them.
-
-| link:camel-paho/src/main/docs/paho-component.adoc[Paho] (camel-paho) +
-`paho:topic` | Component for communicating with MQTT M2M message brokers using Eclipse Paho MQTT Client.
-
-| link:camel-pdf/src/main/docs/pdf-component.adoc[PDF] (camel-pdf) +
-`pdf:operation` | The pdf components provides the ability to create modify or extract content from PDF documents.
-
-| link:camel-pgevent/src/main/docs/pgevent-component.adoc[PostgresSQL Event] (camel-pgevent) +
-`pgevent:host:port/database/channel` | The pgevent component allows for producing/consuming PostgreSQL events related to the LISTEN/NOTIFY commands.
-
-| link:camel-printer/src/main/docs/lpr-component.adoc[Printer] (camel-printer) +
-`lpr:hostname:port/printername` | The printer component is used for sending messages to printers as print jobs.
-
-| link:camel-quartz/src/main/docs/quartz-component.adoc[Quartz] (camel-quartz) +
-`quartz:groupName/timerName` | *deprecated* Provides a scheduled delivery of messages using the Quartz 1.x scheduler.
-
-| link:camel-quartz2/src/main/docs/quartz2-component.adoc[Quartz2] (camel-quartz2) +
-`quartz2:groupName/triggerName` | Provides a scheduled delivery of messages using the Quartz 2.x scheduler.
-
-| link:camel-quickfix/src/main/docs/quickfix-component.adoc[QuickFix] (camel-quickfix) +
-`quickfix:configurationName` | The quickfix component allows to send Financial Interchange (FIX) messages to the QuickFix engine.
-
-| link:camel-rabbitmq/src/main/docs/rabbitmq-component.adoc[RabbitMQ] (camel-rabbitmq) +
-`rabbitmq:hostname:portNumber/exchangeName` | The rabbitmq component allows you produce and consume messages from RabbitMQ instances.
-
-| link:camel-restlet/src/main/docs/restlet-component.adoc[Restlet] (camel-restlet) +
-`restlet:protocol:host:port/uriPattern` | Component for consuming and producing Restful resources using Restlet.
-
-| link:camel-rmi/src/main/docs/rmi-component.adoc[RMI] (camel-rmi) +
-`rmi:hostname:port/name` | The rmi component is for invoking Java RMI beans from Camel.
-
-| link:camel-routebox/src/main/docs/routebox-component.adoc[RouteBox] (camel-routebox) +
-`routebox:routeboxName` | *deprecated* The routebox component allows to send/receive messages between Camel routes in a black box way.
-
-| link:camel-rss/src/main/docs/rss-component.adoc[RSS] (camel-rss) +
-`rss:feedUri` | The rss component is used for consuming RSS feeds.
-
| link:camel-salesforce/src/main/docs/salesforce-component.adoc[Salesforce] (camel-salesforce) +
`salesforce:operationName:topicName` | The salesforce component is used for integrating Camel with the massive Salesforce API.

-| link:camel-sap-netweaver/src/main/docs/sap-netweaver-component.adoc[SAP NetWeaver] (camel-sap-netweaver) +
-`sap-netweaver:url` | The sap-netweaver component integrates with the SAP NetWeaver Gateway using HTTP transports.
-
-| link:camel-schematron/src/main/docs/schematron-component.adoc[Schematron] (camel-schematron) +
-`schematron:path` | Validates the payload of a message using the Schematron Library.
-
-| link:camel-jsch/src/main/docs/scp-component.adoc[SCP] (camel-jsch) +
-`scp:host:port/directoryName` | To copy files using the secure copy protocol (SCP).
-
-| link:camel-servicenow/src/main/docs/servicenow-component.adoc[ServiceNow] (camel-servicenow) +
-`servicenow:instanceName` | The servicenow component is used to integrate Camel with ServiceNow cloud services.
-
| link:camel-servlet/src/main/docs/servlet-component.adoc[Servlet] (camel-servlet) +
`servlet:contextPath` | To use a HTTP Servlet as entry for Camel routes when running in a servlet container.

-| link:camel-ftp/src/main/docs/sftp-component.adoc[SFTP] (camel-ftp) +
-`sftp:host:port/directoryName` | The sftp (FTP over SSH) component is used for uploading or downloading files from SFTP servers.
-
-| link:camel-sjms/src/main/docs/sjms-component.adoc[Simple JMS] (camel-sjms) +
-`sjms:destinationType:destinationName` | The sjms component (simple jms) allows messages to be sent to (or consumed from) a JMS Queue or Topic.
-
-| link:camel-sjms/src/main/docs/sjms-batch-component.adoc[Simple JMS Batch] (camel-sjms) +
-`sjms-batch:destinationName` | The sjms-batch component is a specialized for highly performant transactional batch consumption from a JMS queue.
-
-| link:camel-sip/src/main/docs/sip-component.adoc[SIP] (camel-sip) +
-`sip:uri` | To send and receive messages using the SIP protocol (used in telco and mobile).
-
-| link:camel-slack/src/main/docs/slack-component.adoc[Slack] (camel-slack) +
-`slack:channel` | The slack component allows you to send messages to Slack.
-
| link:camel-smpp/src/main/docs/smpp-component.adoc[SMPP] (camel-smpp) +
`smpp:host:port` | To send and receive SMS using a SMSC (Short Message Service Center).

-| link:camel-snmp/src/main/docs/snmp-component.adoc[SNMP] (camel-snmp) +
-`snmp:host:port` | The snmp component gives you the ability to poll SNMP capable devices or receiving traps.
-
-| link:camel-solr/src/main/docs/solr-component.adoc[Solr] (camel-solr) +
-`solr:url` | The solr component allows you to interface with an Apache Lucene Solr server.
-
-| link:camel-spark-rest/src/main/docs/spark-rest-component.adoc[Spark Rest] (camel-spark-rest) +
-`spark-rest:verb:path` | The spark-rest component is used for hosting REST services which has been defined using Camel rest-dsl.
-
-| link:camel-splunk/src/main/docs/splunk-component.adoc[Splunk] (camel-splunk) +
-`splunk:name` | The splunk component allows to publish or search for events in Splunk.
-
-| link:camel-spring-batch/src/main/docs/spring-batch-component.adoc[Spring Batch] (camel-spring-batch) +
-`spring-batch:jobName` | The spring-batch component allows to send messages to Spring Batch for further processing.
-
| link:camel-spring/src/main/docs/spring-event-component.adoc[Spring Event] (camel-spring) +
`spring-event:name` | The spring-event component allows to listen for Spring Application Events.

-| link:camel-spring-integration/src/main/docs/spring-integration-component.adoc[Spring Integration] (camel-spring-integration) +
-`spring-integration:defaultChannel` | Bridges Camel with Spring Integration.
-
-| link:camel-spring-ldap/src/main/docs/spring-ldap-component.adoc[Spring LDAP] (camel-spring-ldap) +
-`spring-ldap:templateName` | The spring-ldap component allows you to perform searches in LDAP servers using filters as the message payload.
-
-| link:camel-spring-redis/src/main/docs/spring-redis-component.adoc[Spring Redis] (camel-spring-redis) +
-`spring-redis:host:port` | The spring-redis component allows sending and receiving messages from Redis.
-
-| link:camel-spring-ws/src/main/docs/spring-ws-component.adoc[Spring WebService] (camel-spring-ws) +
-`spring-ws:type:lookupKey:webServiceEndpointUri` | The spring-ws component is used for SOAP WebServices using Spring WebServices.
-
| link:camel-sql/src/main/docs/sql-component.adoc[SQL] (camel-sql) +
`sql:query` | The sql component allows you to work with databases using JDBC SQL queries.

| link:camel-sql/src/main/docs/sql-stored-component.adoc[SQL StoredProcedure] (camel-sql) +
`sql-stored:template` | The sql component allows you to work with databases using JDBC Stored Procedure queries.

-| link:camel-ssh/src/main/docs/ssh-component.adoc[SSH] (camel-ssh) +
-`ssh:host:port` | The ssh component enables access to SSH servers such that you can send an SSH command and process the response.
-
-| link:camel-stax/src/main/docs/stax-component.adoc[StAX] (camel-stax) +
-`stax:contentHandlerClass` | The stax component allows messages to be process through a SAX ContentHandler.
-
-| link:camel-stomp/src/main/docs/stomp-component.adoc[Stomp] (camel-stomp) +
-`stomp:destination` | The stomp component is used for communicating with Stomp compliant message brokers.
-
| link:camel-stream/src/main/docs/stream-component.adoc[Stream] (camel-stream) +
`stream:kind` | The stream: component provides access to the system-in system-out and system-err streams as well as allowing streaming of file and URL.

-| link:camel-stringtemplate/src/main/docs/string-template-component.adoc[String Template] (camel-stringtemplate) +
-`string-template:resourceUri` | Transforms the message using a String template.
-
-| link:camel-telegram/src/main/docs/telegram-component.adoc[Telegram] (camel-telegram) +
-`telegram:type/authorizationToken` | The telegram component provides access to the Telegram Bot API.
-
-| link:camel-twitter/src/main/docs/twitter-component.adoc[Twitter] (camel-twitter) +
-`twitter:kind` | This component integrates with Twitter to send tweets or search for tweets and more.
-
-| link:camel-undertow/src/main/docs/undertow-component.adoc[Undertow] (camel-undertow) +
-`undertow:httpURI` | The undertow component provides HTTP-based endpoints for consuming and producing HTTP requests.
-
| link:camel-velocity/src/main/docs/velocity-component.adoc[Velocity] (camel-velocity) +
`velocity:resourceUri` | Transforms the message using a Velocity template.

-| link:camel-vertx/src/main/docs/vertx-component.adoc[Vert.x] (camel-vertx) +
-`vertx:address` | The vertx component is used for sending and receive messages from a vertx event bus.
-
| link:camel-weather/src/main/docs/weather-component.adoc[Weather] (camel-weather) +
`weather:name` | Polls the weather information from Open Weather Map.

-| link:camel-xmlrpc/src/main/docs/xmlrpc-component.adoc[XML RPC] (camel-xmlrpc) +
-`xmlrpc:address` | The xmlrpc component is used for sending messages to a XML RPC service.
-
-| link:camel-xmlsecurity/src/main/docs/xmlsecurity-component.adoc[XML Security] (camel-xmlsecurity) +
-`xmlsecurity:command:name` | Used to sign and verify exchanges using the XML signature specification.
-
-| link:camel-xmpp/src/main/docs/xmpp-component.adoc[XMPP] (camel-xmpp) +
-`xmpp:host:port/participant` | To send and receive messages from a XMPP (chat) server.
-
-| link:camel-saxon/src/main/docs/xquery-component.adoc[XQuery] (camel-saxon) +
-`xquery:resourceUri` | Transforms the message using a XQuery template using Saxon.
-
-| link:camel-yammer/src/main/docs/yammer-component.adoc[Yammer] (camel-yammer) +
-`yammer:function` | The yammer component allows you to interact with the Yammer enterprise social network.
-
-| link:camel-zookeeper/src/main/docs/zookeeper-component.adoc[ZooKeeper] (camel-zookeeper) +
-`zookeeper:serverUrls/path` | The zookeeper component allows interaction with a ZooKeeper cluster.
-
|=======================================================================
// components: END

@@ -646,65 +310,17 @@ Data Formats

| link:camel-csv/src/main/docs/csv-dataformat.adoc[CSV] (camel-csv) | Camel CSV data format support

-| link:camel-flatpack/src/main/docs/flatpack-dataformat.adoc[Flatpack] (camel-flatpack) | Camel FlatPack support
-
| link:camel-hessian/src/main/docs/hessian-dataformat.adoc[Hessian] (camel-hessian) | Hessian serialization support

| link:camel-hl7/src/main/docs/hl7-dataformat.adoc[HL7] (camel-hl7) | Camel HL7 support

-| link:camel-ical/src/main/docs/ical-dataformat.adoc[iCal] (camel-ical) | Camel iCal component
-
| link:camel-jacksonxml/src/main/docs/jacksonxml-dataformat.adoc[JacksonXML] (camel-jacksonxml) | Camel Jackson XML support

| link:camel-jaxb/src/main/docs/jaxb-dataformat.adoc[JAXB] (camel-jaxb) | Camel JAXB support

-| link:camel-jibx/src/main/docs/jibx-dataformat.adoc[JiBX] (camel-jibx) | Camel Jibx support
-
-| link:camel-gson/src/main/docs/json-gson-dataformat.adoc[JSon GSon] (camel-gson) | Camel Gson support
-
| link:camel-jackson/src/main/docs/json-jackson-dataformat.adoc[JSon Jackson] (camel-jackson) | Camel Jackson support

-| link:camel-johnzon/src/main/docs/json-johnzon-dataformat.adoc[JSon Johnzon] (camel-johnzon) | Camel Johnzon support
-
-| link:camel-xstream/src/main/docs/json-xstream-dataformat.adoc[JSon XStream] (camel-xstream) | Camel XStream support
-
-| link:camel-lzf/src/main/docs/lzf-dataformat.adoc[LZF Deflate Compression] (camel-lzf) | Camel LZF support
-
-| link:camel-mail/src/main/docs/mime-multipart-dataformat.adoc[MIME Multipart] (camel-mail) | Camel Mail support
-
| link:camel-crypto/src/main/docs/pgp-dataformat.adoc[PGP] (camel-crypto) | Camel Cryptographic Support
-
-| link:camel-protobuf/src/main/docs/protobuf-dataformat.adoc[Protobuf] (camel-protobuf) | Camel Google Protobuf data format support
-
-| link:camel-rss/src/main/docs/rss-dataformat.adoc[RSS] (camel-rss) | Camel RSS support
-
-| link:camel-soap/src/main/docs/soapjaxb-dataformat.adoc[SOAP] (camel-soap) | Camel SOAP support
-
-| link:camel-syslog/src/main/docs/syslog-dataformat.adoc[Syslog] (camel-syslog) | Camel Syslog support
-
-| link:camel-tarfile/src/main/docs/tarfile-dataformat.adoc[Tar File] (camel-tarfile) | Camel Tar file support
-
-| link:camel-tagsoup/src/main/docs/tidyMarkup-dataformat.adoc[TidyMarkup] (camel-tagsoup) | Camel TagSoup support
-
-| link:camel-univocity-parsers/src/main/docs/univocity-csv-dataformat.adoc[uniVocity CSV] (camel-univocity-parsers) | Camel UniVocity parsers data format support
-
-| link:camel-univocity-parsers/src/main/docs/univocity-fixed-dataformat.adoc[uniVocity Fixed Length] (camel-univocity-parsers) | Camel UniVocity parsers data format support
-
-| link:camel-univocity-parsers/src/main/docs/univocity-tsv-dataformat.adoc[uniVocity TSV] (camel-univocity-parsers) | Camel UniVocity parsers data format support
-
-| link:camel-xmlbeans/src/main/docs/xmlBeans-dataformat.adoc[XML Beans] (camel-xmlbeans) | Camel XMLBeans support
-
-| link:camel-xmljson/src/main/docs/xmljson-dataformat.adoc[XML JSon] (camel-xmljson) | Camel XML JSON Data Format
-
-| link:camel-xmlrpc/src/main/docs/xmlrpc-dataformat.adoc[XML RPC] (camel-xmlrpc) | Camel XML RPC support
-
-| link:camel-xmlsecurity/src/main/docs/secureXML-dataformat.adoc[XML Security] (camel-xmlsecurity) | Camel Partial XML Encryption/Decryption and XML Signature support
-
-| link:camel-xstream/src/main/docs/xstream-dataformat.adoc[XStream] (camel-xstream) | Camel XStream support
-
-| link:camel-snakeyaml/src/main/docs/yaml-snakeyaml-dataformat.adoc[YAML SnakeYAML] (camel-snakeyaml) | Camel SnakeYAML support
-
-| link:camel-zipfile/src/main/docs/zipfile-dataformat.adoc[Zip File] (camel-zipfile) | Camel Zip file support
|=======================================================================
// dataformats: END

@@ -723,27 +339,9 @@ Expression Languages

| link:camel-hl7/src/main/docs/terser-language.adoc[HL7 Terser] (camel-hl7) | For HL7 terser expressions and predicates

-| link:camel-script/src/main/docs/javaScript-language.adoc[JavaScript] (camel-script) | For JavaScript expressions and predicates
-
-| link:camel-jsonpath/src/main/docs/jsonpath-language.adoc[JSonPath] (camel-jsonpath) | For JSonPath expressions and predicates
-
| link:camel-jxpath/src/main/docs/jxpath-language.adoc[JXPath] (camel-jxpath) | For JXPath expressions and predicates

-| link:camel-mvel/src/main/docs/mvel-language.adoc[MVEL] (camel-mvel) | For MVEL expressions and predicates
-
-| link:camel-ognl/src/main/docs/ognl-language.adoc[OGNL] (camel-ognl) | For OGNL expressions and predicates
-
-| link:camel-script/src/main/docs/php-language.adoc[PHP] (camel-script) | For PHP expressions and predicates
-
-| link:camel-script/src/main/docs/python-language.adoc[Python] (camel-script) | For Python expressions and predicates
-
-| link:camel-script/src/main/docs/ruby-language.adoc[Ruby] (camel-script) | For Ruby expressions and predicates
-
| link:camel-spring/src/main/docs/spel-language.adoc[SpEL] (camel-spring) | For Spring Expression Language (SpEL) expressions and predicates
-
-| link:camel-josql/src/main/docs/sql-language.adoc[SQL] (camel-josql) | For SQL expressions and predicates
-
-| link:camel-saxon/src/main/docs/xquery-language.adoc[XQuery] (camel-saxon) | For XQuery expressions and predicates
|=======================================================================
// languages: END


Re: camel git commit: Fix CS violations

Posted by Babak Vahdat <ba...@swissonline.ch>.
> On 19 Dec 2016, at 11:15, Claus Ibsen <cl...@gmail.com> wrote:
> 
> Hi
> 
> Okay I found the issue. Its when you don't run the platforms/catalog
> build which is the guy that is responsible for updating that readme
> file.
> 
> I just regen the doc and its up to date again.
> 

Just a side note: the full-build I triggered yesterday after the made changes looks also good: 

https://builds.apache.org/view/All/job/Camel.trunk.fulltest.java8/1073/ <https://builds.apache.org/view/All/job/Camel.trunk.fulltest.java8/1073/>

Babak

> On Mon, Dec 19, 2016 at 11:00 AM, Claus Ibsen <cl...@gmail.com> wrote:
>> Yeah we need to revert those .docs files.
>> 
>> And keep an eye on the build if it generates those two files
>> correctly, there may be a flaw in the camel-package-maven-plugin that
>> has the code for this.
>> 
>> On Mon, Dec 19, 2016 at 10:55 AM, Andrea Cosentino
>> <an...@yahoo.com.invalid> wrote:
>>> It looks like the build deleted the components list from readme.
>>> --
>>> Andrea Cosentino
>>> ----------------------------------
>>> Apache Camel PMC Member
>>> Apache Karaf Committer
>>> Apache Servicemix Committer
>>> Email: ancosen1985@yahoo.com
>>> Twitter: @oscerd2
>>> Github: oscerd
>>> 
>>> 
>>> 
>>> On Sunday, December 18, 2016 6:27 PM, "bvahdat@apache.org" <bv...@apache.org> wrote:
>>> Repository: camel
>>> Updated Branches:
>>>  refs/heads/master 079b5f9e6 -> 490a76f17
>>> 
>>> 
>>> Fix CS violations
>>> 
>>> Project: http://git-wip-us.apache.org/repos/asf/camel/repo
>>> Commit: http://git-wip-us.apache.org/repos/asf/camel/commit/490a76f1
>>> Tree: http://git-wip-us.apache.org/repos/asf/camel/tree/490a76f1
>>> Diff: http://git-wip-us.apache.org/repos/asf/camel/diff/490a76f1
>>> 
>>> Branch: refs/heads/master
>>> Commit: 490a76f17a1cb96a08009607a7aa972e7bc0372d
>>> Parents: 079b5f9
>>> Author: Babak Vahdat <bv...@apache.org>
>>> Authored: Sun Dec 18 18:26:52 2016 +0100
>>> Committer: Babak Vahdat <bv...@apache.org>
>>> Committed: Sun Dec 18 18:26:52 2016 +0100
>>> 
>>> ----------------------------------------------------------------------
>>> .../component/bonita/BonitaConfiguration.java   |   6 +-
>>> .../core/xml/CamelProxyFactoryDefinition.java   |   2 +-
>>> .../camel/component/gridfs/GridFsEndpoint.java  |   1 -
>>> .../openstack/nova/KeypairProducerTest.java     |   2 +-
>>> .../processor/RibbonServiceCallProcessor.java   |  19 +-
>>> .../component/servicenow/ServiceNowClient.java  |   2 +-
>>> components/readme.adoc                          | 402 -------------------
>>> 7 files changed, 15 insertions(+), 419 deletions(-)
>>> ----------------------------------------------------------------------
>>> 
>>> 
>>> http://git-wip-us.apache.org/repos/asf/camel/blob/490a76f1/components/camel-bonita/src/main/java/org/apache/camel/component/bonita/BonitaConfiguration.java
>>> ----------------------------------------------------------------------
>>> diff --git a/components/camel-bonita/src/main/java/org/apache/camel/component/bonita/BonitaConfiguration.java b/components/camel-bonita/src/main/java/org/apache/camel/component/bonita/BonitaConfiguration.java
>>> index 7343e2c..b992682 100644
>>> --- a/components/camel-bonita/src/main/java/org/apache/camel/component/bonita/BonitaConfiguration.java
>>> +++ b/components/camel-bonita/src/main/java/org/apache/camel/component/bonita/BonitaConfiguration.java
>>> @@ -5,9 +5,9 @@
>>>  * 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
>>> - * <p>
>>> - * http://www.apache.org/licenses/LICENSE-2.0
>>> - * <p>
>>> + *
>>> + *      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.
>>> 
>>> http://git-wip-us.apache.org/repos/asf/camel/blob/490a76f1/components/camel-core-xml/src/main/java/org/apache/camel/core/xml/CamelProxyFactoryDefinition.java
>>> ----------------------------------------------------------------------
>>> diff --git a/components/camel-core-xml/src/main/java/org/apache/camel/core/xml/CamelProxyFactoryDefinition.java b/components/camel-core-xml/src/main/java/org/apache/camel/core/xml/CamelProxyFactoryDefinition.java
>>> index 6f160ce..5c78b93 100644
>>> --- a/components/camel-core-xml/src/main/java/org/apache/camel/core/xml/CamelProxyFactoryDefinition.java
>>> +++ b/components/camel-core-xml/src/main/java/org/apache/camel/core/xml/CamelProxyFactoryDefinition.java
>>> @@ -63,7 +63,7 @@ public class CamelProxyFactoryDefinition extends IdentifiedType {
>>>      * @deprecated use serviceUrl instead with the ref endpoint.
>>>      */
>>>     @Deprecated
>>> -    public void setServiceRef(String serviceRef) {
>>> +    public void setServiceRef(String serviceRef) {
>>>         this.serviceRef = serviceRef;
>>>     }
>>> 
>>> 
>>> http://git-wip-us.apache.org/repos/asf/camel/blob/490a76f1/components/camel-mongodb-gridfs/src/main/java/org/apache/camel/component/gridfs/GridFsEndpoint.java
>>> ----------------------------------------------------------------------
>>> diff --git a/components/camel-mongodb-gridfs/src/main/java/org/apache/camel/component/gridfs/GridFsEndpoint.java b/components/camel-mongodb-gridfs/src/main/java/org/apache/camel/component/gridfs/GridFsEndpoint.java
>>> index cb8f686..f4d5d65 100644
>>> --- a/components/camel-mongodb-gridfs/src/main/java/org/apache/camel/component/gridfs/GridFsEndpoint.java
>>> +++ b/components/camel-mongodb-gridfs/src/main/java/org/apache/camel/component/gridfs/GridFsEndpoint.java
>>> @@ -39,7 +39,6 @@ import org.slf4j.LoggerFactory;
>>> @UriEndpoint(scheme = "gridfs", title = "MongoDBGridFS", syntax = "gridfs:connectionBean", label = "database,nosql")
>>> public class GridFsEndpoint extends DefaultEndpoint {
>>> 
>>> -    ;
>>>     public static final String GRIDFS_OPERATION = "gridfs.operation";
>>>     public static final String GRIDFS_METADATA = "gridfs.metadata";
>>>     public static final String GRIDFS_CHUNKSIZE = "gridfs.chunksize";
>>> 
>>> http://git-wip-us.apache.org/repos/asf/camel/blob/490a76f1/components/camel-openstack/src/test/java/org/apache/camel/component/openstack/nova/KeypairProducerTest.java
>>> ----------------------------------------------------------------------
>>> diff --git a/components/camel-openstack/src/test/java/org/apache/camel/component/openstack/nova/KeypairProducerTest.java b/components/camel-openstack/src/test/java/org/apache/camel/component/openstack/nova/KeypairProducerTest.java
>>> index c851a40..ba4813e 100644
>>> --- a/components/camel-openstack/src/test/java/org/apache/camel/component/openstack/nova/KeypairProducerTest.java
>>> +++ b/components/camel-openstack/src/test/java/org/apache/camel/component/openstack/nova/KeypairProducerTest.java
>>> @@ -114,6 +114,6 @@ public class KeypairProducerTest extends NovaProducerTestSupport {
>>>     }
>>> 
>>>     private Keypair createDummyKeypair() {
>>> -        return NovaKeypair.create(KEYPAIR_NAME, "string contains private key");
>>> +        return NovaKeypair.create(KEYPAIR_NAME, "string contains private key");
>>>     }
>>> }
>>> 
>>> http://git-wip-us.apache.org/repos/asf/camel/blob/490a76f1/components/camel-ribbon/src/main/java/org/apache/camel/component/ribbon/processor/RibbonServiceCallProcessor.java
>>> ----------------------------------------------------------------------
>>> diff --git a/components/camel-ribbon/src/main/java/org/apache/camel/component/ribbon/processor/RibbonServiceCallProcessor.java b/components/camel-ribbon/src/main/java/org/apache/camel/component/ribbon/processor/RibbonServiceCallProcessor.java
>>> index f9151ce..f701ba0 100644
>>> --- a/components/camel-ribbon/src/main/java/org/apache/camel/component/ribbon/processor/RibbonServiceCallProcessor.java
>>> +++ b/components/camel-ribbon/src/main/java/org/apache/camel/component/ribbon/processor/RibbonServiceCallProcessor.java
>>> @@ -19,7 +19,6 @@ package org.apache.camel.component.ribbon.processor;
>>> import java.util.Map;
>>> import java.util.concurrent.RejectedExecutionException;
>>> 
>>> -import com.netflix.client.config.CommonClientConfigKey;
>>> import com.netflix.client.config.IClientConfig;
>>> import com.netflix.client.config.IClientConfigKey;
>>> import com.netflix.loadbalancer.DummyPing;
>>> @@ -46,8 +45,8 @@ import org.apache.camel.spi.IdAware;
>>> import org.apache.camel.spi.ServiceCallServerListStrategy;
>>> import org.apache.camel.support.ServiceSupport;
>>> import org.apache.camel.util.AsyncProcessorHelper;
>>> -import org.apache.camel.util.ObjectHelper;
>>> import org.apache.camel.util.ServiceHelper;
>>> +import org.apache.camel.util.StringHelper;
>>> import org.slf4j.Logger;
>>> import org.slf4j.LoggerFactory;
>>> 
>>> @@ -78,18 +77,18 @@ public class RibbonServiceCallProcessor extends ServiceSupport implements AsyncP
>>>         // setup from the provided name which can contain scheme and context-path information as well
>>>         String serviceName;
>>>         if (name.contains("/")) {
>>> -            serviceName = ObjectHelper.before(name, "/");
>>> -            this.contextPath = ObjectHelper.after(name, "/");
>>> +            serviceName = StringHelper.before(name, "/");
>>> +            this.contextPath = StringHelper.after(name, "/");
>>>         } else if (name.contains("?")) {
>>> -            serviceName = ObjectHelper.before(name, "?");
>>> -            this.contextPath = ObjectHelper.after(name, "?");
>>> +            serviceName = StringHelper.before(name, "?");
>>> +            this.contextPath = StringHelper.after(name, "?");
>>>         } else {
>>>             serviceName = name;
>>>             this.contextPath = null;
>>>         }
>>>         if (serviceName.contains(":")) {
>>> -            this.scheme = ObjectHelper.before(serviceName, ":");
>>> -            this.name = ObjectHelper.after(serviceName, ":");
>>> +            this.scheme = StringHelper.before(serviceName, ":");
>>> +            this.name = StringHelper.after(serviceName, ":");
>>>         } else {
>>>             this.scheme = scheme;
>>>             this.name = serviceName;
>>> @@ -199,7 +198,7 @@ public class RibbonServiceCallProcessor extends ServiceSupport implements AsyncP
>>>     @Override
>>>     @SuppressWarnings("unchecked")
>>>     protected void doStart() throws Exception {
>>> -        ObjectHelper.notEmpty(name, "name", this);
>>> +        StringHelper.notEmpty(name, "name", this);
>>> 
>>>         if (serverListStrategy == null) {
>>>             serverListStrategy = new RibbonServiceCallStaticServerListStrategy();
>>> @@ -222,7 +221,7 @@ public class RibbonServiceCallProcessor extends ServiceSupport implements AsyncP
>>>         IClientConfig config = IClientConfig.Builder.newBuilder(name).build();
>>>         if (ribbonClientConfig != null) {
>>>             for (Map.Entry<String, String> entry : ribbonClientConfig.entrySet()) {
>>> -                IClientConfigKey key = CommonClientConfigKey.valueOf(entry.getKey());
>>> +                IClientConfigKey key = IClientConfigKey.Keys.valueOf(entry.getKey());
>>>                 String value = entry.getValue();
>>>                 LOG.debug("RibbonClientConfig: {}={}", key.key(), value);
>>>                 config.set(key, entry.getValue());
>>> 
>>> http://git-wip-us.apache.org/repos/asf/camel/blob/490a76f1/components/camel-servicenow/src/main/java/org/apache/camel/component/servicenow/ServiceNowClient.java
>>> ----------------------------------------------------------------------
>>> diff --git a/components/camel-servicenow/src/main/java/org/apache/camel/component/servicenow/ServiceNowClient.java b/components/camel-servicenow/src/main/java/org/apache/camel/component/servicenow/ServiceNowClient.java
>>> index 2bdd86a..fa33607 100644
>>> --- a/components/camel-servicenow/src/main/java/org/apache/camel/component/servicenow/ServiceNowClient.java
>>> +++ b/components/camel-servicenow/src/main/java/org/apache/camel/component/servicenow/ServiceNowClient.java
>>> @@ -162,7 +162,7 @@ public final class ServiceNowClient {
>>>     }
>>> 
>>>     private static void configureTls(
>>> -        CamelContext camelContext, ServiceNowConfiguration configuration, WebClient client) throws Exception{
>>> +        CamelContext camelContext, ServiceNowConfiguration configuration, WebClient client) throws Exception {
>>> 
>>>         SSLContextParameters sslContextParams = configuration.getSslContextParameters();
>>>         if (sslContextParams != null) {
>>> 
>>> http://git-wip-us.apache.org/repos/asf/camel/blob/490a76f1/components/readme.adoc
>>> ----------------------------------------------------------------------
>>> diff --git a/components/readme.adoc b/components/readme.adoc
>>> index 6d1eb1a..81b3828 100644
>>> --- a/components/readme.adoc
>>> +++ b/components/readme.adoc
>>> @@ -15,12 +15,6 @@ Components
>>> | link:camel-amqp/src/main/docs/amqp-component.adoc[AMQP] (camel-amqp) +
>>> `amqp:destinationType:destinationName` | Messaging with AMQP protocol using Apache QPid Client.
>>> 
>>> -| link:camel-flink/src/main/docs/flink-component.adoc[Apache Flink] (camel-flink) +
>>> -`flink:endpointType` | The flink component can be used to send DataSet jobs to Apache Flink cluster.
>>> -
>>> -| link:camel-spark/src/main/docs/spark-component.adoc[Apache Spark] (camel-spark) +
>>> -`spark:endpointType` | The spark component can be used to send RDD or DataFrame jobs to Apache Spark cluster.
>>> -
>>> | link:camel-apns/src/main/docs/apns-component.adoc[APNS] (camel-apns) +
>>> `apns:name` | For sending notifications to Apple iOS devices.
>>> 
>>> @@ -141,249 +135,60 @@ Components
>>> | link:camel-drill/src/main/docs/drill-component.adoc[Drill] (camel-drill) +
>>> `drill:host` | The drill component gives you the ability to quering into apache drill cluster.
>>> 
>>> -| link:camel-dropbox/src/main/docs/dropbox-component.adoc[Dropbox] (camel-dropbox) +
>>> -`dropbox:operation` | For uploading downloading and managing files folders groups collaborations etc on dropbox DOT com.
>>> -
>>> | link:camel-cache/src/main/docs/cache-component.adoc[EHCache] (camel-cache) +
>>> `cache:cacheName` | *deprecated* The cache component enables you to perform caching operations using EHCache as the Cache Implementation.
>>> 
>>> -| link:camel-ehcache/src/main/docs/ehcache-component.adoc[Ehcache] (camel-ehcache) +
>>> -`ehcache:cacheName` | The ehcache component enables you to perform caching operations using Ehcache as cache implementation.
>>> -
>>> -| link:camel-ejb/src/main/docs/ejb-component.adoc[EJB] (camel-ejb) +
>>> -`ejb:beanName` | The ejb component is for invoking EJB Java beans from Camel.
>>> -
>>> -| link:camel-elasticsearch/src/main/docs/elasticsearch-component.adoc[Elasticsearch] (camel-elasticsearch) +
>>> -`elasticsearch:clusterName` | The elasticsearch component is used for interfacing with ElasticSearch server.
>>> -
>>> -| link:camel-elsql/src/main/docs/elsql-component.adoc[ElSQL] (camel-elsql) +
>>> -`elsql:elsqlName:resourceUri` | The elsql component is an extension to the existing SQL Component that uses ElSql to define the SQL queries.
>>> -
>>> -| link:camel-etcd/src/main/docs/etcd-component.adoc[etcd] (camel-etcd) +
>>> -`etcd:namespace/path` | The camel etcd component allows you to work with Etcd a distributed A distributed reliable key-value store.
>>> -
>>> -| link:camel-exec/src/main/docs/exec-component.adoc[Exec] (camel-exec) +
>>> -`exec:executable` | The exec component can be used to execute OS system commands.
>>> -
>>> -| link:camel-facebook/src/main/docs/facebook-component.adoc[Facebook] (camel-facebook) +
>>> -`facebook:methodName` | The Facebook component provides access to all of the Facebook APIs accessible using Facebook4J.
>>> -
>>> -| link:camel-flatpack/src/main/docs/flatpack-component.adoc[Flatpack] (camel-flatpack) +
>>> -`flatpack:type:resourceUri` | The flatpack component supports fixed width and delimited file parsing via the FlatPack library.
>>> -
>>> -| link:camel-fop/src/main/docs/fop-component.adoc[FOP] (camel-fop) +
>>> -`fop:outputType` | The fop component allows you to render a message into different output formats using Apache FOP.
>>> -
>>> -| link:camel-freemarker/src/main/docs/freemarker-component.adoc[Freemarker] (camel-freemarker) +
>>> -`freemarker:resourceUri` | Transforms the message using a FreeMarker template.
>>> -
>>> -| link:camel-ftp/src/main/docs/ftp-component.adoc[FTP] (camel-ftp) +
>>> -`ftp:host:port/directoryName` | The ftp component is used for uploading or downloading files from FTP servers.
>>> -
>>> -| link:camel-ftp/src/main/docs/ftps-component.adoc[FTPS] (camel-ftp) +
>>> -`ftps:host:port/directoryName` | The ftps (FTP secure SSL/TLS) component is used for uploading or downloading files from FTP servers.
>>> -
>>> -| link:camel-ganglia/src/main/docs/ganglia-component.adoc[Ganglia] (camel-ganglia) +
>>> -`ganglia:host:port` | The ganglia component is used for sending metrics to the Ganglia monitoring system.
>>> -
>>> -| link:camel-geocoder/src/main/docs/geocoder-component.adoc[Geocoder] (camel-geocoder) +
>>> -`geocoder:address:latlng` | The geocoder component is used for looking up geocodes (latitude and longitude) for a given address or reverse lookup.
>>> -
>>> -| link:camel-git/src/main/docs/git-component.adoc[Git] (camel-git) +
>>> -`git:localPath` | The git component is used for working with git repositories.
>>> -
>>> -| link:camel-github/src/main/docs/github-component.adoc[GitHub] (camel-github) +
>>> -`github:type/branchName` | The github component is used for integrating Camel with github.
>>> -
>>> | link:camel-google-calendar/src/main/docs/google-calendar-component.adoc[Google Calendar] (camel-google-calendar) +
>>> `google-calendar:apiName/methodName` | The google-calendar component provides access to Google Calendar.
>>> 
>>> -| link:camel-google-drive/src/main/docs/google-drive-component.adoc[Google Drive] (camel-google-drive) +
>>> -`google-drive:apiName/methodName` | The google-drive component provides access to Google Drive file storage service.
>>> -
>>> -| link:camel-google-mail/src/main/docs/google-mail-component.adoc[Google Mail] (camel-google-mail) +
>>> -`google-mail:apiName/methodName` | The google-mail component provides access to Google Mail.
>>> -
>>> | link:camel-google-pubsub/src/main/docs/google-pubsub-component.adoc[Google Pubsub] (camel-google-pubsub) +
>>> `google-pubsub:projectId:destinationName` | Messaging client for Google Cloud Platform PubSub Service: https://cloud.google.com/pubsub/
>>> 
>>> -| link:camel-gora/src/main/docs/gora-component.adoc[Gora] (camel-gora) +
>>> -`gora:name` | The gora component allows you to work with NoSQL databases using the Apache Gora framework.
>>> -
>>> | link:camel-grape/src/main/docs/grape-component.adoc[Grape] (camel-grape) +
>>> `grape:defaultCoordinates` | Grape component allows you to fetch, load and manage additional jars when CamelContext is running.
>>> 
>>> -| link:camel-guava-eventbus/src/main/docs/guava-eventbus-component.adoc[Guava EventBus] (camel-guava-eventbus) +
>>> -`guava-eventbus:eventBusRef` | The guava-eventbus component provides integration bridge between Camel and Google Guava EventBus.
>>> -
>>> -| link:camel-hazelcast/src/main/docs/hazelcast-component.adoc[Hazelcast] (camel-hazelcast) +
>>> -`hazelcast:command:cacheName` | The hazelcast component allows you to work with the Hazelcast distributed data grid / cache.
>>> -
>>> -| link:camel-hbase/src/main/docs/hbase-component.adoc[HBase] (camel-hbase) +
>>> -`hbase:tableName` | For reading/writing from/to an HBase store (Hadoop database).
>>> -
>>> -| link:camel-hdfs/src/main/docs/hdfs-component.adoc[HDFS] (camel-hdfs) +
>>> -`hdfs:hostName:port/path` | *deprecated* For reading/writing from/to an HDFS filesystem using Hadoop 1.x.
>>> -
>>> -| link:camel-hdfs2/src/main/docs/hdfs2-component.adoc[HDFS2] (camel-hdfs2) +
>>> -`hdfs2:hostName:port/path` | For reading/writing from/to an HDFS filesystem using Hadoop 2.x.
>>> -
>>> -| link:camel-hipchat/src/main/docs/hipchat-component.adoc[Hipchat] (camel-hipchat) +
>>> -`hipchat:protocol:host:port` | The hipchat component supports producing and consuming messages from/to Hipchat service.
>>> -
>>> | link:camel-http/src/main/docs/http-component.adoc[HTTP] (camel-http) +
>>> `http:httpUri` | For calling out to external HTTP servers using Apache HTTP Client 3.x.
>>> 
>>> | link:camel-http4/src/main/docs/http4-component.adoc[HTTP4] (camel-http4) +
>>> `http4:httpUri` | For calling out to external HTTP servers using Apache HTTP Client 4.x.
>>> 
>>> -| link:camel-ibatis/src/main/docs/ibatis-component.adoc[iBatis] (camel-ibatis) +
>>> -`ibatis:statement` | *deprecated* Performs a query poll insert update or delete in a relational database using Apache iBATIS.
>>> -
>>> -| link:camel-mail/src/main/docs/imap-component.adoc[IMAP] (camel-mail) +
>>> -`imap:host:port` | To send or receive emails using imap/pop3 or stmp protocols.
>>> -
>>> | link:camel-infinispan/src/main/docs/infinispan-component.adoc[Infinispan] (camel-infinispan) +
>>> `infinispan:host` | For reading/writing from/to Infinispan distributed key/value store and data grid.
>>> 
>>> -| link:camel-influxdb/src/main/docs/influxdb-component.adoc[InfluxDB] (camel-influxdb) +
>>> -`influxdb:connectionBean` | The influxdb component allows you to interact with InfluxDB a time series database.
>>> -
>>> -| link:camel-irc/src/main/docs/irc-component.adoc[IRC] (camel-irc) +
>>> -`irc:hostname:port` | The irc component implements an IRC (Internet Relay Chat) transport.
>>> -
>>> | link:camel-ironmq/src/main/docs/ironmq-component.adoc[ironmq] (camel-ironmq) +
>>> `ironmq:queueName` | The ironmq provides integration with IronMQ an elastic and durable hosted message queue as a service.
>>> 
>>> -| link:camel-javaspace/src/main/docs/javaspace-component.adoc[JavaSpace] (camel-javaspace) +
>>> -`javaspace:url` | *deprecated* Sending and receiving messages through JavaSpace.
>>> -
>>> -| link:camel-jbpm/src/main/docs/jbpm-component.adoc[JBPM] (camel-jbpm) +
>>> -`jbpm:connectionURL` | The jbpm component provides integration with jBPM (Business Process Management).
>>> -
>>> | link:camel-jcache/src/main/docs/jcache-component.adoc[JCache] (camel-jcache) +
>>> `jcache:cacheName` | The jcache component enables you to perform caching operations using JSR107/JCache as cache implementation.
>>> 
>>> -| link:camel-jclouds/src/main/docs/jclouds-component.adoc[JClouds] (camel-jclouds) +
>>> -`jclouds:command:providerId` | For interacting with cloud compute & blobstore service via jclouds.
>>> -
>>> -| link:camel-jcr/src/main/docs/jcr-component.adoc[JCR] (camel-jcr) +
>>> -`jcr:host/base` | The jcr component allows you to add/read nodes to/from a JCR compliant content repository.
>>> -
>>> -| link:camel-jdbc/src/main/docs/jdbc-component.adoc[JDBC] (camel-jdbc) +
>>> -`jdbc:dataSourceName` | The jdbc component enables you to access databases through JDBC where SQL queries are sent in the message body.
>>> -
>>> | link:camel-jetty9/src/main/docs/jetty-component.adoc[Jetty 9] (camel-jetty9) +
>>> `jetty:httpUri` | The jetty component provides HTTP-based endpoints for consuming and producing HTTP requests.
>>> 
>>> | link:camel-websocket/src/main/docs/websocket-component.adoc[Jetty Websocket] (camel-websocket) +
>>> `websocket:host:port/resourceUri` | The websocket component provides websocket endpoints for communicating with clients using websocket.
>>> 
>>> -| link:camel-jgroups/src/main/docs/jgroups-component.adoc[JGroups] (camel-jgroups) +
>>> -`jgroups:clusterName` | The jgroups component provides exchange of messages between Camel and JGroups clusters.
>>> -
>>> -| link:camel-jing/src/main/docs/jing-component.adoc[Jing] (camel-jing) +
>>> -`jing:resourceUri` | Validates the payload of a message using RelaxNG Syntax using Jing library.
>>> -
>>> -| link:camel-jira/src/main/docs/jira-component.adoc[JIRA] (camel-jira) +
>>> -`jira:type` | The jira component interacts with the JIRA issue tracker.
>>> -
>>> | link:camel-jms/src/main/docs/jms-component.adoc[JMS] (camel-jms) +
>>> `jms:destinationType:destinationName` | The jms component allows messages to be sent to (or consumed from) a JMS Queue or Topic.
>>> 
>>> -| link:camel-jmx/src/main/docs/jmx-component.adoc[JMX] (camel-jmx) +
>>> -`jmx:serverURL` | The jmx component allows to receive JMX notifications.
>>> -
>>> -| link:camel-jolt/src/main/docs/jolt-component.adoc[JOLT] (camel-jolt) +
>>> -`jolt:resourceUri` | The jolt component allows you to process a JSON messages using an JOLT specification (such as JSON-JSON transformation).
>>> -
>>> -| link:camel-jpa/src/main/docs/jpa-component.adoc[JPA] (camel-jpa) +
>>> -`jpa:entityType` | The jpa component enables you to store and retrieve Java objects from databases using JPA.
>>> -
>>> -| link:camel-jt400/src/main/docs/jt400-component.adoc[JT400] (camel-jt400) +
>>> -`jt400:userID:password/systemName/objectPath.type` | The jt400 component allows you to exchanges messages with an AS/400 system using data queues or program call.
>>> -
>>> | link:camel-kafka/src/main/docs/kafka-component.adoc[Kafka] (camel-kafka) +
>>> `kafka:brokers` | The kafka component allows messages to be sent to (or consumed from) Apache Kafka brokers.
>>> 
>>> -| link:camel-kestrel/src/main/docs/kestrel-component.adoc[Kestrel] (camel-kestrel) +
>>> -`kestrel:addresses/queue` | *deprecated* The kestrel component allows messages to be sent to (or consumed from) Kestrel brokers.
>>> -
>>> -| link:camel-krati/src/main/docs/krati-component.adoc[Krati] (camel-krati) +
>>> -`krati:path` | The krati allows the use krati datastores and datasets inside Camel.
>>> -
>>> -| link:camel-kubernetes/src/main/docs/kubernetes-component.adoc[Kubernetes] (camel-kubernetes) +
>>> -`kubernetes:masterUrl` | The kubernetes component allows to work with Kubernetes PaaS.
>>> -
>>> -| link:camel-ldap/src/main/docs/ldap-component.adoc[LDAP] (camel-ldap) +
>>> -`ldap:dirContextName` | The ldap component allows you to perform searches in LDAP servers using filters as the message payload.
>>> -
>>> -| link:camel-linkedin/src/main/docs/linkedin-component.adoc[Linkedin] (camel-linkedin) +
>>> -`linkedin:apiName/methodName` | The linkedin component is uses for retrieving LinkedIn user profiles connections companies groups posts etc.
>>> -
>>> -| link:camel-lucene/src/main/docs/lucene-component.adoc[Lucene] (camel-lucene) +
>>> -`lucene:host:operation` | To insert or query from Apache Lucene databases.
>>> -
>>> -| link:camel-lumberjack/src/main/docs/lumberjack-component.adoc[Lumberjack] (camel-lumberjack) +
>>> -`lumberjack:host:port` | The lumberjack retrieves logs sent over the network using the Lumberjack protocol.
>>> -
>>> | link:camel-metrics/src/main/docs/metrics-component.adoc[Metrics] (camel-metrics) +
>>> `metrics:metricsType:metricsName` | To collect various metrics directly from Camel routes using the DropWizard metrics library.
>>> 
>>> -| link:camel-mina/src/main/docs/mina-component.adoc[Mina] (camel-mina) +
>>> -`mina:protocol:host:port` | *deprecated* Socket level networking using TCP or UDP with the Apache Mina 1.x library.
>>> -
>>> -| link:camel-mina2/src/main/docs/mina2-component.adoc[Mina2] (camel-mina2) +
>>> -`mina2:protocol:host:port` | Socket level networking using TCP or UDP with the Apache Mina 2.x library.
>>> -
>>> | link:camel-mllp/src/main/docs/mllp-component.adoc[MLLP] (camel-mllp) +
>>> `mllp:hostname:port` | The MLLP component is designed to handle the MLLP protocol and provide the functionality required by Healthcare providers to communicate with other systems using the MLLP protocol.
>>> 
>>> | link:camel-mongodb/src/main/docs/mongodb-component.adoc[MongoDB] (camel-mongodb) +
>>> `mongodb:connectionBean` | Component for working with documents stored in MongoDB database.
>>> 
>>> -| link:camel-mongodb3/src/main/docs/mongodb3-component.adoc[MongoDB] (camel-mongodb3) +
>>> -`mongodb3:connectionBean` | Component for working with documents stored in MongoDB database.
>>> -
>>> -| link:camel-mongodb-gridfs/src/main/docs/gridfs-component.adoc[MongoDBGridFS] (camel-mongodb-gridfs) +
>>> -`gridfs:connectionBean` | Component for working with MongoDB GridFS.
>>> -
>>> -| link:camel-mqtt/src/main/docs/mqtt-component.adoc[MQTT] (camel-mqtt) +
>>> -`mqtt:name` | Component for communicating with MQTT M2M message brokers using FuseSource MQTT Client.
>>> -
>>> -| link:camel-msv/src/main/docs/msv-component.adoc[MSV] (camel-msv) +
>>> -`msv:resourceUri` | Validates the payload of a message using the MSV Library.
>>> -
>>> -| link:camel-mustache/src/main/docs/mustache-component.adoc[Mustache] (camel-mustache) +
>>> -`mustache:resourceUri` | Transforms the message using a Mustache template.
>>> -
>>> -| link:camel-mvel/src/main/docs/mvel-component.adoc[MVEL] (camel-mvel) +
>>> -`mvel:resourceUri` | Transforms the message using a MVEL template.
>>> -
>>> -| link:camel-mybatis/src/main/docs/mybatis-component.adoc[MyBatis] (camel-mybatis) +
>>> -`mybatis:statement` | Performs a query poll insert update or delete in a relational database using MyBatis.
>>> -
>>> -| link:camel-nagios/src/main/docs/nagios-component.adoc[Nagios] (camel-nagios) +
>>> -`nagios:host:port` | To send passive checks to Nagios using JSendNSCA.
>>> -
>>> -| link:camel-nats/src/main/docs/nats-component.adoc[Nats] (camel-nats) +
>>> -`nats:servers` | The nats component allows you produce and consume messages from NATS.
>>> -
>>> -| link:camel-netty/src/main/docs/netty-component.adoc[Netty] (camel-netty) +
>>> -`netty:protocol:host:port` | *deprecated* Socket level networking using TCP or UDP with the Netty 3.x library.
>>> -
>>> -| link:camel-netty-http/src/main/docs/netty-http-component.adoc[Netty HTTP] (camel-netty-http) +
>>> -`netty-http:protocol:host:port/path` | *deprecated* Netty HTTP server and client using the Netty 3.x library.
>>> -
>>> | link:camel-netty4/src/main/docs/netty4-component.adoc[Netty4] (camel-netty4) +
>>> `netty4:protocol:host:port` | Socket level networking using TCP or UDP with the Netty 4.x library.
>>> 
>>> | link:camel-netty4-http/src/main/docs/netty4-http-component.adoc[Netty4 HTTP] (camel-netty4-http) +
>>> `netty4-http:protocol:host:port/path` | Netty HTTP server and client using the Netty 4.x library.
>>> 
>>> -| link:camel-openshift/src/main/docs/openshift-component.adoc[OpenShift] (camel-openshift) +
>>> -`openshift:clientId` | *deprecated* To manage your Openshift 2.x applications.
>>> -
>>> | link:camel-openstack/src/main/docs/openstack-cinder-component.adoc[OpenStack-Cinder] (camel-openstack) +
>>> `openstack-cinder:host` | Camel Components
>>> 
>>> @@ -402,174 +207,33 @@ Components
>>> | link:camel-openstack/src/main/docs/openstack-swift-component.adoc[OpenStack-Swift] (camel-openstack) +
>>> `openstack-swift:host` | Camel Components
>>> 
>>> -| link:camel-optaplanner/src/main/docs/optaplanner-component.adoc[OptaPlanner] (camel-optaplanner) +
>>> -`optaplanner:configFile` | Solves the planning problem contained in a message with OptaPlanner.
>>> -
>>> -| link:camel-eventadmin/src/main/docs/eventadmin-component.adoc[OSGi EventAdmin] (camel-eventadmin) +
>>> -`eventadmin:topic` | The eventadmin component can be used in an OSGi environment to receive OSGi EventAdmin events and process them.
>>> -
>>> -| link:camel-paxlogging/src/main/docs/paxlogging-component.adoc[OSGi PAX Logging] (camel-paxlogging) +
>>> -`paxlogging:appender` | The paxlogging component can be used in an OSGi environment to receive PaxLogging events and process them.
>>> -
>>> -| link:camel-paho/src/main/docs/paho-component.adoc[Paho] (camel-paho) +
>>> -`paho:topic` | Component for communicating with MQTT M2M message brokers using Eclipse Paho MQTT Client.
>>> -
>>> -| link:camel-pdf/src/main/docs/pdf-component.adoc[PDF] (camel-pdf) +
>>> -`pdf:operation` | The pdf components provides the ability to create modify or extract content from PDF documents.
>>> -
>>> -| link:camel-pgevent/src/main/docs/pgevent-component.adoc[PostgresSQL Event] (camel-pgevent) +
>>> -`pgevent:host:port/database/channel` | The pgevent component allows for producing/consuming PostgreSQL events related to the LISTEN/NOTIFY commands.
>>> -
>>> -| link:camel-printer/src/main/docs/lpr-component.adoc[Printer] (camel-printer) +
>>> -`lpr:hostname:port/printername` | The printer component is used for sending messages to printers as print jobs.
>>> -
>>> -| link:camel-quartz/src/main/docs/quartz-component.adoc[Quartz] (camel-quartz) +
>>> -`quartz:groupName/timerName` | *deprecated* Provides a scheduled delivery of messages using the Quartz 1.x scheduler.
>>> -
>>> -| link:camel-quartz2/src/main/docs/quartz2-component.adoc[Quartz2] (camel-quartz2) +
>>> -`quartz2:groupName/triggerName` | Provides a scheduled delivery of messages using the Quartz 2.x scheduler.
>>> -
>>> -| link:camel-quickfix/src/main/docs/quickfix-component.adoc[QuickFix] (camel-quickfix) +
>>> -`quickfix:configurationName` | The quickfix component allows to send Financial Interchange (FIX) messages to the QuickFix engine.
>>> -
>>> -| link:camel-rabbitmq/src/main/docs/rabbitmq-component.adoc[RabbitMQ] (camel-rabbitmq) +
>>> -`rabbitmq:hostname:portNumber/exchangeName` | The rabbitmq component allows you produce and consume messages from RabbitMQ instances.
>>> -
>>> -| link:camel-restlet/src/main/docs/restlet-component.adoc[Restlet] (camel-restlet) +
>>> -`restlet:protocol:host:port/uriPattern` | Component for consuming and producing Restful resources using Restlet.
>>> -
>>> -| link:camel-rmi/src/main/docs/rmi-component.adoc[RMI] (camel-rmi) +
>>> -`rmi:hostname:port/name` | The rmi component is for invoking Java RMI beans from Camel.
>>> -
>>> -| link:camel-routebox/src/main/docs/routebox-component.adoc[RouteBox] (camel-routebox) +
>>> -`routebox:routeboxName` | *deprecated* The routebox component allows to send/receive messages between Camel routes in a black box way.
>>> -
>>> -| link:camel-rss/src/main/docs/rss-component.adoc[RSS] (camel-rss) +
>>> -`rss:feedUri` | The rss component is used for consuming RSS feeds.
>>> -
>>> | link:camel-salesforce/src/main/docs/salesforce-component.adoc[Salesforce] (camel-salesforce) +
>>> `salesforce:operationName:topicName` | The salesforce component is used for integrating Camel with the massive Salesforce API.
>>> 
>>> -| link:camel-sap-netweaver/src/main/docs/sap-netweaver-component.adoc[SAP NetWeaver] (camel-sap-netweaver) +
>>> -`sap-netweaver:url` | The sap-netweaver component integrates with the SAP NetWeaver Gateway using HTTP transports.
>>> -
>>> -| link:camel-schematron/src/main/docs/schematron-component.adoc[Schematron] (camel-schematron) +
>>> -`schematron:path` | Validates the payload of a message using the Schematron Library.
>>> -
>>> -| link:camel-jsch/src/main/docs/scp-component.adoc[SCP] (camel-jsch) +
>>> -`scp:host:port/directoryName` | To copy files using the secure copy protocol (SCP).
>>> -
>>> -| link:camel-servicenow/src/main/docs/servicenow-component.adoc[ServiceNow] (camel-servicenow) +
>>> -`servicenow:instanceName` | The servicenow component is used to integrate Camel with ServiceNow cloud services.
>>> -
>>> | link:camel-servlet/src/main/docs/servlet-component.adoc[Servlet] (camel-servlet) +
>>> `servlet:contextPath` | To use a HTTP Servlet as entry for Camel routes when running in a servlet container.
>>> 
>>> -| link:camel-ftp/src/main/docs/sftp-component.adoc[SFTP] (camel-ftp) +
>>> -`sftp:host:port/directoryName` | The sftp (FTP over SSH) component is used for uploading or downloading files from SFTP servers.
>>> -
>>> -| link:camel-sjms/src/main/docs/sjms-component.adoc[Simple JMS] (camel-sjms) +
>>> -`sjms:destinationType:destinationName` | The sjms component (simple jms) allows messages to be sent to (or consumed from) a JMS Queue or Topic.
>>> -
>>> -| link:camel-sjms/src/main/docs/sjms-batch-component.adoc[Simple JMS Batch] (camel-sjms) +
>>> -`sjms-batch:destinationName` | The sjms-batch component is a specialized for highly performant transactional batch consumption from a JMS queue.
>>> -
>>> -| link:camel-sip/src/main/docs/sip-component.adoc[SIP] (camel-sip) +
>>> -`sip:uri` | To send and receive messages using the SIP protocol (used in telco and mobile).
>>> -
>>> -| link:camel-slack/src/main/docs/slack-component.adoc[Slack] (camel-slack) +
>>> -`slack:channel` | The slack component allows you to send messages to Slack.
>>> -
>>> | link:camel-smpp/src/main/docs/smpp-component.adoc[SMPP] (camel-smpp) +
>>> `smpp:host:port` | To send and receive SMS using a SMSC (Short Message Service Center).
>>> 
>>> -| link:camel-snmp/src/main/docs/snmp-component.adoc[SNMP] (camel-snmp) +
>>> -`snmp:host:port` | The snmp component gives you the ability to poll SNMP capable devices or receiving traps.
>>> -
>>> -| link:camel-solr/src/main/docs/solr-component.adoc[Solr] (camel-solr) +
>>> -`solr:url` | The solr component allows you to interface with an Apache Lucene Solr server.
>>> -
>>> -| link:camel-spark-rest/src/main/docs/spark-rest-component.adoc[Spark Rest] (camel-spark-rest) +
>>> -`spark-rest:verb:path` | The spark-rest component is used for hosting REST services which has been defined using Camel rest-dsl.
>>> -
>>> -| link:camel-splunk/src/main/docs/splunk-component.adoc[Splunk] (camel-splunk) +
>>> -`splunk:name` | The splunk component allows to publish or search for events in Splunk.
>>> -
>>> -| link:camel-spring-batch/src/main/docs/spring-batch-component.adoc[Spring Batch] (camel-spring-batch) +
>>> -`spring-batch:jobName` | The spring-batch component allows to send messages to Spring Batch for further processing.
>>> -
>>> | link:camel-spring/src/main/docs/spring-event-component.adoc[Spring Event] (camel-spring) +
>>> `spring-event:name` | The spring-event component allows to listen for Spring Application Events.
>>> 
>>> -| link:camel-spring-integration/src/main/docs/spring-integration-component.adoc[Spring Integration] (camel-spring-integration) +
>>> -`spring-integration:defaultChannel` | Bridges Camel with Spring Integration.
>>> -
>>> -| link:camel-spring-ldap/src/main/docs/spring-ldap-component.adoc[Spring LDAP] (camel-spring-ldap) +
>>> -`spring-ldap:templateName` | The spring-ldap component allows you to perform searches in LDAP servers using filters as the message payload.
>>> -
>>> -| link:camel-spring-redis/src/main/docs/spring-redis-component.adoc[Spring Redis] (camel-spring-redis) +
>>> -`spring-redis:host:port` | The spring-redis component allows sending and receiving messages from Redis.
>>> -
>>> -| link:camel-spring-ws/src/main/docs/spring-ws-component.adoc[Spring WebService] (camel-spring-ws) +
>>> -`spring-ws:type:lookupKey:webServiceEndpointUri` | The spring-ws component is used for SOAP WebServices using Spring WebServices.
>>> -
>>> | link:camel-sql/src/main/docs/sql-component.adoc[SQL] (camel-sql) +
>>> `sql:query` | The sql component allows you to work with databases using JDBC SQL queries.
>>> 
>>> | link:camel-sql/src/main/docs/sql-stored-component.adoc[SQL StoredProcedure] (camel-sql) +
>>> `sql-stored:template` | The sql component allows you to work with databases using JDBC Stored Procedure queries.
>>> 
>>> -| link:camel-ssh/src/main/docs/ssh-component.adoc[SSH] (camel-ssh) +
>>> -`ssh:host:port` | The ssh component enables access to SSH servers such that you can send an SSH command and process the response.
>>> -
>>> -| link:camel-stax/src/main/docs/stax-component.adoc[StAX] (camel-stax) +
>>> -`stax:contentHandlerClass` | The stax component allows messages to be process through a SAX ContentHandler.
>>> -
>>> -| link:camel-stomp/src/main/docs/stomp-component.adoc[Stomp] (camel-stomp) +
>>> -`stomp:destination` | The stomp component is used for communicating with Stomp compliant message brokers.
>>> -
>>> | link:camel-stream/src/main/docs/stream-component.adoc[Stream] (camel-stream) +
>>> `stream:kind` | The stream: component provides access to the system-in system-out and system-err streams as well as allowing streaming of file and URL.
>>> 
>>> -| link:camel-stringtemplate/src/main/docs/string-template-component.adoc[String Template] (camel-stringtemplate) +
>>> -`string-template:resourceUri` | Transforms the message using a String template.
>>> -
>>> -| link:camel-telegram/src/main/docs/telegram-component.adoc[Telegram] (camel-telegram) +
>>> -`telegram:type/authorizationToken` | The telegram component provides access to the Telegram Bot API.
>>> -
>>> -| link:camel-twitter/src/main/docs/twitter-component.adoc[Twitter] (camel-twitter) +
>>> -`twitter:kind` | This component integrates with Twitter to send tweets or search for tweets and more.
>>> -
>>> -| link:camel-undertow/src/main/docs/undertow-component.adoc[Undertow] (camel-undertow) +
>>> -`undertow:httpURI` | The undertow component provides HTTP-based endpoints for consuming and producing HTTP requests.
>>> -
>>> | link:camel-velocity/src/main/docs/velocity-component.adoc[Velocity] (camel-velocity) +
>>> `velocity:resourceUri` | Transforms the message using a Velocity template.
>>> 
>>> -| link:camel-vertx/src/main/docs/vertx-component.adoc[Vert.x] (camel-vertx) +
>>> -`vertx:address` | The vertx component is used for sending and receive messages from a vertx event bus.
>>> -
>>> | link:camel-weather/src/main/docs/weather-component.adoc[Weather] (camel-weather) +
>>> `weather:name` | Polls the weather information from Open Weather Map.
>>> 
>>> -| link:camel-xmlrpc/src/main/docs/xmlrpc-component.adoc[XML RPC] (camel-xmlrpc) +
>>> -`xmlrpc:address` | The xmlrpc component is used for sending messages to a XML RPC service.
>>> -
>>> -| link:camel-xmlsecurity/src/main/docs/xmlsecurity-component.adoc[XML Security] (camel-xmlsecurity) +
>>> -`xmlsecurity:command:name` | Used to sign and verify exchanges using the XML signature specification.
>>> -
>>> -| link:camel-xmpp/src/main/docs/xmpp-component.adoc[XMPP] (camel-xmpp) +
>>> -`xmpp:host:port/participant` | To send and receive messages from a XMPP (chat) server.
>>> -
>>> -| link:camel-saxon/src/main/docs/xquery-component.adoc[XQuery] (camel-saxon) +
>>> -`xquery:resourceUri` | Transforms the message using a XQuery template using Saxon.
>>> -
>>> -| link:camel-yammer/src/main/docs/yammer-component.adoc[Yammer] (camel-yammer) +
>>> -`yammer:function` | The yammer component allows you to interact with the Yammer enterprise social network.
>>> -
>>> -| link:camel-zookeeper/src/main/docs/zookeeper-component.adoc[ZooKeeper] (camel-zookeeper) +
>>> -`zookeeper:serverUrls/path` | The zookeeper component allows interaction with a ZooKeeper cluster.
>>> -
>>> |=======================================================================
>>> // components: END
>>> 
>>> @@ -646,65 +310,17 @@ Data Formats
>>> 
>>> | link:camel-csv/src/main/docs/csv-dataformat.adoc[CSV] (camel-csv) | Camel CSV data format support
>>> 
>>> -| link:camel-flatpack/src/main/docs/flatpack-dataformat.adoc[Flatpack] (camel-flatpack) | Camel FlatPack support
>>> -
>>> | link:camel-hessian/src/main/docs/hessian-dataformat.adoc[Hessian] (camel-hessian) | Hessian serialization support
>>> 
>>> | link:camel-hl7/src/main/docs/hl7-dataformat.adoc[HL7] (camel-hl7) | Camel HL7 support
>>> 
>>> -| link:camel-ical/src/main/docs/ical-dataformat.adoc[iCal] (camel-ical) | Camel iCal component
>>> -
>>> | link:camel-jacksonxml/src/main/docs/jacksonxml-dataformat.adoc[JacksonXML] (camel-jacksonxml) | Camel Jackson XML support
>>> 
>>> | link:camel-jaxb/src/main/docs/jaxb-dataformat.adoc[JAXB] (camel-jaxb) | Camel JAXB support
>>> 
>>> -| link:camel-jibx/src/main/docs/jibx-dataformat.adoc[JiBX] (camel-jibx) | Camel Jibx support
>>> -
>>> -| link:camel-gson/src/main/docs/json-gson-dataformat.adoc[JSon GSon] (camel-gson) | Camel Gson support
>>> -
>>> | link:camel-jackson/src/main/docs/json-jackson-dataformat.adoc[JSon Jackson] (camel-jackson) | Camel Jackson support
>>> 
>>> -| link:camel-johnzon/src/main/docs/json-johnzon-dataformat.adoc[JSon Johnzon] (camel-johnzon) | Camel Johnzon support
>>> -
>>> -| link:camel-xstream/src/main/docs/json-xstream-dataformat.adoc[JSon XStream] (camel-xstream) | Camel XStream support
>>> -
>>> -| link:camel-lzf/src/main/docs/lzf-dataformat.adoc[LZF Deflate Compression] (camel-lzf) | Camel LZF support
>>> -
>>> -| link:camel-mail/src/main/docs/mime-multipart-dataformat.adoc[MIME Multipart] (camel-mail) | Camel Mail support
>>> -
>>> | link:camel-crypto/src/main/docs/pgp-dataformat.adoc[PGP] (camel-crypto) | Camel Cryptographic Support
>>> -
>>> -| link:camel-protobuf/src/main/docs/protobuf-dataformat.adoc[Protobuf] (camel-protobuf) | Camel Google Protobuf data format support
>>> -
>>> -| link:camel-rss/src/main/docs/rss-dataformat.adoc[RSS] (camel-rss) | Camel RSS support
>>> -
>>> -| link:camel-soap/src/main/docs/soapjaxb-dataformat.adoc[SOAP] (camel-soap) | Camel SOAP support
>>> -
>>> -| link:camel-syslog/src/main/docs/syslog-dataformat.adoc[Syslog] (camel-syslog) | Camel Syslog support
>>> -
>>> -| link:camel-tarfile/src/main/docs/tarfile-dataformat.adoc[Tar File] (camel-tarfile) | Camel Tar file support
>>> -
>>> -| link:camel-tagsoup/src/main/docs/tidyMarkup-dataformat.adoc[TidyMarkup] (camel-tagsoup) | Camel TagSoup support
>>> -
>>> -| link:camel-univocity-parsers/src/main/docs/univocity-csv-dataformat.adoc[uniVocity CSV] (camel-univocity-parsers) | Camel UniVocity parsers data format support
>>> -
>>> -| link:camel-univocity-parsers/src/main/docs/univocity-fixed-dataformat.adoc[uniVocity Fixed Length] (camel-univocity-parsers) | Camel UniVocity parsers data format support
>>> -
>>> -| link:camel-univocity-parsers/src/main/docs/univocity-tsv-dataformat.adoc[uniVocity TSV] (camel-univocity-parsers) | Camel UniVocity parsers data format support
>>> -
>>> -| link:camel-xmlbeans/src/main/docs/xmlBeans-dataformat.adoc[XML Beans] (camel-xmlbeans) | Camel XMLBeans support
>>> -
>>> -| link:camel-xmljson/src/main/docs/xmljson-dataformat.adoc[XML JSon] (camel-xmljson) | Camel XML JSON Data Format
>>> -
>>> -| link:camel-xmlrpc/src/main/docs/xmlrpc-dataformat.adoc[XML RPC] (camel-xmlrpc) | Camel XML RPC support
>>> -
>>> -| link:camel-xmlsecurity/src/main/docs/secureXML-dataformat.adoc[XML Security] (camel-xmlsecurity) | Camel Partial XML Encryption/Decryption and XML Signature support
>>> -
>>> -| link:camel-xstream/src/main/docs/xstream-dataformat.adoc[XStream] (camel-xstream) | Camel XStream support
>>> -
>>> -| link:camel-snakeyaml/src/main/docs/yaml-snakeyaml-dataformat.adoc[YAML SnakeYAML] (camel-snakeyaml) | Camel SnakeYAML support
>>> -
>>> -| link:camel-zipfile/src/main/docs/zipfile-dataformat.adoc[Zip File] (camel-zipfile) | Camel Zip file support
>>> |=======================================================================
>>> // dataformats: END
>>> 
>>> @@ -723,27 +339,9 @@ Expression Languages
>>> 
>>> | link:camel-hl7/src/main/docs/terser-language.adoc[HL7 Terser] (camel-hl7) | For HL7 terser expressions and predicates
>>> 
>>> -| link:camel-script/src/main/docs/javaScript-language.adoc[JavaScript] (camel-script) | For JavaScript expressions and predicates
>>> -
>>> -| link:camel-jsonpath/src/main/docs/jsonpath-language.adoc[JSonPath] (camel-jsonpath) | For JSonPath expressions and predicates
>>> -
>>> | link:camel-jxpath/src/main/docs/jxpath-language.adoc[JXPath] (camel-jxpath) | For JXPath expressions and predicates
>>> 
>>> -| link:camel-mvel/src/main/docs/mvel-language.adoc[MVEL] (camel-mvel) | For MVEL expressions and predicates
>>> -
>>> -| link:camel-ognl/src/main/docs/ognl-language.adoc[OGNL] (camel-ognl) | For OGNL expressions and predicates
>>> -
>>> -| link:camel-script/src/main/docs/php-language.adoc[PHP] (camel-script) | For PHP expressions and predicates
>>> -
>>> -| link:camel-script/src/main/docs/python-language.adoc[Python] (camel-script) | For Python expressions and predicates
>>> -
>>> -| link:camel-script/src/main/docs/ruby-language.adoc[Ruby] (camel-script) | For Ruby expressions and predicates
>>> -
>>> | link:camel-spring/src/main/docs/spel-language.adoc[SpEL] (camel-spring) | For Spring Expression Language (SpEL) expressions and predicates
>>> -
>>> -| link:camel-josql/src/main/docs/sql-language.adoc[SQL] (camel-josql) | For SQL expressions and predicates
>>> -
>>> -| link:camel-saxon/src/main/docs/xquery-language.adoc[XQuery] (camel-saxon) | For XQuery expressions and predicates
>>> |=======================================================================
>>> // languages: END
>>> 
>> 
>> 
>> 
>> --
>> Claus Ibsen
>> -----------------
>> http://davsclaus.com @davsclaus
>> Camel in Action 2: https://www.manning.com/ibsen2
> 
> 
> 
> -- 
> Claus Ibsen
> -----------------
> http://davsclaus.com @davsclaus
> Camel in Action 2: https://www.manning.com/ibsen2
> 


Re: camel git commit: Fix CS violations

Posted by Andrea Cosentino <an...@yahoo.com.INVALID>.
Thanks Claus
 --
Andrea Cosentino 
----------------------------------
Apache Camel PMC Member
Apache Karaf Committer
Apache Servicemix Committer
Email: ancosen1985@yahoo.com
Twitter: @oscerd2
Github: oscerd



On Monday, December 19, 2016 11:15 AM, Claus Ibsen <cl...@gmail.com> wrote:
Hi

Okay I found the issue. Its when you don't run the platforms/catalog
build which is the guy that is responsible for updating that readme
file.

I just regen the doc and its up to date again.

On Mon, Dec 19, 2016 at 11:00 AM, Claus Ibsen <cl...@gmail.com> wrote:
> Yeah we need to revert those .docs files.
>
> And keep an eye on the build if it generates those two files
> correctly, there may be a flaw in the camel-package-maven-plugin that
> has the code for this.
>
> On Mon, Dec 19, 2016 at 10:55 AM, Andrea Cosentino
> <an...@yahoo.com.invalid> wrote:
>> It looks like the build deleted the components list from readme.
>>  --
>> Andrea Cosentino
>> ----------------------------------
>> Apache Camel PMC Member
>> Apache Karaf Committer
>> Apache Servicemix Committer
>> Email: ancosen1985@yahoo.com
>> Twitter: @oscerd2
>> Github: oscerd
>>
>>
>>
>> On Sunday, December 18, 2016 6:27 PM, "bvahdat@apache.org" <bv...@apache.org> wrote:
>> Repository: camel
>> Updated Branches:
>>   refs/heads/master 079b5f9e6 -> 490a76f17
>>
>>
>> Fix CS violations
>>
>> Project: http://git-wip-us.apache.org/repos/asf/camel/repo
>> Commit: http://git-wip-us.apache.org/repos/asf/camel/commit/490a76f1
>> Tree: http://git-wip-us.apache.org/repos/asf/camel/tree/490a76f1
>> Diff: http://git-wip-us.apache.org/repos/asf/camel/diff/490a76f1
>>
>> Branch: refs/heads/master
>> Commit: 490a76f17a1cb96a08009607a7aa972e7bc0372d
>> Parents: 079b5f9
>> Author: Babak Vahdat <bv...@apache.org>
>> Authored: Sun Dec 18 18:26:52 2016 +0100
>> Committer: Babak Vahdat <bv...@apache.org>
>> Committed: Sun Dec 18 18:26:52 2016 +0100
>>
>> ----------------------------------------------------------------------
>> .../component/bonita/BonitaConfiguration.java   |   6 +-
>> .../core/xml/CamelProxyFactoryDefinition.java   |   2 +-
>> .../camel/component/gridfs/GridFsEndpoint.java  |   1 -
>> .../openstack/nova/KeypairProducerTest.java     |   2 +-
>> .../processor/RibbonServiceCallProcessor.java   |  19 +-
>> .../component/servicenow/ServiceNowClient.java  |   2 +-
>> components/readme.adoc                          | 402 -------------------
>> 7 files changed, 15 insertions(+), 419 deletions(-)
>> ----------------------------------------------------------------------
>>
>>
>> http://git-wip-us.apache.org/repos/asf/camel/blob/490a76f1/components/camel-bonita/src/main/java/org/apache/camel/component/bonita/BonitaConfiguration.java
>> ----------------------------------------------------------------------
>> diff --git a/components/camel-bonita/src/main/java/org/apache/camel/component/bonita/BonitaConfiguration.java b/components/camel-bonita/src/main/java/org/apache/camel/component/bonita/BonitaConfiguration.java
>> index 7343e2c..b992682 100644
>> --- a/components/camel-bonita/src/main/java/org/apache/camel/component/bonita/BonitaConfiguration.java
>> +++ b/components/camel-bonita/src/main/java/org/apache/camel/component/bonita/BonitaConfiguration.java
>> @@ -5,9 +5,9 @@
>>   * 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
>> - * <p>
>> - * http://www.apache.org/licenses/LICENSE-2.0
>> - * <p>
>> + *
>> + *      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.
>>
>> http://git-wip-us.apache.org/repos/asf/camel/blob/490a76f1/components/camel-core-xml/src/main/java/org/apache/camel/core/xml/CamelProxyFactoryDefinition.java
>> ----------------------------------------------------------------------
>> diff --git a/components/camel-core-xml/src/main/java/org/apache/camel/core/xml/CamelProxyFactoryDefinition.java b/components/camel-core-xml/src/main/java/org/apache/camel/core/xml/CamelProxyFactoryDefinition.java
>> index 6f160ce..5c78b93 100644
>> --- a/components/camel-core-xml/src/main/java/org/apache/camel/core/xml/CamelProxyFactoryDefinition.java
>> +++ b/components/camel-core-xml/src/main/java/org/apache/camel/core/xml/CamelProxyFactoryDefinition.java
>> @@ -63,7 +63,7 @@ public class CamelProxyFactoryDefinition extends IdentifiedType {
>>       * @deprecated use serviceUrl instead with the ref endpoint.
>>       */
>>      @Deprecated
>> -    public void setServiceRef(String serviceRef) {
>> +    public void setServiceRef(String serviceRef) {
>>          this.serviceRef = serviceRef;
>>      }
>>
>>
>> http://git-wip-us.apache.org/repos/asf/camel/blob/490a76f1/components/camel-mongodb-gridfs/src/main/java/org/apache/camel/component/gridfs/GridFsEndpoint.java
>> ----------------------------------------------------------------------
>> diff --git a/components/camel-mongodb-gridfs/src/main/java/org/apache/camel/component/gridfs/GridFsEndpoint.java b/components/camel-mongodb-gridfs/src/main/java/org/apache/camel/component/gridfs/GridFsEndpoint.java
>> index cb8f686..f4d5d65 100644
>> --- a/components/camel-mongodb-gridfs/src/main/java/org/apache/camel/component/gridfs/GridFsEndpoint.java
>> +++ b/components/camel-mongodb-gridfs/src/main/java/org/apache/camel/component/gridfs/GridFsEndpoint.java
>> @@ -39,7 +39,6 @@ import org.slf4j.LoggerFactory;
>> @UriEndpoint(scheme = "gridfs", title = "MongoDBGridFS", syntax = "gridfs:connectionBean", label = "database,nosql")
>> public class GridFsEndpoint extends DefaultEndpoint {
>>
>> -    ;
>>      public static final String GRIDFS_OPERATION = "gridfs.operation";
>>      public static final String GRIDFS_METADATA = "gridfs.metadata";
>>      public static final String GRIDFS_CHUNKSIZE = "gridfs.chunksize";
>>
>> http://git-wip-us.apache.org/repos/asf/camel/blob/490a76f1/components/camel-openstack/src/test/java/org/apache/camel/component/openstack/nova/KeypairProducerTest.java
>> ----------------------------------------------------------------------
>> diff --git a/components/camel-openstack/src/test/java/org/apache/camel/component/openstack/nova/KeypairProducerTest.java b/components/camel-openstack/src/test/java/org/apache/camel/component/openstack/nova/KeypairProducerTest.java
>> index c851a40..ba4813e 100644
>> --- a/components/camel-openstack/src/test/java/org/apache/camel/component/openstack/nova/KeypairProducerTest.java
>> +++ b/components/camel-openstack/src/test/java/org/apache/camel/component/openstack/nova/KeypairProducerTest.java
>> @@ -114,6 +114,6 @@ public class KeypairProducerTest extends NovaProducerTestSupport {
>>      }
>>
>>      private Keypair createDummyKeypair() {
>> -        return NovaKeypair.create(KEYPAIR_NAME, "string contains private key");
>> +        return NovaKeypair.create(KEYPAIR_NAME, "string contains private key");
>>      }
>> }
>>
>> http://git-wip-us.apache.org/repos/asf/camel/blob/490a76f1/components/camel-ribbon/src/main/java/org/apache/camel/component/ribbon/processor/RibbonServiceCallProcessor.java
>> ----------------------------------------------------------------------
>> diff --git a/components/camel-ribbon/src/main/java/org/apache/camel/component/ribbon/processor/RibbonServiceCallProcessor.java b/components/camel-ribbon/src/main/java/org/apache/camel/component/ribbon/processor/RibbonServiceCallProcessor.java
>> index f9151ce..f701ba0 100644
>> --- a/components/camel-ribbon/src/main/java/org/apache/camel/component/ribbon/processor/RibbonServiceCallProcessor.java
>> +++ b/components/camel-ribbon/src/main/java/org/apache/camel/component/ribbon/processor/RibbonServiceCallProcessor.java
>> @@ -19,7 +19,6 @@ package org.apache.camel.component.ribbon.processor;
>> import java.util.Map;
>> import java.util.concurrent.RejectedExecutionException;
>>
>> -import com.netflix.client.config.CommonClientConfigKey;
>> import com.netflix.client.config.IClientConfig;
>> import com.netflix.client.config.IClientConfigKey;
>> import com.netflix.loadbalancer.DummyPing;
>> @@ -46,8 +45,8 @@ import org.apache.camel.spi.IdAware;
>> import org.apache.camel.spi.ServiceCallServerListStrategy;
>> import org.apache.camel.support.ServiceSupport;
>> import org.apache.camel.util.AsyncProcessorHelper;
>> -import org.apache.camel.util.ObjectHelper;
>> import org.apache.camel.util.ServiceHelper;
>> +import org.apache.camel.util.StringHelper;
>> import org.slf4j.Logger;
>> import org.slf4j.LoggerFactory;
>>
>> @@ -78,18 +77,18 @@ public class RibbonServiceCallProcessor extends ServiceSupport implements AsyncP
>>          // setup from the provided name which can contain scheme and context-path information as well
>>          String serviceName;
>>          if (name.contains("/")) {
>> -            serviceName = ObjectHelper.before(name, "/");
>> -            this.contextPath = ObjectHelper.after(name, "/");
>> +            serviceName = StringHelper.before(name, "/");
>> +            this.contextPath = StringHelper.after(name, "/");
>>          } else if (name.contains("?")) {
>> -            serviceName = ObjectHelper.before(name, "?");
>> -            this.contextPath = ObjectHelper.after(name, "?");
>> +            serviceName = StringHelper.before(name, "?");
>> +            this.contextPath = StringHelper.after(name, "?");
>>          } else {
>>              serviceName = name;
>>              this.contextPath = null;
>>          }
>>          if (serviceName.contains(":")) {
>> -            this.scheme = ObjectHelper.before(serviceName, ":");
>> -            this.name = ObjectHelper.after(serviceName, ":");
>> +            this.scheme = StringHelper.before(serviceName, ":");
>> +            this.name = StringHelper.after(serviceName, ":");
>>          } else {
>>              this.scheme = scheme;
>>              this.name = serviceName;
>> @@ -199,7 +198,7 @@ public class RibbonServiceCallProcessor extends ServiceSupport implements AsyncP
>>      @Override
>>      @SuppressWarnings("unchecked")
>>      protected void doStart() throws Exception {
>> -        ObjectHelper.notEmpty(name, "name", this);
>> +        StringHelper.notEmpty(name, "name", this);
>>
>>          if (serverListStrategy == null) {
>>              serverListStrategy = new RibbonServiceCallStaticServerListStrategy();
>> @@ -222,7 +221,7 @@ public class RibbonServiceCallProcessor extends ServiceSupport implements AsyncP
>>          IClientConfig config = IClientConfig.Builder.newBuilder(name).build();
>>          if (ribbonClientConfig != null) {
>>              for (Map.Entry<String, String> entry : ribbonClientConfig.entrySet()) {
>> -                IClientConfigKey key = CommonClientConfigKey.valueOf(entry.getKey());
>> +                IClientConfigKey key = IClientConfigKey.Keys.valueOf(entry.getKey());
>>                  String value = entry.getValue();
>>                  LOG.debug("RibbonClientConfig: {}={}", key.key(), value);
>>                  config.set(key, entry.getValue());
>>
>> http://git-wip-us.apache.org/repos/asf/camel/blob/490a76f1/components/camel-servicenow/src/main/java/org/apache/camel/component/servicenow/ServiceNowClient.java
>> ----------------------------------------------------------------------
>> diff --git a/components/camel-servicenow/src/main/java/org/apache/camel/component/servicenow/ServiceNowClient.java b/components/camel-servicenow/src/main/java/org/apache/camel/component/servicenow/ServiceNowClient.java
>> index 2bdd86a..fa33607 100644
>> --- a/components/camel-servicenow/src/main/java/org/apache/camel/component/servicenow/ServiceNowClient.java
>> +++ b/components/camel-servicenow/src/main/java/org/apache/camel/component/servicenow/ServiceNowClient.java
>> @@ -162,7 +162,7 @@ public final class ServiceNowClient {
>>      }
>>
>>      private static void configureTls(
>> -        CamelContext camelContext, ServiceNowConfiguration configuration, WebClient client) throws Exception{
>> +        CamelContext camelContext, ServiceNowConfiguration configuration, WebClient client) throws Exception {
>>
>>          SSLContextParameters sslContextParams = configuration.getSslContextParameters();
>>          if (sslContextParams != null) {
>>
>> http://git-wip-us.apache.org/repos/asf/camel/blob/490a76f1/components/readme.adoc
>> ----------------------------------------------------------------------
>> diff --git a/components/readme.adoc b/components/readme.adoc
>> index 6d1eb1a..81b3828 100644
>> --- a/components/readme.adoc
>> +++ b/components/readme.adoc
>> @@ -15,12 +15,6 @@ Components
>> | link:camel-amqp/src/main/docs/amqp-component.adoc[AMQP] (camel-amqp) +
>> `amqp:destinationType:destinationName` | Messaging with AMQP protocol using Apache QPid Client.
>>
>> -| link:camel-flink/src/main/docs/flink-component.adoc[Apache Flink] (camel-flink) +
>> -`flink:endpointType` | The flink component can be used to send DataSet jobs to Apache Flink cluster.
>> -
>> -| link:camel-spark/src/main/docs/spark-component.adoc[Apache Spark] (camel-spark) +
>> -`spark:endpointType` | The spark component can be used to send RDD or DataFrame jobs to Apache Spark cluster.
>> -
>> | link:camel-apns/src/main/docs/apns-component.adoc[APNS] (camel-apns) +
>> `apns:name` | For sending notifications to Apple iOS devices.
>>
>> @@ -141,249 +135,60 @@ Components
>> | link:camel-drill/src/main/docs/drill-component.adoc[Drill] (camel-drill) +
>> `drill:host` | The drill component gives you the ability to quering into apache drill cluster.
>>
>> -| link:camel-dropbox/src/main/docs/dropbox-component.adoc[Dropbox] (camel-dropbox) +
>> -`dropbox:operation` | For uploading downloading and managing files folders groups collaborations etc on dropbox DOT com.
>> -
>> | link:camel-cache/src/main/docs/cache-component.adoc[EHCache] (camel-cache) +
>> `cache:cacheName` | *deprecated* The cache component enables you to perform caching operations using EHCache as the Cache Implementation.
>>
>> -| link:camel-ehcache/src/main/docs/ehcache-component.adoc[Ehcache] (camel-ehcache) +
>> -`ehcache:cacheName` | The ehcache component enables you to perform caching operations using Ehcache as cache implementation.
>> -
>> -| link:camel-ejb/src/main/docs/ejb-component.adoc[EJB] (camel-ejb) +
>> -`ejb:beanName` | The ejb component is for invoking EJB Java beans from Camel.
>> -
>> -| link:camel-elasticsearch/src/main/docs/elasticsearch-component.adoc[Elasticsearch] (camel-elasticsearch) +
>> -`elasticsearch:clusterName` | The elasticsearch component is used for interfacing with ElasticSearch server.
>> -
>> -| link:camel-elsql/src/main/docs/elsql-component.adoc[ElSQL] (camel-elsql) +
>> -`elsql:elsqlName:resourceUri` | The elsql component is an extension to the existing SQL Component that uses ElSql to define the SQL queries.
>> -
>> -| link:camel-etcd/src/main/docs/etcd-component.adoc[etcd] (camel-etcd) +
>> -`etcd:namespace/path` | The camel etcd component allows you to work with Etcd a distributed A distributed reliable key-value store.
>> -
>> -| link:camel-exec/src/main/docs/exec-component.adoc[Exec] (camel-exec) +
>> -`exec:executable` | The exec component can be used to execute OS system commands.
>> -
>> -| link:camel-facebook/src/main/docs/facebook-component.adoc[Facebook] (camel-facebook) +
>> -`facebook:methodName` | The Facebook component provides access to all of the Facebook APIs accessible using Facebook4J.
>> -
>> -| link:camel-flatpack/src/main/docs/flatpack-component.adoc[Flatpack] (camel-flatpack) +
>> -`flatpack:type:resourceUri` | The flatpack component supports fixed width and delimited file parsing via the FlatPack library.
>> -
>> -| link:camel-fop/src/main/docs/fop-component.adoc[FOP] (camel-fop) +
>> -`fop:outputType` | The fop component allows you to render a message into different output formats using Apache FOP.
>> -
>> -| link:camel-freemarker/src/main/docs/freemarker-component.adoc[Freemarker] (camel-freemarker) +
>> -`freemarker:resourceUri` | Transforms the message using a FreeMarker template.
>> -
>> -| link:camel-ftp/src/main/docs/ftp-component.adoc[FTP] (camel-ftp) +
>> -`ftp:host:port/directoryName` | The ftp component is used for uploading or downloading files from FTP servers.
>> -
>> -| link:camel-ftp/src/main/docs/ftps-component.adoc[FTPS] (camel-ftp) +
>> -`ftps:host:port/directoryName` | The ftps (FTP secure SSL/TLS) component is used for uploading or downloading files from FTP servers.
>> -
>> -| link:camel-ganglia/src/main/docs/ganglia-component.adoc[Ganglia] (camel-ganglia) +
>> -`ganglia:host:port` | The ganglia component is used for sending metrics to the Ganglia monitoring system.
>> -
>> -| link:camel-geocoder/src/main/docs/geocoder-component.adoc[Geocoder] (camel-geocoder) +
>> -`geocoder:address:latlng` | The geocoder component is used for looking up geocodes (latitude and longitude) for a given address or reverse lookup.
>> -
>> -| link:camel-git/src/main/docs/git-component.adoc[Git] (camel-git) +
>> -`git:localPath` | The git component is used for working with git repositories.
>> -
>> -| link:camel-github/src/main/docs/github-component.adoc[GitHub] (camel-github) +
>> -`github:type/branchName` | The github component is used for integrating Camel with github.
>> -
>> | link:camel-google-calendar/src/main/docs/google-calendar-component.adoc[Google Calendar] (camel-google-calendar) +
>> `google-calendar:apiName/methodName` | The google-calendar component provides access to Google Calendar.
>>
>> -| link:camel-google-drive/src/main/docs/google-drive-component.adoc[Google Drive] (camel-google-drive) +
>> -`google-drive:apiName/methodName` | The google-drive component provides access to Google Drive file storage service.
>> -
>> -| link:camel-google-mail/src/main/docs/google-mail-component.adoc[Google Mail] (camel-google-mail) +
>> -`google-mail:apiName/methodName` | The google-mail component provides access to Google Mail.
>> -
>> | link:camel-google-pubsub/src/main/docs/google-pubsub-component.adoc[Google Pubsub] (camel-google-pubsub) +
>> `google-pubsub:projectId:destinationName` | Messaging client for Google Cloud Platform PubSub Service: https://cloud.google.com/pubsub/
>>
>> -| link:camel-gora/src/main/docs/gora-component.adoc[Gora] (camel-gora) +
>> -`gora:name` | The gora component allows you to work with NoSQL databases using the Apache Gora framework.
>> -
>> | link:camel-grape/src/main/docs/grape-component.adoc[Grape] (camel-grape) +
>> `grape:defaultCoordinates` | Grape component allows you to fetch, load and manage additional jars when CamelContext is running.
>>
>> -| link:camel-guava-eventbus/src/main/docs/guava-eventbus-component.adoc[Guava EventBus] (camel-guava-eventbus) +
>> -`guava-eventbus:eventBusRef` | The guava-eventbus component provides integration bridge between Camel and Google Guava EventBus.
>> -
>> -| link:camel-hazelcast/src/main/docs/hazelcast-component.adoc[Hazelcast] (camel-hazelcast) +
>> -`hazelcast:command:cacheName` | The hazelcast component allows you to work with the Hazelcast distributed data grid / cache.
>> -
>> -| link:camel-hbase/src/main/docs/hbase-component.adoc[HBase] (camel-hbase) +
>> -`hbase:tableName` | For reading/writing from/to an HBase store (Hadoop database).
>> -
>> -| link:camel-hdfs/src/main/docs/hdfs-component.adoc[HDFS] (camel-hdfs) +
>> -`hdfs:hostName:port/path` | *deprecated* For reading/writing from/to an HDFS filesystem using Hadoop 1.x.
>> -
>> -| link:camel-hdfs2/src/main/docs/hdfs2-component.adoc[HDFS2] (camel-hdfs2) +
>> -`hdfs2:hostName:port/path` | For reading/writing from/to an HDFS filesystem using Hadoop 2.x.
>> -
>> -| link:camel-hipchat/src/main/docs/hipchat-component.adoc[Hipchat] (camel-hipchat) +
>> -`hipchat:protocol:host:port` | The hipchat component supports producing and consuming messages from/to Hipchat service.
>> -
>> | link:camel-http/src/main/docs/http-component.adoc[HTTP] (camel-http) +
>> `http:httpUri` | For calling out to external HTTP servers using Apache HTTP Client 3.x.
>>
>> | link:camel-http4/src/main/docs/http4-component.adoc[HTTP4] (camel-http4) +
>> `http4:httpUri` | For calling out to external HTTP servers using Apache HTTP Client 4.x.
>>
>> -| link:camel-ibatis/src/main/docs/ibatis-component.adoc[iBatis] (camel-ibatis) +
>> -`ibatis:statement` | *deprecated* Performs a query poll insert update or delete in a relational database using Apache iBATIS.
>> -
>> -| link:camel-mail/src/main/docs/imap-component.adoc[IMAP] (camel-mail) +
>> -`imap:host:port` | To send or receive emails using imap/pop3 or stmp protocols.
>> -
>> | link:camel-infinispan/src/main/docs/infinispan-component.adoc[Infinispan] (camel-infinispan) +
>> `infinispan:host` | For reading/writing from/to Infinispan distributed key/value store and data grid.
>>
>> -| link:camel-influxdb/src/main/docs/influxdb-component.adoc[InfluxDB] (camel-influxdb) +
>> -`influxdb:connectionBean` | The influxdb component allows you to interact with InfluxDB a time series database.
>> -
>> -| link:camel-irc/src/main/docs/irc-component.adoc[IRC] (camel-irc) +
>> -`irc:hostname:port` | The irc component implements an IRC (Internet Relay Chat) transport.
>> -
>> | link:camel-ironmq/src/main/docs/ironmq-component.adoc[ironmq] (camel-ironmq) +
>> `ironmq:queueName` | The ironmq provides integration with IronMQ an elastic and durable hosted message queue as a service.
>>
>> -| link:camel-javaspace/src/main/docs/javaspace-component.adoc[JavaSpace] (camel-javaspace) +
>> -`javaspace:url` | *deprecated* Sending and receiving messages through JavaSpace.
>> -
>> -| link:camel-jbpm/src/main/docs/jbpm-component.adoc[JBPM] (camel-jbpm) +
>> -`jbpm:connectionURL` | The jbpm component provides integration with jBPM (Business Process Management).
>> -
>> | link:camel-jcache/src/main/docs/jcache-component.adoc[JCache] (camel-jcache) +
>> `jcache:cacheName` | The jcache component enables you to perform caching operations using JSR107/JCache as cache implementation.
>>
>> -| link:camel-jclouds/src/main/docs/jclouds-component.adoc[JClouds] (camel-jclouds) +
>> -`jclouds:command:providerId` | For interacting with cloud compute & blobstore service via jclouds.
>> -
>> -| link:camel-jcr/src/main/docs/jcr-component.adoc[JCR] (camel-jcr) +
>> -`jcr:host/base` | The jcr component allows you to add/read nodes to/from a JCR compliant content repository.
>> -
>> -| link:camel-jdbc/src/main/docs/jdbc-component.adoc[JDBC] (camel-jdbc) +
>> -`jdbc:dataSourceName` | The jdbc component enables you to access databases through JDBC where SQL queries are sent in the message body.
>> -
>> | link:camel-jetty9/src/main/docs/jetty-component.adoc[Jetty 9] (camel-jetty9) +
>> `jetty:httpUri` | The jetty component provides HTTP-based endpoints for consuming and producing HTTP requests.
>>
>> | link:camel-websocket/src/main/docs/websocket-component.adoc[Jetty Websocket] (camel-websocket) +
>> `websocket:host:port/resourceUri` | The websocket component provides websocket endpoints for communicating with clients using websocket.
>>
>> -| link:camel-jgroups/src/main/docs/jgroups-component.adoc[JGroups] (camel-jgroups) +
>> -`jgroups:clusterName` | The jgroups component provides exchange of messages between Camel and JGroups clusters.
>> -
>> -| link:camel-jing/src/main/docs/jing-component.adoc[Jing] (camel-jing) +
>> -`jing:resourceUri` | Validates the payload of a message using RelaxNG Syntax using Jing library.
>> -
>> -| link:camel-jira/src/main/docs/jira-component.adoc[JIRA] (camel-jira) +
>> -`jira:type` | The jira component interacts with the JIRA issue tracker.
>> -
>> | link:camel-jms/src/main/docs/jms-component.adoc[JMS] (camel-jms) +
>> `jms:destinationType:destinationName` | The jms component allows messages to be sent to (or consumed from) a JMS Queue or Topic.
>>
>> -| link:camel-jmx/src/main/docs/jmx-component.adoc[JMX] (camel-jmx) +
>> -`jmx:serverURL` | The jmx component allows to receive JMX notifications.
>> -
>> -| link:camel-jolt/src/main/docs/jolt-component.adoc[JOLT] (camel-jolt) +
>> -`jolt:resourceUri` | The jolt component allows you to process a JSON messages using an JOLT specification (such as JSON-JSON transformation).
>> -
>> -| link:camel-jpa/src/main/docs/jpa-component.adoc[JPA] (camel-jpa) +
>> -`jpa:entityType` | The jpa component enables you to store and retrieve Java objects from databases using JPA.
>> -
>> -| link:camel-jt400/src/main/docs/jt400-component.adoc[JT400] (camel-jt400) +
>> -`jt400:userID:password/systemName/objectPath.type` | The jt400 component allows you to exchanges messages with an AS/400 system using data queues or program call.
>> -
>> | link:camel-kafka/src/main/docs/kafka-component.adoc[Kafka] (camel-kafka) +
>> `kafka:brokers` | The kafka component allows messages to be sent to (or consumed from) Apache Kafka brokers.
>>
>> -| link:camel-kestrel/src/main/docs/kestrel-component.adoc[Kestrel] (camel-kestrel) +
>> -`kestrel:addresses/queue` | *deprecated* The kestrel component allows messages to be sent to (or consumed from) Kestrel brokers.
>> -
>> -| link:camel-krati/src/main/docs/krati-component.adoc[Krati] (camel-krati) +
>> -`krati:path` | The krati allows the use krati datastores and datasets inside Camel.
>> -
>> -| link:camel-kubernetes/src/main/docs/kubernetes-component.adoc[Kubernetes] (camel-kubernetes) +
>> -`kubernetes:masterUrl` | The kubernetes component allows to work with Kubernetes PaaS.
>> -
>> -| link:camel-ldap/src/main/docs/ldap-component.adoc[LDAP] (camel-ldap) +
>> -`ldap:dirContextName` | The ldap component allows you to perform searches in LDAP servers using filters as the message payload.
>> -
>> -| link:camel-linkedin/src/main/docs/linkedin-component.adoc[Linkedin] (camel-linkedin) +
>> -`linkedin:apiName/methodName` | The linkedin component is uses for retrieving LinkedIn user profiles connections companies groups posts etc.
>> -
>> -| link:camel-lucene/src/main/docs/lucene-component.adoc[Lucene] (camel-lucene) +
>> -`lucene:host:operation` | To insert or query from Apache Lucene databases.
>> -
>> -| link:camel-lumberjack/src/main/docs/lumberjack-component.adoc[Lumberjack] (camel-lumberjack) +
>> -`lumberjack:host:port` | The lumberjack retrieves logs sent over the network using the Lumberjack protocol.
>> -
>> | link:camel-metrics/src/main/docs/metrics-component.adoc[Metrics] (camel-metrics) +
>> `metrics:metricsType:metricsName` | To collect various metrics directly from Camel routes using the DropWizard metrics library.
>>
>> -| link:camel-mina/src/main/docs/mina-component.adoc[Mina] (camel-mina) +
>> -`mina:protocol:host:port` | *deprecated* Socket level networking using TCP or UDP with the Apache Mina 1.x library.
>> -
>> -| link:camel-mina2/src/main/docs/mina2-component.adoc[Mina2] (camel-mina2) +
>> -`mina2:protocol:host:port` | Socket level networking using TCP or UDP with the Apache Mina 2.x library.
>> -
>> | link:camel-mllp/src/main/docs/mllp-component.adoc[MLLP] (camel-mllp) +
>> `mllp:hostname:port` | The MLLP component is designed to handle the MLLP protocol and provide the functionality required by Healthcare providers to communicate with other systems using the MLLP protocol.
>>
>> | link:camel-mongodb/src/main/docs/mongodb-component.adoc[MongoDB] (camel-mongodb) +
>> `mongodb:connectionBean` | Component for working with documents stored in MongoDB database.
>>
>> -| link:camel-mongodb3/src/main/docs/mongodb3-component.adoc[MongoDB] (camel-mongodb3) +
>> -`mongodb3:connectionBean` | Component for working with documents stored in MongoDB database.
>> -
>> -| link:camel-mongodb-gridfs/src/main/docs/gridfs-component.adoc[MongoDBGridFS] (camel-mongodb-gridfs) +
>> -`gridfs:connectionBean` | Component for working with MongoDB GridFS.
>> -
>> -| link:camel-mqtt/src/main/docs/mqtt-component.adoc[MQTT] (camel-mqtt) +
>> -`mqtt:name` | Component for communicating with MQTT M2M message brokers using FuseSource MQTT Client.
>> -
>> -| link:camel-msv/src/main/docs/msv-component.adoc[MSV] (camel-msv) +
>> -`msv:resourceUri` | Validates the payload of a message using the MSV Library.
>> -
>> -| link:camel-mustache/src/main/docs/mustache-component.adoc[Mustache] (camel-mustache) +
>> -`mustache:resourceUri` | Transforms the message using a Mustache template.
>> -
>> -| link:camel-mvel/src/main/docs/mvel-component.adoc[MVEL] (camel-mvel) +
>> -`mvel:resourceUri` | Transforms the message using a MVEL template.
>> -
>> -| link:camel-mybatis/src/main/docs/mybatis-component.adoc[MyBatis] (camel-mybatis) +
>> -`mybatis:statement` | Performs a query poll insert update or delete in a relational database using MyBatis.
>> -
>> -| link:camel-nagios/src/main/docs/nagios-component.adoc[Nagios] (camel-nagios) +
>> -`nagios:host:port` | To send passive checks to Nagios using JSendNSCA.
>> -
>> -| link:camel-nats/src/main/docs/nats-component.adoc[Nats] (camel-nats) +
>> -`nats:servers` | The nats component allows you produce and consume messages from NATS.
>> -
>> -| link:camel-netty/src/main/docs/netty-component.adoc[Netty] (camel-netty) +
>> -`netty:protocol:host:port` | *deprecated* Socket level networking using TCP or UDP with the Netty 3.x library.
>> -
>> -| link:camel-netty-http/src/main/docs/netty-http-component.adoc[Netty HTTP] (camel-netty-http) +
>> -`netty-http:protocol:host:port/path` | *deprecated* Netty HTTP server and client using the Netty 3.x library.
>> -
>> | link:camel-netty4/src/main/docs/netty4-component.adoc[Netty4] (camel-netty4) +
>> `netty4:protocol:host:port` | Socket level networking using TCP or UDP with the Netty 4.x library.
>>
>> | link:camel-netty4-http/src/main/docs/netty4-http-component.adoc[Netty4 HTTP] (camel-netty4-http) +
>> `netty4-http:protocol:host:port/path` | Netty HTTP server and client using the Netty 4.x library.
>>
>> -| link:camel-openshift/src/main/docs/openshift-component.adoc[OpenShift] (camel-openshift) +
>> -`openshift:clientId` | *deprecated* To manage your Openshift 2.x applications.
>> -
>> | link:camel-openstack/src/main/docs/openstack-cinder-component.adoc[OpenStack-Cinder] (camel-openstack) +
>> `openstack-cinder:host` | Camel Components
>>
>> @@ -402,174 +207,33 @@ Components
>> | link:camel-openstack/src/main/docs/openstack-swift-component.adoc[OpenStack-Swift] (camel-openstack) +
>> `openstack-swift:host` | Camel Components
>>
>> -| link:camel-optaplanner/src/main/docs/optaplanner-component.adoc[OptaPlanner] (camel-optaplanner) +
>> -`optaplanner:configFile` | Solves the planning problem contained in a message with OptaPlanner.
>> -
>> -| link:camel-eventadmin/src/main/docs/eventadmin-component.adoc[OSGi EventAdmin] (camel-eventadmin) +
>> -`eventadmin:topic` | The eventadmin component can be used in an OSGi environment to receive OSGi EventAdmin events and process them.
>> -
>> -| link:camel-paxlogging/src/main/docs/paxlogging-component.adoc[OSGi PAX Logging] (camel-paxlogging) +
>> -`paxlogging:appender` | The paxlogging component can be used in an OSGi environment to receive PaxLogging events and process them.
>> -
>> -| link:camel-paho/src/main/docs/paho-component.adoc[Paho] (camel-paho) +
>> -`paho:topic` | Component for communicating with MQTT M2M message brokers using Eclipse Paho MQTT Client.
>> -
>> -| link:camel-pdf/src/main/docs/pdf-component.adoc[PDF] (camel-pdf) +
>> -`pdf:operation` | The pdf components provides the ability to create modify or extract content from PDF documents.
>> -
>> -| link:camel-pgevent/src/main/docs/pgevent-component.adoc[PostgresSQL Event] (camel-pgevent) +
>> -`pgevent:host:port/database/channel` | The pgevent component allows for producing/consuming PostgreSQL events related to the LISTEN/NOTIFY commands.
>> -
>> -| link:camel-printer/src/main/docs/lpr-component.adoc[Printer] (camel-printer) +
>> -`lpr:hostname:port/printername` | The printer component is used for sending messages to printers as print jobs.
>> -
>> -| link:camel-quartz/src/main/docs/quartz-component.adoc[Quartz] (camel-quartz) +
>> -`quartz:groupName/timerName` | *deprecated* Provides a scheduled delivery of messages using the Quartz 1.x scheduler.
>> -
>> -| link:camel-quartz2/src/main/docs/quartz2-component.adoc[Quartz2] (camel-quartz2) +
>> -`quartz2:groupName/triggerName` | Provides a scheduled delivery of messages using the Quartz 2.x scheduler.
>> -
>> -| link:camel-quickfix/src/main/docs/quickfix-component.adoc[QuickFix] (camel-quickfix) +
>> -`quickfix:configurationName` | The quickfix component allows to send Financial Interchange (FIX) messages to the QuickFix engine.
>> -
>> -| link:camel-rabbitmq/src/main/docs/rabbitmq-component.adoc[RabbitMQ] (camel-rabbitmq) +
>> -`rabbitmq:hostname:portNumber/exchangeName` | The rabbitmq component allows you produce and consume messages from RabbitMQ instances.
>> -
>> -| link:camel-restlet/src/main/docs/restlet-component.adoc[Restlet] (camel-restlet) +
>> -`restlet:protocol:host:port/uriPattern` | Component for consuming and producing Restful resources using Restlet.
>> -
>> -| link:camel-rmi/src/main/docs/rmi-component.adoc[RMI] (camel-rmi) +
>> -`rmi:hostname:port/name` | The rmi component is for invoking Java RMI beans from Camel.
>> -
>> -| link:camel-routebox/src/main/docs/routebox-component.adoc[RouteBox] (camel-routebox) +
>> -`routebox:routeboxName` | *deprecated* The routebox component allows to send/receive messages between Camel routes in a black box way.
>> -
>> -| link:camel-rss/src/main/docs/rss-component.adoc[RSS] (camel-rss) +
>> -`rss:feedUri` | The rss component is used for consuming RSS feeds.
>> -
>> | link:camel-salesforce/src/main/docs/salesforce-component.adoc[Salesforce] (camel-salesforce) +
>> `salesforce:operationName:topicName` | The salesforce component is used for integrating Camel with the massive Salesforce API.
>>
>> -| link:camel-sap-netweaver/src/main/docs/sap-netweaver-component.adoc[SAP NetWeaver] (camel-sap-netweaver) +
>> -`sap-netweaver:url` | The sap-netweaver component integrates with the SAP NetWeaver Gateway using HTTP transports.
>> -
>> -| link:camel-schematron/src/main/docs/schematron-component.adoc[Schematron] (camel-schematron) +
>> -`schematron:path` | Validates the payload of a message using the Schematron Library.
>> -
>> -| link:camel-jsch/src/main/docs/scp-component.adoc[SCP] (camel-jsch) +
>> -`scp:host:port/directoryName` | To copy files using the secure copy protocol (SCP).
>> -
>> -| link:camel-servicenow/src/main/docs/servicenow-component.adoc[ServiceNow] (camel-servicenow) +
>> -`servicenow:instanceName` | The servicenow component is used to integrate Camel with ServiceNow cloud services.
>> -
>> | link:camel-servlet/src/main/docs/servlet-component.adoc[Servlet] (camel-servlet) +
>> `servlet:contextPath` | To use a HTTP Servlet as entry for Camel routes when running in a servlet container.
>>
>> -| link:camel-ftp/src/main/docs/sftp-component.adoc[SFTP] (camel-ftp) +
>> -`sftp:host:port/directoryName` | The sftp (FTP over SSH) component is used for uploading or downloading files from SFTP servers.
>> -
>> -| link:camel-sjms/src/main/docs/sjms-component.adoc[Simple JMS] (camel-sjms) +
>> -`sjms:destinationType:destinationName` | The sjms component (simple jms) allows messages to be sent to (or consumed from) a JMS Queue or Topic.
>> -
>> -| link:camel-sjms/src/main/docs/sjms-batch-component.adoc[Simple JMS Batch] (camel-sjms) +
>> -`sjms-batch:destinationName` | The sjms-batch component is a specialized for highly performant transactional batch consumption from a JMS queue.
>> -
>> -| link:camel-sip/src/main/docs/sip-component.adoc[SIP] (camel-sip) +
>> -`sip:uri` | To send and receive messages using the SIP protocol (used in telco and mobile).
>> -
>> -| link:camel-slack/src/main/docs/slack-component.adoc[Slack] (camel-slack) +
>> -`slack:channel` | The slack component allows you to send messages to Slack.
>> -
>> | link:camel-smpp/src/main/docs/smpp-component.adoc[SMPP] (camel-smpp) +
>> `smpp:host:port` | To send and receive SMS using a SMSC (Short Message Service Center).
>>
>> -| link:camel-snmp/src/main/docs/snmp-component.adoc[SNMP] (camel-snmp) +
>> -`snmp:host:port` | The snmp component gives you the ability to poll SNMP capable devices or receiving traps.
>> -
>> -| link:camel-solr/src/main/docs/solr-component.adoc[Solr] (camel-solr) +
>> -`solr:url` | The solr component allows you to interface with an Apache Lucene Solr server.
>> -
>> -| link:camel-spark-rest/src/main/docs/spark-rest-component.adoc[Spark Rest] (camel-spark-rest) +
>> -`spark-rest:verb:path` | The spark-rest component is used for hosting REST services which has been defined using Camel rest-dsl.
>> -
>> -| link:camel-splunk/src/main/docs/splunk-component.adoc[Splunk] (camel-splunk) +
>> -`splunk:name` | The splunk component allows to publish or search for events in Splunk.
>> -
>> -| link:camel-spring-batch/src/main/docs/spring-batch-component.adoc[Spring Batch] (camel-spring-batch) +
>> -`spring-batch:jobName` | The spring-batch component allows to send messages to Spring Batch for further processing.
>> -
>> | link:camel-spring/src/main/docs/spring-event-component.adoc[Spring Event] (camel-spring) +
>> `spring-event:name` | The spring-event component allows to listen for Spring Application Events.
>>
>> -| link:camel-spring-integration/src/main/docs/spring-integration-component.adoc[Spring Integration] (camel-spring-integration) +
>> -`spring-integration:defaultChannel` | Bridges Camel with Spring Integration.
>> -
>> -| link:camel-spring-ldap/src/main/docs/spring-ldap-component.adoc[Spring LDAP] (camel-spring-ldap) +
>> -`spring-ldap:templateName` | The spring-ldap component allows you to perform searches in LDAP servers using filters as the message payload.
>> -
>> -| link:camel-spring-redis/src/main/docs/spring-redis-component.adoc[Spring Redis] (camel-spring-redis) +
>> -`spring-redis:host:port` | The spring-redis component allows sending and receiving messages from Redis.
>> -
>> -| link:camel-spring-ws/src/main/docs/spring-ws-component.adoc[Spring WebService] (camel-spring-ws) +
>> -`spring-ws:type:lookupKey:webServiceEndpointUri` | The spring-ws component is used for SOAP WebServices using Spring WebServices.
>> -
>> | link:camel-sql/src/main/docs/sql-component.adoc[SQL] (camel-sql) +
>> `sql:query` | The sql component allows you to work with databases using JDBC SQL queries.
>>
>> | link:camel-sql/src/main/docs/sql-stored-component.adoc[SQL StoredProcedure] (camel-sql) +
>> `sql-stored:template` | The sql component allows you to work with databases using JDBC Stored Procedure queries.
>>
>> -| link:camel-ssh/src/main/docs/ssh-component.adoc[SSH] (camel-ssh) +
>> -`ssh:host:port` | The ssh component enables access to SSH servers such that you can send an SSH command and process the response.
>> -
>> -| link:camel-stax/src/main/docs/stax-component.adoc[StAX] (camel-stax) +
>> -`stax:contentHandlerClass` | The stax component allows messages to be process through a SAX ContentHandler.
>> -
>> -| link:camel-stomp/src/main/docs/stomp-component.adoc[Stomp] (camel-stomp) +
>> -`stomp:destination` | The stomp component is used for communicating with Stomp compliant message brokers.
>> -
>> | link:camel-stream/src/main/docs/stream-component.adoc[Stream] (camel-stream) +
>> `stream:kind` | The stream: component provides access to the system-in system-out and system-err streams as well as allowing streaming of file and URL.
>>
>> -| link:camel-stringtemplate/src/main/docs/string-template-component.adoc[String Template] (camel-stringtemplate) +
>> -`string-template:resourceUri` | Transforms the message using a String template.
>> -
>> -| link:camel-telegram/src/main/docs/telegram-component.adoc[Telegram] (camel-telegram) +
>> -`telegram:type/authorizationToken` | The telegram component provides access to the Telegram Bot API.
>> -
>> -| link:camel-twitter/src/main/docs/twitter-component.adoc[Twitter] (camel-twitter) +
>> -`twitter:kind` | This component integrates with Twitter to send tweets or search for tweets and more.
>> -
>> -| link:camel-undertow/src/main/docs/undertow-component.adoc[Undertow] (camel-undertow) +
>> -`undertow:httpURI` | The undertow component provides HTTP-based endpoints for consuming and producing HTTP requests.
>> -
>> | link:camel-velocity/src/main/docs/velocity-component.adoc[Velocity] (camel-velocity) +
>> `velocity:resourceUri` | Transforms the message using a Velocity template.
>>
>> -| link:camel-vertx/src/main/docs/vertx-component.adoc[Vert.x] (camel-vertx) +
>> -`vertx:address` | The vertx component is used for sending and receive messages from a vertx event bus.
>> -
>> | link:camel-weather/src/main/docs/weather-component.adoc[Weather] (camel-weather) +
>> `weather:name` | Polls the weather information from Open Weather Map.
>>
>> -| link:camel-xmlrpc/src/main/docs/xmlrpc-component.adoc[XML RPC] (camel-xmlrpc) +
>> -`xmlrpc:address` | The xmlrpc component is used for sending messages to a XML RPC service.
>> -
>> -| link:camel-xmlsecurity/src/main/docs/xmlsecurity-component.adoc[XML Security] (camel-xmlsecurity) +
>> -`xmlsecurity:command:name` | Used to sign and verify exchanges using the XML signature specification.
>> -
>> -| link:camel-xmpp/src/main/docs/xmpp-component.adoc[XMPP] (camel-xmpp) +
>> -`xmpp:host:port/participant` | To send and receive messages from a XMPP (chat) server.
>> -
>> -| link:camel-saxon/src/main/docs/xquery-component.adoc[XQuery] (camel-saxon) +
>> -`xquery:resourceUri` | Transforms the message using a XQuery template using Saxon.
>> -
>> -| link:camel-yammer/src/main/docs/yammer-component.adoc[Yammer] (camel-yammer) +
>> -`yammer:function` | The yammer component allows you to interact with the Yammer enterprise social network.
>> -
>> -| link:camel-zookeeper/src/main/docs/zookeeper-component.adoc[ZooKeeper] (camel-zookeeper) +
>> -`zookeeper:serverUrls/path` | The zookeeper component allows interaction with a ZooKeeper cluster.
>> -
>> |=======================================================================
>> // components: END
>>
>> @@ -646,65 +310,17 @@ Data Formats
>>
>> | link:camel-csv/src/main/docs/csv-dataformat.adoc[CSV] (camel-csv) | Camel CSV data format support
>>
>> -| link:camel-flatpack/src/main/docs/flatpack-dataformat.adoc[Flatpack] (camel-flatpack) | Camel FlatPack support
>> -
>> | link:camel-hessian/src/main/docs/hessian-dataformat.adoc[Hessian] (camel-hessian) | Hessian serialization support
>>
>> | link:camel-hl7/src/main/docs/hl7-dataformat.adoc[HL7] (camel-hl7) | Camel HL7 support
>>
>> -| link:camel-ical/src/main/docs/ical-dataformat.adoc[iCal] (camel-ical) | Camel iCal component
>> -
>> | link:camel-jacksonxml/src/main/docs/jacksonxml-dataformat.adoc[JacksonXML] (camel-jacksonxml) | Camel Jackson XML support
>>
>> | link:camel-jaxb/src/main/docs/jaxb-dataformat.adoc[JAXB] (camel-jaxb) | Camel JAXB support
>>
>> -| link:camel-jibx/src/main/docs/jibx-dataformat.adoc[JiBX] (camel-jibx) | Camel Jibx support
>> -
>> -| link:camel-gson/src/main/docs/json-gson-dataformat.adoc[JSon GSon] (camel-gson) | Camel Gson support
>> -
>> | link:camel-jackson/src/main/docs/json-jackson-dataformat.adoc[JSon Jackson] (camel-jackson) | Camel Jackson support
>>
>> -| link:camel-johnzon/src/main/docs/json-johnzon-dataformat.adoc[JSon Johnzon] (camel-johnzon) | Camel Johnzon support
>> -
>> -| link:camel-xstream/src/main/docs/json-xstream-dataformat.adoc[JSon XStream] (camel-xstream) | Camel XStream support
>> -
>> -| link:camel-lzf/src/main/docs/lzf-dataformat.adoc[LZF Deflate Compression] (camel-lzf) | Camel LZF support
>> -
>> -| link:camel-mail/src/main/docs/mime-multipart-dataformat.adoc[MIME Multipart] (camel-mail) | Camel Mail support
>> -
>> | link:camel-crypto/src/main/docs/pgp-dataformat.adoc[PGP] (camel-crypto) | Camel Cryptographic Support
>> -
>> -| link:camel-protobuf/src/main/docs/protobuf-dataformat.adoc[Protobuf] (camel-protobuf) | Camel Google Protobuf data format support
>> -
>> -| link:camel-rss/src/main/docs/rss-dataformat.adoc[RSS] (camel-rss) | Camel RSS support
>> -
>> -| link:camel-soap/src/main/docs/soapjaxb-dataformat.adoc[SOAP] (camel-soap) | Camel SOAP support
>> -
>> -| link:camel-syslog/src/main/docs/syslog-dataformat.adoc[Syslog] (camel-syslog) | Camel Syslog support
>> -
>> -| link:camel-tarfile/src/main/docs/tarfile-dataformat.adoc[Tar File] (camel-tarfile) | Camel Tar file support
>> -
>> -| link:camel-tagsoup/src/main/docs/tidyMarkup-dataformat.adoc[TidyMarkup] (camel-tagsoup) | Camel TagSoup support
>> -
>> -| link:camel-univocity-parsers/src/main/docs/univocity-csv-dataformat.adoc[uniVocity CSV] (camel-univocity-parsers) | Camel UniVocity parsers data format support
>> -
>> -| link:camel-univocity-parsers/src/main/docs/univocity-fixed-dataformat.adoc[uniVocity Fixed Length] (camel-univocity-parsers) | Camel UniVocity parsers data format support
>> -
>> -| link:camel-univocity-parsers/src/main/docs/univocity-tsv-dataformat.adoc[uniVocity TSV] (camel-univocity-parsers) | Camel UniVocity parsers data format support
>> -
>> -| link:camel-xmlbeans/src/main/docs/xmlBeans-dataformat.adoc[XML Beans] (camel-xmlbeans) | Camel XMLBeans support
>> -
>> -| link:camel-xmljson/src/main/docs/xmljson-dataformat.adoc[XML JSon] (camel-xmljson) | Camel XML JSON Data Format
>> -
>> -| link:camel-xmlrpc/src/main/docs/xmlrpc-dataformat.adoc[XML RPC] (camel-xmlrpc) | Camel XML RPC support
>> -
>> -| link:camel-xmlsecurity/src/main/docs/secureXML-dataformat.adoc[XML Security] (camel-xmlsecurity) | Camel Partial XML Encryption/Decryption and XML Signature support
>> -
>> -| link:camel-xstream/src/main/docs/xstream-dataformat.adoc[XStream] (camel-xstream) | Camel XStream support
>> -
>> -| link:camel-snakeyaml/src/main/docs/yaml-snakeyaml-dataformat.adoc[YAML SnakeYAML] (camel-snakeyaml) | Camel SnakeYAML support
>> -
>> -| link:camel-zipfile/src/main/docs/zipfile-dataformat.adoc[Zip File] (camel-zipfile) | Camel Zip file support
>> |=======================================================================
>> // dataformats: END
>>
>> @@ -723,27 +339,9 @@ Expression Languages
>>
>> | link:camel-hl7/src/main/docs/terser-language.adoc[HL7 Terser] (camel-hl7) | For HL7 terser expressions and predicates
>>
>> -| link:camel-script/src/main/docs/javaScript-language.adoc[JavaScript] (camel-script) | For JavaScript expressions and predicates
>> -
>> -| link:camel-jsonpath/src/main/docs/jsonpath-language.adoc[JSonPath] (camel-jsonpath) | For JSonPath expressions and predicates
>> -
>> | link:camel-jxpath/src/main/docs/jxpath-language.adoc[JXPath] (camel-jxpath) | For JXPath expressions and predicates
>>
>> -| link:camel-mvel/src/main/docs/mvel-language.adoc[MVEL] (camel-mvel) | For MVEL expressions and predicates
>> -
>> -| link:camel-ognl/src/main/docs/ognl-language.adoc[OGNL] (camel-ognl) | For OGNL expressions and predicates
>> -
>> -| link:camel-script/src/main/docs/php-language.adoc[PHP] (camel-script) | For PHP expressions and predicates
>> -
>> -| link:camel-script/src/main/docs/python-language.adoc[Python] (camel-script) | For Python expressions and predicates
>> -
>> -| link:camel-script/src/main/docs/ruby-language.adoc[Ruby] (camel-script) | For Ruby expressions and predicates
>> -
>> | link:camel-spring/src/main/docs/spel-language.adoc[SpEL] (camel-spring) | For Spring Expression Language (SpEL) expressions and predicates
>> -
>> -| link:camel-josql/src/main/docs/sql-language.adoc[SQL] (camel-josql) | For SQL expressions and predicates
>> -
>> -| link:camel-saxon/src/main/docs/xquery-language.adoc[XQuery] (camel-saxon) | For XQuery expressions and predicates
>> |=======================================================================
>> // languages: END
>>
>
>
>
> --
> Claus Ibsen
> -----------------
> http://davsclaus.com @davsclaus
> Camel in Action 2: https://www.manning.com/ibsen2



-- 
Claus Ibsen
-----------------
http://davsclaus.com @davsclaus
Camel in Action 2: https://www.manning.com/ibsen2


Re: camel git commit: Fix CS violations

Posted by Babak Vahdat <ba...@swissonline.ch>.
> Am 19.12.2016 um 11:15 schrieb Claus Ibsen <cl...@gmail.com>:
> 
> Hi
> 
> Okay I found the issue. Its when you don't run the platforms/catalog
> build which is the guy that is responsible for updating that readme
> file.
> 
> I just regen the doc and its up to date again.
> 

Thanks!

Babak

>> On Mon, Dec 19, 2016 at 11:00 AM, Claus Ibsen <cl...@gmail.com> wrote:
>> Yeah we need to revert those .docs files.
>> 
>> And keep an eye on the build if it generates those two files
>> correctly, there may be a flaw in the camel-package-maven-plugin that
>> has the code for this.
>> 
>> On Mon, Dec 19, 2016 at 10:55 AM, Andrea Cosentino
>> <an...@yahoo.com.invalid> wrote:
>>> It looks like the build deleted the components list from readme.
>>> --
>>> Andrea Cosentino
>>> ----------------------------------
>>> Apache Camel PMC Member
>>> Apache Karaf Committer
>>> Apache Servicemix Committer
>>> Email: ancosen1985@yahoo.com
>>> Twitter: @oscerd2
>>> Github: oscerd
>>> 
>>> 
>>> 
>>> On Sunday, December 18, 2016 6:27 PM, "bvahdat@apache.org" <bv...@apache.org> wrote:
>>> Repository: camel
>>> Updated Branches:
>>>  refs/heads/master 079b5f9e6 -> 490a76f17
>>> 
>>> 
>>> Fix CS violations
>>> 
>>> Project: http://git-wip-us.apache.org/repos/asf/camel/repo
>>> Commit: http://git-wip-us.apache.org/repos/asf/camel/commit/490a76f1
>>> Tree: http://git-wip-us.apache.org/repos/asf/camel/tree/490a76f1
>>> Diff: http://git-wip-us.apache.org/repos/asf/camel/diff/490a76f1
>>> 
>>> Branch: refs/heads/master
>>> Commit: 490a76f17a1cb96a08009607a7aa972e7bc0372d
>>> Parents: 079b5f9
>>> Author: Babak Vahdat <bv...@apache.org>
>>> Authored: Sun Dec 18 18:26:52 2016 +0100
>>> Committer: Babak Vahdat <bv...@apache.org>
>>> Committed: Sun Dec 18 18:26:52 2016 +0100
>>> 
>>> ----------------------------------------------------------------------
>>> .../component/bonita/BonitaConfiguration.java   |   6 +-
>>> .../core/xml/CamelProxyFactoryDefinition.java   |   2 +-
>>> .../camel/component/gridfs/GridFsEndpoint.java  |   1 -
>>> .../openstack/nova/KeypairProducerTest.java     |   2 +-
>>> .../processor/RibbonServiceCallProcessor.java   |  19 +-
>>> .../component/servicenow/ServiceNowClient.java  |   2 +-
>>> components/readme.adoc                          | 402 -------------------
>>> 7 files changed, 15 insertions(+), 419 deletions(-)
>>> ----------------------------------------------------------------------
>>> 
>>> 
>>> http://git-wip-us.apache.org/repos/asf/camel/blob/490a76f1/components/camel-bonita/src/main/java/org/apache/camel/component/bonita/BonitaConfiguration.java
>>> ----------------------------------------------------------------------
>>> diff --git a/components/camel-bonita/src/main/java/org/apache/camel/component/bonita/BonitaConfiguration.java b/components/camel-bonita/src/main/java/org/apache/camel/component/bonita/BonitaConfiguration.java
>>> index 7343e2c..b992682 100644
>>> --- a/components/camel-bonita/src/main/java/org/apache/camel/component/bonita/BonitaConfiguration.java
>>> +++ b/components/camel-bonita/src/main/java/org/apache/camel/component/bonita/BonitaConfiguration.java
>>> @@ -5,9 +5,9 @@
>>>  * 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
>>> - * <p>
>>> - * http://www.apache.org/licenses/LICENSE-2.0
>>> - * <p>
>>> + *
>>> + *      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.
>>> 
>>> http://git-wip-us.apache.org/repos/asf/camel/blob/490a76f1/components/camel-core-xml/src/main/java/org/apache/camel/core/xml/CamelProxyFactoryDefinition.java
>>> ----------------------------------------------------------------------
>>> diff --git a/components/camel-core-xml/src/main/java/org/apache/camel/core/xml/CamelProxyFactoryDefinition.java b/components/camel-core-xml/src/main/java/org/apache/camel/core/xml/CamelProxyFactoryDefinition.java
>>> index 6f160ce..5c78b93 100644
>>> --- a/components/camel-core-xml/src/main/java/org/apache/camel/core/xml/CamelProxyFactoryDefinition.java
>>> +++ b/components/camel-core-xml/src/main/java/org/apache/camel/core/xml/CamelProxyFactoryDefinition.java
>>> @@ -63,7 +63,7 @@ public class CamelProxyFactoryDefinition extends IdentifiedType {
>>>      * @deprecated use serviceUrl instead with the ref endpoint.
>>>      */
>>>     @Deprecated
>>> -    public void setServiceRef(String serviceRef) {
>>> +    public void setServiceRef(String serviceRef) {
>>>         this.serviceRef = serviceRef;
>>>     }
>>> 
>>> 
>>> http://git-wip-us.apache.org/repos/asf/camel/blob/490a76f1/components/camel-mongodb-gridfs/src/main/java/org/apache/camel/component/gridfs/GridFsEndpoint.java
>>> ----------------------------------------------------------------------
>>> diff --git a/components/camel-mongodb-gridfs/src/main/java/org/apache/camel/component/gridfs/GridFsEndpoint.java b/components/camel-mongodb-gridfs/src/main/java/org/apache/camel/component/gridfs/GridFsEndpoint.java
>>> index cb8f686..f4d5d65 100644
>>> --- a/components/camel-mongodb-gridfs/src/main/java/org/apache/camel/component/gridfs/GridFsEndpoint.java
>>> +++ b/components/camel-mongodb-gridfs/src/main/java/org/apache/camel/component/gridfs/GridFsEndpoint.java
>>> @@ -39,7 +39,6 @@ import org.slf4j.LoggerFactory;
>>> @UriEndpoint(scheme = "gridfs", title = "MongoDBGridFS", syntax = "gridfs:connectionBean", label = "database,nosql")
>>> public class GridFsEndpoint extends DefaultEndpoint {
>>> 
>>> -    ;
>>>     public static final String GRIDFS_OPERATION = "gridfs.operation";
>>>     public static final String GRIDFS_METADATA = "gridfs.metadata";
>>>     public static final String GRIDFS_CHUNKSIZE = "gridfs.chunksize";
>>> 
>>> http://git-wip-us.apache.org/repos/asf/camel/blob/490a76f1/components/camel-openstack/src/test/java/org/apache/camel/component/openstack/nova/KeypairProducerTest.java
>>> ----------------------------------------------------------------------
>>> diff --git a/components/camel-openstack/src/test/java/org/apache/camel/component/openstack/nova/KeypairProducerTest.java b/components/camel-openstack/src/test/java/org/apache/camel/component/openstack/nova/KeypairProducerTest.java
>>> index c851a40..ba4813e 100644
>>> --- a/components/camel-openstack/src/test/java/org/apache/camel/component/openstack/nova/KeypairProducerTest.java
>>> +++ b/components/camel-openstack/src/test/java/org/apache/camel/component/openstack/nova/KeypairProducerTest.java
>>> @@ -114,6 +114,6 @@ public class KeypairProducerTest extends NovaProducerTestSupport {
>>>     }
>>> 
>>>     private Keypair createDummyKeypair() {
>>> -        return NovaKeypair.create(KEYPAIR_NAME, "string contains private key");
>>> +        return NovaKeypair.create(KEYPAIR_NAME, "string contains private key");
>>>     }
>>> }
>>> 
>>> http://git-wip-us.apache.org/repos/asf/camel/blob/490a76f1/components/camel-ribbon/src/main/java/org/apache/camel/component/ribbon/processor/RibbonServiceCallProcessor.java
>>> ----------------------------------------------------------------------
>>> diff --git a/components/camel-ribbon/src/main/java/org/apache/camel/component/ribbon/processor/RibbonServiceCallProcessor.java b/components/camel-ribbon/src/main/java/org/apache/camel/component/ribbon/processor/RibbonServiceCallProcessor.java
>>> index f9151ce..f701ba0 100644
>>> --- a/components/camel-ribbon/src/main/java/org/apache/camel/component/ribbon/processor/RibbonServiceCallProcessor.java
>>> +++ b/components/camel-ribbon/src/main/java/org/apache/camel/component/ribbon/processor/RibbonServiceCallProcessor.java
>>> @@ -19,7 +19,6 @@ package org.apache.camel.component.ribbon.processor;
>>> import java.util.Map;
>>> import java.util.concurrent.RejectedExecutionException;
>>> 
>>> -import com.netflix.client.config.CommonClientConfigKey;
>>> import com.netflix.client.config.IClientConfig;
>>> import com.netflix.client.config.IClientConfigKey;
>>> import com.netflix.loadbalancer.DummyPing;
>>> @@ -46,8 +45,8 @@ import org.apache.camel.spi.IdAware;
>>> import org.apache.camel.spi.ServiceCallServerListStrategy;
>>> import org.apache.camel.support.ServiceSupport;
>>> import org.apache.camel.util.AsyncProcessorHelper;
>>> -import org.apache.camel.util.ObjectHelper;
>>> import org.apache.camel.util.ServiceHelper;
>>> +import org.apache.camel.util.StringHelper;
>>> import org.slf4j.Logger;
>>> import org.slf4j.LoggerFactory;
>>> 
>>> @@ -78,18 +77,18 @@ public class RibbonServiceCallProcessor extends ServiceSupport implements AsyncP
>>>         // setup from the provided name which can contain scheme and context-path information as well
>>>         String serviceName;
>>>         if (name.contains("/")) {
>>> -            serviceName = ObjectHelper.before(name, "/");
>>> -            this.contextPath = ObjectHelper.after(name, "/");
>>> +            serviceName = StringHelper.before(name, "/");
>>> +            this.contextPath = StringHelper.after(name, "/");
>>>         } else if (name.contains("?")) {
>>> -            serviceName = ObjectHelper.before(name, "?");
>>> -            this.contextPath = ObjectHelper.after(name, "?");
>>> +            serviceName = StringHelper.before(name, "?");
>>> +            this.contextPath = StringHelper.after(name, "?");
>>>         } else {
>>>             serviceName = name;
>>>             this.contextPath = null;
>>>         }
>>>         if (serviceName.contains(":")) {
>>> -            this.scheme = ObjectHelper.before(serviceName, ":");
>>> -            this.name = ObjectHelper.after(serviceName, ":");
>>> +            this.scheme = StringHelper.before(serviceName, ":");
>>> +            this.name = StringHelper.after(serviceName, ":");
>>>         } else {
>>>             this.scheme = scheme;
>>>             this.name = serviceName;
>>> @@ -199,7 +198,7 @@ public class RibbonServiceCallProcessor extends ServiceSupport implements AsyncP
>>>     @Override
>>>     @SuppressWarnings("unchecked")
>>>     protected void doStart() throws Exception {
>>> -        ObjectHelper.notEmpty(name, "name", this);
>>> +        StringHelper.notEmpty(name, "name", this);
>>> 
>>>         if (serverListStrategy == null) {
>>>             serverListStrategy = new RibbonServiceCallStaticServerListStrategy();
>>> @@ -222,7 +221,7 @@ public class RibbonServiceCallProcessor extends ServiceSupport implements AsyncP
>>>         IClientConfig config = IClientConfig.Builder.newBuilder(name).build();
>>>         if (ribbonClientConfig != null) {
>>>             for (Map.Entry<String, String> entry : ribbonClientConfig.entrySet()) {
>>> -                IClientConfigKey key = CommonClientConfigKey.valueOf(entry.getKey());
>>> +                IClientConfigKey key = IClientConfigKey.Keys.valueOf(entry.getKey());
>>>                 String value = entry.getValue();
>>>                 LOG.debug("RibbonClientConfig: {}={}", key.key(), value);
>>>                 config.set(key, entry.getValue());
>>> 
>>> http://git-wip-us.apache.org/repos/asf/camel/blob/490a76f1/components/camel-servicenow/src/main/java/org/apache/camel/component/servicenow/ServiceNowClient.java
>>> ----------------------------------------------------------------------
>>> diff --git a/components/camel-servicenow/src/main/java/org/apache/camel/component/servicenow/ServiceNowClient.java b/components/camel-servicenow/src/main/java/org/apache/camel/component/servicenow/ServiceNowClient.java
>>> index 2bdd86a..fa33607 100644
>>> --- a/components/camel-servicenow/src/main/java/org/apache/camel/component/servicenow/ServiceNowClient.java
>>> +++ b/components/camel-servicenow/src/main/java/org/apache/camel/component/servicenow/ServiceNowClient.java
>>> @@ -162,7 +162,7 @@ public final class ServiceNowClient {
>>>     }
>>> 
>>>     private static void configureTls(
>>> -        CamelContext camelContext, ServiceNowConfiguration configuration, WebClient client) throws Exception{
>>> +        CamelContext camelContext, ServiceNowConfiguration configuration, WebClient client) throws Exception {
>>> 
>>>         SSLContextParameters sslContextParams = configuration.getSslContextParameters();
>>>         if (sslContextParams != null) {
>>> 
>>> http://git-wip-us.apache.org/repos/asf/camel/blob/490a76f1/components/readme.adoc
>>> ----------------------------------------------------------------------
>>> diff --git a/components/readme.adoc b/components/readme.adoc
>>> index 6d1eb1a..81b3828 100644
>>> --- a/components/readme.adoc
>>> +++ b/components/readme.adoc
>>> @@ -15,12 +15,6 @@ Components
>>> | link:camel-amqp/src/main/docs/amqp-component.adoc[AMQP] (camel-amqp) +
>>> `amqp:destinationType:destinationName` | Messaging with AMQP protocol using Apache QPid Client.
>>> 
>>> -| link:camel-flink/src/main/docs/flink-component.adoc[Apache Flink] (camel-flink) +
>>> -`flink:endpointType` | The flink component can be used to send DataSet jobs to Apache Flink cluster.
>>> -
>>> -| link:camel-spark/src/main/docs/spark-component.adoc[Apache Spark] (camel-spark) +
>>> -`spark:endpointType` | The spark component can be used to send RDD or DataFrame jobs to Apache Spark cluster.
>>> -
>>> | link:camel-apns/src/main/docs/apns-component.adoc[APNS] (camel-apns) +
>>> `apns:name` | For sending notifications to Apple iOS devices.
>>> 
>>> @@ -141,249 +135,60 @@ Components
>>> | link:camel-drill/src/main/docs/drill-component.adoc[Drill] (camel-drill) +
>>> `drill:host` | The drill component gives you the ability to quering into apache drill cluster.
>>> 
>>> -| link:camel-dropbox/src/main/docs/dropbox-component.adoc[Dropbox] (camel-dropbox) +
>>> -`dropbox:operation` | For uploading downloading and managing files folders groups collaborations etc on dropbox DOT com.
>>> -
>>> | link:camel-cache/src/main/docs/cache-component.adoc[EHCache] (camel-cache) +
>>> `cache:cacheName` | *deprecated* The cache component enables you to perform caching operations using EHCache as the Cache Implementation.
>>> 
>>> -| link:camel-ehcache/src/main/docs/ehcache-component.adoc[Ehcache] (camel-ehcache) +
>>> -`ehcache:cacheName` | The ehcache component enables you to perform caching operations using Ehcache as cache implementation.
>>> -
>>> -| link:camel-ejb/src/main/docs/ejb-component.adoc[EJB] (camel-ejb) +
>>> -`ejb:beanName` | The ejb component is for invoking EJB Java beans from Camel.
>>> -
>>> -| link:camel-elasticsearch/src/main/docs/elasticsearch-component.adoc[Elasticsearch] (camel-elasticsearch) +
>>> -`elasticsearch:clusterName` | The elasticsearch component is used for interfacing with ElasticSearch server.
>>> -
>>> -| link:camel-elsql/src/main/docs/elsql-component.adoc[ElSQL] (camel-elsql) +
>>> -`elsql:elsqlName:resourceUri` | The elsql component is an extension to the existing SQL Component that uses ElSql to define the SQL queries.
>>> -
>>> -| link:camel-etcd/src/main/docs/etcd-component.adoc[etcd] (camel-etcd) +
>>> -`etcd:namespace/path` | The camel etcd component allows you to work with Etcd a distributed A distributed reliable key-value store.
>>> -
>>> -| link:camel-exec/src/main/docs/exec-component.adoc[Exec] (camel-exec) +
>>> -`exec:executable` | The exec component can be used to execute OS system commands.
>>> -
>>> -| link:camel-facebook/src/main/docs/facebook-component.adoc[Facebook] (camel-facebook) +
>>> -`facebook:methodName` | The Facebook component provides access to all of the Facebook APIs accessible using Facebook4J.
>>> -
>>> -| link:camel-flatpack/src/main/docs/flatpack-component.adoc[Flatpack] (camel-flatpack) +
>>> -`flatpack:type:resourceUri` | The flatpack component supports fixed width and delimited file parsing via the FlatPack library.
>>> -
>>> -| link:camel-fop/src/main/docs/fop-component.adoc[FOP] (camel-fop) +
>>> -`fop:outputType` | The fop component allows you to render a message into different output formats using Apache FOP.
>>> -
>>> -| link:camel-freemarker/src/main/docs/freemarker-component.adoc[Freemarker] (camel-freemarker) +
>>> -`freemarker:resourceUri` | Transforms the message using a FreeMarker template.
>>> -
>>> -| link:camel-ftp/src/main/docs/ftp-component.adoc[FTP] (camel-ftp) +
>>> -`ftp:host:port/directoryName` | The ftp component is used for uploading or downloading files from FTP servers.
>>> -
>>> -| link:camel-ftp/src/main/docs/ftps-component.adoc[FTPS] (camel-ftp) +
>>> -`ftps:host:port/directoryName` | The ftps (FTP secure SSL/TLS) component is used for uploading or downloading files from FTP servers.
>>> -
>>> -| link:camel-ganglia/src/main/docs/ganglia-component.adoc[Ganglia] (camel-ganglia) +
>>> -`ganglia:host:port` | The ganglia component is used for sending metrics to the Ganglia monitoring system.
>>> -
>>> -| link:camel-geocoder/src/main/docs/geocoder-component.adoc[Geocoder] (camel-geocoder) +
>>> -`geocoder:address:latlng` | The geocoder component is used for looking up geocodes (latitude and longitude) for a given address or reverse lookup.
>>> -
>>> -| link:camel-git/src/main/docs/git-component.adoc[Git] (camel-git) +
>>> -`git:localPath` | The git component is used for working with git repositories.
>>> -
>>> -| link:camel-github/src/main/docs/github-component.adoc[GitHub] (camel-github) +
>>> -`github:type/branchName` | The github component is used for integrating Camel with github.
>>> -
>>> | link:camel-google-calendar/src/main/docs/google-calendar-component.adoc[Google Calendar] (camel-google-calendar) +
>>> `google-calendar:apiName/methodName` | The google-calendar component provides access to Google Calendar.
>>> 
>>> -| link:camel-google-drive/src/main/docs/google-drive-component.adoc[Google Drive] (camel-google-drive) +
>>> -`google-drive:apiName/methodName` | The google-drive component provides access to Google Drive file storage service.
>>> -
>>> -| link:camel-google-mail/src/main/docs/google-mail-component.adoc[Google Mail] (camel-google-mail) +
>>> -`google-mail:apiName/methodName` | The google-mail component provides access to Google Mail.
>>> -
>>> | link:camel-google-pubsub/src/main/docs/google-pubsub-component.adoc[Google Pubsub] (camel-google-pubsub) +
>>> `google-pubsub:projectId:destinationName` | Messaging client for Google Cloud Platform PubSub Service: https://cloud.google.com/pubsub/
>>> 
>>> -| link:camel-gora/src/main/docs/gora-component.adoc[Gora] (camel-gora) +
>>> -`gora:name` | The gora component allows you to work with NoSQL databases using the Apache Gora framework.
>>> -
>>> | link:camel-grape/src/main/docs/grape-component.adoc[Grape] (camel-grape) +
>>> `grape:defaultCoordinates` | Grape component allows you to fetch, load and manage additional jars when CamelContext is running.
>>> 
>>> -| link:camel-guava-eventbus/src/main/docs/guava-eventbus-component.adoc[Guava EventBus] (camel-guava-eventbus) +
>>> -`guava-eventbus:eventBusRef` | The guava-eventbus component provides integration bridge between Camel and Google Guava EventBus.
>>> -
>>> -| link:camel-hazelcast/src/main/docs/hazelcast-component.adoc[Hazelcast] (camel-hazelcast) +
>>> -`hazelcast:command:cacheName` | The hazelcast component allows you to work with the Hazelcast distributed data grid / cache.
>>> -
>>> -| link:camel-hbase/src/main/docs/hbase-component.adoc[HBase] (camel-hbase) +
>>> -`hbase:tableName` | For reading/writing from/to an HBase store (Hadoop database).
>>> -
>>> -| link:camel-hdfs/src/main/docs/hdfs-component.adoc[HDFS] (camel-hdfs) +
>>> -`hdfs:hostName:port/path` | *deprecated* For reading/writing from/to an HDFS filesystem using Hadoop 1.x.
>>> -
>>> -| link:camel-hdfs2/src/main/docs/hdfs2-component.adoc[HDFS2] (camel-hdfs2) +
>>> -`hdfs2:hostName:port/path` | For reading/writing from/to an HDFS filesystem using Hadoop 2.x.
>>> -
>>> -| link:camel-hipchat/src/main/docs/hipchat-component.adoc[Hipchat] (camel-hipchat) +
>>> -`hipchat:protocol:host:port` | The hipchat component supports producing and consuming messages from/to Hipchat service.
>>> -
>>> | link:camel-http/src/main/docs/http-component.adoc[HTTP] (camel-http) +
>>> `http:httpUri` | For calling out to external HTTP servers using Apache HTTP Client 3.x.
>>> 
>>> | link:camel-http4/src/main/docs/http4-component.adoc[HTTP4] (camel-http4) +
>>> `http4:httpUri` | For calling out to external HTTP servers using Apache HTTP Client 4.x.
>>> 
>>> -| link:camel-ibatis/src/main/docs/ibatis-component.adoc[iBatis] (camel-ibatis) +
>>> -`ibatis:statement` | *deprecated* Performs a query poll insert update or delete in a relational database using Apache iBATIS.
>>> -
>>> -| link:camel-mail/src/main/docs/imap-component.adoc[IMAP] (camel-mail) +
>>> -`imap:host:port` | To send or receive emails using imap/pop3 or stmp protocols.
>>> -
>>> | link:camel-infinispan/src/main/docs/infinispan-component.adoc[Infinispan] (camel-infinispan) +
>>> `infinispan:host` | For reading/writing from/to Infinispan distributed key/value store and data grid.
>>> 
>>> -| link:camel-influxdb/src/main/docs/influxdb-component.adoc[InfluxDB] (camel-influxdb) +
>>> -`influxdb:connectionBean` | The influxdb component allows you to interact with InfluxDB a time series database.
>>> -
>>> -| link:camel-irc/src/main/docs/irc-component.adoc[IRC] (camel-irc) +
>>> -`irc:hostname:port` | The irc component implements an IRC (Internet Relay Chat) transport.
>>> -
>>> | link:camel-ironmq/src/main/docs/ironmq-component.adoc[ironmq] (camel-ironmq) +
>>> `ironmq:queueName` | The ironmq provides integration with IronMQ an elastic and durable hosted message queue as a service.
>>> 
>>> -| link:camel-javaspace/src/main/docs/javaspace-component.adoc[JavaSpace] (camel-javaspace) +
>>> -`javaspace:url` | *deprecated* Sending and receiving messages through JavaSpace.
>>> -
>>> -| link:camel-jbpm/src/main/docs/jbpm-component.adoc[JBPM] (camel-jbpm) +
>>> -`jbpm:connectionURL` | The jbpm component provides integration with jBPM (Business Process Management).
>>> -
>>> | link:camel-jcache/src/main/docs/jcache-component.adoc[JCache] (camel-jcache) +
>>> `jcache:cacheName` | The jcache component enables you to perform caching operations using JSR107/JCache as cache implementation.
>>> 
>>> -| link:camel-jclouds/src/main/docs/jclouds-component.adoc[JClouds] (camel-jclouds) +
>>> -`jclouds:command:providerId` | For interacting with cloud compute & blobstore service via jclouds.
>>> -
>>> -| link:camel-jcr/src/main/docs/jcr-component.adoc[JCR] (camel-jcr) +
>>> -`jcr:host/base` | The jcr component allows you to add/read nodes to/from a JCR compliant content repository.
>>> -
>>> -| link:camel-jdbc/src/main/docs/jdbc-component.adoc[JDBC] (camel-jdbc) +
>>> -`jdbc:dataSourceName` | The jdbc component enables you to access databases through JDBC where SQL queries are sent in the message body.
>>> -
>>> | link:camel-jetty9/src/main/docs/jetty-component.adoc[Jetty 9] (camel-jetty9) +
>>> `jetty:httpUri` | The jetty component provides HTTP-based endpoints for consuming and producing HTTP requests.
>>> 
>>> | link:camel-websocket/src/main/docs/websocket-component.adoc[Jetty Websocket] (camel-websocket) +
>>> `websocket:host:port/resourceUri` | The websocket component provides websocket endpoints for communicating with clients using websocket.
>>> 
>>> -| link:camel-jgroups/src/main/docs/jgroups-component.adoc[JGroups] (camel-jgroups) +
>>> -`jgroups:clusterName` | The jgroups component provides exchange of messages between Camel and JGroups clusters.
>>> -
>>> -| link:camel-jing/src/main/docs/jing-component.adoc[Jing] (camel-jing) +
>>> -`jing:resourceUri` | Validates the payload of a message using RelaxNG Syntax using Jing library.
>>> -
>>> -| link:camel-jira/src/main/docs/jira-component.adoc[JIRA] (camel-jira) +
>>> -`jira:type` | The jira component interacts with the JIRA issue tracker.
>>> -
>>> | link:camel-jms/src/main/docs/jms-component.adoc[JMS] (camel-jms) +
>>> `jms:destinationType:destinationName` | The jms component allows messages to be sent to (or consumed from) a JMS Queue or Topic.
>>> 
>>> -| link:camel-jmx/src/main/docs/jmx-component.adoc[JMX] (camel-jmx) +
>>> -`jmx:serverURL` | The jmx component allows to receive JMX notifications.
>>> -
>>> -| link:camel-jolt/src/main/docs/jolt-component.adoc[JOLT] (camel-jolt) +
>>> -`jolt:resourceUri` | The jolt component allows you to process a JSON messages using an JOLT specification (such as JSON-JSON transformation).
>>> -
>>> -| link:camel-jpa/src/main/docs/jpa-component.adoc[JPA] (camel-jpa) +
>>> -`jpa:entityType` | The jpa component enables you to store and retrieve Java objects from databases using JPA.
>>> -
>>> -| link:camel-jt400/src/main/docs/jt400-component.adoc[JT400] (camel-jt400) +
>>> -`jt400:userID:password/systemName/objectPath.type` | The jt400 component allows you to exchanges messages with an AS/400 system using data queues or program call.
>>> -
>>> | link:camel-kafka/src/main/docs/kafka-component.adoc[Kafka] (camel-kafka) +
>>> `kafka:brokers` | The kafka component allows messages to be sent to (or consumed from) Apache Kafka brokers.
>>> 
>>> -| link:camel-kestrel/src/main/docs/kestrel-component.adoc[Kestrel] (camel-kestrel) +
>>> -`kestrel:addresses/queue` | *deprecated* The kestrel component allows messages to be sent to (or consumed from) Kestrel brokers.
>>> -
>>> -| link:camel-krati/src/main/docs/krati-component.adoc[Krati] (camel-krati) +
>>> -`krati:path` | The krati allows the use krati datastores and datasets inside Camel.
>>> -
>>> -| link:camel-kubernetes/src/main/docs/kubernetes-component.adoc[Kubernetes] (camel-kubernetes) +
>>> -`kubernetes:masterUrl` | The kubernetes component allows to work with Kubernetes PaaS.
>>> -
>>> -| link:camel-ldap/src/main/docs/ldap-component.adoc[LDAP] (camel-ldap) +
>>> -`ldap:dirContextName` | The ldap component allows you to perform searches in LDAP servers using filters as the message payload.
>>> -
>>> -| link:camel-linkedin/src/main/docs/linkedin-component.adoc[Linkedin] (camel-linkedin) +
>>> -`linkedin:apiName/methodName` | The linkedin component is uses for retrieving LinkedIn user profiles connections companies groups posts etc.
>>> -
>>> -| link:camel-lucene/src/main/docs/lucene-component.adoc[Lucene] (camel-lucene) +
>>> -`lucene:host:operation` | To insert or query from Apache Lucene databases.
>>> -
>>> -| link:camel-lumberjack/src/main/docs/lumberjack-component.adoc[Lumberjack] (camel-lumberjack) +
>>> -`lumberjack:host:port` | The lumberjack retrieves logs sent over the network using the Lumberjack protocol.
>>> -
>>> | link:camel-metrics/src/main/docs/metrics-component.adoc[Metrics] (camel-metrics) +
>>> `metrics:metricsType:metricsName` | To collect various metrics directly from Camel routes using the DropWizard metrics library.
>>> 
>>> -| link:camel-mina/src/main/docs/mina-component.adoc[Mina] (camel-mina) +
>>> -`mina:protocol:host:port` | *deprecated* Socket level networking using TCP or UDP with the Apache Mina 1.x library.
>>> -
>>> -| link:camel-mina2/src/main/docs/mina2-component.adoc[Mina2] (camel-mina2) +
>>> -`mina2:protocol:host:port` | Socket level networking using TCP or UDP with the Apache Mina 2.x library.
>>> -
>>> | link:camel-mllp/src/main/docs/mllp-component.adoc[MLLP] (camel-mllp) +
>>> `mllp:hostname:port` | The MLLP component is designed to handle the MLLP protocol and provide the functionality required by Healthcare providers to communicate with other systems using the MLLP protocol.
>>> 
>>> | link:camel-mongodb/src/main/docs/mongodb-component.adoc[MongoDB] (camel-mongodb) +
>>> `mongodb:connectionBean` | Component for working with documents stored in MongoDB database.
>>> 
>>> -| link:camel-mongodb3/src/main/docs/mongodb3-component.adoc[MongoDB] (camel-mongodb3) +
>>> -`mongodb3:connectionBean` | Component for working with documents stored in MongoDB database.
>>> -
>>> -| link:camel-mongodb-gridfs/src/main/docs/gridfs-component.adoc[MongoDBGridFS] (camel-mongodb-gridfs) +
>>> -`gridfs:connectionBean` | Component for working with MongoDB GridFS.
>>> -
>>> -| link:camel-mqtt/src/main/docs/mqtt-component.adoc[MQTT] (camel-mqtt) +
>>> -`mqtt:name` | Component for communicating with MQTT M2M message brokers using FuseSource MQTT Client.
>>> -
>>> -| link:camel-msv/src/main/docs/msv-component.adoc[MSV] (camel-msv) +
>>> -`msv:resourceUri` | Validates the payload of a message using the MSV Library.
>>> -
>>> -| link:camel-mustache/src/main/docs/mustache-component.adoc[Mustache] (camel-mustache) +
>>> -`mustache:resourceUri` | Transforms the message using a Mustache template.
>>> -
>>> -| link:camel-mvel/src/main/docs/mvel-component.adoc[MVEL] (camel-mvel) +
>>> -`mvel:resourceUri` | Transforms the message using a MVEL template.
>>> -
>>> -| link:camel-mybatis/src/main/docs/mybatis-component.adoc[MyBatis] (camel-mybatis) +
>>> -`mybatis:statement` | Performs a query poll insert update or delete in a relational database using MyBatis.
>>> -
>>> -| link:camel-nagios/src/main/docs/nagios-component.adoc[Nagios] (camel-nagios) +
>>> -`nagios:host:port` | To send passive checks to Nagios using JSendNSCA.
>>> -
>>> -| link:camel-nats/src/main/docs/nats-component.adoc[Nats] (camel-nats) +
>>> -`nats:servers` | The nats component allows you produce and consume messages from NATS.
>>> -
>>> -| link:camel-netty/src/main/docs/netty-component.adoc[Netty] (camel-netty) +
>>> -`netty:protocol:host:port` | *deprecated* Socket level networking using TCP or UDP with the Netty 3.x library.
>>> -
>>> -| link:camel-netty-http/src/main/docs/netty-http-component.adoc[Netty HTTP] (camel-netty-http) +
>>> -`netty-http:protocol:host:port/path` | *deprecated* Netty HTTP server and client using the Netty 3.x library.
>>> -
>>> | link:camel-netty4/src/main/docs/netty4-component.adoc[Netty4] (camel-netty4) +
>>> `netty4:protocol:host:port` | Socket level networking using TCP or UDP with the Netty 4.x library.
>>> 
>>> | link:camel-netty4-http/src/main/docs/netty4-http-component.adoc[Netty4 HTTP] (camel-netty4-http) +
>>> `netty4-http:protocol:host:port/path` | Netty HTTP server and client using the Netty 4.x library.
>>> 
>>> -| link:camel-openshift/src/main/docs/openshift-component.adoc[OpenShift] (camel-openshift) +
>>> -`openshift:clientId` | *deprecated* To manage your Openshift 2.x applications.
>>> -
>>> | link:camel-openstack/src/main/docs/openstack-cinder-component.adoc[OpenStack-Cinder] (camel-openstack) +
>>> `openstack-cinder:host` | Camel Components
>>> 
>>> @@ -402,174 +207,33 @@ Components
>>> | link:camel-openstack/src/main/docs/openstack-swift-component.adoc[OpenStack-Swift] (camel-openstack) +
>>> `openstack-swift:host` | Camel Components
>>> 
>>> -| link:camel-optaplanner/src/main/docs/optaplanner-component.adoc[OptaPlanner] (camel-optaplanner) +
>>> -`optaplanner:configFile` | Solves the planning problem contained in a message with OptaPlanner.
>>> -
>>> -| link:camel-eventadmin/src/main/docs/eventadmin-component.adoc[OSGi EventAdmin] (camel-eventadmin) +
>>> -`eventadmin:topic` | The eventadmin component can be used in an OSGi environment to receive OSGi EventAdmin events and process them.
>>> -
>>> -| link:camel-paxlogging/src/main/docs/paxlogging-component.adoc[OSGi PAX Logging] (camel-paxlogging) +
>>> -`paxlogging:appender` | The paxlogging component can be used in an OSGi environment to receive PaxLogging events and process them.
>>> -
>>> -| link:camel-paho/src/main/docs/paho-component.adoc[Paho] (camel-paho) +
>>> -`paho:topic` | Component for communicating with MQTT M2M message brokers using Eclipse Paho MQTT Client.
>>> -
>>> -| link:camel-pdf/src/main/docs/pdf-component.adoc[PDF] (camel-pdf) +
>>> -`pdf:operation` | The pdf components provides the ability to create modify or extract content from PDF documents.
>>> -
>>> -| link:camel-pgevent/src/main/docs/pgevent-component.adoc[PostgresSQL Event] (camel-pgevent) +
>>> -`pgevent:host:port/database/channel` | The pgevent component allows for producing/consuming PostgreSQL events related to the LISTEN/NOTIFY commands.
>>> -
>>> -| link:camel-printer/src/main/docs/lpr-component.adoc[Printer] (camel-printer) +
>>> -`lpr:hostname:port/printername` | The printer component is used for sending messages to printers as print jobs.
>>> -
>>> -| link:camel-quartz/src/main/docs/quartz-component.adoc[Quartz] (camel-quartz) +
>>> -`quartz:groupName/timerName` | *deprecated* Provides a scheduled delivery of messages using the Quartz 1.x scheduler.
>>> -
>>> -| link:camel-quartz2/src/main/docs/quartz2-component.adoc[Quartz2] (camel-quartz2) +
>>> -`quartz2:groupName/triggerName` | Provides a scheduled delivery of messages using the Quartz 2.x scheduler.
>>> -
>>> -| link:camel-quickfix/src/main/docs/quickfix-component.adoc[QuickFix] (camel-quickfix) +
>>> -`quickfix:configurationName` | The quickfix component allows to send Financial Interchange (FIX) messages to the QuickFix engine.
>>> -
>>> -| link:camel-rabbitmq/src/main/docs/rabbitmq-component.adoc[RabbitMQ] (camel-rabbitmq) +
>>> -`rabbitmq:hostname:portNumber/exchangeName` | The rabbitmq component allows you produce and consume messages from RabbitMQ instances.
>>> -
>>> -| link:camel-restlet/src/main/docs/restlet-component.adoc[Restlet] (camel-restlet) +
>>> -`restlet:protocol:host:port/uriPattern` | Component for consuming and producing Restful resources using Restlet.
>>> -
>>> -| link:camel-rmi/src/main/docs/rmi-component.adoc[RMI] (camel-rmi) +
>>> -`rmi:hostname:port/name` | The rmi component is for invoking Java RMI beans from Camel.
>>> -
>>> -| link:camel-routebox/src/main/docs/routebox-component.adoc[RouteBox] (camel-routebox) +
>>> -`routebox:routeboxName` | *deprecated* The routebox component allows to send/receive messages between Camel routes in a black box way.
>>> -
>>> -| link:camel-rss/src/main/docs/rss-component.adoc[RSS] (camel-rss) +
>>> -`rss:feedUri` | The rss component is used for consuming RSS feeds.
>>> -
>>> | link:camel-salesforce/src/main/docs/salesforce-component.adoc[Salesforce] (camel-salesforce) +
>>> `salesforce:operationName:topicName` | The salesforce component is used for integrating Camel with the massive Salesforce API.
>>> 
>>> -| link:camel-sap-netweaver/src/main/docs/sap-netweaver-component.adoc[SAP NetWeaver] (camel-sap-netweaver) +
>>> -`sap-netweaver:url` | The sap-netweaver component integrates with the SAP NetWeaver Gateway using HTTP transports.
>>> -
>>> -| link:camel-schematron/src/main/docs/schematron-component.adoc[Schematron] (camel-schematron) +
>>> -`schematron:path` | Validates the payload of a message using the Schematron Library.
>>> -
>>> -| link:camel-jsch/src/main/docs/scp-component.adoc[SCP] (camel-jsch) +
>>> -`scp:host:port/directoryName` | To copy files using the secure copy protocol (SCP).
>>> -
>>> -| link:camel-servicenow/src/main/docs/servicenow-component.adoc[ServiceNow] (camel-servicenow) +
>>> -`servicenow:instanceName` | The servicenow component is used to integrate Camel with ServiceNow cloud services.
>>> -
>>> | link:camel-servlet/src/main/docs/servlet-component.adoc[Servlet] (camel-servlet) +
>>> `servlet:contextPath` | To use a HTTP Servlet as entry for Camel routes when running in a servlet container.
>>> 
>>> -| link:camel-ftp/src/main/docs/sftp-component.adoc[SFTP] (camel-ftp) +
>>> -`sftp:host:port/directoryName` | The sftp (FTP over SSH) component is used for uploading or downloading files from SFTP servers.
>>> -
>>> -| link:camel-sjms/src/main/docs/sjms-component.adoc[Simple JMS] (camel-sjms) +
>>> -`sjms:destinationType:destinationName` | The sjms component (simple jms) allows messages to be sent to (or consumed from) a JMS Queue or Topic.
>>> -
>>> -| link:camel-sjms/src/main/docs/sjms-batch-component.adoc[Simple JMS Batch] (camel-sjms) +
>>> -`sjms-batch:destinationName` | The sjms-batch component is a specialized for highly performant transactional batch consumption from a JMS queue.
>>> -
>>> -| link:camel-sip/src/main/docs/sip-component.adoc[SIP] (camel-sip) +
>>> -`sip:uri` | To send and receive messages using the SIP protocol (used in telco and mobile).
>>> -
>>> -| link:camel-slack/src/main/docs/slack-component.adoc[Slack] (camel-slack) +
>>> -`slack:channel` | The slack component allows you to send messages to Slack.
>>> -
>>> | link:camel-smpp/src/main/docs/smpp-component.adoc[SMPP] (camel-smpp) +
>>> `smpp:host:port` | To send and receive SMS using a SMSC (Short Message Service Center).
>>> 
>>> -| link:camel-snmp/src/main/docs/snmp-component.adoc[SNMP] (camel-snmp) +
>>> -`snmp:host:port` | The snmp component gives you the ability to poll SNMP capable devices or receiving traps.
>>> -
>>> -| link:camel-solr/src/main/docs/solr-component.adoc[Solr] (camel-solr) +
>>> -`solr:url` | The solr component allows you to interface with an Apache Lucene Solr server.
>>> -
>>> -| link:camel-spark-rest/src/main/docs/spark-rest-component.adoc[Spark Rest] (camel-spark-rest) +
>>> -`spark-rest:verb:path` | The spark-rest component is used for hosting REST services which has been defined using Camel rest-dsl.
>>> -
>>> -| link:camel-splunk/src/main/docs/splunk-component.adoc[Splunk] (camel-splunk) +
>>> -`splunk:name` | The splunk component allows to publish or search for events in Splunk.
>>> -
>>> -| link:camel-spring-batch/src/main/docs/spring-batch-component.adoc[Spring Batch] (camel-spring-batch) +
>>> -`spring-batch:jobName` | The spring-batch component allows to send messages to Spring Batch for further processing.
>>> -
>>> | link:camel-spring/src/main/docs/spring-event-component.adoc[Spring Event] (camel-spring) +
>>> `spring-event:name` | The spring-event component allows to listen for Spring Application Events.
>>> 
>>> -| link:camel-spring-integration/src/main/docs/spring-integration-component.adoc[Spring Integration] (camel-spring-integration) +
>>> -`spring-integration:defaultChannel` | Bridges Camel with Spring Integration.
>>> -
>>> -| link:camel-spring-ldap/src/main/docs/spring-ldap-component.adoc[Spring LDAP] (camel-spring-ldap) +
>>> -`spring-ldap:templateName` | The spring-ldap component allows you to perform searches in LDAP servers using filters as the message payload.
>>> -
>>> -| link:camel-spring-redis/src/main/docs/spring-redis-component.adoc[Spring Redis] (camel-spring-redis) +
>>> -`spring-redis:host:port` | The spring-redis component allows sending and receiving messages from Redis.
>>> -
>>> -| link:camel-spring-ws/src/main/docs/spring-ws-component.adoc[Spring WebService] (camel-spring-ws) +
>>> -`spring-ws:type:lookupKey:webServiceEndpointUri` | The spring-ws component is used for SOAP WebServices using Spring WebServices.
>>> -
>>> | link:camel-sql/src/main/docs/sql-component.adoc[SQL] (camel-sql) +
>>> `sql:query` | The sql component allows you to work with databases using JDBC SQL queries.
>>> 
>>> | link:camel-sql/src/main/docs/sql-stored-component.adoc[SQL StoredProcedure] (camel-sql) +
>>> `sql-stored:template` | The sql component allows you to work with databases using JDBC Stored Procedure queries.
>>> 
>>> -| link:camel-ssh/src/main/docs/ssh-component.adoc[SSH] (camel-ssh) +
>>> -`ssh:host:port` | The ssh component enables access to SSH servers such that you can send an SSH command and process the response.
>>> -
>>> -| link:camel-stax/src/main/docs/stax-component.adoc[StAX] (camel-stax) +
>>> -`stax:contentHandlerClass` | The stax component allows messages to be process through a SAX ContentHandler.
>>> -
>>> -| link:camel-stomp/src/main/docs/stomp-component.adoc[Stomp] (camel-stomp) +
>>> -`stomp:destination` | The stomp component is used for communicating with Stomp compliant message brokers.
>>> -
>>> | link:camel-stream/src/main/docs/stream-component.adoc[Stream] (camel-stream) +
>>> `stream:kind` | The stream: component provides access to the system-in system-out and system-err streams as well as allowing streaming of file and URL.
>>> 
>>> -| link:camel-stringtemplate/src/main/docs/string-template-component.adoc[String Template] (camel-stringtemplate) +
>>> -`string-template:resourceUri` | Transforms the message using a String template.
>>> -
>>> -| link:camel-telegram/src/main/docs/telegram-component.adoc[Telegram] (camel-telegram) +
>>> -`telegram:type/authorizationToken` | The telegram component provides access to the Telegram Bot API.
>>> -
>>> -| link:camel-twitter/src/main/docs/twitter-component.adoc[Twitter] (camel-twitter) +
>>> -`twitter:kind` | This component integrates with Twitter to send tweets or search for tweets and more.
>>> -
>>> -| link:camel-undertow/src/main/docs/undertow-component.adoc[Undertow] (camel-undertow) +
>>> -`undertow:httpURI` | The undertow component provides HTTP-based endpoints for consuming and producing HTTP requests.
>>> -
>>> | link:camel-velocity/src/main/docs/velocity-component.adoc[Velocity] (camel-velocity) +
>>> `velocity:resourceUri` | Transforms the message using a Velocity template.
>>> 
>>> -| link:camel-vertx/src/main/docs/vertx-component.adoc[Vert.x] (camel-vertx) +
>>> -`vertx:address` | The vertx component is used for sending and receive messages from a vertx event bus.
>>> -
>>> | link:camel-weather/src/main/docs/weather-component.adoc[Weather] (camel-weather) +
>>> `weather:name` | Polls the weather information from Open Weather Map.
>>> 
>>> -| link:camel-xmlrpc/src/main/docs/xmlrpc-component.adoc[XML RPC] (camel-xmlrpc) +
>>> -`xmlrpc:address` | The xmlrpc component is used for sending messages to a XML RPC service.
>>> -
>>> -| link:camel-xmlsecurity/src/main/docs/xmlsecurity-component.adoc[XML Security] (camel-xmlsecurity) +
>>> -`xmlsecurity:command:name` | Used to sign and verify exchanges using the XML signature specification.
>>> -
>>> -| link:camel-xmpp/src/main/docs/xmpp-component.adoc[XMPP] (camel-xmpp) +
>>> -`xmpp:host:port/participant` | To send and receive messages from a XMPP (chat) server.
>>> -
>>> -| link:camel-saxon/src/main/docs/xquery-component.adoc[XQuery] (camel-saxon) +
>>> -`xquery:resourceUri` | Transforms the message using a XQuery template using Saxon.
>>> -
>>> -| link:camel-yammer/src/main/docs/yammer-component.adoc[Yammer] (camel-yammer) +
>>> -`yammer:function` | The yammer component allows you to interact with the Yammer enterprise social network.
>>> -
>>> -| link:camel-zookeeper/src/main/docs/zookeeper-component.adoc[ZooKeeper] (camel-zookeeper) +
>>> -`zookeeper:serverUrls/path` | The zookeeper component allows interaction with a ZooKeeper cluster.
>>> -
>>> |=======================================================================
>>> // components: END
>>> 
>>> @@ -646,65 +310,17 @@ Data Formats
>>> 
>>> | link:camel-csv/src/main/docs/csv-dataformat.adoc[CSV] (camel-csv) | Camel CSV data format support
>>> 
>>> -| link:camel-flatpack/src/main/docs/flatpack-dataformat.adoc[Flatpack] (camel-flatpack) | Camel FlatPack support
>>> -
>>> | link:camel-hessian/src/main/docs/hessian-dataformat.adoc[Hessian] (camel-hessian) | Hessian serialization support
>>> 
>>> | link:camel-hl7/src/main/docs/hl7-dataformat.adoc[HL7] (camel-hl7) | Camel HL7 support
>>> 
>>> -| link:camel-ical/src/main/docs/ical-dataformat.adoc[iCal] (camel-ical) | Camel iCal component
>>> -
>>> | link:camel-jacksonxml/src/main/docs/jacksonxml-dataformat.adoc[JacksonXML] (camel-jacksonxml) | Camel Jackson XML support
>>> 
>>> | link:camel-jaxb/src/main/docs/jaxb-dataformat.adoc[JAXB] (camel-jaxb) | Camel JAXB support
>>> 
>>> -| link:camel-jibx/src/main/docs/jibx-dataformat.adoc[JiBX] (camel-jibx) | Camel Jibx support
>>> -
>>> -| link:camel-gson/src/main/docs/json-gson-dataformat.adoc[JSon GSon] (camel-gson) | Camel Gson support
>>> -
>>> | link:camel-jackson/src/main/docs/json-jackson-dataformat.adoc[JSon Jackson] (camel-jackson) | Camel Jackson support
>>> 
>>> -| link:camel-johnzon/src/main/docs/json-johnzon-dataformat.adoc[JSon Johnzon] (camel-johnzon) | Camel Johnzon support
>>> -
>>> -| link:camel-xstream/src/main/docs/json-xstream-dataformat.adoc[JSon XStream] (camel-xstream) | Camel XStream support
>>> -
>>> -| link:camel-lzf/src/main/docs/lzf-dataformat.adoc[LZF Deflate Compression] (camel-lzf) | Camel LZF support
>>> -
>>> -| link:camel-mail/src/main/docs/mime-multipart-dataformat.adoc[MIME Multipart] (camel-mail) | Camel Mail support
>>> -
>>> | link:camel-crypto/src/main/docs/pgp-dataformat.adoc[PGP] (camel-crypto) | Camel Cryptographic Support
>>> -
>>> -| link:camel-protobuf/src/main/docs/protobuf-dataformat.adoc[Protobuf] (camel-protobuf) | Camel Google Protobuf data format support
>>> -
>>> -| link:camel-rss/src/main/docs/rss-dataformat.adoc[RSS] (camel-rss) | Camel RSS support
>>> -
>>> -| link:camel-soap/src/main/docs/soapjaxb-dataformat.adoc[SOAP] (camel-soap) | Camel SOAP support
>>> -
>>> -| link:camel-syslog/src/main/docs/syslog-dataformat.adoc[Syslog] (camel-syslog) | Camel Syslog support
>>> -
>>> -| link:camel-tarfile/src/main/docs/tarfile-dataformat.adoc[Tar File] (camel-tarfile) | Camel Tar file support
>>> -
>>> -| link:camel-tagsoup/src/main/docs/tidyMarkup-dataformat.adoc[TidyMarkup] (camel-tagsoup) | Camel TagSoup support
>>> -
>>> -| link:camel-univocity-parsers/src/main/docs/univocity-csv-dataformat.adoc[uniVocity CSV] (camel-univocity-parsers) | Camel UniVocity parsers data format support
>>> -
>>> -| link:camel-univocity-parsers/src/main/docs/univocity-fixed-dataformat.adoc[uniVocity Fixed Length] (camel-univocity-parsers) | Camel UniVocity parsers data format support
>>> -
>>> -| link:camel-univocity-parsers/src/main/docs/univocity-tsv-dataformat.adoc[uniVocity TSV] (camel-univocity-parsers) | Camel UniVocity parsers data format support
>>> -
>>> -| link:camel-xmlbeans/src/main/docs/xmlBeans-dataformat.adoc[XML Beans] (camel-xmlbeans) | Camel XMLBeans support
>>> -
>>> -| link:camel-xmljson/src/main/docs/xmljson-dataformat.adoc[XML JSon] (camel-xmljson) | Camel XML JSON Data Format
>>> -
>>> -| link:camel-xmlrpc/src/main/docs/xmlrpc-dataformat.adoc[XML RPC] (camel-xmlrpc) | Camel XML RPC support
>>> -
>>> -| link:camel-xmlsecurity/src/main/docs/secureXML-dataformat.adoc[XML Security] (camel-xmlsecurity) | Camel Partial XML Encryption/Decryption and XML Signature support
>>> -
>>> -| link:camel-xstream/src/main/docs/xstream-dataformat.adoc[XStream] (camel-xstream) | Camel XStream support
>>> -
>>> -| link:camel-snakeyaml/src/main/docs/yaml-snakeyaml-dataformat.adoc[YAML SnakeYAML] (camel-snakeyaml) | Camel SnakeYAML support
>>> -
>>> -| link:camel-zipfile/src/main/docs/zipfile-dataformat.adoc[Zip File] (camel-zipfile) | Camel Zip file support
>>> |=======================================================================
>>> // dataformats: END
>>> 
>>> @@ -723,27 +339,9 @@ Expression Languages
>>> 
>>> | link:camel-hl7/src/main/docs/terser-language.adoc[HL7 Terser] (camel-hl7) | For HL7 terser expressions and predicates
>>> 
>>> -| link:camel-script/src/main/docs/javaScript-language.adoc[JavaScript] (camel-script) | For JavaScript expressions and predicates
>>> -
>>> -| link:camel-jsonpath/src/main/docs/jsonpath-language.adoc[JSonPath] (camel-jsonpath) | For JSonPath expressions and predicates
>>> -
>>> | link:camel-jxpath/src/main/docs/jxpath-language.adoc[JXPath] (camel-jxpath) | For JXPath expressions and predicates
>>> 
>>> -| link:camel-mvel/src/main/docs/mvel-language.adoc[MVEL] (camel-mvel) | For MVEL expressions and predicates
>>> -
>>> -| link:camel-ognl/src/main/docs/ognl-language.adoc[OGNL] (camel-ognl) | For OGNL expressions and predicates
>>> -
>>> -| link:camel-script/src/main/docs/php-language.adoc[PHP] (camel-script) | For PHP expressions and predicates
>>> -
>>> -| link:camel-script/src/main/docs/python-language.adoc[Python] (camel-script) | For Python expressions and predicates
>>> -
>>> -| link:camel-script/src/main/docs/ruby-language.adoc[Ruby] (camel-script) | For Ruby expressions and predicates
>>> -
>>> | link:camel-spring/src/main/docs/spel-language.adoc[SpEL] (camel-spring) | For Spring Expression Language (SpEL) expressions and predicates
>>> -
>>> -| link:camel-josql/src/main/docs/sql-language.adoc[SQL] (camel-josql) | For SQL expressions and predicates
>>> -
>>> -| link:camel-saxon/src/main/docs/xquery-language.adoc[XQuery] (camel-saxon) | For XQuery expressions and predicates
>>> |=======================================================================
>>> // languages: END
>>> 
>> 
>> 
>> 
>> --
>> Claus Ibsen
>> -----------------
>> http://davsclaus.com @davsclaus
>> Camel in Action 2: https://www.manning.com/ibsen2
> 
> 
> 
> -- 
> Claus Ibsen
> -----------------
> http://davsclaus.com @davsclaus
> Camel in Action 2: https://www.manning.com/ibsen2
> 


Re: camel git commit: Fix CS violations

Posted by Claus Ibsen <cl...@gmail.com>.
Hi

Okay I found the issue. Its when you don't run the platforms/catalog
build which is the guy that is responsible for updating that readme
file.

I just regen the doc and its up to date again.

On Mon, Dec 19, 2016 at 11:00 AM, Claus Ibsen <cl...@gmail.com> wrote:
> Yeah we need to revert those .docs files.
>
> And keep an eye on the build if it generates those two files
> correctly, there may be a flaw in the camel-package-maven-plugin that
> has the code for this.
>
> On Mon, Dec 19, 2016 at 10:55 AM, Andrea Cosentino
> <an...@yahoo.com.invalid> wrote:
>> It looks like the build deleted the components list from readme.
>>  --
>> Andrea Cosentino
>> ----------------------------------
>> Apache Camel PMC Member
>> Apache Karaf Committer
>> Apache Servicemix Committer
>> Email: ancosen1985@yahoo.com
>> Twitter: @oscerd2
>> Github: oscerd
>>
>>
>>
>> On Sunday, December 18, 2016 6:27 PM, "bvahdat@apache.org" <bv...@apache.org> wrote:
>> Repository: camel
>> Updated Branches:
>>   refs/heads/master 079b5f9e6 -> 490a76f17
>>
>>
>> Fix CS violations
>>
>> Project: http://git-wip-us.apache.org/repos/asf/camel/repo
>> Commit: http://git-wip-us.apache.org/repos/asf/camel/commit/490a76f1
>> Tree: http://git-wip-us.apache.org/repos/asf/camel/tree/490a76f1
>> Diff: http://git-wip-us.apache.org/repos/asf/camel/diff/490a76f1
>>
>> Branch: refs/heads/master
>> Commit: 490a76f17a1cb96a08009607a7aa972e7bc0372d
>> Parents: 079b5f9
>> Author: Babak Vahdat <bv...@apache.org>
>> Authored: Sun Dec 18 18:26:52 2016 +0100
>> Committer: Babak Vahdat <bv...@apache.org>
>> Committed: Sun Dec 18 18:26:52 2016 +0100
>>
>> ----------------------------------------------------------------------
>> .../component/bonita/BonitaConfiguration.java   |   6 +-
>> .../core/xml/CamelProxyFactoryDefinition.java   |   2 +-
>> .../camel/component/gridfs/GridFsEndpoint.java  |   1 -
>> .../openstack/nova/KeypairProducerTest.java     |   2 +-
>> .../processor/RibbonServiceCallProcessor.java   |  19 +-
>> .../component/servicenow/ServiceNowClient.java  |   2 +-
>> components/readme.adoc                          | 402 -------------------
>> 7 files changed, 15 insertions(+), 419 deletions(-)
>> ----------------------------------------------------------------------
>>
>>
>> http://git-wip-us.apache.org/repos/asf/camel/blob/490a76f1/components/camel-bonita/src/main/java/org/apache/camel/component/bonita/BonitaConfiguration.java
>> ----------------------------------------------------------------------
>> diff --git a/components/camel-bonita/src/main/java/org/apache/camel/component/bonita/BonitaConfiguration.java b/components/camel-bonita/src/main/java/org/apache/camel/component/bonita/BonitaConfiguration.java
>> index 7343e2c..b992682 100644
>> --- a/components/camel-bonita/src/main/java/org/apache/camel/component/bonita/BonitaConfiguration.java
>> +++ b/components/camel-bonita/src/main/java/org/apache/camel/component/bonita/BonitaConfiguration.java
>> @@ -5,9 +5,9 @@
>>   * 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
>> - * <p>
>> - * http://www.apache.org/licenses/LICENSE-2.0
>> - * <p>
>> + *
>> + *      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.
>>
>> http://git-wip-us.apache.org/repos/asf/camel/blob/490a76f1/components/camel-core-xml/src/main/java/org/apache/camel/core/xml/CamelProxyFactoryDefinition.java
>> ----------------------------------------------------------------------
>> diff --git a/components/camel-core-xml/src/main/java/org/apache/camel/core/xml/CamelProxyFactoryDefinition.java b/components/camel-core-xml/src/main/java/org/apache/camel/core/xml/CamelProxyFactoryDefinition.java
>> index 6f160ce..5c78b93 100644
>> --- a/components/camel-core-xml/src/main/java/org/apache/camel/core/xml/CamelProxyFactoryDefinition.java
>> +++ b/components/camel-core-xml/src/main/java/org/apache/camel/core/xml/CamelProxyFactoryDefinition.java
>> @@ -63,7 +63,7 @@ public class CamelProxyFactoryDefinition extends IdentifiedType {
>>       * @deprecated use serviceUrl instead with the ref endpoint.
>>       */
>>      @Deprecated
>> -    public void setServiceRef(String serviceRef) {
>> +    public void setServiceRef(String serviceRef) {
>>          this.serviceRef = serviceRef;
>>      }
>>
>>
>> http://git-wip-us.apache.org/repos/asf/camel/blob/490a76f1/components/camel-mongodb-gridfs/src/main/java/org/apache/camel/component/gridfs/GridFsEndpoint.java
>> ----------------------------------------------------------------------
>> diff --git a/components/camel-mongodb-gridfs/src/main/java/org/apache/camel/component/gridfs/GridFsEndpoint.java b/components/camel-mongodb-gridfs/src/main/java/org/apache/camel/component/gridfs/GridFsEndpoint.java
>> index cb8f686..f4d5d65 100644
>> --- a/components/camel-mongodb-gridfs/src/main/java/org/apache/camel/component/gridfs/GridFsEndpoint.java
>> +++ b/components/camel-mongodb-gridfs/src/main/java/org/apache/camel/component/gridfs/GridFsEndpoint.java
>> @@ -39,7 +39,6 @@ import org.slf4j.LoggerFactory;
>> @UriEndpoint(scheme = "gridfs", title = "MongoDBGridFS", syntax = "gridfs:connectionBean", label = "database,nosql")
>> public class GridFsEndpoint extends DefaultEndpoint {
>>
>> -    ;
>>      public static final String GRIDFS_OPERATION = "gridfs.operation";
>>      public static final String GRIDFS_METADATA = "gridfs.metadata";
>>      public static final String GRIDFS_CHUNKSIZE = "gridfs.chunksize";
>>
>> http://git-wip-us.apache.org/repos/asf/camel/blob/490a76f1/components/camel-openstack/src/test/java/org/apache/camel/component/openstack/nova/KeypairProducerTest.java
>> ----------------------------------------------------------------------
>> diff --git a/components/camel-openstack/src/test/java/org/apache/camel/component/openstack/nova/KeypairProducerTest.java b/components/camel-openstack/src/test/java/org/apache/camel/component/openstack/nova/KeypairProducerTest.java
>> index c851a40..ba4813e 100644
>> --- a/components/camel-openstack/src/test/java/org/apache/camel/component/openstack/nova/KeypairProducerTest.java
>> +++ b/components/camel-openstack/src/test/java/org/apache/camel/component/openstack/nova/KeypairProducerTest.java
>> @@ -114,6 +114,6 @@ public class KeypairProducerTest extends NovaProducerTestSupport {
>>      }
>>
>>      private Keypair createDummyKeypair() {
>> -        return NovaKeypair.create(KEYPAIR_NAME, "string contains private key");
>> +        return NovaKeypair.create(KEYPAIR_NAME, "string contains private key");
>>      }
>> }
>>
>> http://git-wip-us.apache.org/repos/asf/camel/blob/490a76f1/components/camel-ribbon/src/main/java/org/apache/camel/component/ribbon/processor/RibbonServiceCallProcessor.java
>> ----------------------------------------------------------------------
>> diff --git a/components/camel-ribbon/src/main/java/org/apache/camel/component/ribbon/processor/RibbonServiceCallProcessor.java b/components/camel-ribbon/src/main/java/org/apache/camel/component/ribbon/processor/RibbonServiceCallProcessor.java
>> index f9151ce..f701ba0 100644
>> --- a/components/camel-ribbon/src/main/java/org/apache/camel/component/ribbon/processor/RibbonServiceCallProcessor.java
>> +++ b/components/camel-ribbon/src/main/java/org/apache/camel/component/ribbon/processor/RibbonServiceCallProcessor.java
>> @@ -19,7 +19,6 @@ package org.apache.camel.component.ribbon.processor;
>> import java.util.Map;
>> import java.util.concurrent.RejectedExecutionException;
>>
>> -import com.netflix.client.config.CommonClientConfigKey;
>> import com.netflix.client.config.IClientConfig;
>> import com.netflix.client.config.IClientConfigKey;
>> import com.netflix.loadbalancer.DummyPing;
>> @@ -46,8 +45,8 @@ import org.apache.camel.spi.IdAware;
>> import org.apache.camel.spi.ServiceCallServerListStrategy;
>> import org.apache.camel.support.ServiceSupport;
>> import org.apache.camel.util.AsyncProcessorHelper;
>> -import org.apache.camel.util.ObjectHelper;
>> import org.apache.camel.util.ServiceHelper;
>> +import org.apache.camel.util.StringHelper;
>> import org.slf4j.Logger;
>> import org.slf4j.LoggerFactory;
>>
>> @@ -78,18 +77,18 @@ public class RibbonServiceCallProcessor extends ServiceSupport implements AsyncP
>>          // setup from the provided name which can contain scheme and context-path information as well
>>          String serviceName;
>>          if (name.contains("/")) {
>> -            serviceName = ObjectHelper.before(name, "/");
>> -            this.contextPath = ObjectHelper.after(name, "/");
>> +            serviceName = StringHelper.before(name, "/");
>> +            this.contextPath = StringHelper.after(name, "/");
>>          } else if (name.contains("?")) {
>> -            serviceName = ObjectHelper.before(name, "?");
>> -            this.contextPath = ObjectHelper.after(name, "?");
>> +            serviceName = StringHelper.before(name, "?");
>> +            this.contextPath = StringHelper.after(name, "?");
>>          } else {
>>              serviceName = name;
>>              this.contextPath = null;
>>          }
>>          if (serviceName.contains(":")) {
>> -            this.scheme = ObjectHelper.before(serviceName, ":");
>> -            this.name = ObjectHelper.after(serviceName, ":");
>> +            this.scheme = StringHelper.before(serviceName, ":");
>> +            this.name = StringHelper.after(serviceName, ":");
>>          } else {
>>              this.scheme = scheme;
>>              this.name = serviceName;
>> @@ -199,7 +198,7 @@ public class RibbonServiceCallProcessor extends ServiceSupport implements AsyncP
>>      @Override
>>      @SuppressWarnings("unchecked")
>>      protected void doStart() throws Exception {
>> -        ObjectHelper.notEmpty(name, "name", this);
>> +        StringHelper.notEmpty(name, "name", this);
>>
>>          if (serverListStrategy == null) {
>>              serverListStrategy = new RibbonServiceCallStaticServerListStrategy();
>> @@ -222,7 +221,7 @@ public class RibbonServiceCallProcessor extends ServiceSupport implements AsyncP
>>          IClientConfig config = IClientConfig.Builder.newBuilder(name).build();
>>          if (ribbonClientConfig != null) {
>>              for (Map.Entry<String, String> entry : ribbonClientConfig.entrySet()) {
>> -                IClientConfigKey key = CommonClientConfigKey.valueOf(entry.getKey());
>> +                IClientConfigKey key = IClientConfigKey.Keys.valueOf(entry.getKey());
>>                  String value = entry.getValue();
>>                  LOG.debug("RibbonClientConfig: {}={}", key.key(), value);
>>                  config.set(key, entry.getValue());
>>
>> http://git-wip-us.apache.org/repos/asf/camel/blob/490a76f1/components/camel-servicenow/src/main/java/org/apache/camel/component/servicenow/ServiceNowClient.java
>> ----------------------------------------------------------------------
>> diff --git a/components/camel-servicenow/src/main/java/org/apache/camel/component/servicenow/ServiceNowClient.java b/components/camel-servicenow/src/main/java/org/apache/camel/component/servicenow/ServiceNowClient.java
>> index 2bdd86a..fa33607 100644
>> --- a/components/camel-servicenow/src/main/java/org/apache/camel/component/servicenow/ServiceNowClient.java
>> +++ b/components/camel-servicenow/src/main/java/org/apache/camel/component/servicenow/ServiceNowClient.java
>> @@ -162,7 +162,7 @@ public final class ServiceNowClient {
>>      }
>>
>>      private static void configureTls(
>> -        CamelContext camelContext, ServiceNowConfiguration configuration, WebClient client) throws Exception{
>> +        CamelContext camelContext, ServiceNowConfiguration configuration, WebClient client) throws Exception {
>>
>>          SSLContextParameters sslContextParams = configuration.getSslContextParameters();
>>          if (sslContextParams != null) {
>>
>> http://git-wip-us.apache.org/repos/asf/camel/blob/490a76f1/components/readme.adoc
>> ----------------------------------------------------------------------
>> diff --git a/components/readme.adoc b/components/readme.adoc
>> index 6d1eb1a..81b3828 100644
>> --- a/components/readme.adoc
>> +++ b/components/readme.adoc
>> @@ -15,12 +15,6 @@ Components
>> | link:camel-amqp/src/main/docs/amqp-component.adoc[AMQP] (camel-amqp) +
>> `amqp:destinationType:destinationName` | Messaging with AMQP protocol using Apache QPid Client.
>>
>> -| link:camel-flink/src/main/docs/flink-component.adoc[Apache Flink] (camel-flink) +
>> -`flink:endpointType` | The flink component can be used to send DataSet jobs to Apache Flink cluster.
>> -
>> -| link:camel-spark/src/main/docs/spark-component.adoc[Apache Spark] (camel-spark) +
>> -`spark:endpointType` | The spark component can be used to send RDD or DataFrame jobs to Apache Spark cluster.
>> -
>> | link:camel-apns/src/main/docs/apns-component.adoc[APNS] (camel-apns) +
>> `apns:name` | For sending notifications to Apple iOS devices.
>>
>> @@ -141,249 +135,60 @@ Components
>> | link:camel-drill/src/main/docs/drill-component.adoc[Drill] (camel-drill) +
>> `drill:host` | The drill component gives you the ability to quering into apache drill cluster.
>>
>> -| link:camel-dropbox/src/main/docs/dropbox-component.adoc[Dropbox] (camel-dropbox) +
>> -`dropbox:operation` | For uploading downloading and managing files folders groups collaborations etc on dropbox DOT com.
>> -
>> | link:camel-cache/src/main/docs/cache-component.adoc[EHCache] (camel-cache) +
>> `cache:cacheName` | *deprecated* The cache component enables you to perform caching operations using EHCache as the Cache Implementation.
>>
>> -| link:camel-ehcache/src/main/docs/ehcache-component.adoc[Ehcache] (camel-ehcache) +
>> -`ehcache:cacheName` | The ehcache component enables you to perform caching operations using Ehcache as cache implementation.
>> -
>> -| link:camel-ejb/src/main/docs/ejb-component.adoc[EJB] (camel-ejb) +
>> -`ejb:beanName` | The ejb component is for invoking EJB Java beans from Camel.
>> -
>> -| link:camel-elasticsearch/src/main/docs/elasticsearch-component.adoc[Elasticsearch] (camel-elasticsearch) +
>> -`elasticsearch:clusterName` | The elasticsearch component is used for interfacing with ElasticSearch server.
>> -
>> -| link:camel-elsql/src/main/docs/elsql-component.adoc[ElSQL] (camel-elsql) +
>> -`elsql:elsqlName:resourceUri` | The elsql component is an extension to the existing SQL Component that uses ElSql to define the SQL queries.
>> -
>> -| link:camel-etcd/src/main/docs/etcd-component.adoc[etcd] (camel-etcd) +
>> -`etcd:namespace/path` | The camel etcd component allows you to work with Etcd a distributed A distributed reliable key-value store.
>> -
>> -| link:camel-exec/src/main/docs/exec-component.adoc[Exec] (camel-exec) +
>> -`exec:executable` | The exec component can be used to execute OS system commands.
>> -
>> -| link:camel-facebook/src/main/docs/facebook-component.adoc[Facebook] (camel-facebook) +
>> -`facebook:methodName` | The Facebook component provides access to all of the Facebook APIs accessible using Facebook4J.
>> -
>> -| link:camel-flatpack/src/main/docs/flatpack-component.adoc[Flatpack] (camel-flatpack) +
>> -`flatpack:type:resourceUri` | The flatpack component supports fixed width and delimited file parsing via the FlatPack library.
>> -
>> -| link:camel-fop/src/main/docs/fop-component.adoc[FOP] (camel-fop) +
>> -`fop:outputType` | The fop component allows you to render a message into different output formats using Apache FOP.
>> -
>> -| link:camel-freemarker/src/main/docs/freemarker-component.adoc[Freemarker] (camel-freemarker) +
>> -`freemarker:resourceUri` | Transforms the message using a FreeMarker template.
>> -
>> -| link:camel-ftp/src/main/docs/ftp-component.adoc[FTP] (camel-ftp) +
>> -`ftp:host:port/directoryName` | The ftp component is used for uploading or downloading files from FTP servers.
>> -
>> -| link:camel-ftp/src/main/docs/ftps-component.adoc[FTPS] (camel-ftp) +
>> -`ftps:host:port/directoryName` | The ftps (FTP secure SSL/TLS) component is used for uploading or downloading files from FTP servers.
>> -
>> -| link:camel-ganglia/src/main/docs/ganglia-component.adoc[Ganglia] (camel-ganglia) +
>> -`ganglia:host:port` | The ganglia component is used for sending metrics to the Ganglia monitoring system.
>> -
>> -| link:camel-geocoder/src/main/docs/geocoder-component.adoc[Geocoder] (camel-geocoder) +
>> -`geocoder:address:latlng` | The geocoder component is used for looking up geocodes (latitude and longitude) for a given address or reverse lookup.
>> -
>> -| link:camel-git/src/main/docs/git-component.adoc[Git] (camel-git) +
>> -`git:localPath` | The git component is used for working with git repositories.
>> -
>> -| link:camel-github/src/main/docs/github-component.adoc[GitHub] (camel-github) +
>> -`github:type/branchName` | The github component is used for integrating Camel with github.
>> -
>> | link:camel-google-calendar/src/main/docs/google-calendar-component.adoc[Google Calendar] (camel-google-calendar) +
>> `google-calendar:apiName/methodName` | The google-calendar component provides access to Google Calendar.
>>
>> -| link:camel-google-drive/src/main/docs/google-drive-component.adoc[Google Drive] (camel-google-drive) +
>> -`google-drive:apiName/methodName` | The google-drive component provides access to Google Drive file storage service.
>> -
>> -| link:camel-google-mail/src/main/docs/google-mail-component.adoc[Google Mail] (camel-google-mail) +
>> -`google-mail:apiName/methodName` | The google-mail component provides access to Google Mail.
>> -
>> | link:camel-google-pubsub/src/main/docs/google-pubsub-component.adoc[Google Pubsub] (camel-google-pubsub) +
>> `google-pubsub:projectId:destinationName` | Messaging client for Google Cloud Platform PubSub Service: https://cloud.google.com/pubsub/
>>
>> -| link:camel-gora/src/main/docs/gora-component.adoc[Gora] (camel-gora) +
>> -`gora:name` | The gora component allows you to work with NoSQL databases using the Apache Gora framework.
>> -
>> | link:camel-grape/src/main/docs/grape-component.adoc[Grape] (camel-grape) +
>> `grape:defaultCoordinates` | Grape component allows you to fetch, load and manage additional jars when CamelContext is running.
>>
>> -| link:camel-guava-eventbus/src/main/docs/guava-eventbus-component.adoc[Guava EventBus] (camel-guava-eventbus) +
>> -`guava-eventbus:eventBusRef` | The guava-eventbus component provides integration bridge between Camel and Google Guava EventBus.
>> -
>> -| link:camel-hazelcast/src/main/docs/hazelcast-component.adoc[Hazelcast] (camel-hazelcast) +
>> -`hazelcast:command:cacheName` | The hazelcast component allows you to work with the Hazelcast distributed data grid / cache.
>> -
>> -| link:camel-hbase/src/main/docs/hbase-component.adoc[HBase] (camel-hbase) +
>> -`hbase:tableName` | For reading/writing from/to an HBase store (Hadoop database).
>> -
>> -| link:camel-hdfs/src/main/docs/hdfs-component.adoc[HDFS] (camel-hdfs) +
>> -`hdfs:hostName:port/path` | *deprecated* For reading/writing from/to an HDFS filesystem using Hadoop 1.x.
>> -
>> -| link:camel-hdfs2/src/main/docs/hdfs2-component.adoc[HDFS2] (camel-hdfs2) +
>> -`hdfs2:hostName:port/path` | For reading/writing from/to an HDFS filesystem using Hadoop 2.x.
>> -
>> -| link:camel-hipchat/src/main/docs/hipchat-component.adoc[Hipchat] (camel-hipchat) +
>> -`hipchat:protocol:host:port` | The hipchat component supports producing and consuming messages from/to Hipchat service.
>> -
>> | link:camel-http/src/main/docs/http-component.adoc[HTTP] (camel-http) +
>> `http:httpUri` | For calling out to external HTTP servers using Apache HTTP Client 3.x.
>>
>> | link:camel-http4/src/main/docs/http4-component.adoc[HTTP4] (camel-http4) +
>> `http4:httpUri` | For calling out to external HTTP servers using Apache HTTP Client 4.x.
>>
>> -| link:camel-ibatis/src/main/docs/ibatis-component.adoc[iBatis] (camel-ibatis) +
>> -`ibatis:statement` | *deprecated* Performs a query poll insert update or delete in a relational database using Apache iBATIS.
>> -
>> -| link:camel-mail/src/main/docs/imap-component.adoc[IMAP] (camel-mail) +
>> -`imap:host:port` | To send or receive emails using imap/pop3 or stmp protocols.
>> -
>> | link:camel-infinispan/src/main/docs/infinispan-component.adoc[Infinispan] (camel-infinispan) +
>> `infinispan:host` | For reading/writing from/to Infinispan distributed key/value store and data grid.
>>
>> -| link:camel-influxdb/src/main/docs/influxdb-component.adoc[InfluxDB] (camel-influxdb) +
>> -`influxdb:connectionBean` | The influxdb component allows you to interact with InfluxDB a time series database.
>> -
>> -| link:camel-irc/src/main/docs/irc-component.adoc[IRC] (camel-irc) +
>> -`irc:hostname:port` | The irc component implements an IRC (Internet Relay Chat) transport.
>> -
>> | link:camel-ironmq/src/main/docs/ironmq-component.adoc[ironmq] (camel-ironmq) +
>> `ironmq:queueName` | The ironmq provides integration with IronMQ an elastic and durable hosted message queue as a service.
>>
>> -| link:camel-javaspace/src/main/docs/javaspace-component.adoc[JavaSpace] (camel-javaspace) +
>> -`javaspace:url` | *deprecated* Sending and receiving messages through JavaSpace.
>> -
>> -| link:camel-jbpm/src/main/docs/jbpm-component.adoc[JBPM] (camel-jbpm) +
>> -`jbpm:connectionURL` | The jbpm component provides integration with jBPM (Business Process Management).
>> -
>> | link:camel-jcache/src/main/docs/jcache-component.adoc[JCache] (camel-jcache) +
>> `jcache:cacheName` | The jcache component enables you to perform caching operations using JSR107/JCache as cache implementation.
>>
>> -| link:camel-jclouds/src/main/docs/jclouds-component.adoc[JClouds] (camel-jclouds) +
>> -`jclouds:command:providerId` | For interacting with cloud compute & blobstore service via jclouds.
>> -
>> -| link:camel-jcr/src/main/docs/jcr-component.adoc[JCR] (camel-jcr) +
>> -`jcr:host/base` | The jcr component allows you to add/read nodes to/from a JCR compliant content repository.
>> -
>> -| link:camel-jdbc/src/main/docs/jdbc-component.adoc[JDBC] (camel-jdbc) +
>> -`jdbc:dataSourceName` | The jdbc component enables you to access databases through JDBC where SQL queries are sent in the message body.
>> -
>> | link:camel-jetty9/src/main/docs/jetty-component.adoc[Jetty 9] (camel-jetty9) +
>> `jetty:httpUri` | The jetty component provides HTTP-based endpoints for consuming and producing HTTP requests.
>>
>> | link:camel-websocket/src/main/docs/websocket-component.adoc[Jetty Websocket] (camel-websocket) +
>> `websocket:host:port/resourceUri` | The websocket component provides websocket endpoints for communicating with clients using websocket.
>>
>> -| link:camel-jgroups/src/main/docs/jgroups-component.adoc[JGroups] (camel-jgroups) +
>> -`jgroups:clusterName` | The jgroups component provides exchange of messages between Camel and JGroups clusters.
>> -
>> -| link:camel-jing/src/main/docs/jing-component.adoc[Jing] (camel-jing) +
>> -`jing:resourceUri` | Validates the payload of a message using RelaxNG Syntax using Jing library.
>> -
>> -| link:camel-jira/src/main/docs/jira-component.adoc[JIRA] (camel-jira) +
>> -`jira:type` | The jira component interacts with the JIRA issue tracker.
>> -
>> | link:camel-jms/src/main/docs/jms-component.adoc[JMS] (camel-jms) +
>> `jms:destinationType:destinationName` | The jms component allows messages to be sent to (or consumed from) a JMS Queue or Topic.
>>
>> -| link:camel-jmx/src/main/docs/jmx-component.adoc[JMX] (camel-jmx) +
>> -`jmx:serverURL` | The jmx component allows to receive JMX notifications.
>> -
>> -| link:camel-jolt/src/main/docs/jolt-component.adoc[JOLT] (camel-jolt) +
>> -`jolt:resourceUri` | The jolt component allows you to process a JSON messages using an JOLT specification (such as JSON-JSON transformation).
>> -
>> -| link:camel-jpa/src/main/docs/jpa-component.adoc[JPA] (camel-jpa) +
>> -`jpa:entityType` | The jpa component enables you to store and retrieve Java objects from databases using JPA.
>> -
>> -| link:camel-jt400/src/main/docs/jt400-component.adoc[JT400] (camel-jt400) +
>> -`jt400:userID:password/systemName/objectPath.type` | The jt400 component allows you to exchanges messages with an AS/400 system using data queues or program call.
>> -
>> | link:camel-kafka/src/main/docs/kafka-component.adoc[Kafka] (camel-kafka) +
>> `kafka:brokers` | The kafka component allows messages to be sent to (or consumed from) Apache Kafka brokers.
>>
>> -| link:camel-kestrel/src/main/docs/kestrel-component.adoc[Kestrel] (camel-kestrel) +
>> -`kestrel:addresses/queue` | *deprecated* The kestrel component allows messages to be sent to (or consumed from) Kestrel brokers.
>> -
>> -| link:camel-krati/src/main/docs/krati-component.adoc[Krati] (camel-krati) +
>> -`krati:path` | The krati allows the use krati datastores and datasets inside Camel.
>> -
>> -| link:camel-kubernetes/src/main/docs/kubernetes-component.adoc[Kubernetes] (camel-kubernetes) +
>> -`kubernetes:masterUrl` | The kubernetes component allows to work with Kubernetes PaaS.
>> -
>> -| link:camel-ldap/src/main/docs/ldap-component.adoc[LDAP] (camel-ldap) +
>> -`ldap:dirContextName` | The ldap component allows you to perform searches in LDAP servers using filters as the message payload.
>> -
>> -| link:camel-linkedin/src/main/docs/linkedin-component.adoc[Linkedin] (camel-linkedin) +
>> -`linkedin:apiName/methodName` | The linkedin component is uses for retrieving LinkedIn user profiles connections companies groups posts etc.
>> -
>> -| link:camel-lucene/src/main/docs/lucene-component.adoc[Lucene] (camel-lucene) +
>> -`lucene:host:operation` | To insert or query from Apache Lucene databases.
>> -
>> -| link:camel-lumberjack/src/main/docs/lumberjack-component.adoc[Lumberjack] (camel-lumberjack) +
>> -`lumberjack:host:port` | The lumberjack retrieves logs sent over the network using the Lumberjack protocol.
>> -
>> | link:camel-metrics/src/main/docs/metrics-component.adoc[Metrics] (camel-metrics) +
>> `metrics:metricsType:metricsName` | To collect various metrics directly from Camel routes using the DropWizard metrics library.
>>
>> -| link:camel-mina/src/main/docs/mina-component.adoc[Mina] (camel-mina) +
>> -`mina:protocol:host:port` | *deprecated* Socket level networking using TCP or UDP with the Apache Mina 1.x library.
>> -
>> -| link:camel-mina2/src/main/docs/mina2-component.adoc[Mina2] (camel-mina2) +
>> -`mina2:protocol:host:port` | Socket level networking using TCP or UDP with the Apache Mina 2.x library.
>> -
>> | link:camel-mllp/src/main/docs/mllp-component.adoc[MLLP] (camel-mllp) +
>> `mllp:hostname:port` | The MLLP component is designed to handle the MLLP protocol and provide the functionality required by Healthcare providers to communicate with other systems using the MLLP protocol.
>>
>> | link:camel-mongodb/src/main/docs/mongodb-component.adoc[MongoDB] (camel-mongodb) +
>> `mongodb:connectionBean` | Component for working with documents stored in MongoDB database.
>>
>> -| link:camel-mongodb3/src/main/docs/mongodb3-component.adoc[MongoDB] (camel-mongodb3) +
>> -`mongodb3:connectionBean` | Component for working with documents stored in MongoDB database.
>> -
>> -| link:camel-mongodb-gridfs/src/main/docs/gridfs-component.adoc[MongoDBGridFS] (camel-mongodb-gridfs) +
>> -`gridfs:connectionBean` | Component for working with MongoDB GridFS.
>> -
>> -| link:camel-mqtt/src/main/docs/mqtt-component.adoc[MQTT] (camel-mqtt) +
>> -`mqtt:name` | Component for communicating with MQTT M2M message brokers using FuseSource MQTT Client.
>> -
>> -| link:camel-msv/src/main/docs/msv-component.adoc[MSV] (camel-msv) +
>> -`msv:resourceUri` | Validates the payload of a message using the MSV Library.
>> -
>> -| link:camel-mustache/src/main/docs/mustache-component.adoc[Mustache] (camel-mustache) +
>> -`mustache:resourceUri` | Transforms the message using a Mustache template.
>> -
>> -| link:camel-mvel/src/main/docs/mvel-component.adoc[MVEL] (camel-mvel) +
>> -`mvel:resourceUri` | Transforms the message using a MVEL template.
>> -
>> -| link:camel-mybatis/src/main/docs/mybatis-component.adoc[MyBatis] (camel-mybatis) +
>> -`mybatis:statement` | Performs a query poll insert update or delete in a relational database using MyBatis.
>> -
>> -| link:camel-nagios/src/main/docs/nagios-component.adoc[Nagios] (camel-nagios) +
>> -`nagios:host:port` | To send passive checks to Nagios using JSendNSCA.
>> -
>> -| link:camel-nats/src/main/docs/nats-component.adoc[Nats] (camel-nats) +
>> -`nats:servers` | The nats component allows you produce and consume messages from NATS.
>> -
>> -| link:camel-netty/src/main/docs/netty-component.adoc[Netty] (camel-netty) +
>> -`netty:protocol:host:port` | *deprecated* Socket level networking using TCP or UDP with the Netty 3.x library.
>> -
>> -| link:camel-netty-http/src/main/docs/netty-http-component.adoc[Netty HTTP] (camel-netty-http) +
>> -`netty-http:protocol:host:port/path` | *deprecated* Netty HTTP server and client using the Netty 3.x library.
>> -
>> | link:camel-netty4/src/main/docs/netty4-component.adoc[Netty4] (camel-netty4) +
>> `netty4:protocol:host:port` | Socket level networking using TCP or UDP with the Netty 4.x library.
>>
>> | link:camel-netty4-http/src/main/docs/netty4-http-component.adoc[Netty4 HTTP] (camel-netty4-http) +
>> `netty4-http:protocol:host:port/path` | Netty HTTP server and client using the Netty 4.x library.
>>
>> -| link:camel-openshift/src/main/docs/openshift-component.adoc[OpenShift] (camel-openshift) +
>> -`openshift:clientId` | *deprecated* To manage your Openshift 2.x applications.
>> -
>> | link:camel-openstack/src/main/docs/openstack-cinder-component.adoc[OpenStack-Cinder] (camel-openstack) +
>> `openstack-cinder:host` | Camel Components
>>
>> @@ -402,174 +207,33 @@ Components
>> | link:camel-openstack/src/main/docs/openstack-swift-component.adoc[OpenStack-Swift] (camel-openstack) +
>> `openstack-swift:host` | Camel Components
>>
>> -| link:camel-optaplanner/src/main/docs/optaplanner-component.adoc[OptaPlanner] (camel-optaplanner) +
>> -`optaplanner:configFile` | Solves the planning problem contained in a message with OptaPlanner.
>> -
>> -| link:camel-eventadmin/src/main/docs/eventadmin-component.adoc[OSGi EventAdmin] (camel-eventadmin) +
>> -`eventadmin:topic` | The eventadmin component can be used in an OSGi environment to receive OSGi EventAdmin events and process them.
>> -
>> -| link:camel-paxlogging/src/main/docs/paxlogging-component.adoc[OSGi PAX Logging] (camel-paxlogging) +
>> -`paxlogging:appender` | The paxlogging component can be used in an OSGi environment to receive PaxLogging events and process them.
>> -
>> -| link:camel-paho/src/main/docs/paho-component.adoc[Paho] (camel-paho) +
>> -`paho:topic` | Component for communicating with MQTT M2M message brokers using Eclipse Paho MQTT Client.
>> -
>> -| link:camel-pdf/src/main/docs/pdf-component.adoc[PDF] (camel-pdf) +
>> -`pdf:operation` | The pdf components provides the ability to create modify or extract content from PDF documents.
>> -
>> -| link:camel-pgevent/src/main/docs/pgevent-component.adoc[PostgresSQL Event] (camel-pgevent) +
>> -`pgevent:host:port/database/channel` | The pgevent component allows for producing/consuming PostgreSQL events related to the LISTEN/NOTIFY commands.
>> -
>> -| link:camel-printer/src/main/docs/lpr-component.adoc[Printer] (camel-printer) +
>> -`lpr:hostname:port/printername` | The printer component is used for sending messages to printers as print jobs.
>> -
>> -| link:camel-quartz/src/main/docs/quartz-component.adoc[Quartz] (camel-quartz) +
>> -`quartz:groupName/timerName` | *deprecated* Provides a scheduled delivery of messages using the Quartz 1.x scheduler.
>> -
>> -| link:camel-quartz2/src/main/docs/quartz2-component.adoc[Quartz2] (camel-quartz2) +
>> -`quartz2:groupName/triggerName` | Provides a scheduled delivery of messages using the Quartz 2.x scheduler.
>> -
>> -| link:camel-quickfix/src/main/docs/quickfix-component.adoc[QuickFix] (camel-quickfix) +
>> -`quickfix:configurationName` | The quickfix component allows to send Financial Interchange (FIX) messages to the QuickFix engine.
>> -
>> -| link:camel-rabbitmq/src/main/docs/rabbitmq-component.adoc[RabbitMQ] (camel-rabbitmq) +
>> -`rabbitmq:hostname:portNumber/exchangeName` | The rabbitmq component allows you produce and consume messages from RabbitMQ instances.
>> -
>> -| link:camel-restlet/src/main/docs/restlet-component.adoc[Restlet] (camel-restlet) +
>> -`restlet:protocol:host:port/uriPattern` | Component for consuming and producing Restful resources using Restlet.
>> -
>> -| link:camel-rmi/src/main/docs/rmi-component.adoc[RMI] (camel-rmi) +
>> -`rmi:hostname:port/name` | The rmi component is for invoking Java RMI beans from Camel.
>> -
>> -| link:camel-routebox/src/main/docs/routebox-component.adoc[RouteBox] (camel-routebox) +
>> -`routebox:routeboxName` | *deprecated* The routebox component allows to send/receive messages between Camel routes in a black box way.
>> -
>> -| link:camel-rss/src/main/docs/rss-component.adoc[RSS] (camel-rss) +
>> -`rss:feedUri` | The rss component is used for consuming RSS feeds.
>> -
>> | link:camel-salesforce/src/main/docs/salesforce-component.adoc[Salesforce] (camel-salesforce) +
>> `salesforce:operationName:topicName` | The salesforce component is used for integrating Camel with the massive Salesforce API.
>>
>> -| link:camel-sap-netweaver/src/main/docs/sap-netweaver-component.adoc[SAP NetWeaver] (camel-sap-netweaver) +
>> -`sap-netweaver:url` | The sap-netweaver component integrates with the SAP NetWeaver Gateway using HTTP transports.
>> -
>> -| link:camel-schematron/src/main/docs/schematron-component.adoc[Schematron] (camel-schematron) +
>> -`schematron:path` | Validates the payload of a message using the Schematron Library.
>> -
>> -| link:camel-jsch/src/main/docs/scp-component.adoc[SCP] (camel-jsch) +
>> -`scp:host:port/directoryName` | To copy files using the secure copy protocol (SCP).
>> -
>> -| link:camel-servicenow/src/main/docs/servicenow-component.adoc[ServiceNow] (camel-servicenow) +
>> -`servicenow:instanceName` | The servicenow component is used to integrate Camel with ServiceNow cloud services.
>> -
>> | link:camel-servlet/src/main/docs/servlet-component.adoc[Servlet] (camel-servlet) +
>> `servlet:contextPath` | To use a HTTP Servlet as entry for Camel routes when running in a servlet container.
>>
>> -| link:camel-ftp/src/main/docs/sftp-component.adoc[SFTP] (camel-ftp) +
>> -`sftp:host:port/directoryName` | The sftp (FTP over SSH) component is used for uploading or downloading files from SFTP servers.
>> -
>> -| link:camel-sjms/src/main/docs/sjms-component.adoc[Simple JMS] (camel-sjms) +
>> -`sjms:destinationType:destinationName` | The sjms component (simple jms) allows messages to be sent to (or consumed from) a JMS Queue or Topic.
>> -
>> -| link:camel-sjms/src/main/docs/sjms-batch-component.adoc[Simple JMS Batch] (camel-sjms) +
>> -`sjms-batch:destinationName` | The sjms-batch component is a specialized for highly performant transactional batch consumption from a JMS queue.
>> -
>> -| link:camel-sip/src/main/docs/sip-component.adoc[SIP] (camel-sip) +
>> -`sip:uri` | To send and receive messages using the SIP protocol (used in telco and mobile).
>> -
>> -| link:camel-slack/src/main/docs/slack-component.adoc[Slack] (camel-slack) +
>> -`slack:channel` | The slack component allows you to send messages to Slack.
>> -
>> | link:camel-smpp/src/main/docs/smpp-component.adoc[SMPP] (camel-smpp) +
>> `smpp:host:port` | To send and receive SMS using a SMSC (Short Message Service Center).
>>
>> -| link:camel-snmp/src/main/docs/snmp-component.adoc[SNMP] (camel-snmp) +
>> -`snmp:host:port` | The snmp component gives you the ability to poll SNMP capable devices or receiving traps.
>> -
>> -| link:camel-solr/src/main/docs/solr-component.adoc[Solr] (camel-solr) +
>> -`solr:url` | The solr component allows you to interface with an Apache Lucene Solr server.
>> -
>> -| link:camel-spark-rest/src/main/docs/spark-rest-component.adoc[Spark Rest] (camel-spark-rest) +
>> -`spark-rest:verb:path` | The spark-rest component is used for hosting REST services which has been defined using Camel rest-dsl.
>> -
>> -| link:camel-splunk/src/main/docs/splunk-component.adoc[Splunk] (camel-splunk) +
>> -`splunk:name` | The splunk component allows to publish or search for events in Splunk.
>> -
>> -| link:camel-spring-batch/src/main/docs/spring-batch-component.adoc[Spring Batch] (camel-spring-batch) +
>> -`spring-batch:jobName` | The spring-batch component allows to send messages to Spring Batch for further processing.
>> -
>> | link:camel-spring/src/main/docs/spring-event-component.adoc[Spring Event] (camel-spring) +
>> `spring-event:name` | The spring-event component allows to listen for Spring Application Events.
>>
>> -| link:camel-spring-integration/src/main/docs/spring-integration-component.adoc[Spring Integration] (camel-spring-integration) +
>> -`spring-integration:defaultChannel` | Bridges Camel with Spring Integration.
>> -
>> -| link:camel-spring-ldap/src/main/docs/spring-ldap-component.adoc[Spring LDAP] (camel-spring-ldap) +
>> -`spring-ldap:templateName` | The spring-ldap component allows you to perform searches in LDAP servers using filters as the message payload.
>> -
>> -| link:camel-spring-redis/src/main/docs/spring-redis-component.adoc[Spring Redis] (camel-spring-redis) +
>> -`spring-redis:host:port` | The spring-redis component allows sending and receiving messages from Redis.
>> -
>> -| link:camel-spring-ws/src/main/docs/spring-ws-component.adoc[Spring WebService] (camel-spring-ws) +
>> -`spring-ws:type:lookupKey:webServiceEndpointUri` | The spring-ws component is used for SOAP WebServices using Spring WebServices.
>> -
>> | link:camel-sql/src/main/docs/sql-component.adoc[SQL] (camel-sql) +
>> `sql:query` | The sql component allows you to work with databases using JDBC SQL queries.
>>
>> | link:camel-sql/src/main/docs/sql-stored-component.adoc[SQL StoredProcedure] (camel-sql) +
>> `sql-stored:template` | The sql component allows you to work with databases using JDBC Stored Procedure queries.
>>
>> -| link:camel-ssh/src/main/docs/ssh-component.adoc[SSH] (camel-ssh) +
>> -`ssh:host:port` | The ssh component enables access to SSH servers such that you can send an SSH command and process the response.
>> -
>> -| link:camel-stax/src/main/docs/stax-component.adoc[StAX] (camel-stax) +
>> -`stax:contentHandlerClass` | The stax component allows messages to be process through a SAX ContentHandler.
>> -
>> -| link:camel-stomp/src/main/docs/stomp-component.adoc[Stomp] (camel-stomp) +
>> -`stomp:destination` | The stomp component is used for communicating with Stomp compliant message brokers.
>> -
>> | link:camel-stream/src/main/docs/stream-component.adoc[Stream] (camel-stream) +
>> `stream:kind` | The stream: component provides access to the system-in system-out and system-err streams as well as allowing streaming of file and URL.
>>
>> -| link:camel-stringtemplate/src/main/docs/string-template-component.adoc[String Template] (camel-stringtemplate) +
>> -`string-template:resourceUri` | Transforms the message using a String template.
>> -
>> -| link:camel-telegram/src/main/docs/telegram-component.adoc[Telegram] (camel-telegram) +
>> -`telegram:type/authorizationToken` | The telegram component provides access to the Telegram Bot API.
>> -
>> -| link:camel-twitter/src/main/docs/twitter-component.adoc[Twitter] (camel-twitter) +
>> -`twitter:kind` | This component integrates with Twitter to send tweets or search for tweets and more.
>> -
>> -| link:camel-undertow/src/main/docs/undertow-component.adoc[Undertow] (camel-undertow) +
>> -`undertow:httpURI` | The undertow component provides HTTP-based endpoints for consuming and producing HTTP requests.
>> -
>> | link:camel-velocity/src/main/docs/velocity-component.adoc[Velocity] (camel-velocity) +
>> `velocity:resourceUri` | Transforms the message using a Velocity template.
>>
>> -| link:camel-vertx/src/main/docs/vertx-component.adoc[Vert.x] (camel-vertx) +
>> -`vertx:address` | The vertx component is used for sending and receive messages from a vertx event bus.
>> -
>> | link:camel-weather/src/main/docs/weather-component.adoc[Weather] (camel-weather) +
>> `weather:name` | Polls the weather information from Open Weather Map.
>>
>> -| link:camel-xmlrpc/src/main/docs/xmlrpc-component.adoc[XML RPC] (camel-xmlrpc) +
>> -`xmlrpc:address` | The xmlrpc component is used for sending messages to a XML RPC service.
>> -
>> -| link:camel-xmlsecurity/src/main/docs/xmlsecurity-component.adoc[XML Security] (camel-xmlsecurity) +
>> -`xmlsecurity:command:name` | Used to sign and verify exchanges using the XML signature specification.
>> -
>> -| link:camel-xmpp/src/main/docs/xmpp-component.adoc[XMPP] (camel-xmpp) +
>> -`xmpp:host:port/participant` | To send and receive messages from a XMPP (chat) server.
>> -
>> -| link:camel-saxon/src/main/docs/xquery-component.adoc[XQuery] (camel-saxon) +
>> -`xquery:resourceUri` | Transforms the message using a XQuery template using Saxon.
>> -
>> -| link:camel-yammer/src/main/docs/yammer-component.adoc[Yammer] (camel-yammer) +
>> -`yammer:function` | The yammer component allows you to interact with the Yammer enterprise social network.
>> -
>> -| link:camel-zookeeper/src/main/docs/zookeeper-component.adoc[ZooKeeper] (camel-zookeeper) +
>> -`zookeeper:serverUrls/path` | The zookeeper component allows interaction with a ZooKeeper cluster.
>> -
>> |=======================================================================
>> // components: END
>>
>> @@ -646,65 +310,17 @@ Data Formats
>>
>> | link:camel-csv/src/main/docs/csv-dataformat.adoc[CSV] (camel-csv) | Camel CSV data format support
>>
>> -| link:camel-flatpack/src/main/docs/flatpack-dataformat.adoc[Flatpack] (camel-flatpack) | Camel FlatPack support
>> -
>> | link:camel-hessian/src/main/docs/hessian-dataformat.adoc[Hessian] (camel-hessian) | Hessian serialization support
>>
>> | link:camel-hl7/src/main/docs/hl7-dataformat.adoc[HL7] (camel-hl7) | Camel HL7 support
>>
>> -| link:camel-ical/src/main/docs/ical-dataformat.adoc[iCal] (camel-ical) | Camel iCal component
>> -
>> | link:camel-jacksonxml/src/main/docs/jacksonxml-dataformat.adoc[JacksonXML] (camel-jacksonxml) | Camel Jackson XML support
>>
>> | link:camel-jaxb/src/main/docs/jaxb-dataformat.adoc[JAXB] (camel-jaxb) | Camel JAXB support
>>
>> -| link:camel-jibx/src/main/docs/jibx-dataformat.adoc[JiBX] (camel-jibx) | Camel Jibx support
>> -
>> -| link:camel-gson/src/main/docs/json-gson-dataformat.adoc[JSon GSon] (camel-gson) | Camel Gson support
>> -
>> | link:camel-jackson/src/main/docs/json-jackson-dataformat.adoc[JSon Jackson] (camel-jackson) | Camel Jackson support
>>
>> -| link:camel-johnzon/src/main/docs/json-johnzon-dataformat.adoc[JSon Johnzon] (camel-johnzon) | Camel Johnzon support
>> -
>> -| link:camel-xstream/src/main/docs/json-xstream-dataformat.adoc[JSon XStream] (camel-xstream) | Camel XStream support
>> -
>> -| link:camel-lzf/src/main/docs/lzf-dataformat.adoc[LZF Deflate Compression] (camel-lzf) | Camel LZF support
>> -
>> -| link:camel-mail/src/main/docs/mime-multipart-dataformat.adoc[MIME Multipart] (camel-mail) | Camel Mail support
>> -
>> | link:camel-crypto/src/main/docs/pgp-dataformat.adoc[PGP] (camel-crypto) | Camel Cryptographic Support
>> -
>> -| link:camel-protobuf/src/main/docs/protobuf-dataformat.adoc[Protobuf] (camel-protobuf) | Camel Google Protobuf data format support
>> -
>> -| link:camel-rss/src/main/docs/rss-dataformat.adoc[RSS] (camel-rss) | Camel RSS support
>> -
>> -| link:camel-soap/src/main/docs/soapjaxb-dataformat.adoc[SOAP] (camel-soap) | Camel SOAP support
>> -
>> -| link:camel-syslog/src/main/docs/syslog-dataformat.adoc[Syslog] (camel-syslog) | Camel Syslog support
>> -
>> -| link:camel-tarfile/src/main/docs/tarfile-dataformat.adoc[Tar File] (camel-tarfile) | Camel Tar file support
>> -
>> -| link:camel-tagsoup/src/main/docs/tidyMarkup-dataformat.adoc[TidyMarkup] (camel-tagsoup) | Camel TagSoup support
>> -
>> -| link:camel-univocity-parsers/src/main/docs/univocity-csv-dataformat.adoc[uniVocity CSV] (camel-univocity-parsers) | Camel UniVocity parsers data format support
>> -
>> -| link:camel-univocity-parsers/src/main/docs/univocity-fixed-dataformat.adoc[uniVocity Fixed Length] (camel-univocity-parsers) | Camel UniVocity parsers data format support
>> -
>> -| link:camel-univocity-parsers/src/main/docs/univocity-tsv-dataformat.adoc[uniVocity TSV] (camel-univocity-parsers) | Camel UniVocity parsers data format support
>> -
>> -| link:camel-xmlbeans/src/main/docs/xmlBeans-dataformat.adoc[XML Beans] (camel-xmlbeans) | Camel XMLBeans support
>> -
>> -| link:camel-xmljson/src/main/docs/xmljson-dataformat.adoc[XML JSon] (camel-xmljson) | Camel XML JSON Data Format
>> -
>> -| link:camel-xmlrpc/src/main/docs/xmlrpc-dataformat.adoc[XML RPC] (camel-xmlrpc) | Camel XML RPC support
>> -
>> -| link:camel-xmlsecurity/src/main/docs/secureXML-dataformat.adoc[XML Security] (camel-xmlsecurity) | Camel Partial XML Encryption/Decryption and XML Signature support
>> -
>> -| link:camel-xstream/src/main/docs/xstream-dataformat.adoc[XStream] (camel-xstream) | Camel XStream support
>> -
>> -| link:camel-snakeyaml/src/main/docs/yaml-snakeyaml-dataformat.adoc[YAML SnakeYAML] (camel-snakeyaml) | Camel SnakeYAML support
>> -
>> -| link:camel-zipfile/src/main/docs/zipfile-dataformat.adoc[Zip File] (camel-zipfile) | Camel Zip file support
>> |=======================================================================
>> // dataformats: END
>>
>> @@ -723,27 +339,9 @@ Expression Languages
>>
>> | link:camel-hl7/src/main/docs/terser-language.adoc[HL7 Terser] (camel-hl7) | For HL7 terser expressions and predicates
>>
>> -| link:camel-script/src/main/docs/javaScript-language.adoc[JavaScript] (camel-script) | For JavaScript expressions and predicates
>> -
>> -| link:camel-jsonpath/src/main/docs/jsonpath-language.adoc[JSonPath] (camel-jsonpath) | For JSonPath expressions and predicates
>> -
>> | link:camel-jxpath/src/main/docs/jxpath-language.adoc[JXPath] (camel-jxpath) | For JXPath expressions and predicates
>>
>> -| link:camel-mvel/src/main/docs/mvel-language.adoc[MVEL] (camel-mvel) | For MVEL expressions and predicates
>> -
>> -| link:camel-ognl/src/main/docs/ognl-language.adoc[OGNL] (camel-ognl) | For OGNL expressions and predicates
>> -
>> -| link:camel-script/src/main/docs/php-language.adoc[PHP] (camel-script) | For PHP expressions and predicates
>> -
>> -| link:camel-script/src/main/docs/python-language.adoc[Python] (camel-script) | For Python expressions and predicates
>> -
>> -| link:camel-script/src/main/docs/ruby-language.adoc[Ruby] (camel-script) | For Ruby expressions and predicates
>> -
>> | link:camel-spring/src/main/docs/spel-language.adoc[SpEL] (camel-spring) | For Spring Expression Language (SpEL) expressions and predicates
>> -
>> -| link:camel-josql/src/main/docs/sql-language.adoc[SQL] (camel-josql) | For SQL expressions and predicates
>> -
>> -| link:camel-saxon/src/main/docs/xquery-language.adoc[XQuery] (camel-saxon) | For XQuery expressions and predicates
>> |=======================================================================
>> // languages: END
>>
>
>
>
> --
> Claus Ibsen
> -----------------
> http://davsclaus.com @davsclaus
> Camel in Action 2: https://www.manning.com/ibsen2



-- 
Claus Ibsen
-----------------
http://davsclaus.com @davsclaus
Camel in Action 2: https://www.manning.com/ibsen2


Re: camel git commit: Fix CS violations

Posted by Claus Ibsen <cl...@gmail.com>.
Yeah we need to revert those .docs files.

And keep an eye on the build if it generates those two files
correctly, there may be a flaw in the camel-package-maven-plugin that
has the code for this.

On Mon, Dec 19, 2016 at 10:55 AM, Andrea Cosentino
<an...@yahoo.com.invalid> wrote:
> It looks like the build deleted the components list from readme.
>  --
> Andrea Cosentino
> ----------------------------------
> Apache Camel PMC Member
> Apache Karaf Committer
> Apache Servicemix Committer
> Email: ancosen1985@yahoo.com
> Twitter: @oscerd2
> Github: oscerd
>
>
>
> On Sunday, December 18, 2016 6:27 PM, "bvahdat@apache.org" <bv...@apache.org> wrote:
> Repository: camel
> Updated Branches:
>   refs/heads/master 079b5f9e6 -> 490a76f17
>
>
> Fix CS violations
>
> Project: http://git-wip-us.apache.org/repos/asf/camel/repo
> Commit: http://git-wip-us.apache.org/repos/asf/camel/commit/490a76f1
> Tree: http://git-wip-us.apache.org/repos/asf/camel/tree/490a76f1
> Diff: http://git-wip-us.apache.org/repos/asf/camel/diff/490a76f1
>
> Branch: refs/heads/master
> Commit: 490a76f17a1cb96a08009607a7aa972e7bc0372d
> Parents: 079b5f9
> Author: Babak Vahdat <bv...@apache.org>
> Authored: Sun Dec 18 18:26:52 2016 +0100
> Committer: Babak Vahdat <bv...@apache.org>
> Committed: Sun Dec 18 18:26:52 2016 +0100
>
> ----------------------------------------------------------------------
> .../component/bonita/BonitaConfiguration.java   |   6 +-
> .../core/xml/CamelProxyFactoryDefinition.java   |   2 +-
> .../camel/component/gridfs/GridFsEndpoint.java  |   1 -
> .../openstack/nova/KeypairProducerTest.java     |   2 +-
> .../processor/RibbonServiceCallProcessor.java   |  19 +-
> .../component/servicenow/ServiceNowClient.java  |   2 +-
> components/readme.adoc                          | 402 -------------------
> 7 files changed, 15 insertions(+), 419 deletions(-)
> ----------------------------------------------------------------------
>
>
> http://git-wip-us.apache.org/repos/asf/camel/blob/490a76f1/components/camel-bonita/src/main/java/org/apache/camel/component/bonita/BonitaConfiguration.java
> ----------------------------------------------------------------------
> diff --git a/components/camel-bonita/src/main/java/org/apache/camel/component/bonita/BonitaConfiguration.java b/components/camel-bonita/src/main/java/org/apache/camel/component/bonita/BonitaConfiguration.java
> index 7343e2c..b992682 100644
> --- a/components/camel-bonita/src/main/java/org/apache/camel/component/bonita/BonitaConfiguration.java
> +++ b/components/camel-bonita/src/main/java/org/apache/camel/component/bonita/BonitaConfiguration.java
> @@ -5,9 +5,9 @@
>   * 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
> - * <p>
> - * http://www.apache.org/licenses/LICENSE-2.0
> - * <p>
> + *
> + *      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.
>
> http://git-wip-us.apache.org/repos/asf/camel/blob/490a76f1/components/camel-core-xml/src/main/java/org/apache/camel/core/xml/CamelProxyFactoryDefinition.java
> ----------------------------------------------------------------------
> diff --git a/components/camel-core-xml/src/main/java/org/apache/camel/core/xml/CamelProxyFactoryDefinition.java b/components/camel-core-xml/src/main/java/org/apache/camel/core/xml/CamelProxyFactoryDefinition.java
> index 6f160ce..5c78b93 100644
> --- a/components/camel-core-xml/src/main/java/org/apache/camel/core/xml/CamelProxyFactoryDefinition.java
> +++ b/components/camel-core-xml/src/main/java/org/apache/camel/core/xml/CamelProxyFactoryDefinition.java
> @@ -63,7 +63,7 @@ public class CamelProxyFactoryDefinition extends IdentifiedType {
>       * @deprecated use serviceUrl instead with the ref endpoint.
>       */
>      @Deprecated
> -    public void setServiceRef(String serviceRef) {
> +    public void setServiceRef(String serviceRef) {
>          this.serviceRef = serviceRef;
>      }
>
>
> http://git-wip-us.apache.org/repos/asf/camel/blob/490a76f1/components/camel-mongodb-gridfs/src/main/java/org/apache/camel/component/gridfs/GridFsEndpoint.java
> ----------------------------------------------------------------------
> diff --git a/components/camel-mongodb-gridfs/src/main/java/org/apache/camel/component/gridfs/GridFsEndpoint.java b/components/camel-mongodb-gridfs/src/main/java/org/apache/camel/component/gridfs/GridFsEndpoint.java
> index cb8f686..f4d5d65 100644
> --- a/components/camel-mongodb-gridfs/src/main/java/org/apache/camel/component/gridfs/GridFsEndpoint.java
> +++ b/components/camel-mongodb-gridfs/src/main/java/org/apache/camel/component/gridfs/GridFsEndpoint.java
> @@ -39,7 +39,6 @@ import org.slf4j.LoggerFactory;
> @UriEndpoint(scheme = "gridfs", title = "MongoDBGridFS", syntax = "gridfs:connectionBean", label = "database,nosql")
> public class GridFsEndpoint extends DefaultEndpoint {
>
> -    ;
>      public static final String GRIDFS_OPERATION = "gridfs.operation";
>      public static final String GRIDFS_METADATA = "gridfs.metadata";
>      public static final String GRIDFS_CHUNKSIZE = "gridfs.chunksize";
>
> http://git-wip-us.apache.org/repos/asf/camel/blob/490a76f1/components/camel-openstack/src/test/java/org/apache/camel/component/openstack/nova/KeypairProducerTest.java
> ----------------------------------------------------------------------
> diff --git a/components/camel-openstack/src/test/java/org/apache/camel/component/openstack/nova/KeypairProducerTest.java b/components/camel-openstack/src/test/java/org/apache/camel/component/openstack/nova/KeypairProducerTest.java
> index c851a40..ba4813e 100644
> --- a/components/camel-openstack/src/test/java/org/apache/camel/component/openstack/nova/KeypairProducerTest.java
> +++ b/components/camel-openstack/src/test/java/org/apache/camel/component/openstack/nova/KeypairProducerTest.java
> @@ -114,6 +114,6 @@ public class KeypairProducerTest extends NovaProducerTestSupport {
>      }
>
>      private Keypair createDummyKeypair() {
> -        return NovaKeypair.create(KEYPAIR_NAME, "string contains private key");
> +        return NovaKeypair.create(KEYPAIR_NAME, "string contains private key");
>      }
> }
>
> http://git-wip-us.apache.org/repos/asf/camel/blob/490a76f1/components/camel-ribbon/src/main/java/org/apache/camel/component/ribbon/processor/RibbonServiceCallProcessor.java
> ----------------------------------------------------------------------
> diff --git a/components/camel-ribbon/src/main/java/org/apache/camel/component/ribbon/processor/RibbonServiceCallProcessor.java b/components/camel-ribbon/src/main/java/org/apache/camel/component/ribbon/processor/RibbonServiceCallProcessor.java
> index f9151ce..f701ba0 100644
> --- a/components/camel-ribbon/src/main/java/org/apache/camel/component/ribbon/processor/RibbonServiceCallProcessor.java
> +++ b/components/camel-ribbon/src/main/java/org/apache/camel/component/ribbon/processor/RibbonServiceCallProcessor.java
> @@ -19,7 +19,6 @@ package org.apache.camel.component.ribbon.processor;
> import java.util.Map;
> import java.util.concurrent.RejectedExecutionException;
>
> -import com.netflix.client.config.CommonClientConfigKey;
> import com.netflix.client.config.IClientConfig;
> import com.netflix.client.config.IClientConfigKey;
> import com.netflix.loadbalancer.DummyPing;
> @@ -46,8 +45,8 @@ import org.apache.camel.spi.IdAware;
> import org.apache.camel.spi.ServiceCallServerListStrategy;
> import org.apache.camel.support.ServiceSupport;
> import org.apache.camel.util.AsyncProcessorHelper;
> -import org.apache.camel.util.ObjectHelper;
> import org.apache.camel.util.ServiceHelper;
> +import org.apache.camel.util.StringHelper;
> import org.slf4j.Logger;
> import org.slf4j.LoggerFactory;
>
> @@ -78,18 +77,18 @@ public class RibbonServiceCallProcessor extends ServiceSupport implements AsyncP
>          // setup from the provided name which can contain scheme and context-path information as well
>          String serviceName;
>          if (name.contains("/")) {
> -            serviceName = ObjectHelper.before(name, "/");
> -            this.contextPath = ObjectHelper.after(name, "/");
> +            serviceName = StringHelper.before(name, "/");
> +            this.contextPath = StringHelper.after(name, "/");
>          } else if (name.contains("?")) {
> -            serviceName = ObjectHelper.before(name, "?");
> -            this.contextPath = ObjectHelper.after(name, "?");
> +            serviceName = StringHelper.before(name, "?");
> +            this.contextPath = StringHelper.after(name, "?");
>          } else {
>              serviceName = name;
>              this.contextPath = null;
>          }
>          if (serviceName.contains(":")) {
> -            this.scheme = ObjectHelper.before(serviceName, ":");
> -            this.name = ObjectHelper.after(serviceName, ":");
> +            this.scheme = StringHelper.before(serviceName, ":");
> +            this.name = StringHelper.after(serviceName, ":");
>          } else {
>              this.scheme = scheme;
>              this.name = serviceName;
> @@ -199,7 +198,7 @@ public class RibbonServiceCallProcessor extends ServiceSupport implements AsyncP
>      @Override
>      @SuppressWarnings("unchecked")
>      protected void doStart() throws Exception {
> -        ObjectHelper.notEmpty(name, "name", this);
> +        StringHelper.notEmpty(name, "name", this);
>
>          if (serverListStrategy == null) {
>              serverListStrategy = new RibbonServiceCallStaticServerListStrategy();
> @@ -222,7 +221,7 @@ public class RibbonServiceCallProcessor extends ServiceSupport implements AsyncP
>          IClientConfig config = IClientConfig.Builder.newBuilder(name).build();
>          if (ribbonClientConfig != null) {
>              for (Map.Entry<String, String> entry : ribbonClientConfig.entrySet()) {
> -                IClientConfigKey key = CommonClientConfigKey.valueOf(entry.getKey());
> +                IClientConfigKey key = IClientConfigKey.Keys.valueOf(entry.getKey());
>                  String value = entry.getValue();
>                  LOG.debug("RibbonClientConfig: {}={}", key.key(), value);
>                  config.set(key, entry.getValue());
>
> http://git-wip-us.apache.org/repos/asf/camel/blob/490a76f1/components/camel-servicenow/src/main/java/org/apache/camel/component/servicenow/ServiceNowClient.java
> ----------------------------------------------------------------------
> diff --git a/components/camel-servicenow/src/main/java/org/apache/camel/component/servicenow/ServiceNowClient.java b/components/camel-servicenow/src/main/java/org/apache/camel/component/servicenow/ServiceNowClient.java
> index 2bdd86a..fa33607 100644
> --- a/components/camel-servicenow/src/main/java/org/apache/camel/component/servicenow/ServiceNowClient.java
> +++ b/components/camel-servicenow/src/main/java/org/apache/camel/component/servicenow/ServiceNowClient.java
> @@ -162,7 +162,7 @@ public final class ServiceNowClient {
>      }
>
>      private static void configureTls(
> -        CamelContext camelContext, ServiceNowConfiguration configuration, WebClient client) throws Exception{
> +        CamelContext camelContext, ServiceNowConfiguration configuration, WebClient client) throws Exception {
>
>          SSLContextParameters sslContextParams = configuration.getSslContextParameters();
>          if (sslContextParams != null) {
>
> http://git-wip-us.apache.org/repos/asf/camel/blob/490a76f1/components/readme.adoc
> ----------------------------------------------------------------------
> diff --git a/components/readme.adoc b/components/readme.adoc
> index 6d1eb1a..81b3828 100644
> --- a/components/readme.adoc
> +++ b/components/readme.adoc
> @@ -15,12 +15,6 @@ Components
> | link:camel-amqp/src/main/docs/amqp-component.adoc[AMQP] (camel-amqp) +
> `amqp:destinationType:destinationName` | Messaging with AMQP protocol using Apache QPid Client.
>
> -| link:camel-flink/src/main/docs/flink-component.adoc[Apache Flink] (camel-flink) +
> -`flink:endpointType` | The flink component can be used to send DataSet jobs to Apache Flink cluster.
> -
> -| link:camel-spark/src/main/docs/spark-component.adoc[Apache Spark] (camel-spark) +
> -`spark:endpointType` | The spark component can be used to send RDD or DataFrame jobs to Apache Spark cluster.
> -
> | link:camel-apns/src/main/docs/apns-component.adoc[APNS] (camel-apns) +
> `apns:name` | For sending notifications to Apple iOS devices.
>
> @@ -141,249 +135,60 @@ Components
> | link:camel-drill/src/main/docs/drill-component.adoc[Drill] (camel-drill) +
> `drill:host` | The drill component gives you the ability to quering into apache drill cluster.
>
> -| link:camel-dropbox/src/main/docs/dropbox-component.adoc[Dropbox] (camel-dropbox) +
> -`dropbox:operation` | For uploading downloading and managing files folders groups collaborations etc on dropbox DOT com.
> -
> | link:camel-cache/src/main/docs/cache-component.adoc[EHCache] (camel-cache) +
> `cache:cacheName` | *deprecated* The cache component enables you to perform caching operations using EHCache as the Cache Implementation.
>
> -| link:camel-ehcache/src/main/docs/ehcache-component.adoc[Ehcache] (camel-ehcache) +
> -`ehcache:cacheName` | The ehcache component enables you to perform caching operations using Ehcache as cache implementation.
> -
> -| link:camel-ejb/src/main/docs/ejb-component.adoc[EJB] (camel-ejb) +
> -`ejb:beanName` | The ejb component is for invoking EJB Java beans from Camel.
> -
> -| link:camel-elasticsearch/src/main/docs/elasticsearch-component.adoc[Elasticsearch] (camel-elasticsearch) +
> -`elasticsearch:clusterName` | The elasticsearch component is used for interfacing with ElasticSearch server.
> -
> -| link:camel-elsql/src/main/docs/elsql-component.adoc[ElSQL] (camel-elsql) +
> -`elsql:elsqlName:resourceUri` | The elsql component is an extension to the existing SQL Component that uses ElSql to define the SQL queries.
> -
> -| link:camel-etcd/src/main/docs/etcd-component.adoc[etcd] (camel-etcd) +
> -`etcd:namespace/path` | The camel etcd component allows you to work with Etcd a distributed A distributed reliable key-value store.
> -
> -| link:camel-exec/src/main/docs/exec-component.adoc[Exec] (camel-exec) +
> -`exec:executable` | The exec component can be used to execute OS system commands.
> -
> -| link:camel-facebook/src/main/docs/facebook-component.adoc[Facebook] (camel-facebook) +
> -`facebook:methodName` | The Facebook component provides access to all of the Facebook APIs accessible using Facebook4J.
> -
> -| link:camel-flatpack/src/main/docs/flatpack-component.adoc[Flatpack] (camel-flatpack) +
> -`flatpack:type:resourceUri` | The flatpack component supports fixed width and delimited file parsing via the FlatPack library.
> -
> -| link:camel-fop/src/main/docs/fop-component.adoc[FOP] (camel-fop) +
> -`fop:outputType` | The fop component allows you to render a message into different output formats using Apache FOP.
> -
> -| link:camel-freemarker/src/main/docs/freemarker-component.adoc[Freemarker] (camel-freemarker) +
> -`freemarker:resourceUri` | Transforms the message using a FreeMarker template.
> -
> -| link:camel-ftp/src/main/docs/ftp-component.adoc[FTP] (camel-ftp) +
> -`ftp:host:port/directoryName` | The ftp component is used for uploading or downloading files from FTP servers.
> -
> -| link:camel-ftp/src/main/docs/ftps-component.adoc[FTPS] (camel-ftp) +
> -`ftps:host:port/directoryName` | The ftps (FTP secure SSL/TLS) component is used for uploading or downloading files from FTP servers.
> -
> -| link:camel-ganglia/src/main/docs/ganglia-component.adoc[Ganglia] (camel-ganglia) +
> -`ganglia:host:port` | The ganglia component is used for sending metrics to the Ganglia monitoring system.
> -
> -| link:camel-geocoder/src/main/docs/geocoder-component.adoc[Geocoder] (camel-geocoder) +
> -`geocoder:address:latlng` | The geocoder component is used for looking up geocodes (latitude and longitude) for a given address or reverse lookup.
> -
> -| link:camel-git/src/main/docs/git-component.adoc[Git] (camel-git) +
> -`git:localPath` | The git component is used for working with git repositories.
> -
> -| link:camel-github/src/main/docs/github-component.adoc[GitHub] (camel-github) +
> -`github:type/branchName` | The github component is used for integrating Camel with github.
> -
> | link:camel-google-calendar/src/main/docs/google-calendar-component.adoc[Google Calendar] (camel-google-calendar) +
> `google-calendar:apiName/methodName` | The google-calendar component provides access to Google Calendar.
>
> -| link:camel-google-drive/src/main/docs/google-drive-component.adoc[Google Drive] (camel-google-drive) +
> -`google-drive:apiName/methodName` | The google-drive component provides access to Google Drive file storage service.
> -
> -| link:camel-google-mail/src/main/docs/google-mail-component.adoc[Google Mail] (camel-google-mail) +
> -`google-mail:apiName/methodName` | The google-mail component provides access to Google Mail.
> -
> | link:camel-google-pubsub/src/main/docs/google-pubsub-component.adoc[Google Pubsub] (camel-google-pubsub) +
> `google-pubsub:projectId:destinationName` | Messaging client for Google Cloud Platform PubSub Service: https://cloud.google.com/pubsub/
>
> -| link:camel-gora/src/main/docs/gora-component.adoc[Gora] (camel-gora) +
> -`gora:name` | The gora component allows you to work with NoSQL databases using the Apache Gora framework.
> -
> | link:camel-grape/src/main/docs/grape-component.adoc[Grape] (camel-grape) +
> `grape:defaultCoordinates` | Grape component allows you to fetch, load and manage additional jars when CamelContext is running.
>
> -| link:camel-guava-eventbus/src/main/docs/guava-eventbus-component.adoc[Guava EventBus] (camel-guava-eventbus) +
> -`guava-eventbus:eventBusRef` | The guava-eventbus component provides integration bridge between Camel and Google Guava EventBus.
> -
> -| link:camel-hazelcast/src/main/docs/hazelcast-component.adoc[Hazelcast] (camel-hazelcast) +
> -`hazelcast:command:cacheName` | The hazelcast component allows you to work with the Hazelcast distributed data grid / cache.
> -
> -| link:camel-hbase/src/main/docs/hbase-component.adoc[HBase] (camel-hbase) +
> -`hbase:tableName` | For reading/writing from/to an HBase store (Hadoop database).
> -
> -| link:camel-hdfs/src/main/docs/hdfs-component.adoc[HDFS] (camel-hdfs) +
> -`hdfs:hostName:port/path` | *deprecated* For reading/writing from/to an HDFS filesystem using Hadoop 1.x.
> -
> -| link:camel-hdfs2/src/main/docs/hdfs2-component.adoc[HDFS2] (camel-hdfs2) +
> -`hdfs2:hostName:port/path` | For reading/writing from/to an HDFS filesystem using Hadoop 2.x.
> -
> -| link:camel-hipchat/src/main/docs/hipchat-component.adoc[Hipchat] (camel-hipchat) +
> -`hipchat:protocol:host:port` | The hipchat component supports producing and consuming messages from/to Hipchat service.
> -
> | link:camel-http/src/main/docs/http-component.adoc[HTTP] (camel-http) +
> `http:httpUri` | For calling out to external HTTP servers using Apache HTTP Client 3.x.
>
> | link:camel-http4/src/main/docs/http4-component.adoc[HTTP4] (camel-http4) +
> `http4:httpUri` | For calling out to external HTTP servers using Apache HTTP Client 4.x.
>
> -| link:camel-ibatis/src/main/docs/ibatis-component.adoc[iBatis] (camel-ibatis) +
> -`ibatis:statement` | *deprecated* Performs a query poll insert update or delete in a relational database using Apache iBATIS.
> -
> -| link:camel-mail/src/main/docs/imap-component.adoc[IMAP] (camel-mail) +
> -`imap:host:port` | To send or receive emails using imap/pop3 or stmp protocols.
> -
> | link:camel-infinispan/src/main/docs/infinispan-component.adoc[Infinispan] (camel-infinispan) +
> `infinispan:host` | For reading/writing from/to Infinispan distributed key/value store and data grid.
>
> -| link:camel-influxdb/src/main/docs/influxdb-component.adoc[InfluxDB] (camel-influxdb) +
> -`influxdb:connectionBean` | The influxdb component allows you to interact with InfluxDB a time series database.
> -
> -| link:camel-irc/src/main/docs/irc-component.adoc[IRC] (camel-irc) +
> -`irc:hostname:port` | The irc component implements an IRC (Internet Relay Chat) transport.
> -
> | link:camel-ironmq/src/main/docs/ironmq-component.adoc[ironmq] (camel-ironmq) +
> `ironmq:queueName` | The ironmq provides integration with IronMQ an elastic and durable hosted message queue as a service.
>
> -| link:camel-javaspace/src/main/docs/javaspace-component.adoc[JavaSpace] (camel-javaspace) +
> -`javaspace:url` | *deprecated* Sending and receiving messages through JavaSpace.
> -
> -| link:camel-jbpm/src/main/docs/jbpm-component.adoc[JBPM] (camel-jbpm) +
> -`jbpm:connectionURL` | The jbpm component provides integration with jBPM (Business Process Management).
> -
> | link:camel-jcache/src/main/docs/jcache-component.adoc[JCache] (camel-jcache) +
> `jcache:cacheName` | The jcache component enables you to perform caching operations using JSR107/JCache as cache implementation.
>
> -| link:camel-jclouds/src/main/docs/jclouds-component.adoc[JClouds] (camel-jclouds) +
> -`jclouds:command:providerId` | For interacting with cloud compute & blobstore service via jclouds.
> -
> -| link:camel-jcr/src/main/docs/jcr-component.adoc[JCR] (camel-jcr) +
> -`jcr:host/base` | The jcr component allows you to add/read nodes to/from a JCR compliant content repository.
> -
> -| link:camel-jdbc/src/main/docs/jdbc-component.adoc[JDBC] (camel-jdbc) +
> -`jdbc:dataSourceName` | The jdbc component enables you to access databases through JDBC where SQL queries are sent in the message body.
> -
> | link:camel-jetty9/src/main/docs/jetty-component.adoc[Jetty 9] (camel-jetty9) +
> `jetty:httpUri` | The jetty component provides HTTP-based endpoints for consuming and producing HTTP requests.
>
> | link:camel-websocket/src/main/docs/websocket-component.adoc[Jetty Websocket] (camel-websocket) +
> `websocket:host:port/resourceUri` | The websocket component provides websocket endpoints for communicating with clients using websocket.
>
> -| link:camel-jgroups/src/main/docs/jgroups-component.adoc[JGroups] (camel-jgroups) +
> -`jgroups:clusterName` | The jgroups component provides exchange of messages between Camel and JGroups clusters.
> -
> -| link:camel-jing/src/main/docs/jing-component.adoc[Jing] (camel-jing) +
> -`jing:resourceUri` | Validates the payload of a message using RelaxNG Syntax using Jing library.
> -
> -| link:camel-jira/src/main/docs/jira-component.adoc[JIRA] (camel-jira) +
> -`jira:type` | The jira component interacts with the JIRA issue tracker.
> -
> | link:camel-jms/src/main/docs/jms-component.adoc[JMS] (camel-jms) +
> `jms:destinationType:destinationName` | The jms component allows messages to be sent to (or consumed from) a JMS Queue or Topic.
>
> -| link:camel-jmx/src/main/docs/jmx-component.adoc[JMX] (camel-jmx) +
> -`jmx:serverURL` | The jmx component allows to receive JMX notifications.
> -
> -| link:camel-jolt/src/main/docs/jolt-component.adoc[JOLT] (camel-jolt) +
> -`jolt:resourceUri` | The jolt component allows you to process a JSON messages using an JOLT specification (such as JSON-JSON transformation).
> -
> -| link:camel-jpa/src/main/docs/jpa-component.adoc[JPA] (camel-jpa) +
> -`jpa:entityType` | The jpa component enables you to store and retrieve Java objects from databases using JPA.
> -
> -| link:camel-jt400/src/main/docs/jt400-component.adoc[JT400] (camel-jt400) +
> -`jt400:userID:password/systemName/objectPath.type` | The jt400 component allows you to exchanges messages with an AS/400 system using data queues or program call.
> -
> | link:camel-kafka/src/main/docs/kafka-component.adoc[Kafka] (camel-kafka) +
> `kafka:brokers` | The kafka component allows messages to be sent to (or consumed from) Apache Kafka brokers.
>
> -| link:camel-kestrel/src/main/docs/kestrel-component.adoc[Kestrel] (camel-kestrel) +
> -`kestrel:addresses/queue` | *deprecated* The kestrel component allows messages to be sent to (or consumed from) Kestrel brokers.
> -
> -| link:camel-krati/src/main/docs/krati-component.adoc[Krati] (camel-krati) +
> -`krati:path` | The krati allows the use krati datastores and datasets inside Camel.
> -
> -| link:camel-kubernetes/src/main/docs/kubernetes-component.adoc[Kubernetes] (camel-kubernetes) +
> -`kubernetes:masterUrl` | The kubernetes component allows to work with Kubernetes PaaS.
> -
> -| link:camel-ldap/src/main/docs/ldap-component.adoc[LDAP] (camel-ldap) +
> -`ldap:dirContextName` | The ldap component allows you to perform searches in LDAP servers using filters as the message payload.
> -
> -| link:camel-linkedin/src/main/docs/linkedin-component.adoc[Linkedin] (camel-linkedin) +
> -`linkedin:apiName/methodName` | The linkedin component is uses for retrieving LinkedIn user profiles connections companies groups posts etc.
> -
> -| link:camel-lucene/src/main/docs/lucene-component.adoc[Lucene] (camel-lucene) +
> -`lucene:host:operation` | To insert or query from Apache Lucene databases.
> -
> -| link:camel-lumberjack/src/main/docs/lumberjack-component.adoc[Lumberjack] (camel-lumberjack) +
> -`lumberjack:host:port` | The lumberjack retrieves logs sent over the network using the Lumberjack protocol.
> -
> | link:camel-metrics/src/main/docs/metrics-component.adoc[Metrics] (camel-metrics) +
> `metrics:metricsType:metricsName` | To collect various metrics directly from Camel routes using the DropWizard metrics library.
>
> -| link:camel-mina/src/main/docs/mina-component.adoc[Mina] (camel-mina) +
> -`mina:protocol:host:port` | *deprecated* Socket level networking using TCP or UDP with the Apache Mina 1.x library.
> -
> -| link:camel-mina2/src/main/docs/mina2-component.adoc[Mina2] (camel-mina2) +
> -`mina2:protocol:host:port` | Socket level networking using TCP or UDP with the Apache Mina 2.x library.
> -
> | link:camel-mllp/src/main/docs/mllp-component.adoc[MLLP] (camel-mllp) +
> `mllp:hostname:port` | The MLLP component is designed to handle the MLLP protocol and provide the functionality required by Healthcare providers to communicate with other systems using the MLLP protocol.
>
> | link:camel-mongodb/src/main/docs/mongodb-component.adoc[MongoDB] (camel-mongodb) +
> `mongodb:connectionBean` | Component for working with documents stored in MongoDB database.
>
> -| link:camel-mongodb3/src/main/docs/mongodb3-component.adoc[MongoDB] (camel-mongodb3) +
> -`mongodb3:connectionBean` | Component for working with documents stored in MongoDB database.
> -
> -| link:camel-mongodb-gridfs/src/main/docs/gridfs-component.adoc[MongoDBGridFS] (camel-mongodb-gridfs) +
> -`gridfs:connectionBean` | Component for working with MongoDB GridFS.
> -
> -| link:camel-mqtt/src/main/docs/mqtt-component.adoc[MQTT] (camel-mqtt) +
> -`mqtt:name` | Component for communicating with MQTT M2M message brokers using FuseSource MQTT Client.
> -
> -| link:camel-msv/src/main/docs/msv-component.adoc[MSV] (camel-msv) +
> -`msv:resourceUri` | Validates the payload of a message using the MSV Library.
> -
> -| link:camel-mustache/src/main/docs/mustache-component.adoc[Mustache] (camel-mustache) +
> -`mustache:resourceUri` | Transforms the message using a Mustache template.
> -
> -| link:camel-mvel/src/main/docs/mvel-component.adoc[MVEL] (camel-mvel) +
> -`mvel:resourceUri` | Transforms the message using a MVEL template.
> -
> -| link:camel-mybatis/src/main/docs/mybatis-component.adoc[MyBatis] (camel-mybatis) +
> -`mybatis:statement` | Performs a query poll insert update or delete in a relational database using MyBatis.
> -
> -| link:camel-nagios/src/main/docs/nagios-component.adoc[Nagios] (camel-nagios) +
> -`nagios:host:port` | To send passive checks to Nagios using JSendNSCA.
> -
> -| link:camel-nats/src/main/docs/nats-component.adoc[Nats] (camel-nats) +
> -`nats:servers` | The nats component allows you produce and consume messages from NATS.
> -
> -| link:camel-netty/src/main/docs/netty-component.adoc[Netty] (camel-netty) +
> -`netty:protocol:host:port` | *deprecated* Socket level networking using TCP or UDP with the Netty 3.x library.
> -
> -| link:camel-netty-http/src/main/docs/netty-http-component.adoc[Netty HTTP] (camel-netty-http) +
> -`netty-http:protocol:host:port/path` | *deprecated* Netty HTTP server and client using the Netty 3.x library.
> -
> | link:camel-netty4/src/main/docs/netty4-component.adoc[Netty4] (camel-netty4) +
> `netty4:protocol:host:port` | Socket level networking using TCP or UDP with the Netty 4.x library.
>
> | link:camel-netty4-http/src/main/docs/netty4-http-component.adoc[Netty4 HTTP] (camel-netty4-http) +
> `netty4-http:protocol:host:port/path` | Netty HTTP server and client using the Netty 4.x library.
>
> -| link:camel-openshift/src/main/docs/openshift-component.adoc[OpenShift] (camel-openshift) +
> -`openshift:clientId` | *deprecated* To manage your Openshift 2.x applications.
> -
> | link:camel-openstack/src/main/docs/openstack-cinder-component.adoc[OpenStack-Cinder] (camel-openstack) +
> `openstack-cinder:host` | Camel Components
>
> @@ -402,174 +207,33 @@ Components
> | link:camel-openstack/src/main/docs/openstack-swift-component.adoc[OpenStack-Swift] (camel-openstack) +
> `openstack-swift:host` | Camel Components
>
> -| link:camel-optaplanner/src/main/docs/optaplanner-component.adoc[OptaPlanner] (camel-optaplanner) +
> -`optaplanner:configFile` | Solves the planning problem contained in a message with OptaPlanner.
> -
> -| link:camel-eventadmin/src/main/docs/eventadmin-component.adoc[OSGi EventAdmin] (camel-eventadmin) +
> -`eventadmin:topic` | The eventadmin component can be used in an OSGi environment to receive OSGi EventAdmin events and process them.
> -
> -| link:camel-paxlogging/src/main/docs/paxlogging-component.adoc[OSGi PAX Logging] (camel-paxlogging) +
> -`paxlogging:appender` | The paxlogging component can be used in an OSGi environment to receive PaxLogging events and process them.
> -
> -| link:camel-paho/src/main/docs/paho-component.adoc[Paho] (camel-paho) +
> -`paho:topic` | Component for communicating with MQTT M2M message brokers using Eclipse Paho MQTT Client.
> -
> -| link:camel-pdf/src/main/docs/pdf-component.adoc[PDF] (camel-pdf) +
> -`pdf:operation` | The pdf components provides the ability to create modify or extract content from PDF documents.
> -
> -| link:camel-pgevent/src/main/docs/pgevent-component.adoc[PostgresSQL Event] (camel-pgevent) +
> -`pgevent:host:port/database/channel` | The pgevent component allows for producing/consuming PostgreSQL events related to the LISTEN/NOTIFY commands.
> -
> -| link:camel-printer/src/main/docs/lpr-component.adoc[Printer] (camel-printer) +
> -`lpr:hostname:port/printername` | The printer component is used for sending messages to printers as print jobs.
> -
> -| link:camel-quartz/src/main/docs/quartz-component.adoc[Quartz] (camel-quartz) +
> -`quartz:groupName/timerName` | *deprecated* Provides a scheduled delivery of messages using the Quartz 1.x scheduler.
> -
> -| link:camel-quartz2/src/main/docs/quartz2-component.adoc[Quartz2] (camel-quartz2) +
> -`quartz2:groupName/triggerName` | Provides a scheduled delivery of messages using the Quartz 2.x scheduler.
> -
> -| link:camel-quickfix/src/main/docs/quickfix-component.adoc[QuickFix] (camel-quickfix) +
> -`quickfix:configurationName` | The quickfix component allows to send Financial Interchange (FIX) messages to the QuickFix engine.
> -
> -| link:camel-rabbitmq/src/main/docs/rabbitmq-component.adoc[RabbitMQ] (camel-rabbitmq) +
> -`rabbitmq:hostname:portNumber/exchangeName` | The rabbitmq component allows you produce and consume messages from RabbitMQ instances.
> -
> -| link:camel-restlet/src/main/docs/restlet-component.adoc[Restlet] (camel-restlet) +
> -`restlet:protocol:host:port/uriPattern` | Component for consuming and producing Restful resources using Restlet.
> -
> -| link:camel-rmi/src/main/docs/rmi-component.adoc[RMI] (camel-rmi) +
> -`rmi:hostname:port/name` | The rmi component is for invoking Java RMI beans from Camel.
> -
> -| link:camel-routebox/src/main/docs/routebox-component.adoc[RouteBox] (camel-routebox) +
> -`routebox:routeboxName` | *deprecated* The routebox component allows to send/receive messages between Camel routes in a black box way.
> -
> -| link:camel-rss/src/main/docs/rss-component.adoc[RSS] (camel-rss) +
> -`rss:feedUri` | The rss component is used for consuming RSS feeds.
> -
> | link:camel-salesforce/src/main/docs/salesforce-component.adoc[Salesforce] (camel-salesforce) +
> `salesforce:operationName:topicName` | The salesforce component is used for integrating Camel with the massive Salesforce API.
>
> -| link:camel-sap-netweaver/src/main/docs/sap-netweaver-component.adoc[SAP NetWeaver] (camel-sap-netweaver) +
> -`sap-netweaver:url` | The sap-netweaver component integrates with the SAP NetWeaver Gateway using HTTP transports.
> -
> -| link:camel-schematron/src/main/docs/schematron-component.adoc[Schematron] (camel-schematron) +
> -`schematron:path` | Validates the payload of a message using the Schematron Library.
> -
> -| link:camel-jsch/src/main/docs/scp-component.adoc[SCP] (camel-jsch) +
> -`scp:host:port/directoryName` | To copy files using the secure copy protocol (SCP).
> -
> -| link:camel-servicenow/src/main/docs/servicenow-component.adoc[ServiceNow] (camel-servicenow) +
> -`servicenow:instanceName` | The servicenow component is used to integrate Camel with ServiceNow cloud services.
> -
> | link:camel-servlet/src/main/docs/servlet-component.adoc[Servlet] (camel-servlet) +
> `servlet:contextPath` | To use a HTTP Servlet as entry for Camel routes when running in a servlet container.
>
> -| link:camel-ftp/src/main/docs/sftp-component.adoc[SFTP] (camel-ftp) +
> -`sftp:host:port/directoryName` | The sftp (FTP over SSH) component is used for uploading or downloading files from SFTP servers.
> -
> -| link:camel-sjms/src/main/docs/sjms-component.adoc[Simple JMS] (camel-sjms) +
> -`sjms:destinationType:destinationName` | The sjms component (simple jms) allows messages to be sent to (or consumed from) a JMS Queue or Topic.
> -
> -| link:camel-sjms/src/main/docs/sjms-batch-component.adoc[Simple JMS Batch] (camel-sjms) +
> -`sjms-batch:destinationName` | The sjms-batch component is a specialized for highly performant transactional batch consumption from a JMS queue.
> -
> -| link:camel-sip/src/main/docs/sip-component.adoc[SIP] (camel-sip) +
> -`sip:uri` | To send and receive messages using the SIP protocol (used in telco and mobile).
> -
> -| link:camel-slack/src/main/docs/slack-component.adoc[Slack] (camel-slack) +
> -`slack:channel` | The slack component allows you to send messages to Slack.
> -
> | link:camel-smpp/src/main/docs/smpp-component.adoc[SMPP] (camel-smpp) +
> `smpp:host:port` | To send and receive SMS using a SMSC (Short Message Service Center).
>
> -| link:camel-snmp/src/main/docs/snmp-component.adoc[SNMP] (camel-snmp) +
> -`snmp:host:port` | The snmp component gives you the ability to poll SNMP capable devices or receiving traps.
> -
> -| link:camel-solr/src/main/docs/solr-component.adoc[Solr] (camel-solr) +
> -`solr:url` | The solr component allows you to interface with an Apache Lucene Solr server.
> -
> -| link:camel-spark-rest/src/main/docs/spark-rest-component.adoc[Spark Rest] (camel-spark-rest) +
> -`spark-rest:verb:path` | The spark-rest component is used for hosting REST services which has been defined using Camel rest-dsl.
> -
> -| link:camel-splunk/src/main/docs/splunk-component.adoc[Splunk] (camel-splunk) +
> -`splunk:name` | The splunk component allows to publish or search for events in Splunk.
> -
> -| link:camel-spring-batch/src/main/docs/spring-batch-component.adoc[Spring Batch] (camel-spring-batch) +
> -`spring-batch:jobName` | The spring-batch component allows to send messages to Spring Batch for further processing.
> -
> | link:camel-spring/src/main/docs/spring-event-component.adoc[Spring Event] (camel-spring) +
> `spring-event:name` | The spring-event component allows to listen for Spring Application Events.
>
> -| link:camel-spring-integration/src/main/docs/spring-integration-component.adoc[Spring Integration] (camel-spring-integration) +
> -`spring-integration:defaultChannel` | Bridges Camel with Spring Integration.
> -
> -| link:camel-spring-ldap/src/main/docs/spring-ldap-component.adoc[Spring LDAP] (camel-spring-ldap) +
> -`spring-ldap:templateName` | The spring-ldap component allows you to perform searches in LDAP servers using filters as the message payload.
> -
> -| link:camel-spring-redis/src/main/docs/spring-redis-component.adoc[Spring Redis] (camel-spring-redis) +
> -`spring-redis:host:port` | The spring-redis component allows sending and receiving messages from Redis.
> -
> -| link:camel-spring-ws/src/main/docs/spring-ws-component.adoc[Spring WebService] (camel-spring-ws) +
> -`spring-ws:type:lookupKey:webServiceEndpointUri` | The spring-ws component is used for SOAP WebServices using Spring WebServices.
> -
> | link:camel-sql/src/main/docs/sql-component.adoc[SQL] (camel-sql) +
> `sql:query` | The sql component allows you to work with databases using JDBC SQL queries.
>
> | link:camel-sql/src/main/docs/sql-stored-component.adoc[SQL StoredProcedure] (camel-sql) +
> `sql-stored:template` | The sql component allows you to work with databases using JDBC Stored Procedure queries.
>
> -| link:camel-ssh/src/main/docs/ssh-component.adoc[SSH] (camel-ssh) +
> -`ssh:host:port` | The ssh component enables access to SSH servers such that you can send an SSH command and process the response.
> -
> -| link:camel-stax/src/main/docs/stax-component.adoc[StAX] (camel-stax) +
> -`stax:contentHandlerClass` | The stax component allows messages to be process through a SAX ContentHandler.
> -
> -| link:camel-stomp/src/main/docs/stomp-component.adoc[Stomp] (camel-stomp) +
> -`stomp:destination` | The stomp component is used for communicating with Stomp compliant message brokers.
> -
> | link:camel-stream/src/main/docs/stream-component.adoc[Stream] (camel-stream) +
> `stream:kind` | The stream: component provides access to the system-in system-out and system-err streams as well as allowing streaming of file and URL.
>
> -| link:camel-stringtemplate/src/main/docs/string-template-component.adoc[String Template] (camel-stringtemplate) +
> -`string-template:resourceUri` | Transforms the message using a String template.
> -
> -| link:camel-telegram/src/main/docs/telegram-component.adoc[Telegram] (camel-telegram) +
> -`telegram:type/authorizationToken` | The telegram component provides access to the Telegram Bot API.
> -
> -| link:camel-twitter/src/main/docs/twitter-component.adoc[Twitter] (camel-twitter) +
> -`twitter:kind` | This component integrates with Twitter to send tweets or search for tweets and more.
> -
> -| link:camel-undertow/src/main/docs/undertow-component.adoc[Undertow] (camel-undertow) +
> -`undertow:httpURI` | The undertow component provides HTTP-based endpoints for consuming and producing HTTP requests.
> -
> | link:camel-velocity/src/main/docs/velocity-component.adoc[Velocity] (camel-velocity) +
> `velocity:resourceUri` | Transforms the message using a Velocity template.
>
> -| link:camel-vertx/src/main/docs/vertx-component.adoc[Vert.x] (camel-vertx) +
> -`vertx:address` | The vertx component is used for sending and receive messages from a vertx event bus.
> -
> | link:camel-weather/src/main/docs/weather-component.adoc[Weather] (camel-weather) +
> `weather:name` | Polls the weather information from Open Weather Map.
>
> -| link:camel-xmlrpc/src/main/docs/xmlrpc-component.adoc[XML RPC] (camel-xmlrpc) +
> -`xmlrpc:address` | The xmlrpc component is used for sending messages to a XML RPC service.
> -
> -| link:camel-xmlsecurity/src/main/docs/xmlsecurity-component.adoc[XML Security] (camel-xmlsecurity) +
> -`xmlsecurity:command:name` | Used to sign and verify exchanges using the XML signature specification.
> -
> -| link:camel-xmpp/src/main/docs/xmpp-component.adoc[XMPP] (camel-xmpp) +
> -`xmpp:host:port/participant` | To send and receive messages from a XMPP (chat) server.
> -
> -| link:camel-saxon/src/main/docs/xquery-component.adoc[XQuery] (camel-saxon) +
> -`xquery:resourceUri` | Transforms the message using a XQuery template using Saxon.
> -
> -| link:camel-yammer/src/main/docs/yammer-component.adoc[Yammer] (camel-yammer) +
> -`yammer:function` | The yammer component allows you to interact with the Yammer enterprise social network.
> -
> -| link:camel-zookeeper/src/main/docs/zookeeper-component.adoc[ZooKeeper] (camel-zookeeper) +
> -`zookeeper:serverUrls/path` | The zookeeper component allows interaction with a ZooKeeper cluster.
> -
> |=======================================================================
> // components: END
>
> @@ -646,65 +310,17 @@ Data Formats
>
> | link:camel-csv/src/main/docs/csv-dataformat.adoc[CSV] (camel-csv) | Camel CSV data format support
>
> -| link:camel-flatpack/src/main/docs/flatpack-dataformat.adoc[Flatpack] (camel-flatpack) | Camel FlatPack support
> -
> | link:camel-hessian/src/main/docs/hessian-dataformat.adoc[Hessian] (camel-hessian) | Hessian serialization support
>
> | link:camel-hl7/src/main/docs/hl7-dataformat.adoc[HL7] (camel-hl7) | Camel HL7 support
>
> -| link:camel-ical/src/main/docs/ical-dataformat.adoc[iCal] (camel-ical) | Camel iCal component
> -
> | link:camel-jacksonxml/src/main/docs/jacksonxml-dataformat.adoc[JacksonXML] (camel-jacksonxml) | Camel Jackson XML support
>
> | link:camel-jaxb/src/main/docs/jaxb-dataformat.adoc[JAXB] (camel-jaxb) | Camel JAXB support
>
> -| link:camel-jibx/src/main/docs/jibx-dataformat.adoc[JiBX] (camel-jibx) | Camel Jibx support
> -
> -| link:camel-gson/src/main/docs/json-gson-dataformat.adoc[JSon GSon] (camel-gson) | Camel Gson support
> -
> | link:camel-jackson/src/main/docs/json-jackson-dataformat.adoc[JSon Jackson] (camel-jackson) | Camel Jackson support
>
> -| link:camel-johnzon/src/main/docs/json-johnzon-dataformat.adoc[JSon Johnzon] (camel-johnzon) | Camel Johnzon support
> -
> -| link:camel-xstream/src/main/docs/json-xstream-dataformat.adoc[JSon XStream] (camel-xstream) | Camel XStream support
> -
> -| link:camel-lzf/src/main/docs/lzf-dataformat.adoc[LZF Deflate Compression] (camel-lzf) | Camel LZF support
> -
> -| link:camel-mail/src/main/docs/mime-multipart-dataformat.adoc[MIME Multipart] (camel-mail) | Camel Mail support
> -
> | link:camel-crypto/src/main/docs/pgp-dataformat.adoc[PGP] (camel-crypto) | Camel Cryptographic Support
> -
> -| link:camel-protobuf/src/main/docs/protobuf-dataformat.adoc[Protobuf] (camel-protobuf) | Camel Google Protobuf data format support
> -
> -| link:camel-rss/src/main/docs/rss-dataformat.adoc[RSS] (camel-rss) | Camel RSS support
> -
> -| link:camel-soap/src/main/docs/soapjaxb-dataformat.adoc[SOAP] (camel-soap) | Camel SOAP support
> -
> -| link:camel-syslog/src/main/docs/syslog-dataformat.adoc[Syslog] (camel-syslog) | Camel Syslog support
> -
> -| link:camel-tarfile/src/main/docs/tarfile-dataformat.adoc[Tar File] (camel-tarfile) | Camel Tar file support
> -
> -| link:camel-tagsoup/src/main/docs/tidyMarkup-dataformat.adoc[TidyMarkup] (camel-tagsoup) | Camel TagSoup support
> -
> -| link:camel-univocity-parsers/src/main/docs/univocity-csv-dataformat.adoc[uniVocity CSV] (camel-univocity-parsers) | Camel UniVocity parsers data format support
> -
> -| link:camel-univocity-parsers/src/main/docs/univocity-fixed-dataformat.adoc[uniVocity Fixed Length] (camel-univocity-parsers) | Camel UniVocity parsers data format support
> -
> -| link:camel-univocity-parsers/src/main/docs/univocity-tsv-dataformat.adoc[uniVocity TSV] (camel-univocity-parsers) | Camel UniVocity parsers data format support
> -
> -| link:camel-xmlbeans/src/main/docs/xmlBeans-dataformat.adoc[XML Beans] (camel-xmlbeans) | Camel XMLBeans support
> -
> -| link:camel-xmljson/src/main/docs/xmljson-dataformat.adoc[XML JSon] (camel-xmljson) | Camel XML JSON Data Format
> -
> -| link:camel-xmlrpc/src/main/docs/xmlrpc-dataformat.adoc[XML RPC] (camel-xmlrpc) | Camel XML RPC support
> -
> -| link:camel-xmlsecurity/src/main/docs/secureXML-dataformat.adoc[XML Security] (camel-xmlsecurity) | Camel Partial XML Encryption/Decryption and XML Signature support
> -
> -| link:camel-xstream/src/main/docs/xstream-dataformat.adoc[XStream] (camel-xstream) | Camel XStream support
> -
> -| link:camel-snakeyaml/src/main/docs/yaml-snakeyaml-dataformat.adoc[YAML SnakeYAML] (camel-snakeyaml) | Camel SnakeYAML support
> -
> -| link:camel-zipfile/src/main/docs/zipfile-dataformat.adoc[Zip File] (camel-zipfile) | Camel Zip file support
> |=======================================================================
> // dataformats: END
>
> @@ -723,27 +339,9 @@ Expression Languages
>
> | link:camel-hl7/src/main/docs/terser-language.adoc[HL7 Terser] (camel-hl7) | For HL7 terser expressions and predicates
>
> -| link:camel-script/src/main/docs/javaScript-language.adoc[JavaScript] (camel-script) | For JavaScript expressions and predicates
> -
> -| link:camel-jsonpath/src/main/docs/jsonpath-language.adoc[JSonPath] (camel-jsonpath) | For JSonPath expressions and predicates
> -
> | link:camel-jxpath/src/main/docs/jxpath-language.adoc[JXPath] (camel-jxpath) | For JXPath expressions and predicates
>
> -| link:camel-mvel/src/main/docs/mvel-language.adoc[MVEL] (camel-mvel) | For MVEL expressions and predicates
> -
> -| link:camel-ognl/src/main/docs/ognl-language.adoc[OGNL] (camel-ognl) | For OGNL expressions and predicates
> -
> -| link:camel-script/src/main/docs/php-language.adoc[PHP] (camel-script) | For PHP expressions and predicates
> -
> -| link:camel-script/src/main/docs/python-language.adoc[Python] (camel-script) | For Python expressions and predicates
> -
> -| link:camel-script/src/main/docs/ruby-language.adoc[Ruby] (camel-script) | For Ruby expressions and predicates
> -
> | link:camel-spring/src/main/docs/spel-language.adoc[SpEL] (camel-spring) | For Spring Expression Language (SpEL) expressions and predicates
> -
> -| link:camel-josql/src/main/docs/sql-language.adoc[SQL] (camel-josql) | For SQL expressions and predicates
> -
> -| link:camel-saxon/src/main/docs/xquery-language.adoc[XQuery] (camel-saxon) | For XQuery expressions and predicates
> |=======================================================================
> // languages: END
>



-- 
Claus Ibsen
-----------------
http://davsclaus.com @davsclaus
Camel in Action 2: https://www.manning.com/ibsen2