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 2015/05/11 10:46:20 UTC

[1/4] camel git commit: Component docs

Repository: camel
Updated Branches:
  refs/heads/master 8d6a94ea0 -> 4cc3541be


Component docs


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

Branch: refs/heads/master
Commit: 5b6134baeabc72b9607f25577685dba7280db10b
Parents: 8d6a94e
Author: Claus Ibsen <da...@apache.org>
Authored: Mon May 11 09:05:18 2015 +0200
Committer: Claus Ibsen <da...@apache.org>
Committed: Mon May 11 09:05:18 2015 +0200

----------------------------------------------------------------------
 .../camel/component/cache/CacheComponent.java   |  5 ++
 .../component/cache/CacheConfiguration.java     | 57 ++++++++++++++++++--
 .../camel/component/cache/CacheEndpoint.java    | 14 +++++
 3 files changed, 72 insertions(+), 4 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/camel/blob/5b6134ba/components/camel-cache/src/main/java/org/apache/camel/component/cache/CacheComponent.java
----------------------------------------------------------------------
diff --git a/components/camel-cache/src/main/java/org/apache/camel/component/cache/CacheComponent.java b/components/camel-cache/src/main/java/org/apache/camel/component/cache/CacheComponent.java
index c19d0c0..d46f40c 100755
--- a/components/camel-cache/src/main/java/org/apache/camel/component/cache/CacheComponent.java
+++ b/components/camel-cache/src/main/java/org/apache/camel/component/cache/CacheComponent.java
@@ -62,6 +62,11 @@ public class CacheComponent extends UriEndpointComponent {
         return cacheManagerFactory;
     }
 
+    /**
+     * To use the given CacheManagerFactory for creating the CacheManager.
+     * <p/>
+     * By default the DefaultCacheManagerFactory is used.
+     */
     public void setCacheManagerFactory(CacheManagerFactory cacheManagerFactory) {
         this.cacheManagerFactory = cacheManagerFactory;
     }

http://git-wip-us.apache.org/repos/asf/camel/blob/5b6134ba/components/camel-cache/src/main/java/org/apache/camel/component/cache/CacheConfiguration.java
----------------------------------------------------------------------
diff --git a/components/camel-cache/src/main/java/org/apache/camel/component/cache/CacheConfiguration.java b/components/camel-cache/src/main/java/org/apache/camel/component/cache/CacheConfiguration.java
index e55d6c4..fe5d99f 100755
--- a/components/camel-cache/src/main/java/org/apache/camel/component/cache/CacheConfiguration.java
+++ b/components/camel-cache/src/main/java/org/apache/camel/component/cache/CacheConfiguration.java
@@ -21,6 +21,7 @@ import java.util.Map;
 
 import net.sf.ehcache.store.MemoryStoreEvictionPolicy;
 import org.apache.camel.RuntimeCamelException;
+import org.apache.camel.spi.Metadata;
 import org.apache.camel.spi.UriParam;
 import org.apache.camel.spi.UriParams;
 import org.apache.camel.spi.UriPath;
