Return-Path: X-Original-To: apmail-camel-commits-archive@www.apache.org Delivered-To: apmail-camel-commits-archive@www.apache.org Received: from mail.apache.org (hermes.apache.org [140.211.11.3]) by minotaur.apache.org (Postfix) with SMTP id 1DCD51151C for ; Mon, 25 Aug 2014 10:19:12 +0000 (UTC) Received: (qmail 41773 invoked by uid 500); 25 Aug 2014 10:19:12 -0000 Delivered-To: apmail-camel-commits-archive@camel.apache.org Received: (qmail 41742 invoked by uid 500); 25 Aug 2014 10:19:12 -0000 Mailing-List: contact commits-help@camel.apache.org; run by ezmlm Precedence: bulk List-Help: List-Unsubscribe: List-Post: List-Id: Reply-To: dev@camel.apache.org Delivered-To: mailing list commits@camel.apache.org Received: (qmail 41733 invoked by uid 99); 25 Aug 2014 10:19:11 -0000 Received: from athena.apache.org (HELO athena.apache.org) (140.211.11.136) by apache.org (qpsmtpd/0.29) with ESMTP; Mon, 25 Aug 2014 10:19:11 +0000 X-ASF-Spam-Status: No, hits=-2000.0 required=5.0 tests=ALL_TRUSTED X-Spam-Check-By: apache.org Received: from [140.211.11.4] (HELO eris.apache.org) (140.211.11.4) by apache.org (qpsmtpd/0.29) with ESMTP; Mon, 25 Aug 2014 10:19:06 +0000 Received: from eris.apache.org (localhost [127.0.0.1]) by eris.apache.org (Postfix) with ESMTP id 4954B2388860 for ; Mon, 25 Aug 2014 10:18:46 +0000 (UTC) Content-Type: text/plain; charset="utf-8" MIME-Version: 1.0 Content-Transfer-Encoding: 7bit Subject: svn commit: r920360 - in /websites/production/camel/content: book-architecture.html book-in-one-page.html cache/main.pageCache camel-2140-release.html component-list.html components.html kafka.html transport.html uris.html Date: Mon, 25 Aug 2014 10:18:45 -0000 To: commits@camel.apache.org From: buildbot@apache.org X-Mailer: svnmailer-1.0.9 Message-Id: <20140825101846.4954B2388860@eris.apache.org> X-Virus-Checked: Checked by ClamAV on apache.org Author: buildbot Date: Mon Aug 25 10:18:45 2014 New Revision: 920360 Log: Production update by buildbot for camel Added: websites/production/camel/content/kafka.html Modified: websites/production/camel/content/book-architecture.html websites/production/camel/content/book-in-one-page.html websites/production/camel/content/cache/main.pageCache websites/production/camel/content/camel-2140-release.html websites/production/camel/content/component-list.html websites/production/camel/content/components.html websites/production/camel/content/transport.html websites/production/camel/content/uris.html Modified: websites/production/camel/content/book-architecture.html ============================================================================== --- websites/production/camel/content/book-architecture.html (original) +++ websites/production/camel/content/book-architecture.html Mon Aug 25 10:18:45 2014 @@ -357,7 +357,9 @@ disruptor-vm:someName[?<option>]

Support for the scp protocol

JT/400 / camel-jt400

-

For integrating with data queues on an AS/400 (aka System i, IBM i, i5, ...) system

Kestrel / camel-kestrel

+

For integrating with data queues on an AS/400 (aka System i, IBM i, i5, ...) system

Kafka / camel-kafka

+ +


For producing to or consuming from Apache Kafka message brokers.

Kestrel / camel-kestrel

For producing to or consuming from Kestrel queues

Krati / camel-krati

Modified: websites/production/camel/content/book-in-one-page.html ============================================================================== --- websites/production/camel/content/book-in-one-page.html (original) +++ websites/production/camel/content/book-in-one-page.html Mon Aug 25 10:18:45 2014 @@ -741,7 +741,9 @@ disruptor-vm:someName[?<option>]

Support for the scp protocol

JT/400 / camel-jt400

-

For integrating with data queues on an AS/400 (aka System i, IBM i, i5, ...) system

Kestrel / camel-kestrel

+

