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:40 UTC

[16/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-ibatis/src/main/docs/ibatis.adoc
----------------------------------------------------------------------
diff --git a/components/camel-ibatis/src/main/docs/ibatis.adoc b/components/camel-ibatis/src/main/docs/ibatis.adoc
deleted file mode 100644
index ef532b0..0000000
--- a/components/camel-ibatis/src/main/docs/ibatis.adoc
+++ /dev/null
@@ -1,260 +0,0 @@
-[[iBATIS-iBATIS]]
-iBATIS
-~~~~~~
-
-The *ibatis:* component allows you to query, poll, insert, update and
-delete data in a relational database using
-http://ibatis.apache.org/[Apache iBATIS].
-
-*Prefer MyBatis*
-
-The Apache iBatis project is no longer active. The project is moved
-outside Apache and is now know as the MyBatis project. +
-Therefore we encourage users to use link:mybatis.html[MyBatis] instead.
-This camel-ibatis component will be removed in Camel 3.0.
-
-iBatis do not support Spring 4.x. So you can only use Spring 3.x or
-older with iBatis.
-
-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-ibatis</artifactId>
-    <version>x.x.x</version>
-    <!-- use the same version as your Camel core version -->
-</dependency>
-------------------------------------------------------------
-
-[[iBATIS-URIformat]]
-URI format
-^^^^^^^^^^
-
-[source,java]
-------------------------------
-ibatis:statementName[?options]
-------------------------------
-
-Where *statementName* is the name in the iBATIS XML configuration file
-which maps to the query, insert, update or delete operation you wish to
-evaluate.
-
-You can append query options to the URI in the following format,
-`?option=value&option=value&...`
-
-This component will by default load the iBatis SqlMapConfig file from
-the root of the classpath and expected named as `SqlMapConfig.xml`. +
- It uses Spring resource loading so you can define it using `classpath`,
-`file` or `http` as prefix to load resources with those schemes. +
- In Camel 2.2 you can configure this on the iBatisComponent with the
-`setSqlMapConfig(String)` method.
-
-[[iBATIS-Options]]
-Options
-^^^^^^^
-
-
-
-// component options: START
-The iBatis component supports 3 options which are listed below.
-
-
-
-{% raw %}
-[width="100%",cols="2s,1m,8",options="header"]
-|=======================================================================
-| Name | Java Type | Description
-| sqlMapClient | SqlMapClient | To use the given com.ibatis.sqlmap.client.SqlMapClient
-| sqlMapConfig | String | Location of iBatis xml configuration file. The default value is: SqlMapConfig.xml loaded from the classpath
-| useTransactions | boolean | Whether to use transactions. This option is by default true.
-|=======================================================================
-{% endraw %}
-// component options: END
-
-
-
-
-
-
-
-// endpoint options: START
-The iBatis component supports 28 endpoint options which are listed below:
-
-{% raw %}
-[width="100%",cols="2s,1,1m,1m,5",options="header"]
-|=======================================================================
-| Name | Group | Default | Java Type | Description
-| statement | common |  | String | *Required* The statement name in the iBatis XML mapping file which maps to the query insert update or delete operation you wish to evaluate.
-| isolation | common | TRANSACTION_REPEATABLE_READ | String | Transaction isolation level
-| useTransactions | common | true | boolean | Whether to use transactions. This option is by default true.
-| 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.
-| maxMessagesPerPoll | consumer | 0 | int | This option is intended to split results returned by the database pool into the batches and deliver them in multiple exchanges. This integer defines the maximum messages to deliver in single exchange. By default no maximum is set. Can be used to set a limit of e.g. 1000 to avoid when starting up the server that there are thousands of files. Set a value of 0 or negative to disable it.
-| onConsume | consumer |  | String | Statement to run after data has been processed in the route
-| routeEmptyResultSet | consumer | false | boolean | Whether allow empty resultset to be routed to the next hop
-| sendEmptyMessageWhenIdle | consumer | false | boolean | If the polling consumer did not poll any files you can enable this option to send an empty message (no body) instead.
-| strategy | consumer |  | IBatisProcessingStrategy | Allows to plugin a custom IBatisProcessingStrategy to use by the consumer.
-| useIterator | consumer | true | boolean | Process resultset individually or as a list
-| 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.
-| pollStrategy | consumer (advanced) |  | PollingConsumerPollStrategy | A pluggable org.apache.camel.PollingConsumerPollingStrategy allowing you to provide your custom implementation to control error handling usually occurred during the poll operation before an Exchange have been created and being routed in Camel.
-| statementType | producer |  | StatementType | Mandatory to specify for the producer to control which kind of operation to invoke.
-| 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).
-| backoffErrorThreshold | scheduler |  | int | The number of subsequent error polls (failed due some error) that should happen before the backoffMultipler should kick-in.
-| backoffIdleThreshold | scheduler |  | int | The number of subsequent idle polls that should happen before the backoffMultipler should kick-in.
-| backoffMultiplier | scheduler |  | int | To let the scheduled polling consumer backoff if there has been a number of subsequent idles/errors in a row. The multiplier is then the number of polls that will be skipped before the next actual attempt is happening again. When this option is in use then backoffIdleThreshold and/or backoffErrorThreshold must also be configured.
-| delay | scheduler | 500 | long | Milliseconds before the next poll. You can also specify time values using units such as 60s (60 seconds) 5m30s (5 minutes and 30 seconds) and 1h (1 hour).
-| greedy | scheduler | false | boolean | If greedy is enabled then the ScheduledPollConsumer will run immediately again if the previous run polled 1 or more messages.
-| initialDelay | scheduler | 1000 | long | Milliseconds before the first poll starts. You can also specify time values using units such as 60s (60 seconds) 5m30s (5 minutes and 30 seconds) and 1h (1 hour).
-| runLoggingLevel | scheduler | TRACE | LoggingLevel | The consumer logs a start/complete log line when it polls. This option allows you to configure the logging level for that.
-| scheduledExecutorService | scheduler |  | ScheduledExecutorService | Allows for configuring a custom/shared thread pool to use for the consumer. By default each consumer has its own single threaded thread pool.
-| scheduler | scheduler | none | ScheduledPollConsumerScheduler | To use a cron scheduler from either camel-spring or camel-quartz2 component
-| schedulerProperties | scheduler |  | Map | To configure additional properties when using a custom scheduler or any of the Quartz2 Spring based scheduler.
-| startScheduler | scheduler | true | boolean | Whether the scheduler should be auto started.
-| timeUnit | scheduler | MILLISECONDS | TimeUnit | Time unit for initialDelay and delay options.
-| useFixedDelay | scheduler | true | boolean | Controls if fixed delay or fixed rate is used. See ScheduledExecutorService in JDK for details.
-|=======================================================================
-{% endraw %}
-// endpoint options: END
-
-
-
-
-
-[[iBATIS-MessageHeaders]]
-Message Headers
-^^^^^^^^^^^^^^^
-
-Camel will populate the result message, either IN or OUT with a header
-with the operationName used:
-
-[width="100%",cols="10%,10%,80%",options="header",]
-|=======================================================================
-|Header |Type |Description
-
-|`CamelIBatisStatementName` |`String` |The *statementName* used (for example: insertAccount).
-
-|`CamelIBatisResult` |`Object` |The *response* returned from iBatis in any of the operations. For
-instance an `INSERT` could return the auto-generated key, or number of
-rows etc.
-|=======================================================================
-
-[[iBATIS-MessageBody]]
-Message Body
-^^^^^^^^^^^^
-
-The response from iBatis will only be set as body if it's a `SELECT`
-statement. That means, for example, for `INSERT` statements Camel will
-not replace the body. This allows you to continue routing and keep the
-original body. The response from iBatis is always stored in the header
-with the key `CamelIBatisResult`.
-
-[[iBATIS-Samples]]
-Samples
-^^^^^^^
-
-For example if you wish to consume beans from a JMS queue and insert
-them into a database you could do the following:
-
-[source,java]
---------------------------------------------------
-from("activemq:queue:newAccount").
-  to("ibatis:insertAccount?statementType=Insert");
---------------------------------------------------
-
-Notice we have to specify the `statementType`, as we need to instruct
-Camel which `SqlMapClient` operation to invoke.
-
-Where *insertAccount* is the iBatis ID in the SQL map file:
-
-[source,xml]
-------------------------------------------------------------
-  <!-- Insert example, using the Account parameter class -->
-  <insert id="insertAccount" parameterClass="Account">
-    insert into ACCOUNT (
-      ACC_ID,
-      ACC_FIRST_NAME,
-      ACC_LAST_NAME,
-      ACC_EMAIL
-    )
-    values (
-      #id#, #firstName#, #lastName#, #emailAddress#
-    )
-  </insert>
-------------------------------------------------------------
-
-[[iBATIS-UsingStatementTypeforbettercontrolofIBatis]]
-Using StatementType for better control of IBatis
-^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^
-
-When routing to an iBatis endpoint you want more fine grained control so
-you can control whether the SQL statement to be executed is a `SELEECT`,
-`UPDATE`, `DELETE` or `INSERT` etc. So for instance if we want to route
-to an iBatis endpoint in which the IN body contains parameters to a
-`SELECT` statement we can do:
-
-In the code above we can invoke the iBatis statement `selectAccountById`
-and the IN body should contain the account id we want to retrieve, such
-as an `Integer` type.
-
-We can do the same for some of the other operations, such as
-`QueryForList`:
-
-And the same for `UPDATE`, where we can send an `Account` object as IN
-body to iBatis:
-
-[[iBATIS-Scheduledpollingexample]]
-Scheduled polling example
-+++++++++++++++++++++++++
-
-Since this component does not support scheduled polling, you need to use
-another mechanism for triggering the scheduled polls, such as the
-link:timer.html[Timer] or link:quartz.html[Quartz] components.
-
-In the sample below we poll the database, every 30 seconds using the
-link:timer.html[Timer] component and send the data to the JMS queue:
-
-[source,java]
----------------------------------------------------------------------------------------------------------------------------------------
-from("timer://pollTheDatabase?delay=30000").to("ibatis:selectAllAccounts?statementType=QueryForList").to("activemq:queue:allAccounts");
----------------------------------------------------------------------------------------------------------------------------------------
-
-And the iBatis SQL map file used:
-
-[source,xml]
-----------------------------------------------------------------------------
-  <!-- Select with no parameters using the result map for Account class. -->
-  <select id="selectAllAccounts" resultMap="AccountResult">
-    select * from ACCOUNT
-  </select>
-----------------------------------------------------------------------------
-
-[[iBATIS-UsingonConsume]]
-Using onConsume
-+++++++++++++++
-
-This component supports executing statements *after* data have been
-consumed and processed by Camel. This allows you to do post updates in
-the database. Notice all statements must be `UPDATE` statements. Camel
-supports executing multiple statements whose name should be separated by
-comma.
-
-The route below illustrates we execute the *consumeAccount* statement
-data is processed. This allows us to change the status of the row in the
-database to processed, so we avoid consuming it twice or more.
-
-And the statements in the sqlmap file:
-
-[[iBATIS-SeeAlso]]
-See Also
-^^^^^^^^
-
-* link:configuring-camel.html[Configuring Camel]
-* link:component.html[Component]
-* link:endpoint.html[Endpoint]
-* link:getting-started.html[Getting Started]
-
-* link:mybatis.html[MyBatis]
-

