You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@camel.apache.org by da...@apache.org on 2016/08/16 08:03:57 UTC

[33/51] [partial] camel git commit: CAMEL-9541: Use -component as suffix for component docs.

http://git-wip-us.apache.org/repos/asf/camel/blob/9c0b7baf/components/camel-cache/src/main/docs/cache.adoc
----------------------------------------------------------------------
diff --git a/components/camel-cache/src/main/docs/cache.adoc b/components/camel-cache/src/main/docs/cache.adoc
deleted file mode 100644
index 71ab13c..0000000
--- a/components/camel-cache/src/main/docs/cache.adoc
+++ /dev/null
@@ -1,497 +0,0 @@
-[[Cache-CacheComponent]]
-Cache Component
-~~~~~~~~~~~~~~~
-
-*Available as of Camel 2.1*
-
-The *cache* component enables you to perform caching operations using
-EHCache as the Cache Implementation. The cache itself is created on
-demand or if a cache of that name already exists then it is simply
-utilized with its original settings.
-
-This component supports producer and event based consumer endpoints.
-
-The Cache consumer is an event based consumer and can be used to listen
-and respond to specific cache activities. If you need to perform
-selections from a pre-existing cache, use the processors defined for the
-cache component.
-
-Maven users will need to add the following dependency to their `pom.xml`
-for this component:
-
-[source,xml]
-------------------------------------------------------------
-<dependency>
-    <groupId>org.apache.camel</groupId>
-    <artifactId>camel-cache</artifactId>
-    <version>x.x.x</version>
-    <!-- use the same version as your Camel core version -->
-</dependency>
-------------------------------------------------------------
-
-[[Cache-URIformat]]
-URI format
-^^^^^^^^^^
-
-[source,java]
----------------------------
-cache://cacheName[?options]
----------------------------
-
-You can append query options to the URI in the following format,
-`?option=value&option=#beanRef&...`
-
-[[Cache-Options]]
-Options
-^^^^^^^
-
-
-
-
-// component options: START
-The EHCache component supports 15 options which are listed below.
-
-
-
-{% raw %}
-[width="100%",cols="2s,1m,8",options="header"]
-|=======================================================================
-| Name | Java Type | Description
-| cacheManagerFactory | CacheManagerFactory | To use the given CacheManagerFactory for creating the CacheManager. By default the DefaultCacheManagerFactory is used.
-| configuration | CacheConfiguration | Sets the Cache configuration. Properties of the shared configuration can also be set individually.
-| configurationFile | String | Sets the location of the ehcache.xml file to load from classpath or file system. By default the file is loaded from classpath:ehcache.xml
-| cacheName | String | Name of the cache
-| maxElementsInMemory | int | The number of elements that may be stored in the defined cache in memory.
-| memoryStoreEvictionPolicy | MemoryStoreEvictionPolicy | Which eviction strategy to use when maximum number of elements in memory is reached. The strategy defines which elements to be removed. LRU - Lest Recently Used LFU - Lest Frequently Used FIFO - First In First Out
-| overflowToDisk | boolean | Specifies whether cache may overflow to disk
-| eternal | boolean | Sets whether elements are eternal. If eternal timeouts are ignored and the element never expires.
-| timeToLiveSeconds | long | The maximum time between creation time and when an element expires. Is used only if the element is not eternal
-| timeToIdleSeconds | long | The maximum amount of time between accesses before an element expires
-| diskPersistent | boolean | Whether the disk store persists between restarts of the application.
-| diskExpiryThreadIntervalSeconds | long | The number of seconds between runs of the disk expiry thread.
-| eventListenerRegistry | CacheEventListenerRegistry | To configure event listeners using the CacheEventListenerRegistry
-| cacheLoaderRegistry | CacheLoaderRegistry | To configure cache loader using the CacheLoaderRegistry
-| objectCache | boolean | Whether to turn on allowing to store non serializable objects in the cache. If this option is enabled then overflow to disk cannot be enabled as well.
-|=======================================================================
-{% endraw %}
-// component options: END
-
-
-
-
-
-// endpoint options: START
-The EHCache component supports 20 endpoint options which are listed below:
-
-{% raw %}
-[width="100%",cols="2s,1,1m,1m,5",options="header"]
-|=======================================================================
-| Name | Group | Default | Java Type | Description
-| cacheName | common |  | String | *Required* Name of the cache
-| diskExpiryThreadIntervalSeconds | common |  | long | The number of seconds between runs of the disk expiry thread.
-| diskPersistent | common | false | boolean | Whether the disk store persists between restarts of the application.
-| diskStorePath | common |  | String | This parameter is ignored. CacheManager sets it using setter injection.
-| eternal | common | false | boolean | Sets whether elements are eternal. If eternal timeouts are ignored and the element never expires.
-| key | common |  | String | The default key to use. If a key is provided in the message header then the key from the header takes precedence.
-| maxElementsInMemory | common | 1000 | int | The number of elements that may be stored in the defined cache in memory.
-| memoryStoreEvictionPolicy | common | LFU | MemoryStoreEvictionPolicy | Which eviction strategy to use when maximum number of elements in memory is reached. The strategy defines which elements to be removed. LRU - Lest Recently Used LFU - Lest Frequently Used FIFO - First In First Out
-| objectCache | common | false | boolean | Whether to turn on allowing to store non serializable objects in the cache. If this option is enabled then overflow to disk cannot be enabled as well.
-| operation | common |  | String | The default cache operation to use. If an operation in the message header then the operation from the header takes precedence.
-| overflowToDisk | common | true | boolean | Specifies whether cache may overflow to disk
-| timeToIdleSeconds | common | 300 | long | The maximum amount of time between accesses before an element expires
-| timeToLiveSeconds | common | 300 | long | The maximum time between creation time and when an element expires. Is used only if the element is not eternal
-| bridgeErrorHandler | consumer | false | boolean | Allows for bridging the consumer to the Camel routing Error Handler which mean any exceptions occurred while the consumer is trying to pickup incoming messages or the likes will now be processed as a message and handled by the routing Error Handler. By default the consumer will use the org.apache.camel.spi.ExceptionHandler to deal with exceptions that will be logged at WARN/ERROR level and ignored.
-| exceptionHandler | consumer (advanced) |  | ExceptionHandler | To let the consumer use a custom ExceptionHandler. Notice if the option bridgeErrorHandler is enabled then this options is not in use. By default the consumer will deal with exceptions that will be logged at WARN/ERROR level and ignored.
-| cacheLoaderRegistry | advanced |  | CacheLoaderRegistry | To configure cache loader using the CacheLoaderRegistry
-| cacheManagerFactory | advanced |  | CacheManagerFactory | To use a custom CacheManagerFactory for creating the CacheManager to be used by this endpoint. By default the CacheManagerFactory configured on the component is used.
-| eventListenerRegistry | advanced |  | CacheEventListenerRegistry | To configure event listeners using the CacheEventListenerRegistry
-| exchangePattern | advanced | InOnly | ExchangePattern | Sets the default exchange pattern when creating an exchange
-| synchronous | advanced | false | boolean | Sets whether synchronous processing should be strictly used or Camel is allowed to use asynchronous processing (if supported).
-|=======================================================================
-{% endraw %}
-// endpoint options: END
-
-
-[[Cache-SendingReceivingMessagestofromthecache]]
-Sending/Receiving Messages to/from the cache
-^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^
-
-[[Cache-MessageHeadersuptoCamel2.7]]
-Message Headers up to Camel 2.7
-+++++++++++++++++++++++++++++++
-
-[width="100%",cols="20%,80%",options="header",]
-|=======================================================================
-|Header |Description
-
-|`CACHE_OPERATION` |The operation to be performed on the cache. Valid options are
-
-* GET
-* CHECK
-* ADD
-* UPDATE
-* DELETE
-* DELETEALL +
- `GET` and `CHECK` requires *Camel 2.3* onwards.
-
-|`CACHE_KEY` |The cache key used to store the Message in the cache. The cache key is
-optional if the CACHE_OPERATION is DELETEALL
-|=======================================================================
-[[Cache-MessageHeadersCamel2.8]]
-Message Headers Camel 2.8+
-++++++++++++++++++++++++++
-
-[Info]
-====
-Header changes in Camel 2.8
-
-The header names and supported values have changed to be prefixed with
-'CamelCache' and use mixed case. This makes them easier to identify and
-keep separate from other headers. The CacheConstants variable names
-remain unchanged, just their values have been changed. Also, these
-headers are now removed from the exchange after the cache operation is
-performed.
-
-====
-
-[width="100%",cols="20%,80%",options="header",]
-|=======================================================================
-|Header |Description
-
-|`CamelCacheOperation` |The operation to be performed on the cache. The valid options are
-
-* CamelCacheGet
-* CamelCacheCheck
-* CamelCacheAdd
-* CamelCacheUpdate
-* CamelCacheDelete
-* CamelCacheDeleteAll
-
-|`CamelCacheKey` |The cache key used to store the Message in the cache. The cache key is
-optional if the CamelCacheOperation is CamelCacheDeleteAll
-|=======================================================================
-
-The `CamelCacheAdd` and `CamelCacheUpdate` operations support additional
-headers:
-
-[width="100%",cols="10%,10%,80%",options="header",]
-|=======================================================================
-|Header |Type |Description
-
-|`CamelCacheTimeToLive` |`Integer` |*Camel 2.11:* Time to live in seconds.
-
-|`CamelCacheTimeToIdle` |`Integer` |*Camel 2.11:* Time to idle in seconds.
-
-|`CamelCacheEternal` |`Boolean` |*Camel 2.11:* Whether the content is eternal.
-|=======================================================================
-
-[[Cache-CacheProducer]]
-Cache Producer
-++++++++++++++
-
-Sending data to the cache involves the ability to direct payloads in
-exchanges to be stored in a pre-existing or created-on-demand cache. The
-mechanics of doing this involve
-
-* setting the Message Exchange Headers shown above.
-* ensuring that the Message Exchange Body contains the message directed
-to the cache
-
-[[Cache-CacheConsumer]]
-Cache Consumer
-++++++++++++++
-
-Receiving data from the cache involves the ability of the CacheConsumer
-to listen on a pre-existing or created-on-demand Cache using an event
-Listener and receive automatic notifications when any cache activity
-take place (i.e
-CamelCacheGet/CamelCacheUpdate/CamelCacheDelete/CamelCacheDeleteAll).
-Upon such an activity taking place
-
-* an exchange containing Message Exchange Headers and a Message Exchange
-Body containing the just added/updated payload is placed and sent.
-* in case of a CamelCacheDeleteAll operation, the Message Exchange
-Header CamelCacheKey and the Message Exchange Body are not populated.
-
-[[Cache-CacheProcessors]]
-Cache Processors
-++++++++++++++++
-
-There are a set of nice processors with the ability to perform cache
-lookups and selectively replace payload content at the
-
-* body
-* token
-* xpath level
-
-[[Cache-CacheUsageSamples]]
-Cache Usage Samples
-^^^^^^^^^^^^^^^^^^^
-
-[[Cache-Example1:Configuringthecache]]
-Example 1: Configuring the cache
-++++++++++++++++++++++++++++++++
-
-[source,java]
--------------------------------------------------
-from("cache://MyApplicationCache" +
-          "?maxElementsInMemory=1000" +
-          "&memoryStoreEvictionPolicy=" +
-              "MemoryStoreEvictionPolicy.LFU" +
-          "&overflowToDisk=true" +
-          "&eternal=true" +
-          "&timeToLiveSeconds=300" +
-          "&timeToIdleSeconds=true" +
-          "&diskPersistent=true" +
-          "&diskExpiryThreadIntervalSeconds=300")
--------------------------------------------------
-
-[[Cache-Example2:Addingkeystothecache]]
-Example 2: Adding keys to the cache
-+++++++++++++++++++++++++++++++++++
-
-[source,java]
----------------------------------------------------------------------------------------------
-RouteBuilder builder = new RouteBuilder() {
-    public void configure() {
-     from("direct:start")
-     .setHeader(CacheConstants.CACHE_OPERATION, constant(CacheConstants.CACHE_OPERATION_ADD))
-     .setHeader(CacheConstants.CACHE_KEY, constant("Ralph_Waldo_Emerson"))
-     .to("cache://TestCache1")
-   }
-};
----------------------------------------------------------------------------------------------
-
-[[Cache-Example2:Updatingexistingkeysinacache]]
-Example 2: Updating existing keys in a cache
-++++++++++++++++++++++++++++++++++++++++++++
-
-[source,java]
-------------------------------------------------------------------------------------------------
-RouteBuilder builder = new RouteBuilder() {
-    public void configure() {
-     from("direct:start")
-     .setHeader(CacheConstants.CACHE_OPERATION, constant(CacheConstants.CACHE_OPERATION_UPDATE))
-     .setHeader(CacheConstants.CACHE_KEY, constant("Ralph_Waldo_Emerson"))
-     .to("cache://TestCache1")
-   }
-};
-------------------------------------------------------------------------------------------------
-
-[[Cache-Example3:Deletingexistingkeysinacache]]
-Example 3: Deleting existing keys in a cache
-++++++++++++++++++++++++++++++++++++++++++++
-
-[source,java]
---------------------------------------------------------------------------------------
-RouteBuilder builder = new RouteBuilder() {
-    public void configure() {
-     from("direct:start")
-     .setHeader(CacheConstants.CACHE_OPERATION, constant(CacheConstants.CACHE_DELETE))
-     .setHeader(CacheConstants.CACHE_KEY", constant("Ralph_Waldo_Emerson"))
-     .to("cache://TestCache1")
-   }
-};
---------------------------------------------------------------------------------------
-
-[[Cache-Example4:Deletingallexistingkeysinacache]]
-Example 4: Deleting all existing keys in a cache
-++++++++++++++++++++++++++++++++++++++++++++++++
-
-[source,java]
------------------------------------------------------------------------------------------
-RouteBuilder builder = new RouteBuilder() {
-    public void configure() {
-     from("direct:start")
-     .setHeader(CacheConstants.CACHE_OPERATION, constant(CacheConstants.CACHE_DELETEALL))
-     .to("cache://TestCache1");
-    }
-};
------------------------------------------------------------------------------------------
-
-[[Cache-Example5:NotifyinganychangesregisteringinaCachetoProcessorsandotherProducers]]
-Example 5: Notifying any changes registering in a Cache to Processors and other Producers
-+++++++++++++++++++++++++++++++++++++++++++++++++++++++++++++++++++++++++++++++++++++++++
-
-[source,java]
---------------------------------------------------------------------------------------------------
-RouteBuilder builder = new RouteBuilder() {
-    public void configure() {
-     from("cache://TestCache1")
-     .process(new Processor() {
-        public void process(Exchange exchange)
-               throws Exception {
-           String operation = (String) exchange.getIn().getHeader(CacheConstants.CACHE_OPERATION);
-           String key = (String) exchange.getIn().getHeader(CacheConstants.CACHE_KEY);
-           Object body = exchange.getIn().getBody();
-           // Do something
-        }
-     })
-   }
-};
---------------------------------------------------------------------------------------------------
-
-[[Cache-Example6:UsingProcessorstoselectivelyreplacepayloadwithcachevalues]]
-Example 6: Using Processors to selectively replace payload with cache values
-++++++++++++++++++++++++++++++++++++++++++++++++++++++++++++++++++++++++++++
-
-[source,java]
----------------------------------------------------------------------------------------
-RouteBuilder builder = new RouteBuilder() {
-   public void configure() {
-     //Message Body Replacer
-     from("cache://TestCache1")
-     .filter(header(CacheConstants.CACHE_KEY).isEqualTo("greeting"))
-     .process(new CacheBasedMessageBodyReplacer("cache://TestCache1","farewell"))
-     .to("direct:next");
-
-    //Message Token replacer
-    from("cache://TestCache1")
-    .filter(header(CacheConstants.CACHE_KEY).isEqualTo("quote"))
-    .process(new CacheBasedTokenReplacer("cache://TestCache1","novel","#novel#"))
-    .process(new CacheBasedTokenReplacer("cache://TestCache1","author","#author#"))
-    .process(new CacheBasedTokenReplacer("cache://TestCache1","number","#number#"))
-    .to("direct:next");
-
-    //Message XPath replacer
-    from("cache://TestCache1").
-    .filter(header(CacheConstants.CACHE_KEY).isEqualTo("XML_FRAGMENT"))
-    .process(new CacheBasedXPathReplacer("cache://TestCache1","book1","/books/book1"))
-    .process (new CacheBasedXPathReplacer("cache://TestCache1","book2","/books/book2"))
-    .to("direct:next");
-   }
-};
----------------------------------------------------------------------------------------
-
-[[Cache-Example7:GettinganentryfromtheCache]]
-Example 7: Getting an entry from the Cache
-++++++++++++++++++++++++++++++++++++++++++
-
-[source,java]
-------------------------------------------------------------------------------------------------
-from("direct:start")
-    // Prepare headers
-    .setHeader(CacheConstants.CACHE_OPERATION, constant(CacheConstants.CACHE_OPERATION_GET))
-    .setHeader(CacheConstants.CACHE_KEY, constant("Ralph_Waldo_Emerson")).
-    .to("cache://TestCache1").
-    // Check if entry was not found
-    .choice().when(header(CacheConstants.CACHE_ELEMENT_WAS_FOUND).isNull()).
-        // If not found, get the payload and put it to cache
-        .to("cxf:bean:someHeavyweightOperation").
-        .setHeader(CacheConstants.CACHE_OPERATION, constant(CacheConstants.CACHE_OPERATION_ADD))
-        .setHeader(CacheConstants.CACHE_KEY, constant("Ralph_Waldo_Emerson"))
-        .to("cache://TestCache1")
-    .end()
-    .to("direct:nextPhase");
-------------------------------------------------------------------------------------------------
-
-[[Cache-Example8:CheckingforanentryintheCache]]
-Example 8: Checking for an entry in the Cache
-+++++++++++++++++++++++++++++++++++++++++++++
-
-Note: The CHECK command tests existence of an entry in the cache but
-doesn't place a message in the body.
-
-[source,java]
-------------------------------------------------------------------------------------------------
-from("direct:start")
-    // Prepare headers
-    .setHeader(CacheConstants.CACHE_OPERATION, constant(CacheConstants.CACHE_OPERATION_CHECK))
-    .setHeader(CacheConstants.CACHE_KEY, constant("Ralph_Waldo_Emerson")).
-    .to("cache://TestCache1").
-    // Check if entry was not found
-    .choice().when(header(CacheConstants.CACHE_ELEMENT_WAS_FOUND).isNull()).
-        // If not found, get the payload and put it to cache
-        .to("cxf:bean:someHeavyweightOperation").
-        .setHeader(CacheConstants.CACHE_OPERATION, constant(CacheConstants.CACHE_OPERATION_ADD))
-        .setHeader(CacheConstants.CACHE_KEY, constant("Ralph_Waldo_Emerson"))
-        .to("cache://TestCache1")
-    .end();
-------------------------------------------------------------------------------------------------
-
-[[Cache-ManagementofEHCache]]
-Management of EHCache
-^^^^^^^^^^^^^^^^^^^^^
-
-http://ehcache.org/[EHCache] has its own statistics and management from
-link:camel-jmx.html[JMX].
-
-Here's a snippet on how to expose them via JMX in a Spring application
-context:
-
-[source,xml]
------------------------------------------------------------------------------------------------------------------------------
-<bean id="ehCacheManagementService" class="net.sf.ehcache.management.ManagementService" init-method="init" lazy-init="false">
-  <constructor-arg>
-    <bean class="net.sf.ehcache.CacheManager" factory-method="getInstance"/>
-  </constructor-arg>
-  <constructor-arg>
-    <bean class="org.springframework.jmx.support.JmxUtils" factory-method="locateMBeanServer"/>
-  </constructor-arg>
-  <constructor-arg value="true"/>
-  <constructor-arg value="true"/>
-  <constructor-arg value="true"/>
-  <constructor-arg value="true"/>
-</bean>
------------------------------------------------------------------------------------------------------------------------------
-
-Of course you can do the same thing in straight Java:
-
-[source,java]
---------------------------------------------------------------------------------------------------
-ManagementService.registerMBeans(CacheManager.getInstance(), mbeanServer, true, true, true, true);
---------------------------------------------------------------------------------------------------
-
-You can get cache hits, misses, in-memory hits, disk hits, size stats
-this way. You can also change CacheConfiguration parameters on the fly.
-
-[[Cache-CachereplicationCamel2.8]]
-Cache replication Camel 2.8
-^^^^^^^^^^^^^^^^^^^^^^^^^^^
-
-The Camel Cache component is able to distribute a cache across server
-nodes using several different replication mechanisms including: RMI,
-JGroups, JMS and Cache Server.
-
-There are two different ways to make it work:
-
-*1.* You can configure `ehcache.xml` manually
-
-OR
-
-*2.* You can configure these three options:
-
-* cacheManagerFactory
-* eventListenerRegistry
-* cacheLoaderRegistry
-
-Configuring Camel Cache replication using the first option is a bit of
-hard work as you have to configure all caches separately. So in a
-situation when the all names of caches are not known, using
-`ehcache.xml` is not a good idea.
-
-The second option is much better when you want to use many different
-caches as you do not need to define options per cache. This is because
-replication options are set per `CacheManager` and per `CacheEndpoint`.
-Also it is the only way when cache names are not know at the development
-phase.
-
-[Note]
-====
-
-
-It might be useful to read the http://ehcache.org/documentation[EHCache
-manual] to get a better understanding of the Camel Cache replication
-mechanism.
-
-====
-
-[[Cache-Example:JMScachereplication]]
-Example: JMS cache replication
-++++++++++++++++++++++++++++++
-
-JMS replication is the most powerful and secured replication method.
-Used together with Camel Cache replication makes it also rather
-simple. An example is available on link:cachereplicationjmsexample.html[a
-separate page].
-