@@ -28,15 +29,16 @@ import org.apache.camel.util.URISupport;
 
 @UriParams
 public class CacheConfiguration implements Cloneable {
-    @UriPath
+    @UriPath @Metadata(required = "true")
     private String cacheName;
     @UriParam(defaultValue = "1000")
     private int maxElementsInMemory = 1000;
-    @UriParam(defaultValue = "LFU", enums = "LRU,LFU,FIFO,CLOCK")
+    @UriParam(defaultValue = "LFU", enums = "LRU,LFU,FIFO")
     private MemoryStoreEvictionPolicy memoryStoreEvictionPolicy = MemoryStoreEvictionPolicy.LFU;
     @UriParam(defaultValue = "true")
     private boolean overflowToDisk = true;
     @UriParam
+    @Deprecated
     private String diskStorePath;
     @UriParam
     private boolean eternal;
@@ -125,6 +127,9 @@ public class CacheConfiguration implements Cloneable {
         return cacheName;
     }
 
+    /**
+     * Name of the cache
+     */
     public void setCacheName(String cacheName) {
         this.cacheName = cacheName;
     }
@@ -133,6 +138,9 @@ public class CacheConfiguration implements Cloneable {
         return maxElementsInMemory;
     }
 
+    /**
+     * The number of elements that may be stored in the defined cache in memory.
+     */
     public void setMaxElementsInMemory(int maxElementsInMemory) {
         this.maxElementsInMemory = maxElementsInMemory;
     }
@@ -141,8 +149,16 @@ public class CacheConfiguration implements Cloneable {
         return memoryStoreEvictionPolicy;
     }
 
-    public void setMemoryStoreEvictionPolicy(
-            MemoryStoreEvictionPolicy memoryStoreEvictionPolicy) {
+    /**
+     * Which eviction strategy to use when maximum number of elements in memory is reached. The strategy defines
+     * which elements to be removed.
+     * <ul>
+     *     <li>LRU - Lest Recently Used</li>
+     *     <li>LFU - Lest Frequently Used</li>
+     *     <li>FIFO - First In First Out</li>
+     * </ul>
+     */
+    public void setMemoryStoreEvictionPolicy(MemoryStoreEvictionPolicy memoryStoreEvictionPolicy) {
         this.memoryStoreEvictionPolicy = memoryStoreEvictionPolicy;
     }
 
@@ -150,14 +166,22 @@ public class CacheConfiguration implements Cloneable {
         return overflowToDisk;
     }
 
+    /**
+     * Specifies whether cache may overflow to disk
+     */
     public void setOverflowToDisk(boolean overflowToDisk) {
         this.overflowToDisk = overflowToDisk;
     }
 
+    @Deprecated
     public String getDiskStorePath() {
         return diskStorePath;
     }
 
+    /**
+     * This parameter is ignored. CacheManager sets it using setter injection.
+     */
+    @Deprecated
     public void setDiskStorePath(String diskStorePath) {
         this.diskStorePath = diskStorePath;
     }
@@ -166,6 +190,9 @@ public class CacheConfiguration implements Cloneable {
         return eternal;
     }
 
+    /**
+     * Sets whether elements are eternal. If eternal, timeouts are ignored and the element never expires.
+     */
     public void setEternal(boolean eternal) {
         this.eternal = eternal;
     }
@@ -174,6 +201,9 @@ public class CacheConfiguration implements Cloneable {
         return timeToLiveSeconds;
     }
 
+    /**
+     * The maximum time between creation time and when an element expires. Is used only if the element is not eternal
+     */
     public void setTimeToLiveSeconds(long timeToLiveSeconds) {
         this.timeToLiveSeconds = timeToLiveSeconds;
     }
@@ -182,6 +212,9 @@ public class CacheConfiguration implements Cloneable {
         return timeToIdleSeconds;
     }
 
+    /**
+     * The maximum amount of time between accesses before an element expires
+     */
     public void setTimeToIdleSeconds(long timeToIdleSeconds) {
         this.timeToIdleSeconds = timeToIdleSeconds;
     }
@@ -190,6 +223,9 @@ public class CacheConfiguration implements Cloneable {
         return diskPersistent;
     }
 
+    /**
+     * Whether the disk store persists between restarts of the application.
+     */
     public void setDiskPersistent(boolean diskPersistent) {
         this.diskPersistent = diskPersistent;
     }
@@ -198,10 +234,16 @@ public class CacheConfiguration implements Cloneable {
         return diskExpiryThreadIntervalSeconds;
     }
 
+    /**
+     * The number of seconds between runs of the disk expiry thread.
+     */
     public void setDiskExpiryThreadIntervalSeconds(long diskExpiryThreadIntervalSeconds) {
         this.diskExpiryThreadIntervalSeconds = diskExpiryThreadIntervalSeconds;
     }
 
+    /**
+     * To configure event listeners using the CacheEventListenerRegistry
+    */
     public void setEventListenerRegistry(CacheEventListenerRegistry eventListenerRegistry) {
         this.eventListenerRegistry = eventListenerRegistry;
     }
@@ -210,6 +252,9 @@ public class CacheConfiguration implements Cloneable {
         return eventListenerRegistry;
     }
 
+    /**
+     * To configure cache loader using the CacheLoaderRegistry
+     */
     public void setCacheLoaderRegistry(CacheLoaderRegistry cacheLoaderRegistry) {
         this.cacheLoaderRegistry = cacheLoaderRegistry;
     }
@@ -222,6 +267,10 @@ public class CacheConfiguration implements Cloneable {
         return objectCache;
     }
 
+    /**
+     * 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.
+     */
     public void setObjectCache(boolean objectCache) {
         this.objectCache = objectCache;
     }

http://git-wip-us.apache.org/repos/asf/camel/blob/5b6134ba/components/camel-cache/src/main/java/org/apache/camel/component/cache/CacheEndpoint.java
----------------------------------------------------------------------
diff --git a/components/camel-cache/src/main/java/org/apache/camel/component/cache/CacheEndpoint.java b/components/camel-cache/src/main/java/org/apache/camel/component/cache/CacheEndpoint.java
index 9d037a1..5ecdb38 100755
--- a/components/camel-cache/src/main/java/org/apache/camel/component/cache/CacheEndpoint.java
+++ b/components/camel-cache/src/main/java/org/apache/camel/component/cache/CacheEndpoint.java
@@ -88,6 +88,11 @@ public class CacheEndpoint extends DefaultEndpoint {
         return cacheManagerFactory;
     }
 
+    /**
+     * To use a custom CacheManagerFactory for creating the CacheManager to be used by this endpoint.
+     * <p/>
+     * By default the CacheManagerFactory configured on the component is used.
+     */
     public void setCacheManagerFactory(CacheManagerFactory cacheManagerFactory) {
         this.cacheManagerFactory = cacheManagerFactory;
     }
@@ -162,6 +167,11 @@ public class CacheEndpoint extends DefaultEndpoint {
         return operation;
     }
 
+
+    /**
+     * The default cache operation to use.
+     * If an operation in the message header, then the operation from the header takes precedence.
+     */
     public void setOperation(String operation) {
         this.operation = operation;
     }
@@ -170,6 +180,10 @@ public class CacheEndpoint extends DefaultEndpoint {
         return key;
     }
 
+    /**
+     * The default key to use.
+     * If a key is provided in the message header, then the key from the header takes precedence.
+     */
     public void setKey(String key) {
         this.key = key;
     }


[2/4] camel git commit: Component docs

Posted by da...@apache.org.
Component docs


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

Branch: refs/heads/master
Commit: 89706cd3cd2f927abda022000bbec97ea86886f2
Parents: 5b6134b
Author: Claus Ibsen <da...@apache.org>
Authored: Mon May 11 09:19:56 2015 +0200
Committer: Claus Ibsen <da...@apache.org>
Committed: Mon May 11 09:19:56 2015 +0200

----------------------------------------------------------------------
 .../component/couchdb/CouchDbEndpoint.java      | 38 ++++++++++++++++++--
 1 file changed, 36 insertions(+), 2 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/camel/blob/89706cd3/components/camel-couchdb/src/main/java/org/apache/camel/component/couchdb/CouchDbEndpoint.java
----------------------------------------------------------------------
diff --git a/components/camel-couchdb/src/main/java/org/apache/camel/component/couchdb/CouchDbEndpoint.java b/components/camel-couchdb/src/main/java/org/apache/camel/component/couchdb/CouchDbEndpoint.java
index 98358e3..231d95a 100644
--- a/components/camel-couchdb/src/main/java/org/apache/camel/component/couchdb/CouchDbEndpoint.java
+++ b/components/camel-couchdb/src/main/java/org/apache/camel/component/couchdb/CouchDbEndpoint.java
@@ -39,7 +39,7 @@ public class CouchDbEndpoint extends DefaultEndpoint {
 
     private static final String URI_ERROR = "Invalid URI. Format must be of the form couchdb:http[s]://hostname[:port]/database?[options...]";
 
-    @UriPath @Metadata(required = "true")
+    @UriPath(enums = "http,https") @Metadata(required = "true")
     private String protocol;
     @UriPath @Metadata(required = "true")
     private String hostname;
@@ -47,7 +47,7 @@ public class CouchDbEndpoint extends DefaultEndpoint {
     private int port;
     @UriPath @Metadata(required = "true")
     private String database;
-    @UriParam(defaultValue = DEFAULT_STYLE)
+    @UriParam(enums = "all_docs,main_only", defaultValue = DEFAULT_STYLE)
     private String style = DEFAULT_STYLE;
     @UriParam
     private String username;
@@ -124,6 +124,9 @@ public class CouchDbEndpoint extends DefaultEndpoint {
         return protocol;
     }
 
+    /**
+     * The protocol to use for communicating with the database.
+     */
     public void setProtocol(String protocol) {
         this.protocol = protocol;
     }
@@ -132,6 +135,9 @@ public class CouchDbEndpoint extends DefaultEndpoint {
         return hostname;
     }
 
+    /**
+     * Hostname of the running couchdb instance
+     */
     public void setHostname(String hostname) {
         this.hostname = hostname;
     }
@@ -140,6 +146,10 @@ public class CouchDbEndpoint extends DefaultEndpoint {
         return style;
     }
 
+    /**
+     * Specifies how many revisions are returned in the changes array.
+     * The default, main_only, will only return the current "winning" revision; all_docs will return all leaf revisions (including conflicts and deleted former conflicts.)
+     */
     public void setStyle(String style) {
         this.style = style;
     }
@@ -148,6 +158,9 @@ public class CouchDbEndpoint extends DefaultEndpoint {
         return username;
     }
 
+    /**
+     * Username in case of authenticated databases
+     */
     public void setUsername(String username) {
         this.username = username;
     }
@@ -156,6 +169,9 @@ public class CouchDbEndpoint extends DefaultEndpoint {
         return database;
     }
 
+    /**
+     * Name of the database to use
+     */
     public void setDatabase(String database) {
         this.database = database;
     }
@@ -164,6 +180,9 @@ public class CouchDbEndpoint extends DefaultEndpoint {
         return password;
     }
 
+    /**
+     * Password for authenticated databases
+     */
     public void setPassword(String password) {
         this.password = password;
     }
@@ -172,6 +191,9 @@ public class CouchDbEndpoint extends DefaultEndpoint {
         return port;
     }
 
+    /**
+     * Port number for the running couchdb instance
+     */
     public void setPort(int port) {
         this.port = port;
     }
@@ -180,6 +202,9 @@ public class CouchDbEndpoint extends DefaultEndpoint {
         return heartbeat;
     }
 
+    /**
+     * How often to send an empty message to keep socket alive in millis
+     */
     public void setHeartbeat(long heartbeat) {
         this.heartbeat = heartbeat;
     }
@@ -188,6 +213,9 @@ public class CouchDbEndpoint extends DefaultEndpoint {
         return createDatabase;
     }
 
+    /**
+     * Creates the database if it does not already exist
+     */
     public void setCreateDatabase(boolean createDatabase) {
         this.createDatabase = createDatabase;
     }
@@ -196,6 +224,9 @@ public class CouchDbEndpoint extends DefaultEndpoint {
         return deletes;
     }
 
+    /**
+     * Document deletes are published as events
+     */
     public void setDeletes(boolean deletes) {
         this.deletes = deletes;
     }
@@ -204,6 +235,9 @@ public class CouchDbEndpoint extends DefaultEndpoint {
         return updates;
     }
 
+    /**
+     * Document inserts/updates are published as events
+     */
     public void setUpdates(boolean updates) {
         this.updates = updates;
     }


[4/4] camel git commit: Component docs

Posted by da...@apache.org.
Component docs


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

Branch: refs/heads/master
Commit: 4cc3541bef457d2b2a6c02f51bda2270a2082047
Parents: 5d66a29
Author: Claus Ibsen <da...@apache.org>
Authored: Mon May 11 09:31:13 2015 +0200
Committer: Claus Ibsen <da...@apache.org>
Committed: Mon May 11 09:31:13 2015 +0200

----------------------------------------------------------------------
 .../component/cassandra/CassandraEndpoint.java  | 36 ++++++++++++++++++++
 1 file changed, 36 insertions(+)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/camel/blob/4cc3541b/components/camel-cassandraql/src/main/java/org/apache/camel/component/cassandra/CassandraEndpoint.java
----------------------------------------------------------------------
diff --git a/components/camel-cassandraql/src/main/java/org/apache/camel/component/cassandra/CassandraEndpoint.java b/components/camel-cassandraql/src/main/java/org/apache/camel/component/cassandra/CassandraEndpoint.java
index a1d1495..0e28d9f 100644
--- a/components/camel-cassandraql/src/main/java/org/apache/camel/component/cassandra/CassandraEndpoint.java
+++ b/components/camel-cassandraql/src/main/java/org/apache/camel/component/cassandra/CassandraEndpoint.java
@@ -185,6 +185,9 @@ public class CassandraEndpoint extends DefaultEndpoint {
         return beanRef;
     }
 
+    /**
+     * Instead of using a hostname:port, refer to an existing configured Session or Cluster from the Camel registry to be used.
+     */
     public void setBean(String beanRef) {
         this.beanRef = beanRef;
     }
@@ -203,6 +206,9 @@ public class CassandraEndpoint extends DefaultEndpoint {
         return hosts;
     }
 
+    /**
+     * Hostname(s) cassansdra server(s). Multiple hosts can be separated by comma.
+     */
     public void setHosts(String hosts) {
         this.hosts = hosts;
     }
@@ -211,6 +217,9 @@ public class CassandraEndpoint extends DefaultEndpoint {
         return port;
     }
 
+    /**
+     * Port number of cassansdra server(s)
+     */
     public void setPort(Integer port) {
         this.port = port;
     }
@@ -219,6 +228,9 @@ public class CassandraEndpoint extends DefaultEndpoint {
         return keyspace;
     }
 
+    /**
+     * Keyspace to use
+     */
     public void setKeyspace(String keyspace) {
         this.keyspace = keyspace;
     }
@@ -227,6 +239,9 @@ public class CassandraEndpoint extends DefaultEndpoint {
         return cql;
     }
 
+    /**
+     * CQL query to perform. Can be overridden with the message header with key CamelCqlQuery.
+     */
     public void setCql(String cql) {
         this.cql = cql;
     }
@@ -235,6 +250,9 @@ public class CassandraEndpoint extends DefaultEndpoint {
         return cluster;
     }
 
+    /**
+     * To use the Cluster instance (you would normally not use this option)
+     */
     public void setCluster(Cluster cluster) {
         this.cluster = cluster;
     }
@@ -247,6 +265,9 @@ public class CassandraEndpoint extends DefaultEndpoint {
         }
     }
 
+    /**
+     * To use the Session instance (you would normally not use this option)
+     */
     public void setSession(Session session) {
         this.session = session;
     }
@@ -255,6 +276,9 @@ public class CassandraEndpoint extends DefaultEndpoint {
         return clusterName;
     }
 
+    /**
+     * Cluster name
+     */
     public void setClusterName(String clusterName) {
         this.clusterName = clusterName;
     }
@@ -263,6 +287,9 @@ public class CassandraEndpoint extends DefaultEndpoint {
         return username;
     }
 
+    /**
+     * Username for session authentication
+     */
     public void setUsername(String username) {
         this.username = username;
     }
@@ -271,6 +298,9 @@ public class CassandraEndpoint extends DefaultEndpoint {
         return password;
     }
 
+    /**
+     * Password for session authentication
+     */
     public void setPassword(String password) {
         this.password = password;
     }
@@ -279,6 +309,9 @@ public class CassandraEndpoint extends DefaultEndpoint {
         return consistencyLevel;
     }
 
+    /**
+     * Consistency level to use
+     */
     public void setConsistencyLevel(ConsistencyLevel consistencyLevel) {
         this.consistencyLevel = consistencyLevel;
     }
@@ -287,6 +320,9 @@ public class CassandraEndpoint extends DefaultEndpoint {
         return resultSetConversionStrategy;
     }
 
+    /**
+     * To use a custom class that implements logic for converting ResultSet into message body ALL, ONE, LIMIT_10, LIMIT_100...
+     */
     public void setResultSetConversionStrategy(ResultSetConversionStrategy resultSetConversionStrategy) {
         this.resultSetConversionStrategy = resultSetConversionStrategy;
     }


[3/4] camel git commit: Component docs

Posted by da...@apache.org.
Component docs


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

Branch: refs/heads/master
Commit: 5d66a295bea2daac555395349a43b880c0e1baa5
Parents: 89706cd
Author: Claus Ibsen <da...@apache.org>
Authored: Mon May 11 09:23:12 2015 +0200
Committer: Claus Ibsen <da...@apache.org>
Committed: Mon May 11 09:23:12 2015 +0200

----------------------------------------------------------------------
 .../apache/camel/component/context/ContextEndpoint.java   | 10 ++++++++++
 .../camel/component/context/LocalContextComponent.java    |  3 +++
 2 files changed, 13 insertions(+)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/camel/blob/5d66a295/components/camel-context/src/main/java/org/apache/camel/component/context/ContextEndpoint.java
----------------------------------------------------------------------
diff --git a/components/camel-context/src/main/java/org/apache/camel/component/context/ContextEndpoint.java b/components/camel-context/src/main/java/org/apache/camel/component/context/ContextEndpoint.java
index 34f9cc7..49dfddd 100644
--- a/components/camel-context/src/main/java/org/apache/camel/component/context/ContextEndpoint.java
+++ b/components/camel-context/src/main/java/org/apache/camel/component/context/ContextEndpoint.java
@@ -51,6 +51,9 @@ public class ContextEndpoint extends DefaultEndpoint implements DelegateEndpoint
         return contextId;
     }
 
+    /**
+     * Is the ID you used to register the CamelContext into the Registry.
+     */
     public void setContextId(String contextId) {
         this.contextId = contextId;
     }
@@ -59,6 +62,13 @@ public class ContextEndpoint extends DefaultEndpoint implements DelegateEndpoint
         return localEndpointUrl;
     }
 
+    /**
+     * Can be a valid Camel URI evaluated within the black box CamelContext.
+     * Or it can be a logical name which is mapped to any local endpoints.
+     * For example if you locally have endpoints like direct:invoices and seda:purchaseOrders
+     * inside a CamelContext of id supplyChain, then you can just use the URIs supplyChain:invoices
+     * or supplyChain:purchaseOrders to omit the physical endpoint kind and use pure logical URIs.
+     */
     public void setLocalEndpointUrl(String localEndpointUrl) {
         this.localEndpointUrl = localEndpointUrl;
     }

http://git-wip-us.apache.org/repos/asf/camel/blob/5d66a295/components/camel-context/src/main/java/org/apache/camel/component/context/LocalContextComponent.java
----------------------------------------------------------------------
diff --git a/components/camel-context/src/main/java/org/apache/camel/component/context/LocalContextComponent.java b/components/camel-context/src/main/java/org/apache/camel/component/context/LocalContextComponent.java
index 0c75bcc..d341b4b 100644
--- a/components/camel-context/src/main/java/org/apache/camel/component/context/LocalContextComponent.java
+++ b/components/camel-context/src/main/java/org/apache/camel/component/context/LocalContextComponent.java
@@ -58,6 +58,9 @@ public class LocalContextComponent extends DefaultComponent {
         return localCamelContext;
     }
 
+    /**
+     * Sets the local CamelContext to use.
+     */
     public void setLocalCamelContext(CamelContext localCamelContext) {
         this.localCamelContext = localCamelContext;
     }