For integrating with data queues on an AS/400 (aka System i, IBM i, i5, ...) system

Kafka / camel-kafka

+ +


For producing to or consuming from Apache Kafka message brokers.

Kestrel / camel-kestrel

For producing to or consuming from Kestrel queues

Krati / camel-krati

@@ -4156,11 +4158,11 @@ While not actual tutorials you might fin

Preface

This tutorial aims to guide the reader through the stages of creating a project which uses Camel to facilitate the routing of messages from a JMS queue to a Spring service. The route works in a synchronous fashion returning a response to the client.

+/*]]>*/

  • Tutorial on Spring Remoting with JMS
  • Preface
  • Prerequisites
  • Distribution
  • About
  • Create the Camel Project
  • Writing the Server @@ -6346,11 +6348,11 @@ So we completed the last piece in the pi

    The cxf: component provides integration with Apache CXF for connecting to JAX-WS services hosted in CXF.

    +/*]]>*/

    • CXF Component
      • URI format
      • Options
        • The descriptions of the dataformats Modified: websites/production/camel/content/cache/main.pageCache ============================================================================== Binary files - no diff available. Modified: websites/production/camel/content/camel-2140-release.html ============================================================================== --- websites/production/camel/content/camel-2140-release.html (original) +++ websites/production/camel/content/camel-2140-release.html Mon Aug 25 10:18:45 2014 @@ -84,7 +84,7 @@ -

          Camel 2.14.0 release (currently in progress)

           

          New and Noteworthy

          Welcome to the 2.14.0 release which approx XXX issues resolved (new features, improvements and bug fixes such as...)

          • Support for running on Java 1.8 JVMs
          • Spring 4.x supported.
          • REST DSL to define REST services using a REST style with verbs such as get/post/put/delete etc. The Rest DSL supports Java and XML DSL.
          • REST DSL integrated with Swagger to expose the service as swagger apis.
          • Simple language defined in routes using resultType as boolean is now evaluated as predicate instead of as expression.
          • Introduced RuntimeEndpointRegistry to capture runtime usage of endpoints in use during routing, such as dynamic endpoints from dynamic EIPs.
          • Added event notification for routes added and removed.
          • Allow to configure cache size in Recipient List, Routing Slip and Dynamic Router EIPs; and as well turn caching off.
          • Netty HTTP producer now supports the CamelHttpPath header to define a dynamic context-path and query parameters to call the remote http server.
          • Polling Consumer allows to configure initial queue size and whether to block when full when using the default  EventDrivenPollingConsumer which most components does. We now block by default, as otherwise the message may be lost if the queue was full, and a new message was offered.
          • Added a generic callback to configure the APNS service builder.
          • Added StreamList option to the JDBC component
          • Allow to define Simple expressions for sql parameters of the SQL component.
          • A new XML tokenizer that is truly XML-aware (e.g., supporting XML namespaces and complex hierarchical structures)
          • Added option parallelAggregate to Multicast, Splitter and Recipient List EIPs
          • Support to set the variable map from message header in Velocity, Freemarker, StringTemplate.
          • Added HazelcastInstance option to Hazelcast component.
          • Producers from static EIPs such as <to> is is now also enlisted in JMX when Camel is starting routes.
          • Unmarshal json to pojo using camel-jackson now supports a header to tell Camel what the pojo class name is, to allow more dynamic behavior, as otherwise the class name would be hardcoded.
          • Also allow to configure camel-jackson to skip null values, by setting includes to NOT_NULL.
          • And camel-jackson can now easily be configured to unmarshal to a List<pojo> or List<Map> instead of either a single pojo or Map type. 
          • Introduced SynchronizationRouteAware allowing to have callbacks before/after an Exchange is being routed. This allows to trigger custom code at these points, for example after a route, but before a Consumer writes any response back to a caller (InOut mode).
          • JDBC now supports outputClass for SelectList type.
          • Routes starting from JMS will now shutdown the consumer (MessageListenerContainer) quicker when CamelContext is being stopped. (assuming the acceptMessagesWhileStopping hasn't been set to true). This can also help a cleaner shutdown as otherwise some JMS clients may attempt re-connect/fail over during shutdown which isn't desired anyway as we are shutting down.
          • OnCompletion can now be configured to use or not use a thread pool, and as well whether to run before or after the route consumer. Running before the consumer allows to modify the exchange before the consumer writes it as response to the callee (if consumer is InOut mode)
          • Added Bulk Index message operation to Elasticsearch component.
          • Added RoutePolicyFactory to create and assign a RoutePolicy for every route, instead of having to configure this for every route.
          • MetricsRoutePolicyFactory to expose route statistics using the codehale metrics library.
          • Improved NettyWorkerPoolBuilder#build visibility.
          • The SJMS component now uses Apache commons-pool for the pool implementation instead of custom code.
          • Using Quartz2 as polling consumer (QuartzScheduledPollConsumerScheduler) now supports task stored in JDBC data store, which means users can setup quartz in clustered mode

          Fixed Issues

          • Timer consumer is now scheduled after CamelContext has started all routes, to ensure other routes is running when timer routes is triggered to ru n.
          • Netty HTTP now returns HTTP status 404 if resource not found instead of 503.
          • Fixed the MongoDB readPreference option which used to cause an IllegalArgumentException to be thrown.
          • Fixed issue with Netty producer may leak HashWhealTimer instances when having many producers that are not reused.
          • Fixed issue with Netty consumer should wait for join to complete when joining a multicast group over UDP 
          • Improved stability when testing with camel-test-blueprint component.
          • Netty HTTP now removes headerFilterStrategy option after resolving it
          • Fixed POJO aggregating when the parameter type was referring to a type that was class annotated.
          • Fixed MyBatis to keep the message body as-is when calling stored procedures, if the procedure returns data as OUT parameters.
          • Fixed Camel Karaf commands to work with multiple CamelContext from the same bundle.
          • Fixed Advice-With to work with transacted routes defined in XML DSL
          • Fixed Advice-With to work with Content Based Router when adding outputs to the when clauses.
          • Fixed Advice-With to honor autoStartup option.
          • Fixed OnCompletion to route the completed Exchange even if it was marked to stop / failed due exception / handled by error handler etc.

          New Enterprise Integration Patterns

          New Components

          New Camel Maven Archetypes

          New DSL

          New Annotations

          New Data Formats

          New Languages

          • XMLTokenizer

          New Examples

          • camel-example-box-osgi
          • camel-example-servlet-rest-blueprint
          • camel-example-servlet-rest-tomcat
          • camel-example-spark-rest-tomcat
          • camel-example-splunk

          New Tooling

          API changes

          • Removed duplicate getter getMessageHistory on ManagedCamelContextMBean

          • Added org.apache.camel.spi.SynchronizationRouteAware

          • Added beforeRoute and afterRoute methods to UnitOfWork.

          Known Issues

          Dependency Upgrades

          You can see any dependency changes using Camel Dependencies Version Differences web tool created by Tracy Snell from the Camel Team.

          The below list is a best effort, and we may miss some updates, its better to use the Camel Dependencies Version Differences web tool which uses the released projects for com parison.

          • Atomikos 3.9.2 to 3.9.3
          • Commons-codec 1.8 to 1.9
          • CXF 2.7.11 to 3.0.1
          • Deltaspike 0.7 to 1.0.1
          • Dozer 5.4.0 to 5.5.1
          • EhCache 2.8.1 to 2.8.3
          • Groovy 2.2.2 to 2.3.4
          • Guava 16.0.1 to 17.0
          • Hapi 2.1 to 2.2
          • Hazelcast 3.0.3 to 3.2.4
          • JRuby 1.7.10 to 1.7.12
          • MongoDB-Java-Driver 2.11.4 to 2.12.0
          • RabbitMQ AMQ Client 3.2.2 to 3.3.0
          • Restlet 2.17 to 2.2.1
          • RxJava 0.17.5 to 0.19.4
          • Scala 2.10.3 to 2.11.2
          • Snmp4j 2.2.5 to 2.3.0
          • SSHD 0.10.1 to 0.11.0
          • spring-redis 1.1.0 to 1.3.0
          • Twitter4j 3.0.5 x to 4.0.1

          Internal changes

          • Changed ...

          Changes that may affect end users

          • Polling Consumer allows to configure initial queue size and whether to block when full when using the default EventDrivenPollingConsumer which most components does. We now block by default, as otherwise the message may be lost if the queue was full, and a new message was offered.
          • camel-scala upgraded from Scala 2.10.x to 2.11.x
          • The option useSsl has been removed from camel-twitter as ssl is always enabled now, enforced by twitter
          • Fixed Restlet to return error code 405 (instead of 404 if a http method is not allowed
          • Routes starting from JMS will now shutdown the consumer (MessageListenerContainer) quicker when CamelContext is being stopped. (assuming the acceptMessagesWhileStopping hasn't been set to true). This can also help a cleaner shutdown as otherwise some JMS clients may attempt re-connect/failover during shutdown which isn't desire d anyway as we are shutting down. If you want the routes to keep accepting messages during shutdown of Camel, then set acceptMessagesWhileStopping=true.
          • OnCompletion now runs without thread pool by default. To restore old behavior set paralllelProcessing to true.
          • Setting autoStartup to false, and starting a CamelContext the 2nd time now does not start the routes, instead use the new startAllRoutes method on CamelContext to start all the routes.

          Important changes to consider when upgrading

          • Java 1.6 no longer supported.
          • Unit testing with Spring 3.x now requires using camel-test-spring3, as camel-test-spring is for Spring 4.x

          Getting the Distributions

          Binary Distributions

          Description

          Download Link

          PGP Signature file of download

          Windows Distribution

          apache-camel-2.14.0.zip

          apache-camel-2.14.0.zip.asc

          Unix/Linux/Cygwin Distribution

          apache-camel-2.14.0.tar.gz

          apache-camel-2.14.0.tar.gz.asc

          Source Distribution

          Description

          Download Link

          PGP Signature file of download

          Source

          apache-camel-2.14.0-src.zip

          apache-camel-2.14.0-src.zip.asc

          Getting the Binaries using Maven 2

          To use this release in your maven project, the proper dependency configuration that you should use in your Maven POM is:

          +

          Camel 2.14.0 release (currently in progress)

           

          New and Noteworthy

          Welcome to the 2.14.0 release which approx XXX issues resolved (new features, improvements and bug fixes such as...)

          • Support for running on Java 1.8 JVMs
          • Spring 4.x supported.
          • REST DSL to define REST services using a REST style with verbs such as get/post/put/delete etc. The Rest DSL supports Java and XML DSL.
          • REST DSL integrated with Swagger to expose the service as swagger apis.
          • Simple language defined in routes using resultType as boolean is now evaluated as predicate instead of as expression.
          • Introduced RuntimeEndpointRegistry to capture runtime usage of endpoints in use during routing, such as dynamic endpoints from dynamic EIPs.
          • Added event notification for routes added and removed.
          • Allow to configure cache size in Recipient List, Routing Slip and Dynamic Router EIPs; and as well turn caching off.
          • Netty HTTP producer now supports the CamelHttpPath header to define a dynamic context-path and query parameters to call the remote http server.
          • Polling Consumer allows to configure initial queue size and whether to block when full when using the default  EventDrivenPollingConsumer which most components does. We now block by default, as otherwise the message may be lost if the queue was full, and a new message was offered.
          • Added a generic callback to configure the APNS service builder.
          • Added StreamList option to the JDBC component
          • Allow to define Simple expressions for sql parameters of the SQL component.
          • A new XML tokenizer that is truly XML-aware (e.g., supporting XML namespaces and complex hierarchical structures)
          • Added option parallelAggregate to Multicast, Splitter and Recipient List EIPs
          • Support to set the variable map from message header in Velocity, Freemarker, StringTemplate.
          • Added HazelcastInstance option to Hazelcast component.
          • Producers from static EIPs such as <to> is is now also enlisted in JMX when Camel is starting routes.
          • Unmarshal json to pojo using camel-jackson now supports a header to tell Camel what the pojo class name is, to allow more dynamic behavior, as otherwise the class name would be hardcoded.
          • Also allow to configure camel-jackson to skip null values, by setting includes to NOT_NULL.
          • And camel-jackson can now easily be configured to unmarshal to a List<pojo> or List<Map> instead of either a single pojo or Map type. 
          • Introduced SynchronizationRouteAware allowing to have callbacks before/after an Exchange is being routed. This allows to trigger custom code at these points, for example after a route, but before a Consumer writes any response back to a caller (InOut mode).
          • JDBC now supports outputClass for SelectList type.
          • Routes starting from JMS will now shutdown the consumer (MessageListenerContainer) quicker when CamelContext is being stopped. (assuming the acceptMessagesWhileStopping hasn't been set to true). This can also help a cleaner shutdown as otherwise some JMS clients may attempt re-connect/fail over during shutdown which isn't desired anyway as we are shutting down.
          • OnCompletion can now be configured to use or not use a thread pool, and as well whether to run before or after the route consumer. Running before the consumer allows to modify the exchange before the consumer writes it as response to the callee (if consumer is InOut mode)
          • Added Bulk Index message operation to Elasticsearch component.
          • Added RoutePolicyFactory to create and assign a RoutePolicy for every route, instead of having to configure this for every route.
          • MetricsRoutePolicyFactory to expose route statistics using the codehale metrics library.
          • Improved NettyWorkerPoolBuilder#build visibility.
          • The SJMS component now uses Apache commons-pool for the pool implementation instead of custom code.
          • Using Quartz2 as polling consumer (QuartzScheduledPollConsumerScheduler) now supports task stored in JDBC data store, which means users can setup quartz in clustered mode
          • Camel component API to output json parameter schema now honors the JSon Schema spec, and also include a description of the javaType for object types.

          Fixed Issues

          • Timer consumer is now scheduled after CamelContext has started all routes, to ensure other routes is running when timer routes is triggered to run.
          • Netty HTTP now returns HTTP status 404 if resource not found instead of 503.
          • Fixed the MongoDB readPreference option which used to cause an IllegalArgumentException to be thrown.
          • Fixed issue with Netty producer may leak HashWhealTimer instances when having many producers that are not reused.
          • Fixed issue with Netty consumer should wait for join to complete when joining a multicast group over UDP 
          • Improved stability when testing with camel-test-blueprint component.
          • Netty HTTP now removes headerFilterStrategy option after resolving it
          • Fixed POJO aggregating when the parameter type was referring to a type that was class annotated.
          • Fixed MyBatis to keep the message body as-is when calling stored procedures, if the procedure returns data as OUT parameters.
          • Fixed Camel Karaf commands to work with multiple CamelContext from the same bundle.
          • Fixed Advice-With to work with transacted routes defined in XML DSL
          • Fixed Advice-With to work with Content Based Router when adding outputs to the when clauses.
          • Fixed Advice-With to honor autoStartup option.
          • Fixed OnCompletion to route the completed Exchange even if it was marked to stop / failed due exception / handled by error handler etc.

          New Enterprise Integration Patterns

          New Components

          New Camel Maven Archetypes

          New DSL

          New Annotations

          New Data Formats

          New Languages

          • XMLTokenizer

          New Examples

          • camel-example-box-osgi
          • camel-example-servlet-rest-blueprint
          • camel-example-servlet-rest-tomcat
          • camel-example-spark-rest-tomcat
          • camel-example-splunk

          New Tooling

          API changes

          • Removed duplicate getter getMessageHistory on ManagedCamelContextMBean

          • Added org.apache.camel.spi.SynchronizationRouteAware

          • Added beforeRoute and afterRoute methods to UnitOfWork.

          Known Issues

          Dependency Upgrades

          You can see any dependency changes using Camel Dependencies Version Differences web tool created by Tracy Snell from the Camel Team.

          The below list is a best effort, and we may miss some updates, its better to use the Camel Dependencies Version Differences web tool which uses the released projects for comparison.

          • Atomikos 3.9.2 to 3.9.3
          • Commons-codec 1.8 to 1.9
          • CXF 2.7.11 to 3.0.1
          • Deltaspike 0.7 to 1.0.1
          • Dozer 5.4.0 to 5.5.1
          • EhCache 2.8.1 to 2.8.3
          • Groovy 2.2.2 to 2.3.4
          • Guava 16.0.1 to 17.0
          • Hapi 2.1 to 2.2
          • Hazelcast 3.0.3 to 3.2.4
          • JRuby 1.7.10 to 1.7.12
          • MongoDB-Java-Driver 2.11.4 to 2.12.0
          • RabbitMQ AMQ Client 3.2.2 to 3.3.0
          • Restlet 2.17 to 2.2.1
          • RxJava 0.17.5 to 0.19.4
          • Scala 2.10.3 to 2.11.2
          • Snmp4j 2.2.5 to 2.3.0
          • SSHD 0.10.1 to 0.11.0
          • spring-redis 1.1.0 to 1.3.0
          • Twitter4j 3.0.5 x to 4.0.1

          Internal changes

          • Changed ...

          Changes that may affect end users

          • Polling Consumer allows to configure initial queue size and whether to block when full when using the default EventDrivenPollingConsumer which most components does. We now block by default, as otherwise the message may be lost if the queue was full, and a new message was offered.
          • camel-scala upgraded from Scala 2.10.x to 2.11.x
          • The option useSsl has been removed from camel-twitter as ssl is always enabled now, enforced by twitter
          • Fixed Restlet to return error code 405 (instead of 404 if a http method is not allowed
          • Routes starting from JMS will now shutdown the consumer (MessageListenerContainer) quicker when CamelContext is being sto pped. (assuming the acceptMessagesWhileStopping hasn't been set to true). This can also help a cleaner shutdown as otherwise some JMS clients may attempt re-connect/failover during shutdown which isn't desired anyway as we are shutting down. If you want the routes to keep accepting messages during shutdown of Camel, then set acceptMessagesWhileStopping=true.
          • OnCompletion now runs without thread pool by default. To restore old behavior set paralllelProcessing to true.
          • Setting autoStartup to false, and starting a CamelContext the 2nd time now does not start the routes, instead use the new startAllRoutes method on CamelContext to start all the routes.

          Important changes to consider when upgrading

          • Java 1.6 no longer supported.
          • Unit testing with Spring 3.x now requires using camel-test-spring3, as camel-test-spring is for Spring 4.x

          Getting the Distributions

          Binary Distributions

          Description

          Download Link

          PGP Signature file of download

          Windows Distribution

          apache-camel-2.14.0.zip

          apache-camel-2.14.0.zip.asc

          Unix/Linux/Cygwin Distribution

          apache-camel-2.14.0.tar.gz

          apache-camel-2.14.0.tar.gz.asc

          Source Distribution

          Description

          Download Link

          PGP Signature file of download

          Source

          apache-camel-2.14.0-src.zip

          apache-camel-2.14.0-src.zip.asc

          Getting the Binaries using Maven 2

          To use this release in your maven project, the proper dependency conf iguration that you should use in your Maven POM is:

          -

          For integrating with data queues on an AS/400 (aka System i, IBM i, i5, ...) system

          Kestrel / camel-kestrel

          +

          For integrating with data queues on an AS/400 (aka System i, IBM i, i5, ...) system

          Kafka / camel-kafka

          + +


          For producing to or consuming from Apache Kafka message brokers.

          Kestrel / camel-kestrel

          For producing to or consuming from Kestrel queues

          Krati / camel-krati

          Modified: websites/production/camel/content/components.html ============================================================================== --- websites/production/camel/content/components.html (original) +++ websites/production/camel/content/components.html Mon Aug 25 10:18:45 2014 @@ -326,7 +326,9 @@ disruptor-vm:someName[?<option>]

          Support for the scp protocol

          JT/400 / camel-jt400

          -

          For integrating with data queues on an AS/400 (aka System i, IBM i, i5, ...) system

          Kestrel / camel-kestrel

          +

          For integrating with data queues on an AS/400 (aka System i, IBM i, i5, ...) system

          Kafka / camel-kafka

          + +


          For producing to or consuming from Apache Kafka message brokers.

          Kestrel / camel-kestrel

          For producing to or consuming from Kestrel queues

          Krati / camel-krati

          Added: websites/production/camel/content/kafka.html ============================================================================== --- websites/production/camel/content/kafka.html (added) +++ websites/production/camel/content/kafka.html Mon Aug 25 10:18:45 2014 @@ -0,0 +1,181 @@ + + + + + + + + + + + + + + + + + + + + + + + + + + Apache Camel: Kafka + + + +
          +
          +
          +
          +
          +
          +
          +
          +
          +
          +
          + + + + + + + + + + + + +
          +

          Kafka Component

          Available as of Camel 2.13

          The kafka: component is used for communicating with Apache Kafka message broker.

          Maven users will need to add the following dependency to their pom.xml for this component:

          + +

          URI format

          + +

           

          Options

          Property

          Default

          Description

          zookeeperHost

           

          The zookeeper host to use

          zookeeperPort

          2181

          The zookeeper port to use

          topic

           

          The topic to use

          groupId  
          partitioner  
          consumerStreams10 
          clientId  
          zookeeperSessionTimeoutMs  
          zookeeperConnectionTimeoutMs  
          zookeeperSyncTimeMs  

          You can append query options to the URI in the following format, ?option=value&option=value&...

          Producer Options

          Property

          Default

          Description

          producerType

           

           
          compressionCodec  
          compressedTopics  
          messageSendMaxRetries  
          retryBackoffMs  
          topicMetadataRefreshIntervalMs  
          sendBufferBytes  
          requestRequiredAcks  
          requestTimeoutMs  
          queueBufferingMaxMs  
          queueBufferingMaxMessages  
          queueEnqueueTimeoutMs  
          batchNumMessages  
          serializerClass  
          keySerializerClass  

          Consumer Options

          Property

          Default

          Description

          consumerId

           

           
          socketTimeoutMs  
          socketReceiveBufferBytes  
          fetchMessageMaxBytes  
          autoCommitEnable  
          autoCommitIntervalMs  
          queuedMaxMessages  
          rebalanceMaxRetries  
          fetchMinBytes  
          fetchWaitMaxMs  
          rebalanceBackoffMs  
          refreshLeaderBackoffMs  
          autoOffsetReset  
          consumerTimeoutMs  

          Samples

          Consuming messages:

          + +

          Producing messages:

          See unit tests of camel-kafka for more examples

          Endpoints

          + +

          Camel supports the Message Endpoint pattern using the Endpoint interface. Endpoints are usually created by a Component and Endpoints are usually referred to in the DSL via their URIs.

          + +

          From an Endpoint you can use the following methods

          + + + +

          See Also

          + +
          +
          + +
          + + +
          +
          +
          +
          +
          +
          + +
          +
          +
          +© 2004-2014 The Apache Software Foundation. +
          +Apache Camel, Camel, Apache, the Apache feather logo, and the Apache Camel project logo are trademarks of The Apache Software Foundation. All other marks mentioned may be trademarks or registered trademarks of their respective owners. +
          +Graphic Design By Hiram +
          + + + + + + + + Modified: websites/production/camel/content/transport.html ============================================================================== --- websites/production/camel/content/transport.html (original) +++ websites/production/camel/content/transport.html Mon Aug 25 10:18:45 2014 @@ -330,7 +330,9 @@ disruptor-vm:someName[?<option>]

          Support for the scp protocol

          JT/400 / camel-jt400

          -

          For integrating with data queues on an AS/400 (aka System i, IBM i, i5, ...) system

          Kestrel / camel-kestrel

          +

          For integrating with data queues on an AS/400 (aka System i, IBM i, i5, ...) system

          Kafka / camel-kafka

          + +


          For producing to or consuming from Apache Kafka message brokers.

          Kestrel / camel-kestrel

          For producing to or consuming from Kestrel queues

          Krati / camel-krati

          Modified: websites/production/camel/content/uris.html ============================================================================== --- websites/production/camel/content/uris.html (original) +++ websites/production/camel/content/uris.html Mon Aug 25 10:18:45 2014 @@ -335,7 +335,9 @@ disruptor-vm:someName[?<option>]

          Support for the scp protocol

          JT/400 / camel-jt400

          -

          For integrating with data queues on an AS/400 (aka System i, IBM i, i5, ...) system

          Kestrel / camel-kestrel

          +

          For integrating with data queues on an AS/400 (aka System i, IBM i, i5, ...) system

          Kafka / camel-kafka

          + +


          For producing to or consuming from Apache Kafka message brokers.

          Kestrel / camel-kestrel

          For producing to or consuming from Kestrel queues

          Krati / camel-krati