http://git-wip-us.apache.org/repos/asf/camel/blob/9c0b7baf/components/camel-cassandraql/src/main/docs/cql-component.adoc
----------------------------------------------------------------------
diff --git a/components/camel-cassandraql/src/main/docs/cql-component.adoc b/components/camel-cassandraql/src/main/docs/cql-component.adoc
new file mode 100644
index 0000000..f166cac
--- /dev/null
+++ b/components/camel-cassandraql/src/main/docs/cql-component.adoc
@@ -0,0 +1,233 @@
+[[Cassandra-CamelCassandraComponent]]
+Camel Cassandra Component
+-------------------------
+
+*Available as of Camel 2.15*
+
+http://cassandra.apache.org[Apache Cassandra] is an open source NoSQL
+database designed to handle large amounts on commodity hardware. Like
+Amazon's DynamoDB, Cassandra has a peer-to-peer and master-less
+architecture to avoid single point of failure and garanty high
+availability. Like Google's BigTable, Cassandra data is structured using
+column families which can be accessed through the Thrift RPC API or a
+SQL-like API called CQL.
+
+This component aims at integrating Cassandra 2.0+ using the CQL3 API
+(not the Thrift API). It's based on
+https://github.com/datastax/java-driver[Cassandra Java Driver] provided
+by DataStax.
+
+Maven users will need to add the following dependency to their
+`pom.xml`:
+
+*pom.xml*
+
+[source,xml]
+------------------------------------------------------------
+<dependency>
+    <groupId>org.apache.camel</groupId>
+    <artifactId>camel-cassandraql</artifactId>
+    <version>x.y.z</version>
+    <!-- use the same version as your Camel core version -->
+</dependency>
+------------------------------------------------------------
+
+[[Cassandra-URIformat]]
+URI format
+~~~~~~~~~~
+
+The endpoint can initiate the Cassandra connection or use an existing
+one.
+
+[cols="<,<",options="header",]
+|======================================================================
+|URI |Description
+|`cql:localhost/keyspace` |Single host, default port, usual for testing
+|`cql:host1,host2/keyspace` |Multi host, default port
+|`cql:host1,host2:9042/keyspace` |Multi host, custom port
+|`cql:host1,host2` |Default port and keyspace
+|`cql:bean:sessionRef` |Provided Session reference
+|`cql:bean:clusterRef/keyspace` |Provided Cluster reference
+|======================================================================
+
+To fine tune the Cassandra connection (SSL options, pooling options,
+load balancing policy, retry policy, reconnection policy...), create
+your own Cluster instance and give it to the Camel endpoint.
+
+[[Cassandra-Options]]
+Cassandra Options
+~~~~~~~~~~~~~~~~~
+
+
+// component options: START
+The Cassandra CQL component has no options.
+// component options: END
+
+
+
+// endpoint options: START
+The Cassandra CQL component supports 18 endpoint options which are listed below:
+
+{% raw %}
+[width="100%",cols="2s,1,1m,1m,5",options="header"]
+|=======================================================================
+| Name | Group | Default | Java Type | Description
+| beanRef | common |  | String | beanRef is defined using bean:id
+| hosts | common |  | String | Hostname(s) cassansdra server(s). Multiple hosts can be separated by comma.
+| port | common |  | Integer | Port number of cassansdra server(s)
+| keyspace | common |  | String | Keyspace to use
+| cluster | common |  | Cluster | To use the Cluster instance (you would normally not use this option)
+| clusterName | common |  | String | Cluster name
+| consistencyLevel | common |  | ConsistencyLevel | Consistency level to use
+| cql | common |  | String | CQL query to perform. Can be overridden with the message header with key CamelCqlQuery.
+| loadBalancingPolicy | common |  | String | To use a specific LoadBalancingPolicy
+| password | common |  | String | Password for session authentication
+| prepareStatements | common | true | boolean | Whether to use PreparedStatements or regular Statements
+| resultSetConversionStrategy | common |  | String | To use a custom class that implements logic for converting ResultSet into message body ALL ONE LIMIT_10 LIMIT_100...
+| session | common |  | Session | To use the Session instance (you would normally not use this option)
+| username | common |  | String | Username for session authentication
+| bridgeErrorHandler | consumer | false | boolean | Allows for bridging the consumer to the Camel routing Error Handler which mean any exceptions occurred while the consumer is trying to pickup incoming messages or the likes will now be processed as a message and handled by the routing Error Handler. By default the consumer will use the org.apache.camel.spi.ExceptionHandler to deal with exceptions that will be logged at WARN/ERROR level and ignored.
+| exceptionHandler | consumer (advanced) |  | ExceptionHandler | To let the consumer use a custom ExceptionHandler. Notice if the option bridgeErrorHandler is enabled then this options is not in use. By default the consumer will deal with exceptions that will be logged at WARN/ERROR level and ignored.
+| exchangePattern | advanced | InOnly | ExchangePattern | Sets the default exchange pattern when creating an exchange
+| synchronous | advanced | false | boolean | Sets whether synchronous processing should be strictly used or Camel is allowed to use asynchronous processing (if supported).
+|=======================================================================
+{% endraw %}
+// endpoint options: END
+
+
+[[Cassandra-Messages]]
+Messages
+~~~~~~~~
+
+[[Cassandra-IncomingMessage]]
+Incoming Message
+^^^^^^^^^^^^^^^^
+
+The Camel Cassandra endpoint expects a bunch of simple objects (`Object`
+or `Object[]` or `Collection<Object>`) which will be bound to the CQL
+statement as query parameters. If message body is null or empty, then�
+CQL query will be executed without binding parameters.
+
+Headers:
+
+* `CamelCqlQuery` (optional, `String` or `RegularStatement`): CQL query
+either as a plain String or built using the `QueryBuilder`.
+
+[[Cassandra-OutgoingMessage]]
+Outgoing Message
+^^^^^^^^^^^^^^^^
+
+The Camel Cassandra endpoint produces one or many a Cassandra Row
+objects depending on the�`resultSetConversionStrategy`:
+
+�
+
+* `List<Row>` if `resultSetConversionStrategy` is `ALL` or
+`LIMIT_[0-9]+`
+* Single` Row` if `resultSetConversionStrategy` is `ONE`
+* Anything else, if `resultSetConversionStrategy` is a custom
+implementation of the `ResultSetConversionStrategy`
+
+[[Cassandra-Repositories]]
+Repositories
+~~~~~~~~~~~~
+
+Cassandra can be used to store message keys or messages for the
+idempotent and aggregation EIP.
+
+Cassandra might not be the best tool for queuing use cases yet, read
+http://www.datastax.com/dev/blog/cassandra-anti-patterns-queues-and-queue-like-datasets[Cassandra
+anti-patterns queues and queue like datasets]. It's advised to use
+LeveledCompaction and a small GC grace setting for these tables to allow
+tombstoned rows to be removed quickly.
+
+[[Cassandra-Idempotentrepository]]
+Idempotent repository
+^^^^^^^^^^^^^^^^^^^^^
+
+The `NamedCassandraIdempotentRepository` stores messages keys in a
+Cassandra table like this:
+
+*CAMEL_IDEMPOTENT.cql*
+
+[source,sql]
+---------------------------------------------------------
+CREATE TABLE CAMEL_IDEMPOTENT (
+  NAME varchar,   -- Repository name
+  KEY varchar,    -- Message key
+  PRIMARY KEY (NAME, KEY)
+) WITH compaction = {'class':'LeveledCompactionStrategy'}
+  AND gc_grace_seconds = 86400;
+---------------------------------------------------------
+
+This repository implementation uses lightweight transactions (also known
+as Compare and Set) and requires Cassandra 2.0.7+.
+
+Alternatively, the `CassandraIdempotentRepository` does not have a
+`NAME` column and can be extended to use a different data model.
+
+[width="100%",cols="<34%,<33%,<33%",options="header",]
+|=======================================================================
+|Option |Default |Description
+
+|`table` |`CAMEL_IDEMPOTENT` |Table name
+
+|`pkColumns` |`NAME`,` KEY` |Primary key columns
+
+|`name` |  | Repository name, value used for `NAME` column
+
+|`ttl` |   | Key time to live
+
+|`writeConsistencyLevel` |  | Consistency level used to insert/delete key: `ANY`, `ONE`, `TWO`,
+`QUORUM`, `LOCAL_QUORUM`\u2026
+
+|`readConsistencyLevel` |  | Consistency level used to read/check key: `ONE`, `TWO`, `QUORUM`,
+`LOCAL_QUORUM`\u2026
+|=======================================================================
+
+[[Cassandra-Aggregationrepository]]
+Aggregation repository
+^^^^^^^^^^^^^^^^^^^^^^
+
+The `NamedCassandraAggregationRepository` stores exchanges by
+correlation key in a Cassandra table like this:
+
+*CAMEL_AGGREGATION.cql*
+
+[source,sql]
+---------------------------------------------------------
+CREATE TABLE CAMEL_AGGREGATION (
+  NAME varchar,        -- Repository name
+  KEY varchar,         -- Correlation id
+  EXCHANGE_ID varchar, -- Exchange id
+  EXCHANGE blob,       -- Serialized exchange
+  PRIMARY KEY (NAME, KEY)
+) WITH compaction = {'class':'LeveledCompactionStrategy'}
+  AND gc_grace_seconds = 86400;
+---------------------------------------------------------
+
+Alternatively, the `CassandraAggregationRepository` does not have a
+`NAME` column and can be extended to use a different data model.
+
+[width="100%",cols="<34%,<33%,<33%",options="header",]
+|=======================================================================
+|Option |Default |Description
+
+|`table` |`CAMEL_AGGREGATION` |Table name
+
+|`pkColumns` |`NAME`,`KEY` |Primary key columns
+
+|`exchangeIdColumn` |`EXCHANGE_ID` |Exchange Id column
+
+|`exchangeColumn` |`EXCHANGE` |Exchange content column
+
+|`name` |  | Repository name, value used for `NAME` column
+
+|`ttl` |  | Exchange time to live
+
+|`writeConsistencyLevel` |  | Consistency level used to insert/delete exchange: `ANY`, `ONE`, `TWO`,
+`QUORUM`, `LOCAL_QUORUM`\u2026
+
+|`readConsistencyLevel` |  | Consistency level used to read/check exchange: `ONE`, `TWO`, `QUORUM`,
+`LOCAL_QUORUM`\u2026
+|=======================================================================