http://git-wip-us.apache.org/repos/asf/camel/blob/9c0b7baf/components/camel-infinispan/src/main/docs/infinispan-component.adoc
----------------------------------------------------------------------
diff --git a/components/camel-infinispan/src/main/docs/infinispan-component.adoc b/components/camel-infinispan/src/main/docs/infinispan-component.adoc
new file mode 100644
index 0000000..dca990c
--- /dev/null
+++ b/components/camel-infinispan/src/main/docs/infinispan-component.adoc
@@ -0,0 +1,191 @@
+[[Infinispan-InfinispanComponent]]
+Infinispan Component
+~~~~~~~~~~~~~~~~~~~~
+
+*Available as of Camel 2.13.0*
+
+This component allows you to interact with
+http://infinispan.org/[Infinispan] distributed data grid / cache.
+Infinispan is an extremely scalable, highly available key/value data
+store and data grid platform written in Java.
+
+From�*Camel 2.17* onwards Infinispan requires Java 8.
+
+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-infinispan</artifactId>
+    <version>x.x.x</version>
+    <!-- use the same version as your Camel core version -->
+</dependency>
+------------------------------------------------------------
+
+[[Infinispan-URIformat]]
+URI format
+^^^^^^^^^^
+
+[source,java]
+-------------------------------
+infinispan://hostName?[options]
+-------------------------------
+
+[[Infinispan-URIOptions]]
+URI Options
+^^^^^^^^^^^
+
+The producer allows sending messages to a local infinispan cache
+configured in the registry, or to a remote cache using the HotRod
+protocol. The consumer allows listening for events from local infinispan cache
+accessible from the registry.
+
+
+// component options: START
+The Infinispan component has no options.
+// component options: END
+
+
+
+
+// endpoint options: START
+The Infinispan component supports 15 endpoint options which are listed below:
+
+{% raw %}
+[width="100%",cols="2s,1,1m,1m,5",options="header"]
+|=======================================================================
+| Name | Group | Default | Java Type | Description
+| host | common |  | String | *Required* Specifies the host of the cache on Infinispan instance
+| cacheContainer | common |  | BasicCacheContainer | Specifies the cache Container to connect
+| cacheName | common |  | String | Specifies the cache name
+| queryBuilder | common |  | InfinispanQueryBuilder | Specifies the query builder.
+| 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.
+| clusteredListener | consumer | false | boolean | If true the listener will be installed for the entire cluster
+| customListener | consumer |  | InfinispanCustomListener | Returns the custom listener in use if provided
+| eventTypes | consumer |  | String | Specifies the set of event types to register by the consumer. Multiple event can be separated by comma. The possible event types are: CACHE_ENTRY_ACTIVATED CACHE_ENTRY_PASSIVATED CACHE_ENTRY_VISITED CACHE_ENTRY_LOADED CACHE_ENTRY_EVICTED CACHE_ENTRY_CREATED CACHE_ENTRY_REMOVED CACHE_ENTRY_MODIFIED TRANSACTION_COMPLETED TRANSACTION_REGISTERED CACHE_ENTRY_INVALIDATED DATA_REHASHED TOPOLOGY_CHANGED PARTITION_STATUS_CHANGED
+| sync | consumer | true | boolean | If true the consumer will receive notifications synchronously
+| 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.
+| command | producer | put | String | The operation to perform.
+| configurationUri | advanced |  | String | An implementation specific URI for the CacheManager
+| exchangePattern | advanced | InOnly | ExchangePattern | Sets the default exchange pattern when creating an exchange
+| flags | advanced |  | String | A comma separated list of Flag to be applied by default on each cache invocation not applicable to remote caches.
+| 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
+
+
+
+[[Infinispan-MessageHeaders]]
+Message Headers
+^^^^^^^^^^^^^^^
+
+[width="100%",cols="10%,10%,10%,10%,60%",options="header",]
+|=======================================================================
+|Name |Default Value |Type |Context |Description
+
+|CamelInfinispanCacheName |`null` |String |Shared |The cache participating in the operation or event.
+
+|CamelInfinispanOperation |`PUT` |String |Producer |The operation to perform: CamelInfinispanOperationPut,
+CamelInfinispanOperationGet, CamelInfinispanOperationRemove,
+CamelInfinispanOperationClear. *From Camel 2.16:* CamelInfinispanOperationPutAll,
+CamelInfinispanOperationPutIfAbsent, CamelInfinispanOperationReplace,
+CamelInfinispanOperationSize.
+
+|CamelInfinispanMap |`null` |Map |Producer |A Map to use in case of CamelInfinispanOperationPutAll operation
+
+|CamelInfinispanKey |`null` |Object |Shared |The key to perform the operation to or the key generating the event.
+
+|CamelInfinispanValue |`null` |Object |Producer |The value to use for the operation.
+
+|CamelInfinispanOperationResult |`null` |Object |Producer |The result of the operation.
+
+|CamelInfinispanEventType |`null` |String |Consumer |The type of the received event. Possible values defined here
+org.infinispan.notifications.cachelistener.event.Event.Type
+
+|CamelInfinispanIsPre |`null` |Boolean |Consumer |Infinispan fires two events for each operation: one before and one after
+the operation.
+
+|CamelInfinispanLifespanTime |`null` |long |Producer |The Lifespan time of a value inside the cache. Negative values are
+interpreted as infinity.
+
+|CamelInfinispanTimeUnit |`null` |String |Producer |The Time Unit of an entry Lifespan Time.
+
+|CamelInfinispanMaxIdleTime |`null` |long |Producer |The maximum amount of time an entry is allowed to be idle for before it
+is considered as expired.
+
+|CamelInfinispanMaxIdleTimeUnit |`null` |String |Producer |The Time Unit of an entry Max Idle Time.
+
+|CamelInfinispanQueryBuilder |null |InfinispanQueryBuilder |Producer | *From Camel 2.17:* The QueryBuilde to use for QUERY command, if not
+present the command defaults to InifinispanConfiguration's one
+
+|CamelInfinispanIgnoreReturnValues |null |Boolean |Producer |*From Camel 2.17:* If this header is set, the return value for cache
+operation returning something is ignored by the client application
+|=======================================================================
+
+[[Infinispan-Example]]
+Example
+^^^^^^^
+
+Below is an example route that retrieves a value from the cache for a
+specific key:
+
+[source,java]
+------------------------------------------------------------------------------------
+from("direct:start")
+        .setHeader(InfinispanConstants.OPERATION, constant(InfinispanConstants.GET))
+        .setHeader(InfinispanConstants.KEY, constant("123"))
+        .to("infinispan://localhost?cacheContainer=#cacheContainer");
+------------------------------------------------------------------------------------
+
+[[Infinispan-UsingtheInfinispanbasedidempotentrepository]]
+Using the Infinispan based idempotent repository
+^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^
+
+In this section we will use the Infinispan based idempotent repository.
+
+First, we need to create a cacheManager and then configure our
+
+------------------------------------------------------------------------------------------
+org.apache.camel.component.infinispan.processor.idempotent.InfinispanIdempotentRepository:
+------------------------------------------------------------------------------------------
+
+[source,xml]
+---------------------------------------------------------------------------------------------------------------------------
+<bean id="cacheManager" class="org.infinispan.manager.DefaultCacheManager" init-method="start" destroy-method="stop"/>
+<bean id="infinispanRepo" class="org.apache.camel.component.infinispan.processor.idempotent.InfinispanIdempotentRepository"
+      factory-method="infinispanIdempotentRepository">
+    <argument ref="cacheManager"/>
+    <argument value="idempotent"/>
+</bean>
+---------------------------------------------------------------------------------------------------------------------------
+
+Then we can create our Infinispan idempotent repository in the spring
+XML file as well:
+
+[source,xml]
+---------------------------------------------------------------------
+<camelContext xmlns="http://camel.apache.org/schema/spring">   
+    <route id="JpaMessageIdRepositoryTest">
+        <from uri="direct:start" />
+        <idempotentConsumer messageIdRepositoryRef="infinispanStore">
+            <header>messageId</header>
+            <to uri="mock:result" />
+        </idempotentConsumer>
+    </route>
+</camelContext>
+---------------------------------------------------------------------
+
+For more information, see these resources...
+
+[[Infinispan-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-infinispan/src/main/docs/infinispan.adoc
----------------------------------------------------------------------
diff --git a/components/camel-infinispan/src/main/docs/infinispan.adoc b/components/camel-infinispan/src/main/docs/infinispan.adoc
deleted file mode 100644
index dca990c..0000000
--- a/components/camel-infinispan/src/main/docs/infinispan.adoc
+++ /dev/null
@@ -1,191 +0,0 @@
-[[Infinispan-InfinispanComponent]]
-Infinispan Component
-~~~~~~~~~~~~~~~~~~~~
-
-*Available as of Camel 2.13.0*
-
-This component allows you to interact with
-http://infinispan.org/[Infinispan] distributed data grid / cache.
-Infinispan is an extremely scalable, highly available key/value data
-store and data grid platform written in Java.
-
-From�*Camel 2.17* onwards Infinispan requires Java 8.
-
-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-infinispan</artifactId>
-    <version>x.x.x</version>
-    <!-- use the same version as your Camel core version -->
-</dependency>
-------------------------------------------------------------
-
-[[Infinispan-URIformat]]
-URI format
-^^^^^^^^^^
-
-[source,java]
--------------------------------
-infinispan://hostName?[options]
--------------------------------
-
-[[Infinispan-URIOptions]]
-URI Options
-^^^^^^^^^^^
-
-The producer allows sending messages to a local infinispan cache
-configured in the registry, or to a remote cache using the HotRod
-protocol. The consumer allows listening for events from local infinispan cache
-accessible from the registry.
-
-
-// component options: START
-The Infinispan component has no options.
-// component options: END
-
-
-
-
-// endpoint options: START
-The Infinispan component supports 15 endpoint options which are listed below:
-
-{% raw %}
-[width="100%",cols="2s,1,1m,1m,5",options="header"]
-|=======================================================================
-| Name | Group | Default | Java Type | Description
-| host | common |  | String | *Required* Specifies the host of the cache on Infinispan instance
-| cacheContainer | common |  | BasicCacheContainer | Specifies the cache Container to connect
-| cacheName | common |  | String | Specifies the cache name
-| queryBuilder | common |  | InfinispanQueryBuilder | Specifies the query builder.
-| 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.
-| clusteredListener | consumer | false | boolean | If true the listener will be installed for the entire cluster
-| customListener | consumer |  | InfinispanCustomListener | Returns the custom listener in use if provided
-| eventTypes | consumer |  | String | Specifies the set of event types to register by the consumer. Multiple event can be separated by comma. The possible event types are: CACHE_ENTRY_ACTIVATED CACHE_ENTRY_PASSIVATED CACHE_ENTRY_VISITED CACHE_ENTRY_LOADED CACHE_ENTRY_EVICTED CACHE_ENTRY_CREATED CACHE_ENTRY_REMOVED CACHE_ENTRY_MODIFIED TRANSACTION_COMPLETED TRANSACTION_REGISTERED CACHE_ENTRY_INVALIDATED DATA_REHASHED TOPOLOGY_CHANGED PARTITION_STATUS_CHANGED
-| sync | consumer | true | boolean | If true the consumer will receive notifications synchronously
-| 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.
-| command | producer | put | String | The operation to perform.
-| configurationUri | advanced |  | String | An implementation specific URI for the CacheManager
-| exchangePattern | advanced | InOnly | ExchangePattern | Sets the default exchange pattern when creating an exchange
-| flags | advanced |  | String | A comma separated list of Flag to be applied by default on each cache invocation not applicable to remote caches.
-| 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
-
-
-
-[[Infinispan-MessageHeaders]]
-Message Headers
-^^^^^^^^^^^^^^^
-
-[width="100%",cols="10%,10%,10%,10%,60%",options="header",]
-|=======================================================================
-|Name |Default Value |Type |Context |Description
-
-|CamelInfinispanCacheName |`null` |String |Shared |The cache participating in the operation or event.
-
-|CamelInfinispanOperation |`PUT` |String |Producer |The operation to perform: CamelInfinispanOperationPut,
-CamelInfinispanOperationGet, CamelInfinispanOperationRemove,
-CamelInfinispanOperationClear. *From Camel 2.16:* CamelInfinispanOperationPutAll,
-CamelInfinispanOperationPutIfAbsent, CamelInfinispanOperationReplace,
-CamelInfinispanOperationSize.
-
-|CamelInfinispanMap |`null` |Map |Producer |A Map to use in case of CamelInfinispanOperationPutAll operation
-
-|CamelInfinispanKey |`null` |Object |Shared |The key to perform the operation to or the key generating the event.
-
-|CamelInfinispanValue |`null` |Object |Producer |The value to use for the operation.
-
-|CamelInfinispanOperationResult |`null` |Object |Producer |The result of the operation.
-
-|CamelInfinispanEventType |`null` |String |Consumer |The type of the received event. Possible values defined here
-org.infinispan.notifications.cachelistener.event.Event.Type
-
-|CamelInfinispanIsPre |`null` |Boolean |Consumer |Infinispan fires two events for each operation: one before and one after
-the operation.
-
-|CamelInfinispanLifespanTime |`null` |long |Producer |The Lifespan time of a value inside the cache. Negative values are
-interpreted as infinity.
-
-|CamelInfinispanTimeUnit |`null` |String |Producer |The Time Unit of an entry Lifespan Time.
-
-|CamelInfinispanMaxIdleTime |`null` |long |Producer |The maximum amount of time an entry is allowed to be idle for before it
-is considered as expired.
-
-|CamelInfinispanMaxIdleTimeUnit |`null` |String |Producer |The Time Unit of an entry Max Idle Time.
-
-|CamelInfinispanQueryBuilder |null |InfinispanQueryBuilder |Producer | *From Camel 2.17:* The QueryBuilde to use for QUERY command, if not
-present the command defaults to InifinispanConfiguration's one
-
-|CamelInfinispanIgnoreReturnValues |null |Boolean |Producer |*From Camel 2.17:* If this header is set, the return value for cache
-operation returning something is ignored by the client application
-|=======================================================================
-
-[[Infinispan-Example]]
-Example
-^^^^^^^
-
-Below is an example route that retrieves a value from the cache for a
-specific key:
-
-[source,java]
-------------------------------------------------------------------------------------
-from("direct:start")
-        .setHeader(InfinispanConstants.OPERATION, constant(InfinispanConstants.GET))
-        .setHeader(InfinispanConstants.KEY, constant("123"))
-        .to("infinispan://localhost?cacheContainer=#cacheContainer");
-------------------------------------------------------------------------------------
-
-[[Infinispan-UsingtheInfinispanbasedidempotentrepository]]
-Using the Infinispan based idempotent repository
-^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^
-
-In this section we will use the Infinispan based idempotent repository.
-
-First, we need to create a cacheManager and then configure our
-
-------------------------------------------------------------------------------------------
-org.apache.camel.component.infinispan.processor.idempotent.InfinispanIdempotentRepository:
-------------------------------------------------------------------------------------------
-
-[source,xml]
----------------------------------------------------------------------------------------------------------------------------
-<bean id="cacheManager" class="org.infinispan.manager.DefaultCacheManager" init-method="start" destroy-method="stop"/>
-<bean id="infinispanRepo" class="org.apache.camel.component.infinispan.processor.idempotent.InfinispanIdempotentRepository"
-      factory-method="infinispanIdempotentRepository">
-    <argument ref="cacheManager"/>
-    <argument value="idempotent"/>
-</bean>
----------------------------------------------------------------------------------------------------------------------------
-
-Then we can create our Infinispan idempotent repository in the spring
-XML file as well:
-
-[source,xml]
----------------------------------------------------------------------
-<camelContext xmlns="http://camel.apache.org/schema/spring">   
-    <route id="JpaMessageIdRepositoryTest">
-        <from uri="direct:start" />
-        <idempotentConsumer messageIdRepositoryRef="infinispanStore">
-            <header>messageId</header>
-            <to uri="mock:result" />
-        </idempotentConsumer>
-    </route>
-</camelContext>
----------------------------------------------------------------------
-
-For more information, see these resources...
-
-[[Infinispan-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-influxdb/src/main/docs/influxdb-component.adoc
----------------------------------------------------------------------
diff --git a/components/camel-influxdb/src/main/docs/influxdb-component.adoc b/components/camel-influxdb/src/main/docs/influxdb-component.adoc
new file mode 100644
index 0000000..a61f574
--- /dev/null
+++ b/components/camel-influxdb/src/main/docs/influxdb-component.adoc
@@ -0,0 +1,117 @@
+[[InfluxDb-InfluxDbComponent]]
+InfluxDb Component
+~~~~~~~~~~~~~~~~~~~~
+
+*Available as of Camel 2.18.0*
+
+This component allows you to interact with InfluxDB
+https://influxdata.com/time-series-platform/influxdb/ a time series database. The native body type for this component is
+Point (the native influxdb class), but it can also accept Map<String, Object> as message body and it will get converted
+to Point.class, please note that the map must contain an element with InfluxDbConstants.MEASUREMENT_NAME as key.
+
+Aditionally of course you may register your own Converters to your data type to Point, or use the
+(un)marshalling tools provided by camel.
+
+
+From�*Camel 2.18* onwards Influxdb requires Java 8.
+
+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-influxdb</artifactId>
+    <version>x.x.x</version>
+    <!-- use the same version as your Camel core version -->
+</dependency>
+------------------------------------------------------------
+
+[[InfluxDb-URIformat]]
+URI format
+^^^^^^^^^^
+
+[source,java]
+-------------------------------
+influxdb://beanName?[options]
+-------------------------------
+
+[[InfluxDb-URIOptions]]
+URI Options
+^^^^^^^^^^^
+
+The producer allows sending messages to a influxdb
+configured in the registry, using the native java driver.
+
+
+
+// component options: START
+The InfluxDB component has no options.
+// component options: END
+
+
+
+
+// endpoint options: START
+The InfluxDB 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
+| connectionBean | producer |  | String | *Required* Name of org.influxdb.InfluxDB to use.
+| databaseName | producer |  | String | Setter for databaseName
+| retentionPolicy | producer | default | String | Setter for retentionPolicy
+| 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
+
+
+
+
+[[InfluxDb-MessageHeaders]]
+Message Headers
+^^^^^^^^^^^^^^^
+
+[width="100%",cols="10%,10%,10%,10%,60%",options="header",]
+|=======================================================================
+|Name |Default Value |Type |Context |Description
+
+
+|=======================================================================
+
+[[InfluxDb-Example]]
+Example
+^^^^^^^
+
+
+Below is an example route that stores a point into the db (taking the db name from the URI)
+specific key:
+
+[source,java]
+------------------------------------------------------------------------------------
+from("direct:start")
+        .setHeader(InfluxDbConstants.DBNAME_HEADER, constant("myTimeSeriesDB"))
+        .to("influxdb://connectionBean);
+------------------------------------------------------------------------------------
+
+[source,java]
+------------------------------------------------------------------------------------
+from("direct:start")
+        .to("influxdb://connectionBean?databaseName=myTimeSeriesDB");
+------------------------------------------------------------------------------------
+
+For more information, see these resources...
+
+[[InfluxDb-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-influxdb/src/main/docs/influxdb.adoc
----------------------------------------------------------------------
diff --git a/components/camel-influxdb/src/main/docs/influxdb.adoc b/components/camel-influxdb/src/main/docs/influxdb.adoc
deleted file mode 100644
index a61f574..0000000
--- a/components/camel-influxdb/src/main/docs/influxdb.adoc
+++ /dev/null
@@ -1,117 +0,0 @@
-[[InfluxDb-InfluxDbComponent]]
-InfluxDb Component
-~~~~~~~~~~~~~~~~~~~~
-
-*Available as of Camel 2.18.0*
-
-This component allows you to interact with InfluxDB
-https://influxdata.com/time-series-platform/influxdb/ a time series database. The native body type for this component is
-Point (the native influxdb class), but it can also accept Map<String, Object> as message body and it will get converted
-to Point.class, please note that the map must contain an element with InfluxDbConstants.MEASUREMENT_NAME as key.
-
-Aditionally of course you may register your own Converters to your data type to Point, or use the
-(un)marshalling tools provided by camel.
-
-
-From�*Camel 2.18* onwards Influxdb requires Java 8.
-
-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-influxdb</artifactId>
-    <version>x.x.x</version>
-    <!-- use the same version as your Camel core version -->
-</dependency>
-------------------------------------------------------------
-
-[[InfluxDb-URIformat]]
-URI format
-^^^^^^^^^^
-
-[source,java]
--------------------------------
-influxdb://beanName?[options]
--------------------------------
-
-[[InfluxDb-URIOptions]]
-URI Options
-^^^^^^^^^^^
-
-The producer allows sending messages to a influxdb
-configured in the registry, using the native java driver.
-
-
-
-// component options: START
-The InfluxDB component has no options.
-// component options: END
-
-
-
-
-// endpoint options: START
-The InfluxDB 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
-| connectionBean | producer |  | String | *Required* Name of org.influxdb.InfluxDB to use.
-| databaseName | producer |  | String | Setter for databaseName
-| retentionPolicy | producer | default | String | Setter for retentionPolicy
-| 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
-
-
-
-
-[[InfluxDb-MessageHeaders]]
-Message Headers
-^^^^^^^^^^^^^^^
-
-[width="100%",cols="10%,10%,10%,10%,60%",options="header",]
-|=======================================================================
-|Name |Default Value |Type |Context |Description
-
-
-|=======================================================================
-
-[[InfluxDb-Example]]
-Example
-^^^^^^^
-
-
-Below is an example route that stores a point into the db (taking the db name from the URI)
-specific key:
-
-[source,java]
-------------------------------------------------------------------------------------
-from("direct:start")
-        .setHeader(InfluxDbConstants.DBNAME_HEADER, constant("myTimeSeriesDB"))
-        .to("influxdb://connectionBean);
-------------------------------------------------------------------------------------
-
-[source,java]
-------------------------------------------------------------------------------------
-from("direct:start")
-        .to("influxdb://connectionBean?databaseName=myTimeSeriesDB");
-------------------------------------------------------------------------------------
-
-For more information, see these resources...
-
-[[InfluxDb-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-irc/src/main/docs/irc-component.adoc
----------------------------------------------------------------------
diff --git a/components/camel-irc/src/main/docs/irc-component.adoc b/components/camel-irc/src/main/docs/irc-component.adoc
new file mode 100644
index 0000000..7635d91
--- /dev/null
+++ b/components/camel-irc/src/main/docs/irc-component.adoc
@@ -0,0 +1,212 @@
+[[IRC-IRCComponent]]
+IRC Component
+~~~~~~~~~~~~~
+
+The *irc* component implements an
+http://en.wikipedia.org/wiki/Internet_Relay_Chat[IRC] (Internet Relay
+Chat) transport.
+
+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-irc</artifactId>
+    <version>x.x.x</version>
+    <!-- use the same version as your Camel core version -->
+</dependency>
+------------------------------------------------------------
+
+[[IRC-URIformat]]
+URI format
+^^^^^^^^^^
+
+[source,java]
+---------------------------------------------------------------------
+irc:nick@host[:port]/#room[?options]
+irc:nick@host[:port]?channels=#channel1,#channel2,#channel3[?options]
+---------------------------------------------------------------------
+
+You can append query options to the URI in the following format,
+`?option=value&option=value&...`
+
+[[IRC-Options]]
+Options
+^^^^^^^
+
+
+// component options: START
+The IRC component has no options.
+// component options: END
+
+
+
+
+
+
+
+// endpoint options: START
+The IRC component supports 26 endpoint options which are listed below:
+
+{% raw %}
+[width="100%",cols="2s,1,1m,1m,5",options="header"]
+|=======================================================================
+| Name | Group | Default | Java Type | Description
+| hostname | common |  | String | *Required* Hostname for the IRC chat server
+| port | common | 6667,6668,6669 | int | Port number for the IRC chat server
+| autoRejoin | common | true | boolean | Whether to auto re-join when being kicked
+| namesOnJoin | common | false | boolean | Sends NAMES command to channel after joining it. link onReply has to be true in order to process the result which will have the header value irc.num = '353'.
+| nickname | common |  | String | The nickname used in chat.
+| persistent | common | true | boolean | Use persistent messages.
+| realname | common |  | String | The IRC user's actual name.
+| 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.
+| colors | advanced | true | boolean | Whether or not the server supports color codes.
+| 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).
+| onJoin | filter | true | boolean | Handle user join events.
+| onKick | filter | true | boolean | Handle kick events.
+| onMode | filter | true | boolean | Handle mode change events.
+| onNick | filter | true | boolean | Handle nickname change events.
+| onPart | filter | true | boolean | Handle user part events.
+| onPrivmsg | filter | true | boolean | Handle private message events.
+| onQuit | filter | true | boolean | Handle user quit events.
+| onReply | filter | false | boolean | Whether or not to handle general responses to commands or informational messages.
+| onTopic | filter | true | boolean | Handle topic change events.
+| nickPassword | security |  | String | Your IRC server nickname password.
+| password | security |  | String | The IRC server password.
+| sslContextParameters | security |  | SSLContextParameters | Used for configuring security using SSL. Reference to a org.apache.camel.util.jsse.SSLContextParameters in the Registry. This reference overrides any configured SSLContextParameters at the component level. Note that this setting overrides the trustManager option.
+| trustManager | security |  | SSLTrustManager | The trust manager used to verify the SSL server's certificate.
+| username | security |  | String | The IRC server user name.
+|=======================================================================
+{% endraw %}
+// endpoint options: END
+
+
+
+
+
+
+[[IRC-SSLSupport]]
+SSL Support
+^^^^^^^^^^^
+
+[[IRC-UsingtheJSSEConfigurationUtility]]
+Using the JSSE Configuration Utility
+++++++++++++++++++++++++++++++++++++
+
+As of Camel 2.9, the IRC component supports SSL/TLS configuration
+through the link:camel-configuration-utilities.html[Camel JSSE
+Configuration Utility].� This utility greatly decreases the amount of
+component specific code you need to write and is configurable at the
+endpoint and component levels.� The following examples demonstrate how
+to use the utility with the IRC component.
+
+[[IRC-Programmaticconfigurationoftheendpoint]]
+Programmatic configuration of the endpoint
+
+[source,java]
+-----------------------------------------------------------------------------------------------------------------------------------------
+KeyStoreParameters ksp = new KeyStoreParameters();
+ksp.setResource("/users/home/server/truststore.jks");
+ksp.setPassword("keystorePassword");
+
+TrustManagersParameters tmp = new TrustManagersParameters();
+tmp.setKeyStore(ksp);
+
+SSLContextParameters scp = new SSLContextParameters();
+scp.setTrustManagers(tmp);
+
+Registry registry = ...
+registry.bind("sslContextParameters", scp);
+
+...
+
+from(...)
+    .to("ircs://camel-prd-user@server:6669/#camel-test?nickname=camel-prd&password=password&sslContextParameters=#sslContextParameters");
+-----------------------------------------------------------------------------------------------------------------------------------------
+
+[[IRC-SpringDSLbasedconfigurationofendpoint]]
+Spring DSL based configuration of endpoint
+
+[source,xml]
+----------------------------------------------------------------------------------------------------------------------------------------------
+...
+  <camel:sslContextParameters
+      id="sslContextParameters">
+    <camel:trustManagers>
+      <camel:keyStore
+          resource="/users/home/server/truststore.jks"
+          password="keystorePassword"/>
+    </camel:keyManagers>
+  </camel:sslContextParameters>...
+...
+  <to uri="ircs://camel-prd-user@server:6669/#camel-test?nickname=camel-prd&password=password&sslContextParameters=#sslContextParameters"/>...
+----------------------------------------------------------------------------------------------------------------------------------------------
+
+[[IRC-Usingthelegacybasicconfigurationoptions]]
+Using the legacy basic configuration options
+++++++++++++++++++++++++++++++++++++++++++++
+
+You can also connect to an SSL enabled IRC server, as follows:
+
+[source,java]
+--------------------------------------------------
+ircs:host[:port]/#room?username=user&password=pass
+--------------------------------------------------
+
+By default, the IRC transport uses
+http://moepii.sourceforge.net/irclib/javadoc/org/schwering/irc/lib/ssl/SSLDefaultTrustManager.html[SSLDefaultTrustManager].
+If you need to provide your own custom trust manager, use the
+`trustManager` parameter as follows:
+
+[source,java]
+----------------------------------------------------------------------------------------------
+ircs:host[:port]/#room?username=user&password=pass&trustManager=#referenceToMyTrustManagerBean
+----------------------------------------------------------------------------------------------
+
+[[IRC-Usingkeys]]
+Using keys
+^^^^^^^^^^
+
+*Available as of Camel 2.2*
+
+Some irc rooms requires you to provide a key to be able to join that
+channel. The key is just a secret word.
+
+For example we join 3 channels where as only channel 1 and 3 uses a key.
+
+[source,java]
+-----------------------------------------------------------------------------
+irc:nick@irc.server.org?channels=#chan1,#chan2,#chan3&keys=chan1Key,,chan3key
+-----------------------------------------------------------------------------
+
+Getting a list of users of the channel
+^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^
+
+Using the `namesOnJoin` option one can invoke the IRC-`NAMES` command after the component has joined a channel. 
+The server will reply with `irc.num = 353`. So in order to process the result the property `onReply` has to be `true`.
+Furthermore one has to filter the `onReply` exchanges in order to get the names.
+
+For example we want to get all exchanges that contain the usernames of the channel:
+
+[source,java]
+-----------------------------------------------------------------------------
+from("ircs:nick@myserver:1234/#mychannelname?listOnJoin=true&onReply=true")
+	.choice()
+		.when(header("irc.messageType").isEqualToIgnoreCase("REPLY"))
+			.filter(header("irc.num").isEqualTo("353"))
+			.to("mock:result").stop();
+-----------------------------------------------------------------------------
+
+[[IRC-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-irc/src/main/docs/irc.adoc
----------------------------------------------------------------------
diff --git a/components/camel-irc/src/main/docs/irc.adoc b/components/camel-irc/src/main/docs/irc.adoc
deleted file mode 100644
index 7635d91..0000000
--- a/components/camel-irc/src/main/docs/irc.adoc
+++ /dev/null
@@ -1,212 +0,0 @@
-[[IRC-IRCComponent]]
-IRC Component
-~~~~~~~~~~~~~
-
-The *irc* component implements an
-http://en.wikipedia.org/wiki/Internet_Relay_Chat[IRC] (Internet Relay
-Chat) transport.
-
-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-irc</artifactId>
-    <version>x.x.x</version>
-    <!-- use the same version as your Camel core version -->
-</dependency>
-------------------------------------------------------------
-
-[[IRC-URIformat]]
-URI format
-^^^^^^^^^^
-
-[source,java]
----------------------------------------------------------------------
-irc:nick@host[:port]/#room[?options]
-irc:nick@host[:port]?channels=#channel1,#channel2,#channel3[?options]
----------------------------------------------------------------------
-
-You can append query options to the URI in the following format,
-`?option=value&option=value&...`
-
-[[IRC-Options]]
-Options
-^^^^^^^
-
-
-// component options: START
-The IRC component has no options.
-// component options: END
-
-
-
-
-
-
-
-// endpoint options: START
-The IRC component supports 26 endpoint options which are listed below:
-
-{% raw %}
-[width="100%",cols="2s,1,1m,1m,5",options="header"]
-|=======================================================================
-| Name | Group | Default | Java Type | Description
-| hostname | common |  | String | *Required* Hostname for the IRC chat server
-| port | common | 6667,6668,6669 | int | Port number for the IRC chat server
-| autoRejoin | common | true | boolean | Whether to auto re-join when being kicked
-| namesOnJoin | common | false | boolean | Sends NAMES command to channel after joining it. link onReply has to be true in order to process the result which will have the header value irc.num = '353'.
-| nickname | common |  | String | The nickname used in chat.
-| persistent | common | true | boolean | Use persistent messages.
-| realname | common |  | String | The IRC user's actual name.
-| 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.
-| colors | advanced | true | boolean | Whether or not the server supports color codes.
-| 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).
-| onJoin | filter | true | boolean | Handle user join events.
-| onKick | filter | true | boolean | Handle kick events.
-| onMode | filter | true | boolean | Handle mode change events.
-| onNick | filter | true | boolean | Handle nickname change events.
-| onPart | filter | true | boolean | Handle user part events.
-| onPrivmsg | filter | true | boolean | Handle private message events.
-| onQuit | filter | true | boolean | Handle user quit events.
-| onReply | filter | false | boolean | Whether or not to handle general responses to commands or informational messages.
-| onTopic | filter | true | boolean | Handle topic change events.
-| nickPassword | security |  | String | Your IRC server nickname password.
-| password | security |  | String | The IRC server password.
-| sslContextParameters | security |  | SSLContextParameters | Used for configuring security using SSL. Reference to a org.apache.camel.util.jsse.SSLContextParameters in the Registry. This reference overrides any configured SSLContextParameters at the component level. Note that this setting overrides the trustManager option.
-| trustManager | security |  | SSLTrustManager | The trust manager used to verify the SSL server's certificate.
-| username | security |  | String | The IRC server user name.
-|=======================================================================
-{% endraw %}
-// endpoint options: END
-
-
-
-
-
-
-[[IRC-SSLSupport]]
-SSL Support
-^^^^^^^^^^^
-
-[[IRC-UsingtheJSSEConfigurationUtility]]
-Using the JSSE Configuration Utility
-++++++++++++++++++++++++++++++++++++
-
-As of Camel 2.9, the IRC component supports SSL/TLS configuration
-through the link:camel-configuration-utilities.html[Camel JSSE
-Configuration Utility].� This utility greatly decreases the amount of
-component specific code you need to write and is configurable at the
-endpoint and component levels.� The following examples demonstrate how
-to use the utility with the IRC component.
-
-[[IRC-Programmaticconfigurationoftheendpoint]]
-Programmatic configuration of the endpoint
-
-[source,java]
------------------------------------------------------------------------------------------------------------------------------------------
-KeyStoreParameters ksp = new KeyStoreParameters();
-ksp.setResource("/users/home/server/truststore.jks");
-ksp.setPassword("keystorePassword");
-
-TrustManagersParameters tmp = new TrustManagersParameters();
-tmp.setKeyStore(ksp);
-
-SSLContextParameters scp = new SSLContextParameters();
-scp.setTrustManagers(tmp);
-
-Registry registry = ...
-registry.bind("sslContextParameters", scp);
-
-...
-
-from(...)
-    .to("ircs://camel-prd-user@server:6669/#camel-test?nickname=camel-prd&password=password&sslContextParameters=#sslContextParameters");
------------------------------------------------------------------------------------------------------------------------------------------
-
-[[IRC-SpringDSLbasedconfigurationofendpoint]]
-Spring DSL based configuration of endpoint
-
-[source,xml]
-----------------------------------------------------------------------------------------------------------------------------------------------
-...
-  <camel:sslContextParameters
-      id="sslContextParameters">
-    <camel:trustManagers>
-      <camel:keyStore
-          resource="/users/home/server/truststore.jks"
-          password="keystorePassword"/>
-    </camel:keyManagers>
-  </camel:sslContextParameters>...
-...
-  <to uri="ircs://camel-prd-user@server:6669/#camel-test?nickname=camel-prd&password=password&sslContextParameters=#sslContextParameters"/>...
-----------------------------------------------------------------------------------------------------------------------------------------------
-
-[[IRC-Usingthelegacybasicconfigurationoptions]]
-Using the legacy basic configuration options
-++++++++++++++++++++++++++++++++++++++++++++
-
-You can also connect to an SSL enabled IRC server, as follows:
-
-[source,java]
---------------------------------------------------
-ircs:host[:port]/#room?username=user&password=pass
---------------------------------------------------
-
-By default, the IRC transport uses
-http://moepii.sourceforge.net/irclib/javadoc/org/schwering/irc/lib/ssl/SSLDefaultTrustManager.html[SSLDefaultTrustManager].
-If you need to provide your own custom trust manager, use the
-`trustManager` parameter as follows:
-
-[source,java]
-----------------------------------------------------------------------------------------------
-ircs:host[:port]/#room?username=user&password=pass&trustManager=#referenceToMyTrustManagerBean
-----------------------------------------------------------------------------------------------
-
-[[IRC-Usingkeys]]
-Using keys
-^^^^^^^^^^
-
-*Available as of Camel 2.2*
-
-Some irc rooms requires you to provide a key to be able to join that
-channel. The key is just a secret word.
-
-For example we join 3 channels where as only channel 1 and 3 uses a key.
-
-[source,java]
------------------------------------------------------------------------------
-irc:nick@irc.server.org?channels=#chan1,#chan2,#chan3&keys=chan1Key,,chan3key
------------------------------------------------------------------------------
-
-Getting a list of users of the channel
-^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^
-
-Using the `namesOnJoin` option one can invoke the IRC-`NAMES` command after the component has joined a channel. 
-The server will reply with `irc.num = 353`. So in order to process the result the property `onReply` has to be `true`.
-Furthermore one has to filter the `onReply` exchanges in order to get the names.
-
-For example we want to get all exchanges that contain the usernames of the channel:
-
-[source,java]
------------------------------------------------------------------------------
-from("ircs:nick@myserver:1234/#mychannelname?listOnJoin=true&onReply=true")
-	.choice()
-		.when(header("irc.messageType").isEqualToIgnoreCase("REPLY"))
-			.filter(header("irc.num").isEqualTo("353"))
-			.to("mock:result").stop();
------------------------------------------------------------------------------
-
-[[IRC-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-ironmq/src/main/docs/ironmq-component.adoc
----------------------------------------------------------------------
diff --git a/components/camel-ironmq/src/main/docs/ironmq-component.adoc b/components/camel-ironmq/src/main/docs/ironmq-component.adoc
new file mode 100644
index 0000000..969bb30
--- /dev/null
+++ b/components/camel-ironmq/src/main/docs/ironmq-component.adoc
@@ -0,0 +1,157 @@
+[[IronMQ-IronMQComponent]]
+IronMQ Component
+~~~~~~~~~~~~~~~~
+
+*Available as of Camel 2.17*
+
+The IronMQ component provides integration with http://www.iron.io/products/mq[IronMQ] an elastic and durable hosted message queue as a service.
+
+The component uses the
+https://github.com/iron-io/iron_mq_java[IronMQ java client]
+library.
+
+To run it requires a IronMQ account, and a project id and token.
+
+Maven users will need to add the following dependency to their `pom.xml`
+for this component:
+
+[source,java]
+------------------------------------------------------------
+<dependency>
+    <groupId>org.apache.camel</groupId>
+    <artifactId>camel-ironmq</artifactId>
+    <version>x.x.x</version>
+    <!-- use the same version as your Camel core version -->
+</dependency>
+------------------------------------------------------------
+
+[[IronMQ-URIformat]]
+URI format
+^^^^^^^^^^
+
+[source,java]
+-----------------------------
+ ironmq:queueName[?options]
+-----------------------------
+Where **queueName** identifies the IronMQ queue you want to publish or consume messages from.
+
+[[IronMQ-Options]]
+Options
+^^^^^^^
+
+
+
+
+
+
+
+// endpoint options: START
+The ironmq component supports 31 endpoint options which are listed below:
+
+{% raw %}
+[width="100%",cols="2s,1,1m,1m,5",options="header"]
+|=======================================================================
+| Name | Group | Default | Java Type | Description
+| queueName | common |  | String | *Required* The name of the IronMQ queue
+| client | common |  | Client | Reference to a io.iron.ironmq.Client in the Registry.
+| ironMQCloud | common | https://mq-aws-us-east-1-1.iron.io | String | IronMq Cloud url. Urls for public clusters: https://mq-aws-us-east-1-1.iron.io (US) and https://mq-aws-eu-west-1-1.iron.io (EU)
+| preserveHeaders | common | false | boolean | Should message headers be preserved when publishing messages. This will add the Camel headers to the Iron MQ message as a json payload with a header list and a message body. Useful when Camel is both consumer and producer.
+| projectId | common |  | String | IronMQ projectId
+| token | common |  | String | IronMQ token
+| batchDelete | consumer | false | boolean | Should messages be deleted in one batch. This will limit the number of api requests since messages are deleted in one request instead of one pr. exchange. If enabled care should be taken that the consumer is idempotent when processing exchanges.
+| 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.
+| concurrentConsumers | consumer | 1 | int | The number of concurrent consumers.
+| maxMessagesPerPoll | consumer | 1 | int | Number of messages to poll pr. call. Maximum is 100.
+| sendEmptyMessageWhenIdle | consumer | false | boolean | If the polling consumer did not poll any files you can enable this option to send an empty message (no body) instead.
+| timeout | consumer | 60 | int | After timeout (in seconds) item will be placed back onto the queue.
+| wait | consumer |  | int | Time in seconds to wait for a message to become available. This enables long polling. Default is 0 (does not wait) maximum is 30.
+| 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.
+| pollStrategy | consumer (advanced) |  | PollingConsumerPollStrategy | A pluggable org.apache.camel.PollingConsumerPollingStrategy allowing you to provide your custom implementation to control error handling usually occurred during the poll operation before an Exchange have been created and being routed in Camel.
+| visibilityDelay | producer |  | int | The item will not be available on the queue until this many seconds have passed. Default is 0 seconds.
+| 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).
+| backoffErrorThreshold | scheduler |  | int | The number of subsequent error polls (failed due some error) that should happen before the backoffMultipler should kick-in.
+| backoffIdleThreshold | scheduler |  | int | The number of subsequent idle polls that should happen before the backoffMultipler should kick-in.
+| backoffMultiplier | scheduler |  | int | To let the scheduled polling consumer backoff if there has been a number of subsequent idles/errors in a row. The multiplier is then the number of polls that will be skipped before the next actual attempt is happening again. When this option is in use then backoffIdleThreshold and/or backoffErrorThreshold must also be configured.
+| delay | scheduler | 500 | long | Milliseconds before the next poll. You can also specify time values using units such as 60s (60 seconds) 5m30s (5 minutes and 30 seconds) and 1h (1 hour).
+| greedy | scheduler | false | boolean | If greedy is enabled then the ScheduledPollConsumer will run immediately again if the previous run polled 1 or more messages.
+| initialDelay | scheduler | 1000 | long | Milliseconds before the first poll starts. You can also specify time values using units such as 60s (60 seconds) 5m30s (5 minutes and 30 seconds) and 1h (1 hour).
+| runLoggingLevel | scheduler | TRACE | LoggingLevel | The consumer logs a start/complete log line when it polls. This option allows you to configure the logging level for that.
+| scheduledExecutorService | scheduler |  | ScheduledExecutorService | Allows for configuring a custom/shared thread pool to use for the consumer. By default each consumer has its own single threaded thread pool.
+| scheduler | scheduler | none | ScheduledPollConsumerScheduler | To use a cron scheduler from either camel-spring or camel-quartz2 component
+| schedulerProperties | scheduler |  | Map | To configure additional properties when using a custom scheduler or any of the Quartz2 Spring based scheduler.
+| startScheduler | scheduler | true | boolean | Whether the scheduler should be auto started.
+| timeUnit | scheduler | MILLISECONDS | TimeUnit | Time unit for initialDelay and delay options.
+| useFixedDelay | scheduler | true | boolean | Controls if fixed delay or fixed rate is used. See ScheduledExecutorService in JDK for details.
+|=======================================================================
+{% endraw %}
+// endpoint options: END
+
+
+
+
+
+
+[[IronMQ-IronMQComponentOptions]]
+IronMQComponent Options
+^^^^^^^^^^^^^^^^^^^^^^^
+
+
+
+
+// component options: START
+The ironmq component has no options.
+// component options: END
+
+
+
+
+
+[[IronMQ-Messagebody]]
+Message Body
+^^^^^^^^^^^^
+Should be either a String or a array of Strings. In the latter case the batch of strings will be send to IronMQ as one request, creating one message pr. element in the array.
+
+[[IronMQ-MessageHeaders]]
+Producer message headers
+^^^^^^^^^^^^^^^^^^^^^^^^
+
+[width="100%",cols="10%,10%,80%",options="header",]
+|=======================================================================
+|Header |Type | Description
+|CamelIronMQOperation |String|If value set to 'CamelIronMQClearQueue' the queue is cleared of unconsumed  messages.
+|CamelIronMQMessageId |String or io.iron.ironmq.Ids|The id of the IronMQ message as a String when sending a single message, or a Ids object when sending a array of strings.
+|=======================================================================
+
+Consumer message headers
+^^^^^^^^^^^^^^^^^^^^^^^^
+
+[width="100%",cols="10%,10%,80%",options="header",]
+|=======================================================================
+|Header |Type | Description
+|CamelIronMQMessageId    |String|The id of the message.
+|CamelIronMQReservationId|String|The reservation id of the message.
+|CamelIronMQReservedCount|String|The number of times this message has been reserved.
+|=======================================================================
+
+
+Consumer example
+^^^^^^^^^^^^^^^^
+
+Consume 50 messages pr. poll from the queue 'testqueue' on aws eu, and save the messages to files.
+
+[source,java]
+--------------------------------------------------
+from("ironmq:testqueue?ironMQCloud=https://mq-aws-eu-west-1-1.iron.io&projectId=myIronMQProjectid&token=myIronMQToken&maxMessagesPerPoll=50")
+  .to("file:somefolder");
+--------------------------------------------------
+
+Producer example
+^^^^^^^^^^^^^^^^
+Dequeue from activemq jms and enqueue the messages on IronMQ.
+
+[source,java]
+--------------------------------------------------
+from("activemq:foo")
+  .to("ironmq:testqueue?projectId=myIronMQProjectid&token=myIronMQToken");
+--------------------------------------------------

http://git-wip-us.apache.org/repos/asf/camel/blob/9c0b7baf/components/camel-ironmq/src/main/docs/ironmq.adoc
----------------------------------------------------------------------
diff --git a/components/camel-ironmq/src/main/docs/ironmq.adoc b/components/camel-ironmq/src/main/docs/ironmq.adoc
deleted file mode 100644
index 969bb30..0000000
--- a/components/camel-ironmq/src/main/docs/ironmq.adoc
+++ /dev/null
@@ -1,157 +0,0 @@
-[[IronMQ-IronMQComponent]]
-IronMQ Component
-~~~~~~~~~~~~~~~~
-
-*Available as of Camel 2.17*
-
-The IronMQ component provides integration with http://www.iron.io/products/mq[IronMQ] an elastic and durable hosted message queue as a service.
-
-The component uses the
-https://github.com/iron-io/iron_mq_java[IronMQ java client]
-library.
-
-To run it requires a IronMQ account, and a project id and token.
-
-Maven users will need to add the following dependency to their `pom.xml`
-for this component:
-
-[source,java]
-------------------------------------------------------------
-<dependency>
-    <groupId>org.apache.camel</groupId>
-    <artifactId>camel-ironmq</artifactId>
-    <version>x.x.x</version>
-    <!-- use the same version as your Camel core version -->
-</dependency>
-------------------------------------------------------------
-
-[[IronMQ-URIformat]]
-URI format
-^^^^^^^^^^
-
-[source,java]
------------------------------
- ironmq:queueName[?options]
------------------------------
-Where **queueName** identifies the IronMQ queue you want to publish or consume messages from.
-
-[[IronMQ-Options]]
-Options
-^^^^^^^
-
-
-
-
-
-
-
-// endpoint options: START
-The ironmq component supports 31 endpoint options which are listed below:
-
-{% raw %}
-[width="100%",cols="2s,1,1m,1m,5",options="header"]
-|=======================================================================
-| Name | Group | Default | Java Type | Description
-| queueName | common |  | String | *Required* The name of the IronMQ queue
-| client | common |  | Client | Reference to a io.iron.ironmq.Client in the Registry.
-| ironMQCloud | common | https://mq-aws-us-east-1-1.iron.io | String | IronMq Cloud url. Urls for public clusters: https://mq-aws-us-east-1-1.iron.io (US) and https://mq-aws-eu-west-1-1.iron.io (EU)
-| preserveHeaders | common | false | boolean | Should message headers be preserved when publishing messages. This will add the Camel headers to the Iron MQ message as a json payload with a header list and a message body. Useful when Camel is both consumer and producer.
-| projectId | common |  | String | IronMQ projectId
-| token | common |  | String | IronMQ token
-| batchDelete | consumer | false | boolean | Should messages be deleted in one batch. This will limit the number of api requests since messages are deleted in one request instead of one pr. exchange. If enabled care should be taken that the consumer is idempotent when processing exchanges.
-| 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.
-| concurrentConsumers | consumer | 1 | int | The number of concurrent consumers.
-| maxMessagesPerPoll | consumer | 1 | int | Number of messages to poll pr. call. Maximum is 100.
-| sendEmptyMessageWhenIdle | consumer | false | boolean | If the polling consumer did not poll any files you can enable this option to send an empty message (no body) instead.
-| timeout | consumer | 60 | int | After timeout (in seconds) item will be placed back onto the queue.
-| wait | consumer |  | int | Time in seconds to wait for a message to become available. This enables long polling. Default is 0 (does not wait) maximum is 30.
-| 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.
-| pollStrategy | consumer (advanced) |  | PollingConsumerPollStrategy | A pluggable org.apache.camel.PollingConsumerPollingStrategy allowing you to provide your custom implementation to control error handling usually occurred during the poll operation before an Exchange have been created and being routed in Camel.
-| visibilityDelay | producer |  | int | The item will not be available on the queue until this many seconds have passed. Default is 0 seconds.
-| 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).
-| backoffErrorThreshold | scheduler |  | int | The number of subsequent error polls (failed due some error) that should happen before the backoffMultipler should kick-in.
-| backoffIdleThreshold | scheduler |  | int | The number of subsequent idle polls that should happen before the backoffMultipler should kick-in.
-| backoffMultiplier | scheduler |  | int | To let the scheduled polling consumer backoff if there has been a number of subsequent idles/errors in a row. The multiplier is then the number of polls that will be skipped before the next actual attempt is happening again. When this option is in use then backoffIdleThreshold and/or backoffErrorThreshold must also be configured.
-| delay | scheduler | 500 | long | Milliseconds before the next poll. You can also specify time values using units such as 60s (60 seconds) 5m30s (5 minutes and 30 seconds) and 1h (1 hour).
-| greedy | scheduler | false | boolean | If greedy is enabled then the ScheduledPollConsumer will run immediately again if the previous run polled 1 or more messages.
-| initialDelay | scheduler | 1000 | long | Milliseconds before the first poll starts. You can also specify time values using units such as 60s (60 seconds) 5m30s (5 minutes and 30 seconds) and 1h (1 hour).
-| runLoggingLevel | scheduler | TRACE | LoggingLevel | The consumer logs a start/complete log line when it polls. This option allows you to configure the logging level for that.
-| scheduledExecutorService | scheduler |  | ScheduledExecutorService | Allows for configuring a custom/shared thread pool to use for the consumer. By default each consumer has its own single threaded thread pool.
-| scheduler | scheduler | none | ScheduledPollConsumerScheduler | To use a cron scheduler from either camel-spring or camel-quartz2 component
-| schedulerProperties | scheduler |  | Map | To configure additional properties when using a custom scheduler or any of the Quartz2 Spring based scheduler.
-| startScheduler | scheduler | true | boolean | Whether the scheduler should be auto started.
-| timeUnit | scheduler | MILLISECONDS | TimeUnit | Time unit for initialDelay and delay options.
-| useFixedDelay | scheduler | true | boolean | Controls if fixed delay or fixed rate is used. See ScheduledExecutorService in JDK for details.
-|=======================================================================
-{% endraw %}
-// endpoint options: END
-
-
-
-
-
-
-[[IronMQ-IronMQComponentOptions]]
-IronMQComponent Options
-^^^^^^^^^^^^^^^^^^^^^^^
-
-
-
-
-// component options: START
-The ironmq component has no options.
-// component options: END
-
-
-
-
-
-[[IronMQ-Messagebody]]
-Message Body
-^^^^^^^^^^^^
-Should be either a String or a array of Strings. In the latter case the batch of strings will be send to IronMQ as one request, creating one message pr. element in the array.
-
-[[IronMQ-MessageHeaders]]
-Producer message headers
-^^^^^^^^^^^^^^^^^^^^^^^^
-
-[width="100%",cols="10%,10%,80%",options="header",]
-|=======================================================================
-|Header |Type | Description
-|CamelIronMQOperation |String|If value set to 'CamelIronMQClearQueue' the queue is cleared of unconsumed  messages.
-|CamelIronMQMessageId |String or io.iron.ironmq.Ids|The id of the IronMQ message as a String when sending a single message, or a Ids object when sending a array of strings.
-|=======================================================================
-
-Consumer message headers
-^^^^^^^^^^^^^^^^^^^^^^^^
-
-[width="100%",cols="10%,10%,80%",options="header",]
-|=======================================================================
-|Header |Type | Description
-|CamelIronMQMessageId    |String|The id of the message.
-|CamelIronMQReservationId|String|The reservation id of the message.
-|CamelIronMQReservedCount|String|The number of times this message has been reserved.
-|=======================================================================
-
-
-Consumer example
-^^^^^^^^^^^^^^^^
-
-Consume 50 messages pr. poll from the queue 'testqueue' on aws eu, and save the messages to files.
-
-[source,java]
---------------------------------------------------
-from("ironmq:testqueue?ironMQCloud=https://mq-aws-eu-west-1-1.iron.io&projectId=myIronMQProjectid&token=myIronMQToken&maxMessagesPerPoll=50")
-  .to("file:somefolder");
---------------------------------------------------
-
-Producer example
-^^^^^^^^^^^^^^^^
-Dequeue from activemq jms and enqueue the messages on IronMQ.
-
-[source,java]
---------------------------------------------------
-from("activemq:foo")
-  .to("ironmq:testqueue?projectId=myIronMQProjectid&token=myIronMQToken");
---------------------------------------------------

http://git-wip-us.apache.org/repos/asf/camel/blob/9c0b7baf/components/camel-javaspace/src/main/docs/javaspace-component.adoc
----------------------------------------------------------------------
diff --git a/components/camel-javaspace/src/main/docs/javaspace-component.adoc b/components/camel-javaspace/src/main/docs/javaspace-component.adoc
new file mode 100644
index 0000000..fadcb7d
--- /dev/null
+++ b/components/camel-javaspace/src/main/docs/javaspace-component.adoc
@@ -0,0 +1,151 @@
+[[JavaSpace-JavaSpaceComponent]]
+JavaSpace Component
+~~~~~~~~~~~~~~~~~~~
+
+*Available as of Camel 2.1*
+
+The *javaspace* component is a transport for working with any JavaSpace
+compliant implementation and this component has been tested with both
+the http://www.dancres.org/blitz/[Blitz implementation] and the
+http://www.gigaspaces.com/[GigaSpace implementation]. +
+ This component can be used for sending and receiving any object
+inheriting from the Jini `net.jini.core.entry.Entry` class. It is also
+possible to pass the bean ID of a template that can be used for
+reading/taking the entries from the space. +
+ This component can be used for sending/receiving any serializable
+object acting as a sort of generic transport. The JavaSpace component
+contains a special optimization for dealing with the `BeanExchange`. It
+can be used to invoke a POJO remotely, using a JavaSpace as a
+transport. +
+ This latter feature can provide a simple implementation of the
+master/worker pattern, where a POJO provides the business logic for the
+worker. +
+ Look at the test cases for examples of various use cases for this
+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-javaspace</artifactId>
+    <version>x.x.x</version>
+    <!-- use the same version as your Camel core version -->
+</dependency>
+------------------------------------------------------------
+
+[[JavaSpace-URIformat]]
+URI format
+^^^^^^^^^^
+
+[source,java]
+-------------------------------
+javaspace:jini://host[?options]
+-------------------------------
+
+You can append query options to the URI in the following format,
+`?option=value&option=value&...`
+
+[[JavaSpace-Options]]
+Options
+^^^^^^^
+
+
+// component options: START
+The JavaSpace component has no options.
+// component options: END
+
+
+
+
+// endpoint options: START
+The JavaSpace component supports 11 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 URL to the JavaSpace server
+| spaceName | common |  | String | *Required* Specifies the JavaSpace name.
+| transactional | common | false | boolean | If true sending and receiving entries is performed within a transaction.
+| transactionTimeout | common |  | long | Specifies the transaction timeout in millis. By default there is no timeout.
+| 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.
+| concurrentConsumers | consumer | 1 | int | Specifies the number of concurrent consumers getting entries from the JavaSpace.
+| templateId | consumer |  | String | If present this option specifies the Spring bean ID of the template to use for reading/taking entries.
+| verb | consumer | take | String | Specifies the verb for getting JavaSpace entries.
+| 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
+
+
+
+[[JavaSpace-Examples]]
+Examples
+^^^^^^^^
+
+[[JavaSpace-SendingandReceivingEntries]]
+Sending and Receiving Entries
++++++++++++++++++++++++++++++
+
+[source,java]
+--------------------------------------------------------------------------------------------------------
+// sending route
+from("direct:input")
+    .to("javaspace:jini://localhost?spaceName=mySpace");
+
+// receiving Route
+from("javaspace:jini://localhost?spaceName=mySpace&templateId=template&verb=take&concurrentConsumers=1")
+    .to("mock:foo");
+--------------------------------------------------------------------------------------------------------
+
+In this case the payload can be any object that inherits from the Jini
+`Entry` type.
+
+[[JavaSpace-Sendingandreceivingserializableobjects]]
+Sending and receiving serializable objects
+++++++++++++++++++++++++++++++++++++++++++
+
+Using the preceding routes, it is also possible to send and receive any
+serializable object. The JavaSpace component detects that the payload is
+not a Jini `Entry` and then it automatically wraps the payload with a
+Camel Jini `Entry`. In this way, a JavaSpace can be used as a generic
+transport mechanism.
+
+[[JavaSpace-UsingJavaSpaceasaremoteinvocationtransport]]
+Using JavaSpace as a remote invocation transport
+++++++++++++++++++++++++++++++++++++++++++++++++
+
+The JavaSpace component has been tailored to work in combination with
+the Camel bean component. It is therefore possible to call a remote POJO
+using JavaSpace as the transport:
+
+[source,java]
+---------------------------------------------------------------------------
+// client side
+from("direct:input")
+    .to("javaspace:jini://localhost?spaceName=mySpace");
+
+// server side
+from("javaspace:jini://localhost?concurrentConsumers=10&spaceName=mySpace")
+    .to("mock:foo");
+---------------------------------------------------------------------------
+
+In the code there are two test cases showing how to use a POJO to
+realize the master/worker pattern. The idea is to use the POJO to
+provide the business logic and rely on Camel for sending/receiving
+requests/replies with the proper correlation.
+
+[[JavaSpace-SeeAlso]]
+See Also
+^^^^^^^^
+
+* link:configuring-camel.html[Configuring Camel]
+* link:component.html[Component]
+* link:endpoint.html[Endpoint]
+* link:getting-started.html[Getting Started]
+