http://git-wip-us.apache.org/repos/asf/camel/blob/9c0b7baf/components/camel-cassandraql/src/main/docs/cql.adoc
----------------------------------------------------------------------
diff --git a/components/camel-cassandraql/src/main/docs/cql.adoc b/components/camel-cassandraql/src/main/docs/cql.adoc
deleted file mode 100644
index f166cac..0000000
--- a/components/camel-cassandraql/src/main/docs/cql.adoc
+++ /dev/null
@@ -1,233 +0,0 @@
-[[Cassandra-CamelCassandraComponent]]
-Camel Cassandra Component
--------------------------
-
-*Available as of Camel 2.15*
-
-http://cassandra.apache.org[Apache Cassandra] is an open source NoSQL
-database designed to handle large amounts on commodity hardware. Like
-Amazon's DynamoDB, Cassandra has a peer-to-peer and master-less
-architecture to avoid single point of failure and garanty high
-availability. Like Google's BigTable, Cassandra data is structured using
-column families which can be accessed through the Thrift RPC API or a
-SQL-like API called CQL.
-
-This component aims at integrating Cassandra 2.0+ using the CQL3 API
-(not the Thrift API). It's based on
-https://github.com/datastax/java-driver[Cassandra Java Driver] provided
-by DataStax.
-
-Maven users will need to add the following dependency to their
-`pom.xml`:
-
-*pom.xml*
-
-[source,xml]
-------------------------------------------------------------
-<dependency>
-    <groupId>org.apache.camel</groupId>
-    <artifactId>camel-cassandraql</artifactId>
-    <version>x.y.z</version>
-    <!-- use the same version as your Camel core version -->
-</dependency>
-------------------------------------------------------------
-
-[[Cassandra-URIformat]]
-URI format
-~~~~~~~~~~
-
-The endpoint can initiate the Cassandra connection or use an existing
-one.
-
-[cols="<,<",options="header",]
-|======================================================================
-|URI |Description
-|`cql:localhost/keyspace` |Single host, default port, usual for testing
-|`cql:host1,host2/keyspace` |Multi host, default port
-|`cql:host1,host2:9042/keyspace` |Multi host, custom port
-|`cql:host1,host2` |Default port and keyspace
-|`cql:bean:sessionRef` |Provided Session reference
-|`cql:bean:clusterRef/keyspace` |Provided Cluster reference
-|======================================================================
-
-To fine tune the Cassandra connection (SSL options, pooling options,
-load balancing policy, retry policy, reconnection policy...), create
-your own Cluster instance and give it to the Camel endpoint.
-
-[[Cassandra-Options]]
-Cassandra Options
-~~~~~~~~~~~~~~~~~
-
-
-// component options: START
-The Cassandra CQL component has no options.
-// component options: END
-
-
-
-// endpoint options: START
-The Cassandra CQL component supports 18 endpoint options which are listed below:
-
-{% raw %}
-[width="100%",cols="2s,1,1m,1m,5",options="header"]
-|=======================================================================
-| Name | Group | Default | Java Type | Description
-| beanRef | common |  | String | beanRef is defined using bean:id
-| hosts | common |  | String | Hostname(s) cassansdra server(s). Multiple hosts can be separated by comma.
-| port | common |  | Integer | Port number of cassansdra server(s)
-| keyspace | common |  | String | Keyspace to use
-| cluster | common |  | Cluster | To use the Cluster instance (you would normally not use this option)
-| clusterName | common |  | String | Cluster name
-| consistencyLevel | common |  | ConsistencyLevel | Consistency level to use
-| cql | common |  | String | CQL query to perform. Can be overridden with the message header with key CamelCqlQuery.
-| loadBalancingPolicy | common |  | String | To use a specific LoadBalancingPolicy
-| password | common |  | String | Password for session authentication
-| prepareStatements | common | true | boolean | Whether to use PreparedStatements or regular Statements
-| resultSetConversionStrategy | common |  | String | To use a custom class that implements logic for converting ResultSet into message body ALL ONE LIMIT_10 LIMIT_100...
-| session | common |  | Session | To use the Session instance (you would normally not use this option)
-| username | common |  | String | Username for session authentication
-| bridgeErrorHandler | consumer | false | boolean | Allows for bridging the consumer to the Camel routing Error Handler which mean any exceptions occurred while the consumer is trying to pickup incoming messages or the likes will now be processed as a message and handled by the routing Error Handler. By default the consumer will use the org.apache.camel.spi.ExceptionHandler to deal with exceptions that will be logged at WARN/ERROR level and ignored.
-| exceptionHandler | consumer (advanced) |  | ExceptionHandler | To let the consumer use a custom ExceptionHandler. Notice if the option bridgeErrorHandler is enabled then this options is not in use. By default the consumer will deal with exceptions that will be logged at WARN/ERROR level and ignored.
-| exchangePattern | advanced | InOnly | ExchangePattern | Sets the default exchange pattern when creating an exchange
-| synchronous | advanced | false | boolean | Sets whether synchronous processing should be strictly used or Camel is allowed to use asynchronous processing (if supported).
-|=======================================================================
-{% endraw %}
-// endpoint options: END
-
-
-[[Cassandra-Messages]]
-Messages
-~~~~~~~~
-
-[[Cassandra-IncomingMessage]]
-Incoming Message
-^^^^^^^^^^^^^^^^
-
-The Camel Cassandra endpoint expects a bunch of simple objects (`Object`
-or `Object[]` or `Collection<Object>`) which will be bound to the CQL
-statement as query parameters. If message body is null or empty, then�
-CQL query will be executed without binding parameters.
-
-Headers:
-
-* `CamelCqlQuery` (optional, `String` or `RegularStatement`): CQL query
-either as a plain String or built using the `QueryBuilder`.
-
-[[Cassandra-OutgoingMessage]]
-Outgoing Message
-^^^^^^^^^^^^^^^^
-
-The Camel Cassandra endpoint produces one or many a Cassandra Row
-objects depending on the�`resultSetConversionStrategy`:
-
-�
-
-* `List<Row>` if `resultSetConversionStrategy` is `ALL` or
-`LIMIT_[0-9]+`
-* Single` Row` if `resultSetConversionStrategy` is `ONE`
-* Anything else, if `resultSetConversionStrategy` is a custom
-implementation of the `ResultSetConversionStrategy`
-
-[[Cassandra-Repositories]]
-Repositories
-~~~~~~~~~~~~
-
-Cassandra can be used to store message keys or messages for the
-idempotent and aggregation EIP.
-
-Cassandra might not be the best tool for queuing use cases yet, read
-http://www.datastax.com/dev/blog/cassandra-anti-patterns-queues-and-queue-like-datasets[Cassandra
-anti-patterns queues and queue like datasets]. It's advised to use
-LeveledCompaction and a small GC grace setting for these tables to allow
-tombstoned rows to be removed quickly.
-
-[[Cassandra-Idempotentrepository]]
-Idempotent repository
-^^^^^^^^^^^^^^^^^^^^^
-
-The `NamedCassandraIdempotentRepository` stores messages keys in a
-Cassandra table like this:
-
-*CAMEL_IDEMPOTENT.cql*
-
-[source,sql]
----------------------------------------------------------
-CREATE TABLE CAMEL_IDEMPOTENT (
-  NAME varchar,   -- Repository name
-  KEY varchar,    -- Message key
-  PRIMARY KEY (NAME, KEY)
-) WITH compaction = {'class':'LeveledCompactionStrategy'}
-  AND gc_grace_seconds = 86400;
----------------------------------------------------------
-
-This repository implementation uses lightweight transactions (also known
-as Compare and Set) and requires Cassandra 2.0.7+.
-
-Alternatively, the `CassandraIdempotentRepository` does not have a
-`NAME` column and can be extended to use a different data model.
-
-[width="100%",cols="<34%,<33%,<33%",options="header",]
-|=======================================================================
-|Option |Default |Description
-
-|`table` |`CAMEL_IDEMPOTENT` |Table name
-
-|`pkColumns` |`NAME`,` KEY` |Primary key columns
-
-|`name` |  | Repository name, value used for `NAME` column
-
-|`ttl` |   | Key time to live
-
-|`writeConsistencyLevel` |  | Consistency level used to insert/delete key: `ANY`, `ONE`, `TWO`,
-`QUORUM`, `LOCAL_QUORUM`\u2026
-
-|`readConsistencyLevel` |  | Consistency level used to read/check key: `ONE`, `TWO`, `QUORUM`,
-`LOCAL_QUORUM`\u2026
-|=======================================================================
-
-[[Cassandra-Aggregationrepository]]
-Aggregation repository
-^^^^^^^^^^^^^^^^^^^^^^
-
-The `NamedCassandraAggregationRepository` stores exchanges by
-correlation key in a Cassandra table like this:
-
-*CAMEL_AGGREGATION.cql*
-
-[source,sql]
----------------------------------------------------------
-CREATE TABLE CAMEL_AGGREGATION (
-  NAME varchar,        -- Repository name
-  KEY varchar,         -- Correlation id
-  EXCHANGE_ID varchar, -- Exchange id
-  EXCHANGE blob,       -- Serialized exchange
-  PRIMARY KEY (NAME, KEY)
-) WITH compaction = {'class':'LeveledCompactionStrategy'}
-  AND gc_grace_seconds = 86400;
----------------------------------------------------------
-
-Alternatively, the `CassandraAggregationRepository` does not have a
-`NAME` column and can be extended to use a different data model.
-
-[width="100%",cols="<34%,<33%,<33%",options="header",]
-|=======================================================================
-|Option |Default |Description
-
-|`table` |`CAMEL_AGGREGATION` |Table name
-
-|`pkColumns` |`NAME`,`KEY` |Primary key columns
-
-|`exchangeIdColumn` |`EXCHANGE_ID` |Exchange Id column
-
-|`exchangeColumn` |`EXCHANGE` |Exchange content column
-
-|`name` |  | Repository name, value used for `NAME` column
-
-|`ttl` |  | Exchange time to live
-
-|`writeConsistencyLevel` |  | Consistency level used to insert/delete exchange: `ANY`, `ONE`, `TWO`,
-`QUORUM`, `LOCAL_QUORUM`\u2026
-
-|`readConsistencyLevel` |  | Consistency level used to read/check exchange: `ONE`, `TWO`, `QUORUM`,
-`LOCAL_QUORUM`\u2026
-|=======================================================================

http://git-wip-us.apache.org/repos/asf/camel/blob/9c0b7baf/components/camel-chronicle/src/main/docs/chronicle-engine-component.adoc
----------------------------------------------------------------------
diff --git a/components/camel-chronicle/src/main/docs/chronicle-engine-component.adoc b/components/camel-chronicle/src/main/docs/chronicle-engine-component.adoc
new file mode 100644
index 0000000..4299701
--- /dev/null
+++ b/components/camel-chronicle/src/main/docs/chronicle-engine-component.adoc
@@ -0,0 +1,23 @@
+
+// component options: START
+The Chronicle Engine component has no options.
+// component options: END
+
+
+
+// endpoint options: START
+The Chronicle Engine component supports 5 endpoint options which are listed below:
+
+{% raw %}
+[width="100%",cols="2s,1,1m,1m,5",options="header"]
+|=======================================================================
+| Name | Group | Default | Java Type | Description
+| path | common |  | String | *Required* engine path
+| bridgeErrorHandler | consumer | false | boolean | Allows for bridging the consumer to the Camel routing Error Handler which mean any exceptions occurred while the consumer is trying to pickup incoming messages or the likes will now be processed as a message and handled by the routing Error Handler. By default the consumer will use the org.apache.camel.spi.ExceptionHandler to deal with exceptions that will be logged at WARN/ERROR level and ignored.
+| exceptionHandler | consumer (advanced) |  | ExceptionHandler | To let the consumer use a custom ExceptionHandler. Notice if the option bridgeErrorHandler is enabled then this options is not in use. By default the consumer will deal with exceptions that will be logged at WARN/ERROR level and ignored.
+| exchangePattern | advanced | InOnly | ExchangePattern | Sets the default exchange pattern when creating an exchange
+| synchronous | advanced | false | boolean | Sets whether synchronous processing should be strictly used or Camel is allowed to use asynchronous processing (if supported).
+|=======================================================================
+{% endraw %}
+// endpoint options: END
+

http://git-wip-us.apache.org/repos/asf/camel/blob/9c0b7baf/components/camel-chronicle/src/main/docs/chronicle-engine.adoc
----------------------------------------------------------------------
diff --git a/components/camel-chronicle/src/main/docs/chronicle-engine.adoc b/components/camel-chronicle/src/main/docs/chronicle-engine.adoc
deleted file mode 100644
index 4299701..0000000
--- a/components/camel-chronicle/src/main/docs/chronicle-engine.adoc
+++ /dev/null
@@ -1,23 +0,0 @@
-
-// component options: START
-The Chronicle Engine component has no options.
-// component options: END
-
-
-
-// endpoint options: START
-The Chronicle Engine component supports 5 endpoint options which are listed below:
-
-{% raw %}
-[width="100%",cols="2s,1,1m,1m,5",options="header"]
-|=======================================================================
-| Name | Group | Default | Java Type | Description
-| path | common |  | String | *Required* engine path
-| bridgeErrorHandler | consumer | false | boolean | Allows for bridging the consumer to the Camel routing Error Handler which mean any exceptions occurred while the consumer is trying to pickup incoming messages or the likes will now be processed as a message and handled by the routing Error Handler. By default the consumer will use the org.apache.camel.spi.ExceptionHandler to deal with exceptions that will be logged at WARN/ERROR level and ignored.
-| exceptionHandler | consumer (advanced) |  | ExceptionHandler | To let the consumer use a custom ExceptionHandler. Notice if the option bridgeErrorHandler is enabled then this options is not in use. By default the consumer will deal with exceptions that will be logged at WARN/ERROR level and ignored.
-| exchangePattern | advanced | InOnly | ExchangePattern | Sets the default exchange pattern when creating an exchange
-| synchronous | advanced | false | boolean | Sets whether synchronous processing should be strictly used or Camel is allowed to use asynchronous processing (if supported).
-|=======================================================================
-{% endraw %}
-// endpoint options: END
-

http://git-wip-us.apache.org/repos/asf/camel/blob/9c0b7baf/components/camel-chunk/src/main/docs/chunk-component.adoc
----------------------------------------------------------------------
diff --git a/components/camel-chunk/src/main/docs/chunk-component.adoc b/components/camel-chunk/src/main/docs/chunk-component.adoc
new file mode 100644
index 0000000..97b2efe
--- /dev/null
+++ b/components/camel-chunk/src/main/docs/chunk-component.adoc
@@ -0,0 +1,194 @@
+[[Chunk-Chunk]]
+Chunk
+~~~~~
+
+*Available as of Camel 2.15*
+
+The *chunk:*�component allows for processing a message using a
+http://www.x5software.com/chunk/examples/ChunkExample?loc=en_US[Chunk]�template.
+This can be ideal when using�link:templating.html[Templating]�to
+generate responses for requests.
+
+Maven users will need to add the following dependency to
+their�`pom.xml`�for this component:
+
+[source,xml]
+---------------------------------------------------------------------------------
+<dependency>
+<groupId>org.apache.camel</groupId>
+<artifactId>camel-chunk</artifactId>
+<version>x.x.x</version> <!-- use the same version as your Camel core version -->
+</dependency>
+---------------------------------------------------------------------------------
+
+[[Chunk-URIformat]]
+URI format
+^^^^^^^^^^
+
+[source,java]
+----------------------------
+chunk:templateName[?options]
+----------------------------
+
+Where�*templateName*�is the classpath-local URI of the template to
+invoke.
+
+You can append query options to the URI in the following
+format,�`?option=value&option=value&...`
+
+[[Chunk-Options]]
+Options
+^^^^^^^
+
+
+// component options: START
+The Chunk component has no options.
+// component options: END
+
+
+
+// endpoint options: START
+The Chunk component supports 9 endpoint options which are listed below:
+
+{% raw %}
+[width="100%",cols="2s,1,1m,1m,5",options="header"]
+|=======================================================================
+| Name | Group | Default | Java Type | Description
+| resourceUri | producer |  | String | *Required* Path to the resource or a reference to lookup a bean in the Registry to use as the resource
+| contentCache | producer | false | boolean | Sets whether to use resource content cache or not
+| encoding | producer |  | String | Define the encoding of the body
+| extension | producer |  | String | Define the file extension of the template
+| themeFolder | producer |  | String | Define the themes folder to scan
+| themeLayer | producer |  | String | Define the theme layer to elaborate
+| themeSubfolder | producer |  | String | Define the themes subfolder to scan
+| exchangePattern | advanced | InOnly | ExchangePattern | Sets the default exchange pattern when creating an exchange
+| synchronous | advanced | false | boolean | Sets whether synchronous processing should be strictly used or Camel is allowed to use asynchronous processing (if supported).
+|=======================================================================
+{% endraw %}
+// endpoint options: END
+
+
+Chunk component will look for a specific template in _themes_ folder
+with extensions _.chtml_ or _.cxml.�_If you need to specify a different
+folder or extensions, you will need to use the specific options listed
+above.
+
+[[Chunk-ChunkContext]]
+Chunk Context
+^^^^^^^^^^^^^
+
+Camel will provide exchange information in the Chunk context (just
+a�`Map`). The�`Exchange`�is transferred as:
+
+�
+[width="100%",cols="20%,80%",options="header",]
+|=======================================================================
+|key |value
+
+|`exchange` |The `Exchange` itself.
+
+|`exchange.properties` |The `Exchange` properties.
+
+|`headers` |The headers of the In message.
+
+|`camelContext` |The Camel Context.
+
+|`request` |The In message.
+
+|`body` |The In message body.
+
+|`response` |The Out message (only for InOut message exchange pattern).
+|=======================================================================
+
+[[Chunk-Dynamictemplates]]
+Dynamic templates
+^^^^^^^^^^^^^^^^^
+
+Camel provides two headers by which you can define a different resource
+location for a template or the template content itself. If any of these
+headers is set then Camel uses this over the endpoint configured
+resource. This allows you to provide a dynamic template at runtime.
+
+[width="100%",cols="20%,10%,10%,60%",options="header",]
+|=======================================================================
+|Header |Type |Description |Support Version
+
+|ChunkConstants.CHUNK_RESOURCE_URI |String |A URI for the template resource to use instead of the endpoint
+configured. |
+
+|ChunkConstants.CHUNK_TEMPLATE |String |The template to use instead of the endpoint configured. |
+|=======================================================================
+
+[[Chunk-Samples]]
+Samples
+^^^^^^^
+
+For example you could use something like:
+
+[source,java]
+--------------------------
+from("activemq:My.Queue").
+to("chunk:template");
+--------------------------
+
+To use a Chunk template to formulate a response for a message for InOut
+message exchanges (where there is a�`JMSReplyTo`�header).
+
+If you want to use InOnly and consume the message and send it to another
+destination you could use:
+
+[source,java]
+-----------------------------
+from("activemq:My.Queue").
+to("chunk:template").
+to("activemq:Another.Queue");
+-----------------------------
+
+It's possible to specify what template the component should use
+dynamically via a header, so for example:
+
+[source,java]
+------------------------------------------------------------------
+from("direct:in").
+setHeader(ChunkConstants.CHUNK_RESOURCE_URI).constant("template").
+to("chunk:dummy");
+------------------------------------------------------------------
+
+An example of Chunk component options use:
+
+[source,java]
+---------------------------------------------------------------------------------------
+from("direct:in").
+to("chunk:file_example?themeFolder=template&themeSubfolder=subfolder&extension=chunk");
+---------------------------------------------------------------------------------------
+
+In this example Chunk component will look for the file
+_file_example.chunk_ in the folder _template/subfolder._
+
+[[Chunk-TheEmailSample]]
+The Email Sample
+^^^^^^^^^^^^^^^^
+
+In this sample we want to use Chunk templating for an order confirmation
+email. The email template is laid out in Chunk as:
+
+[source,java]
+----------------------------------------------
+�
+Dear {$headers.lastName}, {$headers.firstName}
+
+Thanks for the order of {$headers.item}.
+
+Regards Camel Riders Bookstore
+{$body}
+----------------------------------------------
+
+[[Chunk-SeeAlso]]
+See Also
+^^^^^^^^
+
+* link:configuring-camel.html[Configuring Camel]
+* link:component.html[Component]
+* link:endpoint.html[Endpoint]
+* link:getting-started.html[Getting Started]
+

http://git-wip-us.apache.org/repos/asf/camel/blob/9c0b7baf/components/camel-chunk/src/main/docs/chunk.adoc
----------------------------------------------------------------------
diff --git a/components/camel-chunk/src/main/docs/chunk.adoc b/components/camel-chunk/src/main/docs/chunk.adoc
deleted file mode 100644
index 97b2efe..0000000
--- a/components/camel-chunk/src/main/docs/chunk.adoc
+++ /dev/null
@@ -1,194 +0,0 @@
-[[Chunk-Chunk]]
-Chunk
-~~~~~
-
-*Available as of Camel 2.15*
-
-The *chunk:*�component allows for processing a message using a
-http://www.x5software.com/chunk/examples/ChunkExample?loc=en_US[Chunk]�template.
-This can be ideal when using�link:templating.html[Templating]�to
-generate responses for requests.
-
-Maven users will need to add the following dependency to
-their�`pom.xml`�for this component:
-
-[source,xml]
----------------------------------------------------------------------------------
-<dependency>
-<groupId>org.apache.camel</groupId>
-<artifactId>camel-chunk</artifactId>
-<version>x.x.x</version> <!-- use the same version as your Camel core version -->
-</dependency>
----------------------------------------------------------------------------------
-
-[[Chunk-URIformat]]
-URI format
-^^^^^^^^^^
-
-[source,java]
-----------------------------
-chunk:templateName[?options]
-----------------------------
-
-Where�*templateName*�is the classpath-local URI of the template to
-invoke.
-
-You can append query options to the URI in the following
-format,�`?option=value&option=value&...`
-
-[[Chunk-Options]]
-Options
-^^^^^^^
-
-
-// component options: START
-The Chunk component has no options.
-// component options: END
-
-
-
-// endpoint options: START
-The Chunk component supports 9 endpoint options which are listed below:
-
-{% raw %}
-[width="100%",cols="2s,1,1m,1m,5",options="header"]
-|=======================================================================
-| Name | Group | Default | Java Type | Description
-| resourceUri | producer |  | String | *Required* Path to the resource or a reference to lookup a bean in the Registry to use as the resource
-| contentCache | producer | false | boolean | Sets whether to use resource content cache or not
-| encoding | producer |  | String | Define the encoding of the body
-| extension | producer |  | String | Define the file extension of the template
-| themeFolder | producer |  | String | Define the themes folder to scan
-| themeLayer | producer |  | String | Define the theme layer to elaborate
-| themeSubfolder | producer |  | String | Define the themes subfolder to scan
-| exchangePattern | advanced | InOnly | ExchangePattern | Sets the default exchange pattern when creating an exchange
-| synchronous | advanced | false | boolean | Sets whether synchronous processing should be strictly used or Camel is allowed to use asynchronous processing (if supported).
-|=======================================================================
-{% endraw %}
-// endpoint options: END
-
-
-Chunk component will look for a specific template in _themes_ folder
-with extensions _.chtml_ or _.cxml.�_If you need to specify a different
-folder or extensions, you will need to use the specific options listed
-above.
-
-[[Chunk-ChunkContext]]
-Chunk Context
-^^^^^^^^^^^^^
-
-Camel will provide exchange information in the Chunk context (just
-a�`Map`). The�`Exchange`�is transferred as:
-
-�
-[width="100%",cols="20%,80%",options="header",]
-|=======================================================================
-|key |value
-
-|`exchange` |The `Exchange` itself.
-
-|`exchange.properties` |The `Exchange` properties.
-
-|`headers` |The headers of the In message.
-
-|`camelContext` |The Camel Context.
-
-|`request` |The In message.
-
-|`body` |The In message body.
-
-|`response` |The Out message (only for InOut message exchange pattern).
-|=======================================================================
-
-[[Chunk-Dynamictemplates]]
-Dynamic templates
-^^^^^^^^^^^^^^^^^
-
-Camel provides two headers by which you can define a different resource
-location for a template or the template content itself. If any of these
-headers is set then Camel uses this over the endpoint configured
-resource. This allows you to provide a dynamic template at runtime.
-
-[width="100%",cols="20%,10%,10%,60%",options="header",]
-|=======================================================================
-|Header |Type |Description |Support Version
-
-|ChunkConstants.CHUNK_RESOURCE_URI |String |A URI for the template resource to use instead of the endpoint
-configured. |
-
-|ChunkConstants.CHUNK_TEMPLATE |String |The template to use instead of the endpoint configured. |
-|=======================================================================
-
-[[Chunk-Samples]]
-Samples
-^^^^^^^
-
-For example you could use something like:
-
-[source,java]
---------------------------
-from("activemq:My.Queue").
-to("chunk:template");
---------------------------
-
-To use a Chunk template to formulate a response for a message for InOut
-message exchanges (where there is a�`JMSReplyTo`�header).
-
-If you want to use InOnly and consume the message and send it to another
-destination you could use:
-
-[source,java]
------------------------------
-from("activemq:My.Queue").
-to("chunk:template").
-to("activemq:Another.Queue");
------------------------------
-
-It's possible to specify what template the component should use
-dynamically via a header, so for example:
-
-[source,java]
-------------------------------------------------------------------
-from("direct:in").
-setHeader(ChunkConstants.CHUNK_RESOURCE_URI).constant("template").
-to("chunk:dummy");
-------------------------------------------------------------------
-
-An example of Chunk component options use:
-
-[source,java]
----------------------------------------------------------------------------------------
-from("direct:in").
-to("chunk:file_example?themeFolder=template&themeSubfolder=subfolder&extension=chunk");
----------------------------------------------------------------------------------------
-
-In this example Chunk component will look for the file
-_file_example.chunk_ in the folder _template/subfolder._
-
-[[Chunk-TheEmailSample]]
-The Email Sample
-^^^^^^^^^^^^^^^^
-
-In this sample we want to use Chunk templating for an order confirmation
-email. The email template is laid out in Chunk as:
-
-[source,java]
-----------------------------------------------
-�
-Dear {$headers.lastName}, {$headers.firstName}
-
-Thanks for the order of {$headers.item}.
-
-Regards Camel Riders Bookstore
-{$body}
-----------------------------------------------
-
-[[Chunk-SeeAlso]]
-See Also
-^^^^^^^^
-
-* link:configuring-camel.html[Configuring Camel]
-* link:component.html[Component]
-* link:endpoint.html[Endpoint]
-* link:getting-started.html[Getting Started]
-

http://git-wip-us.apache.org/repos/asf/camel/blob/9c0b7baf/components/camel-cm-sms/src/main/docs/cm-sms-component.adoc
----------------------------------------------------------------------
diff --git a/components/camel-cm-sms/src/main/docs/cm-sms-component.adoc b/components/camel-cm-sms/src/main/docs/cm-sms-component.adoc
new file mode 100644
index 0000000..e8afb4d
--- /dev/null
+++ b/components/camel-cm-sms/src/main/docs/cm-sms-component.adoc
@@ -0,0 +1,66 @@
+[[CM-SMS]]
+CM-SMS
+~~~~~~
+
+*Available as of Camel 2.18*
+
+*Camel-Cm-Sms* is an http://camel.apache.org/[Apache Camel] component 
+for the [CM SMS Gateway](https://www.cmtelecom.com). 
+
+It allows to integrate https://dashboard.onlinesmsgateway.com/docs[CM SMS API]in an application as a camel component. 
+
+You must have a valid account.  More information are available at https://www.cmtelecom.com/support[CM Telecom].
+
+[source,java]
+-------------------------------
+cm-sms://sgw01.cm.nl/gateway.ashx?defaultFrom=DefaultSender&defaultMaxNumberOfParts=8&productToken=xxxxx
+-------------------------------
+
+Maven users will need to add the following dependency to their pom.xml
+for this component:
+
+[source,xml]
+---------------------------------------------------------
+<dependency>
+�<groupId>org.apache.camel</groupId>
+�<artifactId>camel-cm-sms</artifactId>
+�<version>x.x.x</version>
+�<!-- use the same version as your Camel core version -->
+</dependency>
+---------------------------------------------------------
+
+[[CM-SMS-Options]]
+Options
+~~~~~~~
+
+
+// component options: START
+The CM SMS Gateway component has no options.
+// component options: END
+
+
+
+// endpoint options: START
+The CM SMS Gateway component supports 7 endpoint options which are listed below:
+
+{% raw %}
+[width="100%",cols="2s,1,1m,1m,5",options="header"]
+|=======================================================================
+| Name | Group | Default | Java Type | Description
+| host | producer |  | String | *Required* SMS Provider HOST with scheme
+| defaultFrom | producer |  | String | This is the sender name. The maximum length is 11 characters.
+| defaultMaxNumberOfParts | producer | 8 | int | If it is a multipart message forces the max number. Message can be truncated. Technically the gateway will first check if a message is larger than 160 characters if so the message will be cut into multiple 153 characters parts limited by these parameters.
+| productToken | producer |  | String | *Required* The unique token to use
+| testConnectionOnStartup | producer | false | boolean | Whether to test the connection to the SMS Gateway on startup
+| exchangePattern | advanced | InOnly | ExchangePattern | Sets the default exchange pattern when creating an exchange
+| synchronous | advanced | false | boolean | Sets whether synchronous processing should be strictly used or Camel is allowed to use asynchronous processing (if supported).
+|=======================================================================
+{% endraw %}
+// endpoint options: END
+
+
+[[CM-SMS-Sample]]
+Sample
+~~~~~~
+
+You can try https://github.com/oalles/camel-cm-sample[this project] to see how camel-cm-sms can be integrated in a camel route. 

http://git-wip-us.apache.org/repos/asf/camel/blob/9c0b7baf/components/camel-cm-sms/src/main/docs/cm-sms.adoc
----------------------------------------------------------------------
diff --git a/components/camel-cm-sms/src/main/docs/cm-sms.adoc b/components/camel-cm-sms/src/main/docs/cm-sms.adoc
deleted file mode 100644
index e8afb4d..0000000
--- a/components/camel-cm-sms/src/main/docs/cm-sms.adoc
+++ /dev/null
@@ -1,66 +0,0 @@
-[[CM-SMS]]
-CM-SMS
-~~~~~~
-
-*Available as of Camel 2.18*
-
-*Camel-Cm-Sms* is an http://camel.apache.org/[Apache Camel] component 
-for the [CM SMS Gateway](https://www.cmtelecom.com). 
-
-It allows to integrate https://dashboard.onlinesmsgateway.com/docs[CM SMS API]in an application as a camel component. 
-
-You must have a valid account.  More information are available at https://www.cmtelecom.com/support[CM Telecom].
-
-[source,java]
--------------------------------
-cm-sms://sgw01.cm.nl/gateway.ashx?defaultFrom=DefaultSender&defaultMaxNumberOfParts=8&productToken=xxxxx
--------------------------------
-
-Maven users will need to add the following dependency to their pom.xml
-for this component:
-
-[source,xml]
----------------------------------------------------------
-<dependency>
-�<groupId>org.apache.camel</groupId>
-�<artifactId>camel-cm-sms</artifactId>
-�<version>x.x.x</version>
-�<!-- use the same version as your Camel core version -->
-</dependency>
----------------------------------------------------------
-
-[[CM-SMS-Options]]
-Options
-~~~~~~~
-
-
-// component options: START
-The CM SMS Gateway component has no options.
-// component options: END
-
-
-
-// endpoint options: START
-The CM SMS Gateway component supports 7 endpoint options which are listed below:
-
-{% raw %}
-[width="100%",cols="2s,1,1m,1m,5",options="header"]
-|=======================================================================
-| Name | Group | Default | Java Type | Description
-| host | producer |  | String | *Required* SMS Provider HOST with scheme
-| defaultFrom | producer |  | String | This is the sender name. The maximum length is 11 characters.
-| defaultMaxNumberOfParts | producer | 8 | int | If it is a multipart message forces the max number. Message can be truncated. Technically the gateway will first check if a message is larger than 160 characters if so the message will be cut into multiple 153 characters parts limited by these parameters.
-| productToken | producer |  | String | *Required* The unique token to use
-| testConnectionOnStartup | producer | false | boolean | Whether to test the connection to the SMS Gateway on startup
-| exchangePattern | advanced | InOnly | ExchangePattern | Sets the default exchange pattern when creating an exchange
-| synchronous | advanced | false | boolean | Sets whether synchronous processing should be strictly used or Camel is allowed to use asynchronous processing (if supported).
-|=======================================================================
-{% endraw %}
-// endpoint options: END
-
-
-[[CM-SMS-Sample]]
-Sample
-~~~~~~
-
-You can try https://github.com/oalles/camel-cm-sample[this project] to see how camel-cm-sms can be integrated in a camel route. 

http://git-wip-us.apache.org/repos/asf/camel/blob/9c0b7baf/components/camel-cmis/src/main/docs/cmis-component.adoc
----------------------------------------------------------------------
diff --git a/components/camel-cmis/src/main/docs/cmis-component.adoc b/components/camel-cmis/src/main/docs/cmis-component.adoc
new file mode 100644
index 0000000..725bcfe
--- /dev/null
+++ b/components/camel-cmis/src/main/docs/cmis-component.adoc
@@ -0,0 +1,127 @@
+[[CMIS-CMISComponent]]
+CMIS Component
+~~~~~~~~~~~~~~
+
+*Available as of Camel 2.11* +
+ The cmis component uses the
+http://chemistry.apache.org/java/opencmis.html[Apache Chemistry] client
+API and allows you to add/read nodes to/from a CMIS compliant content
+repositories.
+
+[[CMIS-URIFormat]]
+URI Format
+^^^^^^^^^^
+
+[source,java]
+------------------------------
+cmis://cmisServerUrl[?options]
+------------------------------
+
+You can append query options to the URI in the following format,
+?options=value&option2=value&...
+
+[[CMIS-URIOptions]]
+CMIS Options
+^^^^^^^^^^^^
+
+
+// component options: START
+The CMIS component has no options.
+// component options: END
+
+
+
+// endpoint options: START
+The CMIS component supports 6 endpoint options which are listed below:
+
+{% raw %}
+[width="100%",cols="2s,1,1m,1m,5",options="header"]
+|=======================================================================
+| Name | Group | Default | Java Type | Description
+| url | common |  | String | *Required* the cmis url
+| bridgeErrorHandler | consumer | false | boolean | Allows for bridging the consumer to the Camel routing Error Handler which mean any exceptions occurred while the consumer is trying to pickup incoming messages or the likes will now be processed as a message and handled by the routing Error Handler. By default the consumer will use the org.apache.camel.spi.ExceptionHandler to deal with exceptions that will be logged at WARN/ERROR level and ignored.
+| exceptionHandler | consumer (advanced) |  | ExceptionHandler | To let the consumer use a custom ExceptionHandler. Notice if the option bridgeErrorHandler is enabled then this options is not in use. By default the consumer will deal with exceptions that will be logged at WARN/ERROR level and ignored.
+| queryMode | producer | false | boolean | If true will execute the cmis query from the message body and return result otherwise will create a node in the cmis repository
+| exchangePattern | advanced | InOnly | ExchangePattern | Sets the default exchange pattern when creating an exchange
+| synchronous | advanced | false | boolean | Sets whether synchronous processing should be strictly used or Camel is allowed to use asynchronous processing (if supported).
+|=======================================================================
+{% endraw %}
+// endpoint options: END
+
+
+[[CMIS-Usage]]
+Usage
+^^^^^
+
+[[CMIS-Messageheadersevaluatedbytheproducer]]
+Message headers evaluated by the producer
++++++++++++++++++++++++++++++++++++++++++
+
+[width="100%",cols="10%,10%,80%",options="header",]
+|=======================================================================
+|Header |Default Value |Description
+
+|`CamelCMISFolderPath` |`/` |The current folder to use during the execution. If not specified will
+use the root folder
+
+|`CamelCMISRetrieveContent` |`false` |In `queryMode` this header will force the producer to retrieve the
+content of document nodes.
+
+|`CamelCMISReadSize` |`0` |Max number of nodes to read.
+
+|`cmis:path` |`null` |If `CamelCMISFolderPath` is not set, will try to find out the path of
+the node from this cmis property and it is name
+
+|`cmis:name` |`null` |If `CamelCMISFolderPath` is not set, will try to find out the path of
+the node from this cmis property and it is path
+
+|`cmis:objectTypeId` |`null` |The type of the node
+
+|`cmis:contentStreamMimeType` |`null` |The mimetype to set for a document
+|=======================================================================
+
+[[CMIS-MessageheaderssetduringqueryingProduceroperation]]
+Message headers set during querying Producer operation
+++++++++++++++++++++++++++++++++++++++++++++++++++++++
+
+[width="100%",cols="10%,10%,80%",options="header",]
+|=======================================================================
+|Header |Type |Description
+
+|`CamelCMISResultCount` |`Integer` |Number of nodes returned from the query.
+|=======================================================================
+
+The message body will contain a list of maps, where each entry in the
+map is cmis property and its value. If `CamelCMISRetrieveContent` header is set to true, one additional
+entry in the map with key `CamelCMISContent` will contain `InputStream`
+of the document type of nodes.
+
+[[CMIS-Dependencies]]
+Dependencies
+^^^^^^^^^^^^
+
+Maven users will need to add the following dependency to their pom.xml.
+
+*pom.xml*
+
+[source,xml]
+---------------------------------------
+<dependency>
+    <groupId>org.apache.camel</groupId>
+    <artifactId>camel-cmis</artifactId>
+    <version>${camel-version}</version>
+</dependency>
+---------------------------------------
+
+where `${camel-version`} must be replaced by the actual version of Camel
+(2.11 or higher).
+
+[[CMIS-SeeAlso]]
+See Also
+^^^^^^^^
+
+* link:configuring-camel.html[Configuring Camel]
+* link:component.html[Component]
+* link:endpoint.html[Endpoint]
+* link:getting-started.html[Getting Started]
+

http://git-wip-us.apache.org/repos/asf/camel/blob/9c0b7baf/components/camel-cmis/src/main/docs/cmis.adoc
----------------------------------------------------------------------
diff --git a/components/camel-cmis/src/main/docs/cmis.adoc b/components/camel-cmis/src/main/docs/cmis.adoc
deleted file mode 100644
index 725bcfe..0000000
--- a/components/camel-cmis/src/main/docs/cmis.adoc
+++ /dev/null
@@ -1,127 +0,0 @@
-[[CMIS-CMISComponent]]
-CMIS Component
-~~~~~~~~~~~~~~
-
-*Available as of Camel 2.11* +
- The cmis component uses the
-http://chemistry.apache.org/java/opencmis.html[Apache Chemistry] client
-API and allows you to add/read nodes to/from a CMIS compliant content
-repositories.
-
-[[CMIS-URIFormat]]
-URI Format
-^^^^^^^^^^
-
-[source,java]
-------------------------------
-cmis://cmisServerUrl[?options]
-------------------------------
-
-You can append query options to the URI in the following format,
-?options=value&option2=value&...
-
-[[CMIS-URIOptions]]
-CMIS Options
-^^^^^^^^^^^^
-
-
-// component options: START
-The CMIS component has no options.
-// component options: END
-
-
-
-// endpoint options: START
-The CMIS component supports 6 endpoint options which are listed below:
-
-{% raw %}
-[width="100%",cols="2s,1,1m,1m,5",options="header"]
-|=======================================================================
-| Name | Group | Default | Java Type | Description
-| url | common |  | String | *Required* the cmis url
-| bridgeErrorHandler | consumer | false | boolean | Allows for bridging the consumer to the Camel routing Error Handler which mean any exceptions occurred while the consumer is trying to pickup incoming messages or the likes will now be processed as a message and handled by the routing Error Handler. By default the consumer will use the org.apache.camel.spi.ExceptionHandler to deal with exceptions that will be logged at WARN/ERROR level and ignored.
-| exceptionHandler | consumer (advanced) |  | ExceptionHandler | To let the consumer use a custom ExceptionHandler. Notice if the option bridgeErrorHandler is enabled then this options is not in use. By default the consumer will deal with exceptions that will be logged at WARN/ERROR level and ignored.
-| queryMode | producer | false | boolean | If true will execute the cmis query from the message body and return result otherwise will create a node in the cmis repository
-| exchangePattern | advanced | InOnly | ExchangePattern | Sets the default exchange pattern when creating an exchange
-| synchronous | advanced | false | boolean | Sets whether synchronous processing should be strictly used or Camel is allowed to use asynchronous processing (if supported).
-|=======================================================================
-{% endraw %}
-// endpoint options: END
-
-
-[[CMIS-Usage]]
-Usage
-^^^^^
-
-[[CMIS-Messageheadersevaluatedbytheproducer]]
-Message headers evaluated by the producer
-+++++++++++++++++++++++++++++++++++++++++
-
-[width="100%",cols="10%,10%,80%",options="header",]
-|=======================================================================
-|Header |Default Value |Description
-
-|`CamelCMISFolderPath` |`/` |The current folder to use during the execution. If not specified will
-use the root folder
-
-|`CamelCMISRetrieveContent` |`false` |In `queryMode` this header will force the producer to retrieve the
-content of document nodes.
-
-|`CamelCMISReadSize` |`0` |Max number of nodes to read.
-
-|`cmis:path` |`null` |If `CamelCMISFolderPath` is not set, will try to find out the path of
-the node from this cmis property and it is name
-
-|`cmis:name` |`null` |If `CamelCMISFolderPath` is not set, will try to find out the path of
-the node from this cmis property and it is path
-
-|`cmis:objectTypeId` |`null` |The type of the node
-
-|`cmis:contentStreamMimeType` |`null` |The mimetype to set for a document
-|=======================================================================
-
-[[CMIS-MessageheaderssetduringqueryingProduceroperation]]
-Message headers set during querying Producer operation
-++++++++++++++++++++++++++++++++++++++++++++++++++++++
-
-[width="100%",cols="10%,10%,80%",options="header",]
-|=======================================================================
-|Header |Type |Description
-
-|`CamelCMISResultCount` |`Integer` |Number of nodes returned from the query.
-|=======================================================================
-
-The message body will contain a list of maps, where each entry in the
-map is cmis property and its value. If `CamelCMISRetrieveContent` header is set to true, one additional
-entry in the map with key `CamelCMISContent` will contain `InputStream`
-of the document type of nodes.
-
-[[CMIS-Dependencies]]
-Dependencies
-^^^^^^^^^^^^
-
-Maven users will need to add the following dependency to their pom.xml.
-
-*pom.xml*
-
-[source,xml]
----------------------------------------
-<dependency>
-    <groupId>org.apache.camel</groupId>
-    <artifactId>camel-cmis</artifactId>
-    <version>${camel-version}</version>
-</dependency>
----------------------------------------
-
-where `${camel-version`} must be replaced by the actual version of Camel
-(2.11 or higher).
-
-[[CMIS-SeeAlso]]
-See Also
-^^^^^^^^
-
-* link:configuring-camel.html[Configuring Camel]
-* link:component.html[Component]
-* link:endpoint.html[Endpoint]
-* link:getting-started.html[Getting Started]
-

http://git-wip-us.apache.org/repos/asf/camel/blob/9c0b7baf/components/camel-coap/src/main/docs/coap-component.adoc
----------------------------------------------------------------------
diff --git a/components/camel-coap/src/main/docs/coap-component.adoc b/components/camel-coap/src/main/docs/coap-component.adoc
new file mode 100644
index 0000000..74a5b21
--- /dev/null
+++ b/components/camel-coap/src/main/docs/coap-component.adoc
@@ -0,0 +1,54 @@
+[[CoAP-CoAPComponent]]
+CoAP Component
+~~~~~~~~~~~~~~
+
+*Camel-CoAP* is an http://camel.apache.org/[Apache Camel] component that
+allows you to work with CoAP, a lightweight REST-type protocol for machine-to-machine operation. 
+http://coap.technology/[CoAP], Constrained Application Protocol is a specialized web transfer protocol 
+for use with constrained nodes and constrained networks and it is based on RFC 7252.
+
+*Available as of Camel 2.16*
+
+Maven users will need to add the following dependency to their pom.xml
+for this component:
+
+[source,xml]
+---------------------------------------------------------
+<dependency>
+�<groupId>org.apache.camel</groupId>
+�<artifactId>camel-coap</artifactId>
+�<version>x.x.x</version>
+�<!-- use the same version as your Camel core version -->
+</dependency>
+---------------------------------------------------------
+
+[[CoAP-Options]]
+Options
+~~~~~~~
+
+
+// component options: START
+The CoAP component has no options.
+// component options: END
+
+
+
+
+// endpoint options: START
+The CoAP component supports 6 endpoint options which are listed below:
+
+{% raw %}
+[width="100%",cols="2s,1,1m,1m,5",options="header"]
+|=======================================================================
+| Name | Group | Default | Java Type | Description
+| uri | common |  | URI | The URI for the CoAP endpoint
+| coapMethod | common | * | String | The CoAP method this endpoint binds to. Default is to bind to all () but can be restricted to GET POST PUT DELETE PING
+| bridgeErrorHandler | consumer | false | boolean | Allows for bridging the consumer to the Camel routing Error Handler which mean any exceptions occurred while the consumer is trying to pickup incoming messages or the likes will now be processed as a message and handled by the routing Error Handler. By default the consumer will use the org.apache.camel.spi.ExceptionHandler to deal with exceptions that will be logged at WARN/ERROR level and ignored.
+| exceptionHandler | consumer (advanced) |  | ExceptionHandler | To let the consumer use a custom ExceptionHandler. Notice if the option bridgeErrorHandler is enabled then this options is not in use. By default the consumer will deal with exceptions that will be logged at WARN/ERROR level and ignored.
+| exchangePattern | advanced | InOnly | ExchangePattern | Sets the default exchange pattern when creating an exchange
+| synchronous | advanced | false | boolean | Sets whether synchronous processing should be strictly used or Camel is allowed to use asynchronous processing (if supported).
+|=======================================================================
+{% endraw %}
+// endpoint options: END
+
+

http://git-wip-us.apache.org/repos/asf/camel/blob/9c0b7baf/components/camel-coap/src/main/docs/coap.adoc
----------------------------------------------------------------------
diff --git a/components/camel-coap/src/main/docs/coap.adoc b/components/camel-coap/src/main/docs/coap.adoc
deleted file mode 100644
index 74a5b21..0000000
--- a/components/camel-coap/src/main/docs/coap.adoc
+++ /dev/null
@@ -1,54 +0,0 @@
-[[CoAP-CoAPComponent]]
-CoAP Component
-~~~~~~~~~~~~~~
-
-*Camel-CoAP* is an http://camel.apache.org/[Apache Camel] component that
-allows you to work with CoAP, a lightweight REST-type protocol for machine-to-machine operation. 
-http://coap.technology/[CoAP], Constrained Application Protocol is a specialized web transfer protocol 
-for use with constrained nodes and constrained networks and it is based on RFC 7252.
-
-*Available as of Camel 2.16*
-
-Maven users will need to add the following dependency to their pom.xml
-for this component:
-
-[source,xml]
----------------------------------------------------------
-<dependency>
-�<groupId>org.apache.camel</groupId>
-�<artifactId>camel-coap</artifactId>
-�<version>x.x.x</version>
-�<!-- use the same version as your Camel core version -->
-</dependency>
----------------------------------------------------------
-
-[[CoAP-Options]]
-Options
-~~~~~~~
-
-
-// component options: START
-The CoAP component has no options.
-// component options: END
-
-
-
-
-// endpoint options: START
-The CoAP component supports 6 endpoint options which are listed below:
-
-{% raw %}
-[width="100%",cols="2s,1,1m,1m,5",options="header"]
-|=======================================================================
-| Name | Group | Default | Java Type | Description
-| uri | common |  | URI | The URI for the CoAP endpoint
-| coapMethod | common | * | String | The CoAP method this endpoint binds to. Default is to bind to all () but can be restricted to GET POST PUT DELETE PING
-| bridgeErrorHandler | consumer | false | boolean | Allows for bridging the consumer to the Camel routing Error Handler which mean any exceptions occurred while the consumer is trying to pickup incoming messages or the likes will now be processed as a message and handled by the routing Error Handler. By default the consumer will use the org.apache.camel.spi.ExceptionHandler to deal with exceptions that will be logged at WARN/ERROR level and ignored.
-| exceptionHandler | consumer (advanced) |  | ExceptionHandler | To let the consumer use a custom ExceptionHandler. Notice if the option bridgeErrorHandler is enabled then this options is not in use. By default the consumer will deal with exceptions that will be logged at WARN/ERROR level and ignored.
-| exchangePattern | advanced | InOnly | ExchangePattern | Sets the default exchange pattern when creating an exchange
-| synchronous | advanced | false | boolean | Sets whether synchronous processing should be strictly used or Camel is allowed to use asynchronous processing (if supported).
-|=======================================================================
-{% endraw %}
-// endpoint options: END
-
-