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/02 08:48:02 UTC

[1/5] camel git commit: CAMEL-10197: Component docs/schema for omponent updated to not have default false values for booleans.

Repository: camel
Updated Branches:
  refs/heads/master 0434eb809 -> 47ff272f3


http://git-wip-us.apache.org/repos/asf/camel/blob/47ff272f/components/camel-netty4/src/main/java/org/apache/camel/component/netty4/springboot/NettyComponentConfiguration.java
----------------------------------------------------------------------
diff --git a/components/camel-netty4/src/main/java/org/apache/camel/component/netty4/springboot/NettyComponentConfiguration.java b/components/camel-netty4/src/main/java/org/apache/camel/component/netty4/springboot/NettyComponentConfiguration.java
index 0c1b3fc..6325701 100644
--- a/components/camel-netty4/src/main/java/org/apache/camel/component/netty4/springboot/NettyComponentConfiguration.java
+++ b/components/camel-netty4/src/main/java/org/apache/camel/component/netty4/springboot/NettyComponentConfiguration.java
@@ -70,7 +70,7 @@ public class NettyComponentConfiguration {
     /**
      * Setting to choose Multicast over UDP
      */
-    private Boolean broadcast = false;
+    private Boolean broadcast;
     /**
      * The TCP/UDP buffer sizes to be used during outbound communication. Size
      * is bytes.
@@ -101,15 +101,15 @@ public class NettyComponentConfiguration {
     /**
      * Setting to ensure socket is not closed due to inactivity
      */
-    private Boolean keepAlive = false;
+    private Boolean keepAlive;
     /**
      * Setting to improve TCP protocol performance
      */
-    private Boolean tcpNoDelay = false;
+    private Boolean tcpNoDelay;
     /**
      * Setting to facilitate socket multiplexing
      */
-    private Boolean reuseAddress = false;
+    private Boolean reuseAddress;
     /**
      * Time to wait for a socket connection to be available. Value is in millis.
      */
@@ -125,14 +125,14 @@ public class NettyComponentConfiguration {
     /**
      * Setting to specify whether SSL encryption is applied to this endpoint
      */
-    private Boolean ssl = false;
+    private Boolean ssl;
     /**
      * When enabled and in SSL mode then the Netty consumer will enrich the
      * Camel Message with headers having information about the client
      * certificate such as subject name issuer name serial number and the valid
      * date range.
      */
-    private Boolean sslClientCertHeaders = false;
+    private Boolean sslClientCertHeaders;
     /**
      * Reference to a class that could be used to return an SSL Handler
      */
@@ -144,7 +144,7 @@ public class NettyComponentConfiguration {
     /**
      * Configures whether the server needs client authentication when using SSL.
      */
-    private Boolean needClientAuth = false;
+    private Boolean needClientAuth;
     /**
      * Client side certificate keystore to be used for encryption. Is loaded by
      * default from classpath but you can prefix with classpath: file: or http:
@@ -190,7 +190,7 @@ public class NettyComponentConfiguration {
     /**
      * Setting to set endpoint as one-way or request-response
      */
-    private Boolean sync = false;
+    private Boolean sync;
     /**
      * Allows to configure additional netty options using option. as prefix. For
      * example option.child.keepAlive=false to set the netty option
@@ -203,7 +203,7 @@ public class NettyComponentConfiguration {
      * indicate a text line based codec; if not specified or the value is false
      * then Object Serialization is assumed over TCP.
      */
-    private Boolean textline = false;
+    private Boolean textline;
     /**
      * Whether to use native transport instead of NIO. Native transport takes
      * advantage of the host operating system and is only supported on some
@@ -211,7 +211,7 @@ public class NettyComponentConfiguration {
      * you are using. See more details at:
      * http://netty.io/wiki/native-transports.html
      */
-    private Boolean nativeTransport = false;
+    private Boolean nativeTransport;
     /**
      * The max line length to use for the textline codec.
      */
@@ -230,7 +230,7 @@ public class NettyComponentConfiguration {
      * Whether or not to auto append missing end delimiter when sending using
      * the textline codec.
      */
-    private Boolean autoAppendDelimiter = false;
+    private Boolean autoAppendDelimiter;
     /**
      * To use a explicit EventLoopGroup as the boss thread pool. For example to
      * share a thread pool with multiple consumers. By default each consumer has
@@ -271,7 +271,7 @@ public class NettyComponentConfiguration {
      * Used only in clientMode in consumer the consumer will attempt to
      * reconnect on disconnection if this is enabled
      */
-    private Boolean reconnect = false;
+    private Boolean reconnect;
     /**
      * A custom ChannelHandler class that can be used to perform special
      * marshalling of outbound payloads.
@@ -291,12 +291,12 @@ public class NettyComponentConfiguration {
      * Whether or not to disconnect(close) from Netty Channel right after use.
      * Can be used for both consumer and producer.
      */
-    private Boolean disconnect = false;
+    private Boolean disconnect;
     /**
      * Channels can be lazily created to avoid exceptions if the remote server
      * is not up and running when the Camel producer is started.
      */
-    private Boolean lazyChannelCreation = false;
+    private Boolean lazyChannelCreation;
     /**
      * Only used for TCP. You can transfer the exchange over the wire instead of
      * just the body. The following fields are transferred: In body Out body
@@ -304,12 +304,12 @@ public class NettyComponentConfiguration {
      * exchange exception. This requires that the objects are serializable.
      * Camel will exclude any non-serializable objects and log it at WARN level.
      */
-    private Boolean transferExchange = false;
+    private Boolean transferExchange;
     /**
      * If sync is enabled then this option dictates NettyConsumer if it should
      * disconnect where there is no reply to send back.
      */
-    private Boolean disconnectOnNoReply = false;
+    private Boolean disconnectOnNoReply;
     /**
      * If sync is enabled this option dictates NettyConsumer which logging level
      * to use when logging a there is no reply to send back.
@@ -334,7 +334,7 @@ public class NettyComponentConfiguration {
      * the netty component from installing a default codec as the first element
      * in the filter chain.
      */
-    private Boolean allowDefaultCodec = false;
+    private Boolean allowDefaultCodec;
     /**
      * To use a custom ClientInitializerFactory
      */
@@ -343,7 +343,7 @@ public class NettyComponentConfiguration {
      * Whether to use ordered thread pool to ensure events are processed orderly
      * on the same channel.
      */
-    private Boolean usingExecutorService = false;
+    private Boolean usingExecutorService;
     /**
      * Sets the cap on the number of objects that can be allocated by the pool
      * (checked out to clients or idle awaiting checkout) at a given time. Use a
@@ -370,28 +370,28 @@ public class NettyComponentConfiguration {
      * as the pooling is needed for handling concurrency and reliable
      * request/reply.
      */
-    private Boolean producerPoolEnabled = false;
+    private Boolean producerPoolEnabled;
     /**
      * This option supports connection less udp sending which is a real fire and
      * forget. A connected udp send receive the PortUnreachableException if no
      * one is listen on the receiving port.
      */
-    private Boolean udpConnectionlessSending = false;
+    private Boolean udpConnectionlessSending;
     /**
      * If the clientMode is true netty consumer will connect the address as a
      * TCP client.
      */
-    private Boolean clientMode = false;
+    private Boolean clientMode;
     /**
      * If the useByteBuf is true netty producer will turn the message body into
      * ByteBuf before sending it out.
      */
-    private Boolean useByteBuf = false;
+    private Boolean useByteBuf;
     /**
      * For UDP only. If enabled the using byte array codec instead of Java
      * serialization protocol.
      */
-    private Boolean udpByteArrayCodec = false;
+    private Boolean udpByteArrayCodec;
     /**
      * This option allows producers to reuse the same Netty Channel for the
      * lifecycle of processing the Exchange. This is useable if you need to call
@@ -402,7 +402,7 @@ public class NettyComponentConfiguration {
      * exchange property with the key link NettyConstantsNETTY_CHANNEL which
      * allows you to obtain the channel during routing and use it as well.
      */
-    private Boolean reuseChannel = false;
+    private Boolean reuseChannel;
 
     public Integer getMaximumPoolSize() {
         return maximumPoolSize;

http://git-wip-us.apache.org/repos/asf/camel/blob/47ff272f/components/camel-quartz/src/main/java/org/apache/camel/component/quartz/springboot/QuartzComponentConfiguration.java
----------------------------------------------------------------------
diff --git a/components/camel-quartz/src/main/java/org/apache/camel/component/quartz/springboot/QuartzComponentConfiguration.java b/components/camel-quartz/src/main/java/org/apache/camel/component/quartz/springboot/QuartzComponentConfiguration.java
index bc94ab5..8a200be 100644
--- a/components/camel-quartz/src/main/java/org/apache/camel/component/quartz/springboot/QuartzComponentConfiguration.java
+++ b/components/camel-quartz/src/main/java/org/apache/camel/component/quartz/springboot/QuartzComponentConfiguration.java
@@ -54,12 +54,12 @@ public class QuartzComponentConfiguration {
      * Whether or not the scheduler should be auto started. This options is
      * default true
      */
-    private Boolean autoStartScheduler = false;
+    private Boolean autoStartScheduler;
     /**
      * Whether to enable Quartz JMX which allows to manage the Quartz scheduler
      * from JMX. This options is default true
      */
-    private Boolean enableJmx = false;
+    private Boolean enableJmx;
 
     public SchedulerFactory getFactory() {
         return factory;

http://git-wip-us.apache.org/repos/asf/camel/blob/47ff272f/components/camel-quartz2/src/main/java/org/apache/camel/component/quartz2/springboot/QuartzComponentConfiguration.java
----------------------------------------------------------------------
diff --git a/components/camel-quartz2/src/main/java/org/apache/camel/component/quartz2/springboot/QuartzComponentConfiguration.java b/components/camel-quartz2/src/main/java/org/apache/camel/component/quartz2/springboot/QuartzComponentConfiguration.java
index 1b0eea6..a3f9824 100644
--- a/components/camel-quartz2/src/main/java/org/apache/camel/component/quartz2/springboot/QuartzComponentConfiguration.java
+++ b/components/camel-quartz2/src/main/java/org/apache/camel/component/quartz2/springboot/QuartzComponentConfiguration.java
@@ -33,7 +33,7 @@ public class QuartzComponentConfiguration {
      * Whether or not the scheduler should be auto started. This options is
      * default true
      */
-    private Boolean autoStartScheduler = false;
+    private Boolean autoStartScheduler;
     /**
      * Seconds to wait before starting the quartz scheduler.
      */
@@ -42,12 +42,12 @@ public class QuartzComponentConfiguration {
      * Whether to prefix the quartz job with the endpoint id. This option is
      * default false.
      */
-    private Boolean prefixJobNameWithEndpointId = false;
+    private Boolean prefixJobNameWithEndpointId;
     /**
      * Whether to enable Quartz JMX which allows to manage the Quartz scheduler
      * from JMX. This options is default true
      */
-    private Boolean enableJmx = false;
+    private Boolean enableJmx;
     /**
      * Properties to configure the Quartz scheduler.
      */
@@ -63,7 +63,7 @@ public class QuartzComponentConfiguration {
      * to false to reuse Quartz scheduler instances between multiple
      * CamelContext's.
      */
-    private Boolean prefixInstanceName = false;
+    private Boolean prefixInstanceName;
     /**
      * To use the custom SchedulerFactory which is used to create the Scheduler.
      */

http://git-wip-us.apache.org/repos/asf/camel/blob/47ff272f/components/camel-quickfix/src/main/java/org/apache/camel/component/quickfixj/springboot/QuickfixjComponentConfiguration.java
----------------------------------------------------------------------
diff --git a/components/camel-quickfix/src/main/java/org/apache/camel/component/quickfixj/springboot/QuickfixjComponentConfiguration.java b/components/camel-quickfix/src/main/java/org/apache/camel/component/quickfixj/springboot/QuickfixjComponentConfiguration.java
index 6440310..c4b186d 100644
--- a/components/camel-quickfix/src/main/java/org/apache/camel/component/quickfixj/springboot/QuickfixjComponentConfiguration.java
+++ b/components/camel-quickfix/src/main/java/org/apache/camel/component/quickfixj/springboot/QuickfixjComponentConfiguration.java
@@ -53,7 +53,7 @@ public class QuickfixjComponentConfiguration {
      * If set to true the engines will be created and started when needed (when
      * first message is send)
      */
-    private Boolean lazyCreateEngines = false;
+    private Boolean lazyCreateEngines;
 
     public MessageFactory getMessageFactory() {
         return messageFactory;

http://git-wip-us.apache.org/repos/asf/camel/blob/47ff272f/components/camel-restlet/src/main/java/org/apache/camel/component/restlet/springboot/RestletComponentConfiguration.java
----------------------------------------------------------------------
diff --git a/components/camel-restlet/src/main/java/org/apache/camel/component/restlet/springboot/RestletComponentConfiguration.java b/components/camel-restlet/src/main/java/org/apache/camel/component/restlet/springboot/RestletComponentConfiguration.java
index 8824e48..612d6af 100644
--- a/components/camel-restlet/src/main/java/org/apache/camel/component/restlet/springboot/RestletComponentConfiguration.java
+++ b/components/camel-restlet/src/main/java/org/apache/camel/component/restlet/springboot/RestletComponentConfiguration.java
@@ -110,7 +110,7 @@ public class RestletComponentConfiguration {
      * request input stream into a stream cache and put it into message body if
      * this option is false to support reading the stream multiple times.
      */
-    private Boolean disableStreamCache = false;
+    private Boolean disableStreamCache;
     /**
      * To configure the port number for the restlet consumer routes. This allows
      * to configure this once to reuse the same port for these consumers.

http://git-wip-us.apache.org/repos/asf/camel/blob/47ff272f/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/springboot/SalesforceComponentConfiguration.java
----------------------------------------------------------------------
diff --git a/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/springboot/SalesforceComponentConfiguration.java b/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/springboot/SalesforceComponentConfiguration.java
index 18894b7..a971286 100644
--- a/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/springboot/SalesforceComponentConfiguration.java
+++ b/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/springboot/SalesforceComponentConfiguration.java
@@ -76,11 +76,11 @@ public class SalesforceComponentConfiguration {
     /**
      * Enable for Socks4 proxy false by default
      */
-    private Boolean isHttpProxySocks4 = false;
+    private Boolean isHttpProxySocks4;
     /**
      * Enable for TLS connections true by default
      */
-    private Boolean isHttpProxySecure = false;
+    private Boolean isHttpProxySecure;
     /**
      * HTTP proxy included addresses
      */
@@ -100,7 +100,7 @@ public class SalesforceComponentConfiguration {
     /**
      * Use HTTP proxy Digest authentication false by default
      */
-    private Boolean httpProxyUseDigestAuth = false;
+    private Boolean httpProxyUseDigestAuth;
     /**
      * Package names to scan for DTO classes (multiple packages can be separated
      * by comma).
@@ -130,7 +130,7 @@ public class SalesforceComponentConfiguration {
      * Flag to enable/disable lazy OAuth default is false. When enabled OAuth
      * token retrieval or generation is not done until the first API call
      */
-    private Boolean lazyLogin = false;
+    private Boolean lazyLogin;
     /**
      * Payload format to use for Salesforce API calls either JSON or XML
      * defaults to JSON
@@ -210,7 +210,7 @@ public class SalesforceComponentConfiguration {
      * Whether to update an existing Push Topic when using the Streaming API
      * defaults to false
      */
-    private Boolean updateTopic = false;
+    private Boolean updateTopic;
     /**
      * Notify for fields options are ALL REFERENCED SELECT WHERE
      */

http://git-wip-us.apache.org/repos/asf/camel/blob/47ff272f/components/camel-servlet/src/main/java/org/apache/camel/component/servlet/springboot/ServletComponentConfiguration.java
----------------------------------------------------------------------
diff --git a/components/camel-servlet/src/main/java/org/apache/camel/component/servlet/springboot/ServletComponentConfiguration.java b/components/camel-servlet/src/main/java/org/apache/camel/component/servlet/springboot/ServletComponentConfiguration.java
index be38061..24fcebe 100644
--- a/components/camel-servlet/src/main/java/org/apache/camel/component/servlet/springboot/ServletComponentConfiguration.java
+++ b/components/camel-servlet/src/main/java/org/apache/camel/component/servlet/springboot/ServletComponentConfiguration.java
@@ -44,7 +44,7 @@ public class ServletComponentConfiguration {
      * Exchange. This is turn off by default as this may require servet specific
      * configuration to enable this when using Servlet's.
      */
-    private Boolean attachmentMultipartBinding = false;
+    private Boolean attachmentMultipartBinding;
     /**
      * To use a custom HttpBinding to control the mapping between Camel message
      * and HttpClient.
@@ -61,7 +61,7 @@ public class ServletComponentConfiguration {
      * the incoming data from the request to Java and that can be a potential
      * security risk.
      */
-    private Boolean allowJavaSerializedObject = false;
+    private Boolean allowJavaSerializedObject;
     /**
      * To use a custom HeaderFilterStrategy to filter header to and from Camel
      * message.

http://git-wip-us.apache.org/repos/asf/camel/blob/47ff272f/components/camel-smpp/src/main/java/org/apache/camel/component/smpp/springboot/SmppComponentConfiguration.java
----------------------------------------------------------------------
diff --git a/components/camel-smpp/src/main/java/org/apache/camel/component/smpp/springboot/SmppComponentConfiguration.java b/components/camel-smpp/src/main/java/org/apache/camel/component/smpp/springboot/SmppComponentConfiguration.java
index e74b26a..f7d9cc8 100644
--- a/components/camel-smpp/src/main/java/org/apache/camel/component/smpp/springboot/SmppComponentConfiguration.java
+++ b/components/camel-smpp/src/main/java/org/apache/camel/component/smpp/springboot/SmppComponentConfiguration.java
@@ -180,7 +180,7 @@ public class SmppComponentConfiguration {
     /**
      * Whether using SSL with the smpps protocol
      */
-    private Boolean usingSSL = false;
+    private Boolean usingSSL;
     /**
      * Defines the initial delay in milliseconds after the consumer/producer
      * tries to reconnect to the SMSC after the connection was lost.
@@ -198,7 +198,7 @@ public class SmppComponentConfiguration {
      * exchange. If they are present Camel will use these data to connect to the
      * SMSC.
      */
-    private Boolean lazySessionCreation = false;
+    private Boolean lazySessionCreation;
     /**
      * If you need to tunnel SMPP through a HTTP proxy set this attribute to the
      * hostname or ip address of your HTTP proxy.

http://git-wip-us.apache.org/repos/asf/camel/blob/47ff272f/components/camel-websocket/src/main/java/org/apache/camel/component/websocket/springboot/WebsocketComponentConfiguration.java
----------------------------------------------------------------------
diff --git a/components/camel-websocket/src/main/java/org/apache/camel/component/websocket/springboot/WebsocketComponentConfiguration.java b/components/camel-websocket/src/main/java/org/apache/camel/component/websocket/springboot/WebsocketComponentConfiguration.java
index 61c5034..4797773 100644
--- a/components/camel-websocket/src/main/java/org/apache/camel/component/websocket/springboot/WebsocketComponentConfiguration.java
+++ b/components/camel-websocket/src/main/java/org/apache/camel/component/websocket/springboot/WebsocketComponentConfiguration.java
@@ -64,7 +64,7 @@ public class WebsocketComponentConfiguration {
      * If this option is true Jetty JMX support will be enabled for this
      * endpoint. See Jetty JMX support for more details.
      */
-    private Boolean enableJmx = false;
+    private Boolean enableJmx;
     /**
      * To set a value for minimum number of threads in server thread pool.
      * MaxThreads/minThreads or threadPool fields are required due to switch to

http://git-wip-us.apache.org/repos/asf/camel/blob/47ff272f/components/camel-zookeeper/src/main/java/org/apache/camel/component/zookeeper/springboot/ZooKeeperComponentConfiguration.java
----------------------------------------------------------------------
diff --git a/components/camel-zookeeper/src/main/java/org/apache/camel/component/zookeeper/springboot/ZooKeeperComponentConfiguration.java b/components/camel-zookeeper/src/main/java/org/apache/camel/component/zookeeper/springboot/ZooKeeperComponentConfiguration.java
index e28b42f..41906c0 100644
--- a/components/camel-zookeeper/src/main/java/org/apache/camel/component/zookeeper/springboot/ZooKeeperComponentConfiguration.java
+++ b/components/camel-zookeeper/src/main/java/org/apache/camel/component/zookeeper/springboot/ZooKeeperComponentConfiguration.java
@@ -44,7 +44,7 @@ public class ZooKeeperComponentConfiguration {
     /**
      * Whether the children of the node should be listed
      */
-    private Boolean listChildren = false;
+    private Boolean listChildren;
     /**
      * The node in the ZooKeeper server (aka znode)
      */
@@ -52,7 +52,7 @@ public class ZooKeeperComponentConfiguration {
     /**
      * Should changes to the znode be 'watched' and repeatedly processed.
      */
-    private Boolean repeat = false;
+    private Boolean repeat;
     /**
      * The time interval to backoff for after an error before retrying.
      */
@@ -60,7 +60,7 @@ public class ZooKeeperComponentConfiguration {
     /**
      * Should the endpoint create the node if it does not currently exist.
      */
-    private Boolean create = false;
+    private Boolean create;
     /**
      * The create mode that should be used for the newly created node
      */
@@ -69,7 +69,7 @@ public class ZooKeeperComponentConfiguration {
      * Upon the delete of a znode should an empty message be send to the
      * consumer
      */
-    private Boolean sendEmptyMessageOnDelete = false;
+    private Boolean sendEmptyMessageOnDelete;
 
     public ZooKeeperConfiguration getConfiguration() {
         return configuration;

http://git-wip-us.apache.org/repos/asf/camel/blob/47ff272f/tooling/apt/src/main/java/org/apache/camel/tools/apt/EndpointAnnotationProcessor.java
----------------------------------------------------------------------
diff --git a/tooling/apt/src/main/java/org/apache/camel/tools/apt/EndpointAnnotationProcessor.java b/tooling/apt/src/main/java/org/apache/camel/tools/apt/EndpointAnnotationProcessor.java
index ad81072..8f38906 100644
--- a/tooling/apt/src/main/java/org/apache/camel/tools/apt/EndpointAnnotationProcessor.java
+++ b/tooling/apt/src/main/java/org/apache/camel/tools/apt/EndpointAnnotationProcessor.java
@@ -264,10 +264,7 @@ public class EndpointAnnotationProcessor extends AbstractAnnotationProcessor {
             doc = sanitizeDescription(doc, false);
             Boolean required = entry.getRequired() != null ? Boolean.valueOf(entry.getRequired()) : null;
             String defaultValue = entry.getDefaultValue();
-            if (Strings.isNullOrEmpty(defaultValue) && "boolean".equals(entry.getType())) {
-                // fallback as false for boolean types
-                defaultValue = "false";
-            }
+            // component option do not have default value for boolean (as we dont really known if its true or false)
 
             // component options do not have prefix
             String optionalPrefix = "";


[2/5] camel git commit: CAMEL-10197: Component docs/schema for omponent updated to not have default false values for booleans.

Posted by da...@apache.org.
CAMEL-10197: Component docs/schema for omponent updated to not have default false values for booleans.


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

Branch: refs/heads/master
Commit: 47ff272f33ddf0cf9e9e58db519f33aeeeece8b9
Parents: 8ba133e
Author: Claus Ibsen <da...@apache.org>
Authored: Tue Aug 2 10:47:43 2016 +0200
Committer: Claus Ibsen <da...@apache.org>
Committed: Tue Aug 2 10:47:53 2016 +0200

----------------------------------------------------------------------
 .../DirectComponentConfiguration.java           |  2 +-
 .../DirectVmComponentConfiguration.java         |  2 +-
 .../PropertiesComponentConfiguration.java       |  6 +-
 .../springboot/XsltComponentConfiguration.java  |  2 +-
 .../ws/springboot/WsComponentConfiguration.java |  2 +-
 .../springboot/AhcComponentConfiguration.java   |  2 +-
 .../springboot/AMQPComponentConfiguration.java  | 58 ++++++++++----------
 .../WebsocketComponentConfiguration.java        |  4 +-
 .../springboot/AvroComponentConfiguration.java  |  4 +-
 .../springboot/BoxComponentConfiguration.java   |  2 +-
 .../springboot/CacheComponentConfiguration.java |  8 +--
 .../DigitalSignatureComponentConfiguration.java |  2 +-
 .../DisruptorComponentConfiguration.java        |  4 +-
 .../DisruptorVmComponentConfiguration.java      |  4 +-
 .../DockerComponentConfiguration.java           |  6 +-
 .../GangliaComponentConfiguration.java          |  2 +-
 .../springboot/HttpComponentConfiguration.java  |  2 +-
 .../springboot/HttpComponentConfiguration.java  |  2 +-
 .../IBatisComponentConfiguration.java           |  2 +-
 .../JettyHttpComponentConfiguration9.java       |  8 +--
 .../JGroupsComponentConfiguration.java          |  2 +-
 .../springboot/JmsComponentConfiguration.java   | 58 ++++++++++----------
 .../springboot/JpaComponentConfiguration.java   |  4 +-
 .../springboot/ScpComponentConfiguration.java   |  2 +-
 .../LinkedInComponentConfiguration.java         |  2 +-
 .../springboot/MailComponentConfiguration.java  | 26 ++++-----
 .../springboot/MinaComponentConfiguration.java  | 18 +++---
 .../springboot/Mina2ComponentConfiguration.java | 24 ++++----
 .../NettyHttpComponentConfiguration.java        | 28 +++++-----
 .../springboot/NettyComponentConfiguration.java | 40 +++++++-------
 .../NettyHttpComponentConfiguration.java        | 30 +++++-----
 .../springboot/NettyComponentConfiguration.java | 48 ++++++++--------
 .../QuartzComponentConfiguration.java           |  4 +-
 .../QuartzComponentConfiguration.java           |  8 +--
 .../QuickfixjComponentConfiguration.java        |  2 +-
 .../RestletComponentConfiguration.java          |  2 +-
 .../SalesforceComponentConfiguration.java       | 10 ++--
 .../ServletComponentConfiguration.java          |  4 +-
 .../springboot/SmppComponentConfiguration.java  |  4 +-
 .../WebsocketComponentConfiguration.java        |  2 +-
 .../ZooKeeperComponentConfiguration.java        |  8 +--
 .../tools/apt/EndpointAnnotationProcessor.java  |  5 +-
 42 files changed, 226 insertions(+), 229 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/camel/blob/47ff272f/camel-core/src/main/java/org/apache/camel/component/direct/springboot/DirectComponentConfiguration.java
----------------------------------------------------------------------
diff --git a/camel-core/src/main/java/org/apache/camel/component/direct/springboot/DirectComponentConfiguration.java b/camel-core/src/main/java/org/apache/camel/component/direct/springboot/DirectComponentConfiguration.java
index ec80b49..7aff386 100644
--- a/camel-core/src/main/java/org/apache/camel/component/direct/springboot/DirectComponentConfiguration.java
+++ b/camel-core/src/main/java/org/apache/camel/component/direct/springboot/DirectComponentConfiguration.java
@@ -32,7 +32,7 @@ public class DirectComponentConfiguration {
      * then we can tell the producer to block and wait for the consumer to
      * become active.
      */
-    private Boolean block = false;
+    private Boolean block;
     /**
      * The timeout value to use if block is enabled.
      */

http://git-wip-us.apache.org/repos/asf/camel/blob/47ff272f/camel-core/src/main/java/org/apache/camel/component/directvm/springboot/DirectVmComponentConfiguration.java
----------------------------------------------------------------------
diff --git a/camel-core/src/main/java/org/apache/camel/component/directvm/springboot/DirectVmComponentConfiguration.java b/camel-core/src/main/java/org/apache/camel/component/directvm/springboot/DirectVmComponentConfiguration.java
index fb29402..de1d07d 100644
--- a/camel-core/src/main/java/org/apache/camel/component/directvm/springboot/DirectVmComponentConfiguration.java
+++ b/camel-core/src/main/java/org/apache/camel/component/directvm/springboot/DirectVmComponentConfiguration.java
@@ -33,7 +33,7 @@ public class DirectVmComponentConfiguration {
      * then we can tell the producer to block and wait for the consumer to
      * become active.
      */
-    private Boolean block = false;
+    private Boolean block;
     /**
      * The timeout value to use if block is enabled.
      */

http://git-wip-us.apache.org/repos/asf/camel/blob/47ff272f/camel-core/src/main/java/org/apache/camel/component/properties/springboot/PropertiesComponentConfiguration.java
----------------------------------------------------------------------
diff --git a/camel-core/src/main/java/org/apache/camel/component/properties/springboot/PropertiesComponentConfiguration.java b/camel-core/src/main/java/org/apache/camel/component/properties/springboot/PropertiesComponentConfiguration.java
index e031886..9bb02df 100644
--- a/camel-core/src/main/java/org/apache/camel/component/properties/springboot/PropertiesComponentConfiguration.java
+++ b/camel-core/src/main/java/org/apache/camel/component/properties/springboot/PropertiesComponentConfiguration.java
@@ -60,7 +60,7 @@ public class PropertiesComponentConfiguration {
     /**
      * Whether or not to cache loaded properties. The default value is true.
      */
-    private Boolean cache = false;
+    private Boolean cache;
     /**
      * Optional prefix prepended to property names before resolution.
      */
@@ -74,12 +74,12 @@ public class PropertiesComponentConfiguration {
      * propertyPrefix and propertySuffix before falling back the plain property
      * name specified. If false only the augmented property name is searched.
      */
-    private Boolean fallbackToUnaugmentedProperty = false;
+    private Boolean fallbackToUnaugmentedProperty;
     /**
      * Whether to silently ignore if a location cannot be located such as a
      * properties file not found.
      */
-    private Boolean ignoreMissingLocation = false;
+    private Boolean ignoreMissingLocation;
     /**
      * Sets the value of the prefix token used to identify properties to
      * replace. Setting a value of null restores the default token (link link

http://git-wip-us.apache.org/repos/asf/camel/blob/47ff272f/camel-core/src/main/java/org/apache/camel/component/xslt/springboot/XsltComponentConfiguration.java
----------------------------------------------------------------------
diff --git a/camel-core/src/main/java/org/apache/camel/component/xslt/springboot/XsltComponentConfiguration.java b/camel-core/src/main/java/org/apache/camel/component/xslt/springboot/XsltComponentConfiguration.java
index 75ccfc4..202f644 100644
--- a/camel-core/src/main/java/org/apache/camel/component/xslt/springboot/XsltComponentConfiguration.java
+++ b/camel-core/src/main/java/org/apache/camel/component/xslt/springboot/XsltComponentConfiguration.java
@@ -60,7 +60,7 @@ public class XsltComponentConfiguration {
      * class net.sf.saxon.TransformerFactoryImpl. You would need to add Saxon to
      * the classpath.
      */
-    private Boolean saxon = false;
+    private Boolean saxon;
 
     public XmlConverter getXmlConverter() {
         return xmlConverter;

http://git-wip-us.apache.org/repos/asf/camel/blob/47ff272f/components/camel-ahc-ws/src/main/java/org/apache/camel/component/ahc/ws/springboot/WsComponentConfiguration.java
----------------------------------------------------------------------
diff --git a/components/camel-ahc-ws/src/main/java/org/apache/camel/component/ahc/ws/springboot/WsComponentConfiguration.java b/components/camel-ahc-ws/src/main/java/org/apache/camel/component/ahc/ws/springboot/WsComponentConfiguration.java
index faa0542..91c0802 100644
--- a/components/camel-ahc-ws/src/main/java/org/apache/camel/component/ahc/ws/springboot/WsComponentConfiguration.java
+++ b/components/camel-ahc-ws/src/main/java/org/apache/camel/component/ahc/ws/springboot/WsComponentConfiguration.java
@@ -59,7 +59,7 @@ public class WsComponentConfiguration {
      * the incoming data from the request to Java and that can be a potential
      * security risk.
      */
-    private Boolean allowJavaSerializedObject = false;
+    private Boolean allowJavaSerializedObject;
     /**
      * To use a custom HeaderFilterStrategy to filter header to and from Camel
      * message.

http://git-wip-us.apache.org/repos/asf/camel/blob/47ff272f/components/camel-ahc/src/main/java/org/apache/camel/component/ahc/springboot/AhcComponentConfiguration.java
----------------------------------------------------------------------
diff --git a/components/camel-ahc/src/main/java/org/apache/camel/component/ahc/springboot/AhcComponentConfiguration.java b/components/camel-ahc/src/main/java/org/apache/camel/component/ahc/springboot/AhcComponentConfiguration.java
index e738e27..0da3874 100644
--- a/components/camel-ahc/src/main/java/org/apache/camel/component/ahc/springboot/AhcComponentConfiguration.java
+++ b/components/camel-ahc/src/main/java/org/apache/camel/component/ahc/springboot/AhcComponentConfiguration.java
@@ -59,7 +59,7 @@ public class AhcComponentConfiguration {
      * the incoming data from the request to Java and that can be a potential
      * security risk.
      */
-    private Boolean allowJavaSerializedObject = false;
+    private Boolean allowJavaSerializedObject;
     /**
      * To use a custom HeaderFilterStrategy to filter header to and from Camel
      * message.

http://git-wip-us.apache.org/repos/asf/camel/blob/47ff272f/components/camel-amqp/src/main/java/org/apache/camel/component/amqp/springboot/AMQPComponentConfiguration.java
----------------------------------------------------------------------
diff --git a/components/camel-amqp/src/main/java/org/apache/camel/component/amqp/springboot/AMQPComponentConfiguration.java b/components/camel-amqp/src/main/java/org/apache/camel/component/amqp/springboot/AMQPComponentConfiguration.java
index a2d67cb..487c7ca 100644
--- a/components/camel-amqp/src/main/java/org/apache/camel/component/amqp/springboot/AMQPComponentConfiguration.java
+++ b/components/camel-amqp/src/main/java/org/apache/camel/component/amqp/springboot/AMQPComponentConfiguration.java
@@ -58,7 +58,7 @@ public class AMQPComponentConfiguration {
      * queue on the JMS broker. To avoid this its recommended to enable this
      * option.
      */
-    private Boolean acceptMessagesWhileStopping = false;
+    private Boolean acceptMessagesWhileStopping;
     /**
      * Whether the DefaultMessageListenerContainer used in the reply managers
      * for request-reply messaging allow the
@@ -68,7 +68,7 @@ public class AMQPComponentConfiguration {
      * ability is enabled by default in the regular JMS consumers but to enable
      * for reply managers you must enable this flag.
      */
-    private Boolean allowReplyManagerQuickStop = false;
+    private Boolean allowReplyManagerQuickStop;
     /**
      * The JMS acknowledgement mode defined as an Integer. Allows you to set
      * vendor-specific extensions to the acknowledgment mode. For the regular
@@ -81,7 +81,7 @@ public class AMQPComponentConfiguration {
      * but sometimes can catch early any issues with the underlying JMS provider
      * and the use of JMS properties
      */
-    private Boolean eagerLoadingOfProperties = false;
+    private Boolean eagerLoadingOfProperties;
     /**
      * The JMS acknowledgement name which is one of: SESSION_TRANSACTED
      * CLIENT_ACKNOWLEDGE AUTO_ACKNOWLEDGE DUPS_OK_ACKNOWLEDGE
@@ -90,7 +90,7 @@ public class AMQPComponentConfiguration {
     /**
      * Specifies whether the consumer container should auto-startup.
      */
-    private Boolean autoStartup = false;
+    private Boolean autoStartup;
     /**
      * Sets the cache level by ID for the underlying JMS resources. See
      * cacheLevelName option for more details.
@@ -152,7 +152,7 @@ public class AMQPComponentConfiguration {
     /**
      * Specifies whether persistent delivery is used by default.
      */
-    private Boolean deliveryPersistent = false;
+    private Boolean deliveryPersistent;
     /**
      * Specifies the delivery mode to be used. Possible values are Possibles
      * values are those defined by javax.jms.DeliveryMode. NON_PERSISTENT = 1
@@ -188,7 +188,7 @@ public class AMQPComponentConfiguration {
      * Allows to control whether stacktraces should be logged or not by the
      * default errorHandler.
      */
-    private Boolean errorHandlerLogStackTrace = false;
+    private Boolean errorHandlerLogStackTrace;
     /**
      * Set if the deliveryMode priority or timeToLive qualities of service
      * should be used when sending messages. This option is based on Spring's
@@ -197,12 +197,12 @@ public class AMQPComponentConfiguration {
      * option which operates at message granularity reading QoS properties
      * exclusively from the Camel In message headers.
      */
-    private Boolean explicitQosEnabled = false;
+    private Boolean explicitQosEnabled;
     /**
      * Specifies whether the listener session should be exposed when consuming
      * messages.
      */
-    private Boolean exposeListenerSession = false;
+    private Boolean exposeListenerSession;
     /**
      * Specifies the limit for idle executions of a receive task not having
      * received any message within its execution. If this limit is reached the
@@ -254,16 +254,16 @@ public class AMQPComponentConfiguration {
      * suited payload type such as javax.jms.TextMessage to a String etc. See
      * section about how mapping works below for more details.
      */
-    private Boolean mapJmsMessage = false;
+    private Boolean mapJmsMessage;
     /**
      * When sending specifies whether message IDs should be added.
      */
-    private Boolean messageIdEnabled = false;
+    private Boolean messageIdEnabled;
     /**
      * Specifies whether timestamps should be enabled by default on sending
      * messages.
      */
-    private Boolean messageTimestampEnabled = false;
+    private Boolean messageTimestampEnabled;
     /**
      * If true Camel will always make a JMS message copy of the message when it
      * is passed to the producer for sending. Copying the message is needed in
@@ -271,12 +271,12 @@ public class AMQPComponentConfiguration {
      * (incidentally Camel will set the alwaysCopyMessage option to true if a
      * replyToDestinationSelectorName is set)
      */
-    private Boolean alwaysCopyMessage = false;
+    private Boolean alwaysCopyMessage;
     /**
      * Specifies whether JMSMessageID should always be used as JMSCorrelationID
      * for InOut messages.
      */
-    private Boolean useMessageIDAsCorrelationID = false;
+    private Boolean useMessageIDAsCorrelationID;
     /**
      * Values greater than 1 specify the message priority when sending (where 0
      * is the lowest priority and 9 is the highest). The explicitQosEnabled
@@ -287,7 +287,7 @@ public class AMQPComponentConfiguration {
      * Specifies whether to inhibit the delivery of messages published by its
      * own connection.
      */
-    private Boolean pubSubNoLocal = false;
+    private Boolean pubSubNoLocal;
     /**
      * The timeout for receiving messages (in milliseconds).
      */
@@ -303,7 +303,7 @@ public class AMQPComponentConfiguration {
      * and a clientId.
      */
     @Deprecated
-    private Boolean subscriptionDurable = false;
+    private Boolean subscriptionDurable;
     /**
      * Allows you to specify a custom task executor for consuming messages.
      */
@@ -316,12 +316,12 @@ public class AMQPComponentConfiguration {
     /**
      * Specifies whether to use transacted mode
      */
-    private Boolean transacted = false;
+    private Boolean transacted;
     /**
      * If true Camel will create a JmsTransactionManager if there is no
      * transactionManager injected when option transacted=true.
      */
-    private Boolean lazyCreateTransactionManager = false;
+    private Boolean lazyCreateTransactionManager;
     /**
      * The Spring transaction manager to use.
      */
@@ -342,7 +342,7 @@ public class AMQPComponentConfiguration {
      * exception on startup. This ensures that Camel is not started with failed
      * connections. The JMS producers is tested as well.
      */
-    private Boolean testConnectionOnStartup = false;
+    private Boolean testConnectionOnStartup;
     /**
      * Whether to startup the JmsConsumer message listener asynchronously when
      * starting a route. For example if a JmsConsumer cannot get a connection to
@@ -355,19 +355,19 @@ public class AMQPComponentConfiguration {
      * will not be able to receive messages; You can then restart the route to
      * retry.
      */
-    private Boolean asyncStartListener = false;
+    private Boolean asyncStartListener;
     /**
      * Whether to stop the JmsConsumer message listener asynchronously when
      * stopping a route.
      */
-    private Boolean asyncStopListener = false;
+    private Boolean asyncStopListener;
     /**
      * When using mapJmsMessage=false Camel will create a new JMS message to
      * send to a new JMS destination if you touch the headers (get or set)
      * during the route. Set this option to true to force Camel to send the
      * original JMS message that was received.
      */
-    private Boolean forceSendOriginalMessage = false;
+    private Boolean forceSendOriginalMessage;
     /**
      * The timeout for waiting for a reply when using the InOut Exchange Pattern
      * (in milliseconds). The default is 20 seconds. You can include the header
@@ -393,7 +393,7 @@ public class AMQPComponentConfiguration {
      * enable this option on both the producer and consumer side so Camel knows
      * the payloads is an Exchange and not a regular payload.
      */
-    private Boolean transferExchange = false;
+    private Boolean transferExchange;
     /**
      * If enabled and you are using Request Reply messaging (InOut) and an
      * Exchange failed on the consumer side then the caused Exception will be
@@ -406,7 +406,7 @@ public class AMQPComponentConfiguration {
      * wrapped in an outer exception such as
      * org.apache.camel.RuntimeCamelException when returned to the producer.
      */
-    private Boolean transferException = false;
+    private Boolean transferException;
     /**
      * If enabled and you are using Request Reply messaging (InOut) and an
      * Exchange failed with a SOAP fault (not exception) on the consumer side
@@ -417,7 +417,7 @@ public class AMQPComponentConfiguration {
      * You may want to enable this when using Camel components that support
      * faults such as SOAP based such as cxf or spring-ws.
      */
-    private Boolean transferFault = false;
+    private Boolean transferFault;
     /**
      * Allows you to use your own implementation of the
      * org.springframework.jms.core.JmsOperations interface. Camel uses
@@ -454,7 +454,7 @@ public class AMQPComponentConfiguration {
      * explicitQosEnabled option by contrast will only use options set on the
      * endpoint and not values from the message header.
      */
-    private Boolean preserveMessageQos = false;
+    private Boolean preserveMessageQos;
     /**
      * Whether the JmsConsumer processes the Exchange asynchronously. If enabled
      * then the JmsConsumer may pickup the next message from the JMS queue while
@@ -466,26 +466,26 @@ public class AMQPComponentConfiguration {
      * asyncConsumer=true does not run asynchronously as transaction must be
      * executed synchronously (Camel 3.0 may support async transactions).
      */
-    private Boolean asyncConsumer = false;
+    private Boolean asyncConsumer;
     /**
      * Whether to allow sending messages with no body. If this option is false
      * and the message body is null then an JMSException is thrown.
      */
-    private Boolean allowNullBody = false;
+    private Boolean allowNullBody;
     /**
      * Only applicable when sending to JMS destination using InOnly (eg fire and
      * forget). Enabling this option will enrich the Camel Exchange with the
      * actual JMSMessageID that was used by the JMS client when the message was
      * sent to the JMS destination.
      */
-    private Boolean includeSentJMSMessageID = false;
+    private Boolean includeSentJMSMessageID;
     /**
      * Whether to include all JMSXxxx properties when mapping from JMS to Camel
      * Message. Setting this to true will include properties such as JMSXAppID
      * and JMSXUserID etc. Note: If you are using a custom headerFilterStrategy
      * then this option does not apply.
      */
-    private Boolean includeAllJMSXProperties = false;
+    private Boolean includeAllJMSXProperties;
     /**
      * Specifies what default TaskExecutor type to use in the
      * DefaultMessageListenerContainer for both consumer endpoints and the

http://git-wip-us.apache.org/repos/asf/camel/blob/47ff272f/components/camel-atmosphere-websocket/src/main/java/org/apache/camel/component/atmosphere/websocket/springboot/WebsocketComponentConfiguration.java
----------------------------------------------------------------------
diff --git a/components/camel-atmosphere-websocket/src/main/java/org/apache/camel/component/atmosphere/websocket/springboot/WebsocketComponentConfiguration.java b/components/camel-atmosphere-websocket/src/main/java/org/apache/camel/component/atmosphere/websocket/springboot/WebsocketComponentConfiguration.java
index 2e433ce..c75fbd8 100644
--- a/components/camel-atmosphere-websocket/src/main/java/org/apache/camel/component/atmosphere/websocket/springboot/WebsocketComponentConfiguration.java
+++ b/components/camel-atmosphere-websocket/src/main/java/org/apache/camel/component/atmosphere/websocket/springboot/WebsocketComponentConfiguration.java
@@ -43,7 +43,7 @@ public class WebsocketComponentConfiguration {
      * Exchange. This is turn off by default as this may require servet specific
      * configuration to enable this when using Servlet's.
      */
-    private Boolean attachmentMultipartBinding = false;
+    private Boolean attachmentMultipartBinding;
     /**
      * To use a custom HttpBinding to control the mapping between Camel message
      * and HttpClient.
@@ -60,7 +60,7 @@ public class WebsocketComponentConfiguration {
      * the incoming data from the request to Java and that can be a potential
      * security risk.
      */
-    private Boolean allowJavaSerializedObject = false;
+    private Boolean allowJavaSerializedObject;
     /**
      * To use a custom HeaderFilterStrategy to filter header to and from Camel
      * message.

http://git-wip-us.apache.org/repos/asf/camel/blob/47ff272f/components/camel-avro/src/main/java/org/apache/camel/component/avro/springboot/AvroComponentConfiguration.java
----------------------------------------------------------------------
diff --git a/components/camel-avro/src/main/java/org/apache/camel/component/avro/springboot/AvroComponentConfiguration.java b/components/camel-avro/src/main/java/org/apache/camel/component/avro/springboot/AvroComponentConfiguration.java
index edb360e..6b53cfc 100644
--- a/components/camel-avro/src/main/java/org/apache/camel/component/avro/springboot/AvroComponentConfiguration.java
+++ b/components/camel-avro/src/main/java/org/apache/camel/component/avro/springboot/AvroComponentConfiguration.java
@@ -70,12 +70,12 @@ public class AvroComponentConfiguration {
      * with protocol parameter because for protocolClassName protocol type will
      * be auto detected
      */
-    private Boolean reflectionProtocol = false;
+    private Boolean reflectionProtocol;
     /**
      * If true consumer parameter won't be wrapped into array. Will fail if
      * protocol specifies more then 1 parameter for the message
      */
-    private Boolean singleParameter = false;
+    private Boolean singleParameter;
 
     public AvroConfiguration getConfiguration() {
         return configuration;

http://git-wip-us.apache.org/repos/asf/camel/blob/47ff272f/components/camel-box/src/main/java/org/apache/camel/component/box/springboot/BoxComponentConfiguration.java
----------------------------------------------------------------------
diff --git a/components/camel-box/src/main/java/org/apache/camel/component/box/springboot/BoxComponentConfiguration.java b/components/camel-box/src/main/java/org/apache/camel/component/box/springboot/BoxComponentConfiguration.java
index 8179dd0..2f84faa 100644
--- a/components/camel-box/src/main/java/org/apache/camel/component/box/springboot/BoxComponentConfiguration.java
+++ b/components/camel-box/src/main/java/org/apache/camel/component/box/springboot/BoxComponentConfiguration.java
@@ -84,7 +84,7 @@ public class BoxComponentConfiguration {
      * IAuthSecureStorage or automatic component login by providing a user
      * password
      */
-    private Boolean revokeOnShutdown = false;
+    private Boolean revokeOnShutdown;
     /**
      * Box shared link for shared endpoints can be a link for a shared comment
      * file or folder

http://git-wip-us.apache.org/repos/asf/camel/blob/47ff272f/components/camel-cache/src/main/java/org/apache/camel/component/cache/springboot/CacheComponentConfiguration.java
----------------------------------------------------------------------
diff --git a/components/camel-cache/src/main/java/org/apache/camel/component/cache/springboot/CacheComponentConfiguration.java b/components/camel-cache/src/main/java/org/apache/camel/component/cache/springboot/CacheComponentConfiguration.java
index 994c43f..e6576aa 100644
--- a/components/camel-cache/src/main/java/org/apache/camel/component/cache/springboot/CacheComponentConfiguration.java
+++ b/components/camel-cache/src/main/java/org/apache/camel/component/cache/springboot/CacheComponentConfiguration.java
@@ -64,12 +64,12 @@ public class CacheComponentConfiguration {
     /**
      * Specifies whether cache may overflow to disk
      */
-    private Boolean overflowToDisk = false;
+    private Boolean overflowToDisk;
     /**
      * Sets whether elements are eternal. If eternal timeouts are ignored and
      * the element never expires.
      */
-    private Boolean eternal = false;
+    private Boolean eternal;
     /**
      * The maximum time between creation time and when an element expires. Is
      * used only if the element is not eternal
@@ -82,7 +82,7 @@ public class CacheComponentConfiguration {
     /**
      * Whether the disk store persists between restarts of the application.
      */
-    private Boolean diskPersistent = false;
+    private Boolean diskPersistent;
     /**
      * The number of seconds between runs of the disk expiry thread.
      */
@@ -100,7 +100,7 @@ public class CacheComponentConfiguration {
      * cache. If this option is enabled then overflow to disk cannot be enabled
      * as well.
      */
-    private Boolean objectCache = false;
+    private Boolean objectCache;
 
     public CacheManagerFactory getCacheManagerFactory() {
         return cacheManagerFactory;

http://git-wip-us.apache.org/repos/asf/camel/blob/47ff272f/components/camel-crypto/src/main/java/org/apache/camel/component/crypto/springboot/DigitalSignatureComponentConfiguration.java
----------------------------------------------------------------------
diff --git a/components/camel-crypto/src/main/java/org/apache/camel/component/crypto/springboot/DigitalSignatureComponentConfiguration.java b/components/camel-crypto/src/main/java/org/apache/camel/component/crypto/springboot/DigitalSignatureComponentConfiguration.java
index 7b3e09e..17a8378 100644
--- a/components/camel-crypto/src/main/java/org/apache/camel/component/crypto/springboot/DigitalSignatureComponentConfiguration.java
+++ b/components/camel-crypto/src/main/java/org/apache/camel/component/crypto/springboot/DigitalSignatureComponentConfiguration.java
@@ -137,7 +137,7 @@ public class DigitalSignatureComponentConfiguration {
      * extreme peril as vital private information such as Keys and passwords may
      * escape if unset.
      */
-    private Boolean clearHeaders = false;
+    private Boolean clearHeaders;
     /**
      * Set the Crypto operation from that supplied after the crypto scheme in
      * the endpoint uri e.g. crypto:sign sets sign as the operation.

http://git-wip-us.apache.org/repos/asf/camel/blob/47ff272f/components/camel-disruptor/src/main/java/org/apache/camel/component/disruptor/springboot/DisruptorComponentConfiguration.java
----------------------------------------------------------------------
diff --git a/components/camel-disruptor/src/main/java/org/apache/camel/component/disruptor/springboot/DisruptorComponentConfiguration.java b/components/camel-disruptor/src/main/java/org/apache/camel/component/disruptor/springboot/DisruptorComponentConfiguration.java
index a2294db..4e9e813 100644
--- a/components/camel-disruptor/src/main/java/org/apache/camel/component/disruptor/springboot/DisruptorComponentConfiguration.java
+++ b/components/camel-disruptor/src/main/java/org/apache/camel/component/disruptor/springboot/DisruptorComponentConfiguration.java
@@ -37,7 +37,7 @@ public class DisruptorComponentConfiguration {
     /**
      * To configure the default value for multiple consumers
      */
-    private Boolean defaultMultipleConsumers = false;
+    private Boolean defaultMultipleConsumers;
     /**
      * To configure the default value for DisruptorProducerType The default
      * value is Multi.
@@ -52,7 +52,7 @@ public class DisruptorComponentConfiguration {
      * To configure the default value for block when full The default value is
      * true.
      */
-    private Boolean defaultBlockWhenFull = false;
+    private Boolean defaultBlockWhenFull;
     /**
      * To configure the ring buffer size
      */

http://git-wip-us.apache.org/repos/asf/camel/blob/47ff272f/components/camel-disruptor/src/main/java/org/apache/camel/component/disruptor/vm/springboot/DisruptorVmComponentConfiguration.java
----------------------------------------------------------------------
diff --git a/components/camel-disruptor/src/main/java/org/apache/camel/component/disruptor/vm/springboot/DisruptorVmComponentConfiguration.java b/components/camel-disruptor/src/main/java/org/apache/camel/component/disruptor/vm/springboot/DisruptorVmComponentConfiguration.java
index 4054c51..986acc9 100644
--- a/components/camel-disruptor/src/main/java/org/apache/camel/component/disruptor/vm/springboot/DisruptorVmComponentConfiguration.java
+++ b/components/camel-disruptor/src/main/java/org/apache/camel/component/disruptor/vm/springboot/DisruptorVmComponentConfiguration.java
@@ -37,7 +37,7 @@ public class DisruptorVmComponentConfiguration {
     /**
      * To configure the default value for multiple consumers
      */
-    private Boolean defaultMultipleConsumers = false;
+    private Boolean defaultMultipleConsumers;
     /**
      * To configure the default value for DisruptorProducerType The default
      * value is Multi.
@@ -52,7 +52,7 @@ public class DisruptorVmComponentConfiguration {
      * To configure the default value for block when full The default value is
      * true.
      */
-    private Boolean defaultBlockWhenFull = false;
+    private Boolean defaultBlockWhenFull;
     /**
      * To configure the ring buffer size
      */

http://git-wip-us.apache.org/repos/asf/camel/blob/47ff272f/components/camel-docker/src/main/java/org/apache/camel/component/docker/springboot/DockerComponentConfiguration.java
----------------------------------------------------------------------
diff --git a/components/camel-docker/src/main/java/org/apache/camel/component/docker/springboot/DockerComponentConfiguration.java b/components/camel-docker/src/main/java/org/apache/camel/component/docker/springboot/DockerComponentConfiguration.java
index 9ea6808..8bd7748 100644
--- a/components/camel-docker/src/main/java/org/apache/camel/component/docker/springboot/DockerComponentConfiguration.java
+++ b/components/camel-docker/src/main/java/org/apache/camel/component/docker/springboot/DockerComponentConfiguration.java
@@ -65,7 +65,7 @@ public class DockerComponentConfiguration {
     /**
      * Use HTTPS communication
      */
-    private Boolean secure = false;
+    private Boolean secure;
     /**
      * Location containing the SSL certificate chain
      */
@@ -81,11 +81,11 @@ public class DockerComponentConfiguration {
     /**
      * Whether to use logging filter
      */
-    private Boolean loggingFilter = false;
+    private Boolean loggingFilter;
     /**
      * Whether to follow redirect filter
      */
-    private Boolean followRedirectFilter = false;
+    private Boolean followRedirectFilter;
     /**
      * Additional configuration parameters as key/value pairs
      */

http://git-wip-us.apache.org/repos/asf/camel/blob/47ff272f/components/camel-ganglia/src/main/java/org/apache/camel/component/ganglia/springboot/GangliaComponentConfiguration.java
----------------------------------------------------------------------
diff --git a/components/camel-ganglia/src/main/java/org/apache/camel/component/ganglia/springboot/GangliaComponentConfiguration.java b/components/camel-ganglia/src/main/java/org/apache/camel/component/ganglia/springboot/GangliaComponentConfiguration.java
index 66d2cc9..91442e5 100644
--- a/components/camel-ganglia/src/main/java/org/apache/camel/component/ganglia/springboot/GangliaComponentConfiguration.java
+++ b/components/camel-ganglia/src/main/java/org/apache/camel/component/ganglia/springboot/GangliaComponentConfiguration.java
@@ -56,7 +56,7 @@ public class GangliaComponentConfiguration {
      * Use the wire format of Ganglia 3.1.0 and later versions. Set this to
      * false to use Ganglia 3.0.x or earlier.
      */
-    private Boolean wireFormat31x = false;
+    private Boolean wireFormat31x;
     /**
      * Spoofing information IP:hostname
      */

http://git-wip-us.apache.org/repos/asf/camel/blob/47ff272f/components/camel-http/src/main/java/org/apache/camel/component/http/springboot/HttpComponentConfiguration.java
----------------------------------------------------------------------
diff --git a/components/camel-http/src/main/java/org/apache/camel/component/http/springboot/HttpComponentConfiguration.java b/components/camel-http/src/main/java/org/apache/camel/component/http/springboot/HttpComponentConfiguration.java
index e1eb6b6..20714b3 100644
--- a/components/camel-http/src/main/java/org/apache/camel/component/http/springboot/HttpComponentConfiguration.java
+++ b/components/camel-http/src/main/java/org/apache/camel/component/http/springboot/HttpComponentConfiguration.java
@@ -56,7 +56,7 @@ public class HttpComponentConfiguration {
      * the incoming data from the request to Java and that can be a potential
      * security risk.
      */
-    private Boolean allowJavaSerializedObject = false;
+    private Boolean allowJavaSerializedObject;
     /**
      * To use a custom HeaderFilterStrategy to filter header to and from Camel
      * message.

http://git-wip-us.apache.org/repos/asf/camel/blob/47ff272f/components/camel-http4/src/main/java/org/apache/camel/component/http4/springboot/HttpComponentConfiguration.java
----------------------------------------------------------------------
diff --git a/components/camel-http4/src/main/java/org/apache/camel/component/http4/springboot/HttpComponentConfiguration.java b/components/camel-http4/src/main/java/org/apache/camel/component/http4/springboot/HttpComponentConfiguration.java
index d9fdf95..c88d77b 100644
--- a/components/camel-http4/src/main/java/org/apache/camel/component/http4/springboot/HttpComponentConfiguration.java
+++ b/components/camel-http4/src/main/java/org/apache/camel/component/http4/springboot/HttpComponentConfiguration.java
@@ -60,7 +60,7 @@ public class HttpComponentConfiguration {
      * the incoming data from the request to Java and that can be a potential
      * security risk.
      */
-    private Boolean allowJavaSerializedObject = false;
+    private Boolean allowJavaSerializedObject;
     /**
      * To use a custom org.apache.http.protocol.HttpContext when executing
      * requests.

http://git-wip-us.apache.org/repos/asf/camel/blob/47ff272f/components/camel-ibatis/src/main/java/org/apache/camel/component/ibatis/springboot/IBatisComponentConfiguration.java
----------------------------------------------------------------------
diff --git a/components/camel-ibatis/src/main/java/org/apache/camel/component/ibatis/springboot/IBatisComponentConfiguration.java b/components/camel-ibatis/src/main/java/org/apache/camel/component/ibatis/springboot/IBatisComponentConfiguration.java
index dd91d89..214cced 100644
--- a/components/camel-ibatis/src/main/java/org/apache/camel/component/ibatis/springboot/IBatisComponentConfiguration.java
+++ b/components/camel-ibatis/src/main/java/org/apache/camel/component/ibatis/springboot/IBatisComponentConfiguration.java
@@ -40,7 +40,7 @@ public class IBatisComponentConfiguration {
     /**
      * Whether to use transactions. This option is by default true.
      */
-    private Boolean useTransactions = false;
+    private Boolean useTransactions;
 
     public SqlMapClient getSqlMapClient() {
         return sqlMapClient;

http://git-wip-us.apache.org/repos/asf/camel/blob/47ff272f/components/camel-jetty9/src/main/java/org/apache/camel/component/jetty9/springboot/JettyHttpComponentConfiguration9.java
----------------------------------------------------------------------
diff --git a/components/camel-jetty9/src/main/java/org/apache/camel/component/jetty9/springboot/JettyHttpComponentConfiguration9.java b/components/camel-jetty9/src/main/java/org/apache/camel/component/jetty9/springboot/JettyHttpComponentConfiguration9.java
index f6f115d..0f23b7b 100644
--- a/components/camel-jetty9/src/main/java/org/apache/camel/component/jetty9/springboot/JettyHttpComponentConfiguration9.java
+++ b/components/camel-jetty9/src/main/java/org/apache/camel/component/jetty9/springboot/JettyHttpComponentConfiguration9.java
@@ -96,7 +96,7 @@ public class JettyHttpComponentConfiguration9 {
      * If this option is true Jetty JMX support will be enabled for this
      * endpoint.
      */
-    private Boolean enableJmx = false;
+    private Boolean enableJmx;
     /**
      * To use a custom org.apache.camel.component.jetty.JettyHttpBinding which
      * are used to customize how a response should be written for the producer.
@@ -135,7 +135,7 @@ public class JettyHttpComponentConfiguration9 {
     /**
      * Whether or not to use Jetty continuations for the Jetty Server.
      */
-    private Boolean useContinuation = false;
+    private Boolean useContinuation;
     /**
      * To configure security using SSLContextParameters
      */
@@ -174,7 +174,7 @@ public class JettyHttpComponentConfiguration9 {
      * other camel-jetty endpoint is share the same port otherwise this option
      * may not work as expected.
      */
-    private Boolean sendServerVersion = false;
+    private Boolean sendServerVersion;
     /**
      * Whether to allow java serialization when a request uses
      * context-type=application/x-java-serialized-object This is by default
@@ -182,7 +182,7 @@ public class JettyHttpComponentConfiguration9 {
      * the incoming data from the request to Java and that can be a potential
      * security risk.
      */
-    private Boolean allowJavaSerializedObject = false;
+    private Boolean allowJavaSerializedObject;
     /**
      * To use a custom HeaderFilterStrategy to filter header to and from Camel
      * message.

http://git-wip-us.apache.org/repos/asf/camel/blob/47ff272f/components/camel-jgroups/src/main/java/org/apache/camel/component/jgroups/springboot/JGroupsComponentConfiguration.java
----------------------------------------------------------------------
diff --git a/components/camel-jgroups/src/main/java/org/apache/camel/component/jgroups/springboot/JGroupsComponentConfiguration.java b/components/camel-jgroups/src/main/java/org/apache/camel/component/jgroups/springboot/JGroupsComponentConfiguration.java
index 6c722d3..8d5e024 100644
--- a/components/camel-jgroups/src/main/java/org/apache/camel/component/jgroups/springboot/JGroupsComponentConfiguration.java
+++ b/components/camel-jgroups/src/main/java/org/apache/camel/component/jgroups/springboot/JGroupsComponentConfiguration.java
@@ -41,7 +41,7 @@ public class JGroupsComponentConfiguration {
      * messages as well (not only org.jgroups.Message instances). By default
      * only regular messages are consumed by the endpoint.
      */
-    private Boolean enableViewMessages = false;
+    private Boolean enableViewMessages;
 
     public Channel getChannel() {
         return channel;

http://git-wip-us.apache.org/repos/asf/camel/blob/47ff272f/components/camel-jms/src/main/java/org/apache/camel/component/jms/springboot/JmsComponentConfiguration.java
----------------------------------------------------------------------
diff --git a/components/camel-jms/src/main/java/org/apache/camel/component/jms/springboot/JmsComponentConfiguration.java b/components/camel-jms/src/main/java/org/apache/camel/component/jms/springboot/JmsComponentConfiguration.java
index 1745f28..504de2d 100644
--- a/components/camel-jms/src/main/java/org/apache/camel/component/jms/springboot/JmsComponentConfiguration.java
+++ b/components/camel-jms/src/main/java/org/apache/camel/component/jms/springboot/JmsComponentConfiguration.java
@@ -59,7 +59,7 @@ public class JmsComponentConfiguration {
      * queue on the JMS broker. To avoid this its recommended to enable this
      * option.
      */
-    private Boolean acceptMessagesWhileStopping = false;
+    private Boolean acceptMessagesWhileStopping;
     /**
      * Whether the DefaultMessageListenerContainer used in the reply managers
      * for request-reply messaging allow the
@@ -69,7 +69,7 @@ public class JmsComponentConfiguration {
      * ability is enabled by default in the regular JMS consumers but to enable
      * for reply managers you must enable this flag.
      */
-    private Boolean allowReplyManagerQuickStop = false;
+    private Boolean allowReplyManagerQuickStop;
     /**
      * The JMS acknowledgement mode defined as an Integer. Allows you to set
      * vendor-specific extensions to the acknowledgment mode. For the regular
@@ -82,7 +82,7 @@ public class JmsComponentConfiguration {
      * but sometimes can catch early any issues with the underlying JMS provider
      * and the use of JMS properties
      */
-    private Boolean eagerLoadingOfProperties = false;
+    private Boolean eagerLoadingOfProperties;
     /**
      * The JMS acknowledgement name which is one of: SESSION_TRANSACTED
      * CLIENT_ACKNOWLEDGE AUTO_ACKNOWLEDGE DUPS_OK_ACKNOWLEDGE
@@ -91,7 +91,7 @@ public class JmsComponentConfiguration {
     /**
      * Specifies whether the consumer container should auto-startup.
      */
-    private Boolean autoStartup = false;
+    private Boolean autoStartup;
     /**
      * Sets the cache level by ID for the underlying JMS resources. See
      * cacheLevelName option for more details.
@@ -153,7 +153,7 @@ public class JmsComponentConfiguration {
     /**
      * Specifies whether persistent delivery is used by default.
      */
-    private Boolean deliveryPersistent = false;
+    private Boolean deliveryPersistent;
     /**
      * Specifies the delivery mode to be used. Possible values are Possibles
      * values are those defined by javax.jms.DeliveryMode. NON_PERSISTENT = 1
@@ -189,7 +189,7 @@ public class JmsComponentConfiguration {
      * Allows to control whether stacktraces should be logged or not by the
      * default errorHandler.
      */
-    private Boolean errorHandlerLogStackTrace = false;
+    private Boolean errorHandlerLogStackTrace;
     /**
      * Set if the deliveryMode priority or timeToLive qualities of service
      * should be used when sending messages. This option is based on Spring's
@@ -198,12 +198,12 @@ public class JmsComponentConfiguration {
      * option which operates at message granularity reading QoS properties
      * exclusively from the Camel In message headers.
      */
-    private Boolean explicitQosEnabled = false;
+    private Boolean explicitQosEnabled;
     /**
      * Specifies whether the listener session should be exposed when consuming
      * messages.
      */
-    private Boolean exposeListenerSession = false;
+    private Boolean exposeListenerSession;
     /**
      * Specifies the limit for idle executions of a receive task not having
      * received any message within its execution. If this limit is reached the
@@ -255,16 +255,16 @@ public class JmsComponentConfiguration {
      * suited payload type such as javax.jms.TextMessage to a String etc. See
      * section about how mapping works below for more details.
      */
-    private Boolean mapJmsMessage = false;
+    private Boolean mapJmsMessage;
     /**
      * When sending specifies whether message IDs should be added.
      */
-    private Boolean messageIdEnabled = false;
+    private Boolean messageIdEnabled;
     /**
      * Specifies whether timestamps should be enabled by default on sending
      * messages.
      */
-    private Boolean messageTimestampEnabled = false;
+    private Boolean messageTimestampEnabled;
     /**
      * If true Camel will always make a JMS message copy of the message when it
      * is passed to the producer for sending. Copying the message is needed in
@@ -272,12 +272,12 @@ public class JmsComponentConfiguration {
      * (incidentally Camel will set the alwaysCopyMessage option to true if a
      * replyToDestinationSelectorName is set)
      */
-    private Boolean alwaysCopyMessage = false;
+    private Boolean alwaysCopyMessage;
     /**
      * Specifies whether JMSMessageID should always be used as JMSCorrelationID
      * for InOut messages.
      */
-    private Boolean useMessageIDAsCorrelationID = false;
+    private Boolean useMessageIDAsCorrelationID;
     /**
      * Values greater than 1 specify the message priority when sending (where 0
      * is the lowest priority and 9 is the highest). The explicitQosEnabled
@@ -288,7 +288,7 @@ public class JmsComponentConfiguration {
      * Specifies whether to inhibit the delivery of messages published by its
      * own connection.
      */
-    private Boolean pubSubNoLocal = false;
+    private Boolean pubSubNoLocal;
     /**
      * The timeout for receiving messages (in milliseconds).
      */
@@ -304,7 +304,7 @@ public class JmsComponentConfiguration {
      * and a clientId.
      */
     @Deprecated
-    private Boolean subscriptionDurable = false;
+    private Boolean subscriptionDurable;
     /**
      * Allows you to specify a custom task executor for consuming messages.
      */
@@ -317,12 +317,12 @@ public class JmsComponentConfiguration {
     /**
      * Specifies whether to use transacted mode
      */
-    private Boolean transacted = false;
+    private Boolean transacted;
     /**
      * If true Camel will create a JmsTransactionManager if there is no
      * transactionManager injected when option transacted=true.
      */
-    private Boolean lazyCreateTransactionManager = false;
+    private Boolean lazyCreateTransactionManager;
     /**
      * The Spring transaction manager to use.
      */
@@ -343,7 +343,7 @@ public class JmsComponentConfiguration {
      * exception on startup. This ensures that Camel is not started with failed
      * connections. The JMS producers is tested as well.
      */
-    private Boolean testConnectionOnStartup = false;
+    private Boolean testConnectionOnStartup;
     /**
      * Whether to startup the JmsConsumer message listener asynchronously when
      * starting a route. For example if a JmsConsumer cannot get a connection to
@@ -356,19 +356,19 @@ public class JmsComponentConfiguration {
      * will not be able to receive messages; You can then restart the route to
      * retry.
      */
-    private Boolean asyncStartListener = false;
+    private Boolean asyncStartListener;
     /**
      * Whether to stop the JmsConsumer message listener asynchronously when
      * stopping a route.
      */
-    private Boolean asyncStopListener = false;
+    private Boolean asyncStopListener;
     /**
      * When using mapJmsMessage=false Camel will create a new JMS message to
      * send to a new JMS destination if you touch the headers (get or set)
      * during the route. Set this option to true to force Camel to send the
      * original JMS message that was received.
      */
-    private Boolean forceSendOriginalMessage = false;
+    private Boolean forceSendOriginalMessage;
     /**
      * The timeout for waiting for a reply when using the InOut Exchange Pattern
      * (in milliseconds). The default is 20 seconds. You can include the header
@@ -394,7 +394,7 @@ public class JmsComponentConfiguration {
      * enable this option on both the producer and consumer side so Camel knows
      * the payloads is an Exchange and not a regular payload.
      */
-    private Boolean transferExchange = false;
+    private Boolean transferExchange;
     /**
      * If enabled and you are using Request Reply messaging (InOut) and an
      * Exchange failed on the consumer side then the caused Exception will be
@@ -407,7 +407,7 @@ public class JmsComponentConfiguration {
      * wrapped in an outer exception such as
      * org.apache.camel.RuntimeCamelException when returned to the producer.
      */
-    private Boolean transferException = false;
+    private Boolean transferException;
     /**
      * If enabled and you are using Request Reply messaging (InOut) and an
      * Exchange failed with a SOAP fault (not exception) on the consumer side
@@ -418,7 +418,7 @@ public class JmsComponentConfiguration {
      * You may want to enable this when using Camel components that support
      * faults such as SOAP based such as cxf or spring-ws.
      */
-    private Boolean transferFault = false;
+    private Boolean transferFault;
     /**
      * Allows you to use your own implementation of the
      * org.springframework.jms.core.JmsOperations interface. Camel uses
@@ -455,7 +455,7 @@ public class JmsComponentConfiguration {
      * explicitQosEnabled option by contrast will only use options set on the
      * endpoint and not values from the message header.
      */
-    private Boolean preserveMessageQos = false;
+    private Boolean preserveMessageQos;
     /**
      * Whether the JmsConsumer processes the Exchange asynchronously. If enabled
      * then the JmsConsumer may pickup the next message from the JMS queue while
@@ -467,26 +467,26 @@ public class JmsComponentConfiguration {
      * asyncConsumer=true does not run asynchronously as transaction must be
      * executed synchronously (Camel 3.0 may support async transactions).
      */
-    private Boolean asyncConsumer = false;
+    private Boolean asyncConsumer;
     /**
      * Whether to allow sending messages with no body. If this option is false
      * and the message body is null then an JMSException is thrown.
      */
-    private Boolean allowNullBody = false;
+    private Boolean allowNullBody;
     /**
      * Only applicable when sending to JMS destination using InOnly (eg fire and
      * forget). Enabling this option will enrich the Camel Exchange with the
      * actual JMSMessageID that was used by the JMS client when the message was
      * sent to the JMS destination.
      */
-    private Boolean includeSentJMSMessageID = false;
+    private Boolean includeSentJMSMessageID;
     /**
      * Whether to include all JMSXxxx properties when mapping from JMS to Camel
      * Message. Setting this to true will include properties such as JMSXAppID
      * and JMSXUserID etc. Note: If you are using a custom headerFilterStrategy
      * then this option does not apply.
      */
-    private Boolean includeAllJMSXProperties = false;
+    private Boolean includeAllJMSXProperties;
     /**
      * Specifies what default TaskExecutor type to use in the
      * DefaultMessageListenerContainer for both consumer endpoints and the

http://git-wip-us.apache.org/repos/asf/camel/blob/47ff272f/components/camel-jpa/src/main/java/org/apache/camel/component/jpa/springboot/JpaComponentConfiguration.java
----------------------------------------------------------------------
diff --git a/components/camel-jpa/src/main/java/org/apache/camel/component/jpa/springboot/JpaComponentConfiguration.java b/components/camel-jpa/src/main/java/org/apache/camel/component/jpa/springboot/JpaComponentConfiguration.java
index 246ecdb..75359ca 100644
--- a/components/camel-jpa/src/main/java/org/apache/camel/component/jpa/springboot/JpaComponentConfiguration.java
+++ b/components/camel-jpa/src/main/java/org/apache/camel/component/jpa/springboot/JpaComponentConfiguration.java
@@ -45,13 +45,13 @@ public class JpaComponentConfiguration {
      * also be set globally on the JpaComponent instead of having to set it on
      * all endpoints.
      */
-    private Boolean joinTransaction = false;
+    private Boolean joinTransaction;
     /**
      * Whether to use Spring's SharedEntityManager for the consumer/producer.
      * Note in most cases joinTransaction should be set to false as this is not
      * an EXTENDED EntityManager.
      */
-    private Boolean sharedEntityManager = false;
+    private Boolean sharedEntityManager;
 
     public EntityManagerFactory getEntityManagerFactory() {
         return entityManagerFactory;

http://git-wip-us.apache.org/repos/asf/camel/blob/47ff272f/components/camel-jsch/src/main/java/org/apache/camel/component/scp/springboot/ScpComponentConfiguration.java
----------------------------------------------------------------------
diff --git a/components/camel-jsch/src/main/java/org/apache/camel/component/scp/springboot/ScpComponentConfiguration.java b/components/camel-jsch/src/main/java/org/apache/camel/component/scp/springboot/ScpComponentConfiguration.java
index f843bdc..2fa62d0 100644
--- a/components/camel-jsch/src/main/java/org/apache/camel/component/scp/springboot/ScpComponentConfiguration.java
+++ b/components/camel-jsch/src/main/java/org/apache/camel/component/scp/springboot/ScpComponentConfiguration.java
@@ -31,7 +31,7 @@ public class ScpComponentConfiguration {
      * down to DEBUG logging by default. But setting this option to true turns
      * on the verbose logging again.
      */
-    private Boolean verboseLogging = false;
+    private Boolean verboseLogging;
 
     public Boolean getVerboseLogging() {
         return verboseLogging;

http://git-wip-us.apache.org/repos/asf/camel/blob/47ff272f/components/camel-linkedin/camel-linkedin-component/src/main/java/org/apache/camel/component/linkedin/springboot/LinkedInComponentConfiguration.java
----------------------------------------------------------------------
diff --git a/components/camel-linkedin/camel-linkedin-component/src/main/java/org/apache/camel/component/linkedin/springboot/LinkedInComponentConfiguration.java b/components/camel-linkedin/camel-linkedin-component/src/main/java/org/apache/camel/component/linkedin/springboot/LinkedInComponentConfiguration.java
index 1a68eb8..c534089 100644
--- a/components/camel-linkedin/camel-linkedin-component/src/main/java/org/apache/camel/component/linkedin/springboot/LinkedInComponentConfiguration.java
+++ b/components/camel-linkedin/camel-linkedin-component/src/main/java/org/apache/camel/component/linkedin/springboot/LinkedInComponentConfiguration.java
@@ -87,7 +87,7 @@ public class LinkedInComponentConfiguration {
      * Flag to enable/disable lazy OAuth default is true. when enabled OAuth
      * token retrieval or generation is not done until the first REST call
      */
-    private Boolean lazyAuth = false;
+    private Boolean lazyAuth;
 
     public LinkedInConfiguration getConfiguration() {
         return configuration;

http://git-wip-us.apache.org/repos/asf/camel/blob/47ff272f/components/camel-mail/src/main/java/org/apache/camel/component/mail/springboot/MailComponentConfiguration.java
----------------------------------------------------------------------
diff --git a/components/camel-mail/src/main/java/org/apache/camel/component/mail/springboot/MailComponentConfiguration.java b/components/camel-mail/src/main/java/org/apache/camel/component/mail/springboot/MailComponentConfiguration.java
index b5427e2..dbcdaf7 100644
--- a/components/camel-mail/src/main/java/org/apache/camel/component/mail/springboot/MailComponentConfiguration.java
+++ b/components/camel-mail/src/main/java/org/apache/camel/component/mail/springboot/MailComponentConfiguration.java
@@ -101,7 +101,7 @@ public class MailComponentConfiguration {
      * by setting a header with the key delete to determine if the mail should
      * be deleted or not.
      */
-    private Boolean delete = false;
+    private Boolean delete;
     /**
      * Specifies whether Camel should map the received mail message to Camel
      * body/headers. If set to true the body of the mail message is mapped to
@@ -110,7 +110,7 @@ public class MailComponentConfiguration {
      * raw javax.mail.Message. You can retrieve this raw message by calling
      * exchange.getIn().getBody(javax.mail.Message.class).
      */
-    private Boolean mapMailMessage = false;
+    private Boolean mapMailMessage;
     /**
      * The folder to poll.
      */
@@ -121,11 +121,11 @@ public class MailComponentConfiguration {
      * represents the unsupported charset) is removed from the content-type and
      * it relies on the platform default instead.
      */
-    private Boolean ignoreUriScheme = false;
+    private Boolean ignoreUriScheme;
     /**
      * Whether to limit by unseen mails only.
      */
-    private Boolean unseen = false;
+    private Boolean unseen;
     /**
      * Sets the To email address. Separate multiple email addresses with comma.
      */
@@ -155,7 +155,7 @@ public class MailComponentConfiguration {
      * Enable debug mode on the underlying mail framework. The SUN Mail
      * framework logs the debug messages to System.out by default.
      */
-    private Boolean debugMode = false;
+    private Boolean debugMode;
     /**
      * The connection timeout in milliseconds.
      */
@@ -164,7 +164,7 @@ public class MailComponentConfiguration {
      * To use a dummy security setting for trusting all certificates. Should
      * only be used for development mode and not production.
      */
-    private Boolean dummyTrustManager = false;
+    private Boolean dummyTrustManager;
     /**
      * The mail message content type. Use text/html for HTML mails.
      */
@@ -179,25 +179,25 @@ public class MailComponentConfiguration {
     /**
      * Whether to use disposition inline or attachment.
      */
-    private Boolean useInlineAttachments = false;
+    private Boolean useInlineAttachments;
     /**
      * Option to let Camel ignore unsupported charset in the local JVM when
      * sending mails. If the charset is unsupported then charset=XXX (where XXX
      * represents the unsupported charset) is removed from the content-type and
      * it relies on the platform default instead.
      */
-    private Boolean ignoreUnsupportedCharset = false;
+    private Boolean ignoreUnsupportedCharset;
     /**
      * Whether the consumer should disconnect after polling. If enabled this
      * forces Camel to connect on each poll.
      */
-    private Boolean disconnect = false;
+    private Boolean disconnect;
     /**
      * Whether the consumer should close the folder after polling. Setting this
      * option to false and having disconnect=false as well then the consumer
      * keep the folder open between polls.
      */
-    private Boolean closeFolder = false;
+    private Boolean closeFolder;
     /**
      * To configure security using SSLContextParameters.
      */
@@ -215,14 +215,14 @@ public class MailComponentConfiguration {
      * the mail will not be eager marked as SEEN on the mail server which allows
      * us to rollback the mail message if there is an error processing in Camel.
      */
-    private Boolean peek = false;
+    private Boolean peek;
     /**
      * If the mail consumer cannot retrieve a given mail message then this
      * option allows to skip the message and move on to retrieve the next mail
      * message. The default behavior would be the consumer throws an exception
      * and no mails from the batch would be able to be routed by Camel.
      */
-    private Boolean skipFailedMessage = false;
+    private Boolean skipFailedMessage;
     /**
      * If the mail consumer cannot retrieve a given mail message then this
      * option allows to handle the caused exception by the consumer's error
@@ -231,7 +231,7 @@ public class MailComponentConfiguration {
      * behavior would be the consumer throws an exception and no mails from the
      * batch would be able to be routed by Camel.
      */
-    private Boolean handleFailedMessage = false;
+    private Boolean handleFailedMessage;
     /**
      * To use a custom AttachmentsContentTransferEncodingResolver to resolve
      * what content-type-encoding to use for attachments.

http://git-wip-us.apache.org/repos/asf/camel/blob/47ff272f/components/camel-mina/src/main/java/org/apache/camel/component/mina/springboot/MinaComponentConfiguration.java
----------------------------------------------------------------------
diff --git a/components/camel-mina/src/main/java/org/apache/camel/component/mina/springboot/MinaComponentConfiguration.java b/components/camel-mina/src/main/java/org/apache/camel/component/mina/springboot/MinaComponentConfiguration.java
index 0b169aa..3e7dbae 100644
--- a/components/camel-mina/src/main/java/org/apache/camel/component/mina/springboot/MinaComponentConfiguration.java
+++ b/components/camel-mina/src/main/java/org/apache/camel/component/mina/springboot/MinaComponentConfiguration.java
@@ -53,13 +53,13 @@ public class MinaComponentConfiguration {
     /**
      * Setting to set endpoint as one-way or request-response.
      */
-    private Boolean sync = false;
+    private Boolean sync;
     /**
      * Only used for TCP. If no codec is specified you can use this flag to
      * indicate a text line based codec; if not specified or the value is false
      * then Object Serialization is assumed over TCP.
      */
-    private Boolean textline = false;
+    private Boolean textline;
     /**
      * Only used for TCP and if textline=true. Sets the text line delimiter to
      * use. If none provided Camel will use DEFAULT. This delimiter is used to
@@ -86,7 +86,7 @@ public class MinaComponentConfiguration {
      * Sessions can be lazily created to avoid exceptions if the remote server
      * is not up and running when the Camel producer is started.
      */
-    private Boolean lazySessionCreation = false;
+    private Boolean lazySessionCreation;
     /**
      * Only used for TCP. You can transfer the exchange over the wire instead of
      * just the body. The following fields are transferred: In body Out body
@@ -94,7 +94,7 @@ public class MinaComponentConfiguration {
      * exchange exception. This requires that the objects are serializable.
      * Camel will exclude any non-serializable objects and log it at WARN level.
      */
-    private Boolean transferExchange = false;
+    private Boolean transferExchange;
     /**
      * To set the textline protocol encoder max line length. By default the
      * default value of Mina itself is used which are Integer.MAX_VALUE.
@@ -109,7 +109,7 @@ public class MinaComponentConfiguration {
      * You can enable the Apache MINA logging filter. Apache MINA uses slf4j
      * logging at INFO level to log all input and output.
      */
-    private Boolean minaLogger = false;
+    private Boolean minaLogger;
     /**
      * You can set a list of Mina IoFilters to use.
      */
@@ -121,17 +121,17 @@ public class MinaComponentConfiguration {
      * filter chain. This is useful in scenarios where another filter must be
      * the first in the filter chain like the SSL filter.
      */
-    private Boolean allowDefaultCodec = false;
+    private Boolean allowDefaultCodec;
     /**
      * Whether or not to disconnect(close) from Mina session right after use.
      * Can be used for both consumer and producer.
      */
-    private Boolean disconnect = false;
+    private Boolean disconnect;
     /**
      * If sync is enabled then this option dictates MinaConsumer if it should
      * disconnect where there is no reply to send back.
      */
-    private Boolean disconnectOnNoReply = false;
+    private Boolean disconnectOnNoReply;
     /**
      * If sync is enabled this option dictates MinaConsumer which logging level
      * to use when logging a there is no reply to send back.
@@ -141,7 +141,7 @@ public class MinaComponentConfiguration {
      * If the clientMode is true mina consumer will connect the address as a TCP
      * client.
      */
-    private Boolean clientMode = false;
+    private Boolean clientMode;
 
     public MinaConfiguration getConfiguration() {
         return configuration;

http://git-wip-us.apache.org/repos/asf/camel/blob/47ff272f/components/camel-mina2/src/main/java/org/apache/camel/component/mina2/springboot/Mina2ComponentConfiguration.java
----------------------------------------------------------------------
diff --git a/components/camel-mina2/src/main/java/org/apache/camel/component/mina2/springboot/Mina2ComponentConfiguration.java b/components/camel-mina2/src/main/java/org/apache/camel/component/mina2/springboot/Mina2ComponentConfiguration.java
index 9de1b29..edb49b5 100644
--- a/components/camel-mina2/src/main/java/org/apache/camel/component/mina2/springboot/Mina2ComponentConfiguration.java
+++ b/components/camel-mina2/src/main/java/org/apache/camel/component/mina2/springboot/Mina2ComponentConfiguration.java
@@ -54,13 +54,13 @@ public class Mina2ComponentConfiguration {
     /**
      * Setting to set endpoint as one-way or request-response.
      */
-    private Boolean sync = false;
+    private Boolean sync;
     /**
      * Only used for TCP. If no codec is specified you can use this flag to
      * indicate a text line based codec; if not specified or the value is false
      * then Object Serialization is assumed over TCP.
      */
-    private Boolean textline = false;
+    private Boolean textline;
     /**
      * Only used for TCP and if textline=true. Sets the text line delimiter to
      * use. If none provided Camel will use DEFAULT. This delimiter is used to
@@ -87,7 +87,7 @@ public class Mina2ComponentConfiguration {
      * Sessions can be lazily created to avoid exceptions if the remote server
      * is not up and running when the Camel producer is started.
      */
-    private Boolean lazySessionCreation = false;
+    private Boolean lazySessionCreation;
     /**
      * Only used for TCP. You can transfer the exchange over the wire instead of
      * just the body. The following fields are transferred: In body Out body
@@ -95,7 +95,7 @@ public class Mina2ComponentConfiguration {
      * exchange exception. This requires that the objects are serializable.
      * Camel will exclude any non-serializable objects and log it at WARN level.
      */
-    private Boolean transferExchange = false;
+    private Boolean transferExchange;
     /**
      * To set the textline protocol encoder max line length. By default the
      * default value of Mina itself is used which are Integer.MAX_VALUE.
@@ -110,7 +110,7 @@ public class Mina2ComponentConfiguration {
      * You can enable the Apache MINA logging filter. Apache MINA uses slf4j
      * logging at INFO level to log all input and output.
      */
-    private Boolean minaLogger = false;
+    private Boolean minaLogger;
     /**
      * You can set a list of Mina IoFilters to use.
      */
@@ -122,17 +122,17 @@ public class Mina2ComponentConfiguration {
      * filter chain. This is useful in scenarios where another filter must be
      * the first in the filter chain like the SSL filter.
      */
-    private Boolean allowDefaultCodec = false;
+    private Boolean allowDefaultCodec;
     /**
      * Whether or not to disconnect(close) from Mina session right after use.
      * Can be used for both consumer and producer.
      */
-    private Boolean disconnect = false;
+    private Boolean disconnect;
     /**
      * If sync is enabled then this option dictates MinaConsumer if it should
      * disconnect where there is no reply to send back.
      */
-    private Boolean disconnectOnNoReply = false;
+    private Boolean disconnectOnNoReply;
     /**
      * If sync is enabled this option dictates MinaConsumer which logging level
      * to use when logging a there is no reply to send back.
@@ -145,7 +145,7 @@ public class Mina2ComponentConfiguration {
     /**
      * Whether to auto start SSL handshake.
      */
-    private Boolean autoStartTls = false;
+    private Boolean autoStartTls;
     /**
      * Number of worker threads in the worker pool for TCP and UDP
      */
@@ -154,17 +154,17 @@ public class Mina2ComponentConfiguration {
      * Whether to use ordered thread pool to ensure events are processed orderly
      * on the same channel.
      */
-    private Boolean orderedThreadPoolExecutor = false;
+    private Boolean orderedThreadPoolExecutor;
     /**
      * Whether to create the InetAddress once and reuse. Setting this to false
      * allows to pickup DNS changes in the network.
      */
-    private Boolean cachedAddress = false;
+    private Boolean cachedAddress;
     /**
      * If the clientMode is true mina consumer will connect the address as a TCP
      * client.
      */
-    private Boolean clientMode = false;
+    private Boolean clientMode;
 
     public Mina2Configuration getConfiguration() {
         return configuration;

http://git-wip-us.apache.org/repos/asf/camel/blob/47ff272f/components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/springboot/NettyHttpComponentConfiguration.java
----------------------------------------------------------------------
diff --git a/components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/springboot/NettyHttpComponentConfiguration.java b/components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/springboot/NettyHttpComponentConfiguration.java
index 6529012..1415e63 100644
--- a/components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/springboot/NettyHttpComponentConfiguration.java
+++ b/components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/springboot/NettyHttpComponentConfiguration.java
@@ -74,7 +74,7 @@ public class NettyHttpComponentConfiguration {
      * org.jboss.netty.handler.execution.OrderedMemoryAwareThreadPoolExecutor
      * for more details.
      */
-    private Boolean orderedThreadPoolExecutor = false;
+    private Boolean orderedThreadPoolExecutor;
     /**
      * Sets the cap on the number of objects that can be allocated by the pool
      * (checked out to clients or idle awaiting checkout) at a given time. Use a
@@ -101,12 +101,12 @@ public class NettyHttpComponentConfiguration {
      * as the pooling is needed for handling concurrency and reliable
      * request/reply.
      */
-    private Boolean producerPoolEnabled = false;
+    private Boolean producerPoolEnabled;
     /**
      * If the useChannelBuffer is true netty producer will turn the message body
      * into ChannelBuffer before sending it out.
      */
-    private Boolean useChannelBuffer = false;
+    private Boolean useChannelBuffer;
     /**
      * The maximum total size of the queued events per channel when using
      * orderedThreadPoolExecutor. Specify 0 to disable.
@@ -160,15 +160,15 @@ public class NettyHttpComponentConfiguration {
     /**
      * Setting to ensure socket is not closed due to inactivity
      */
-    private Boolean keepAlive = false;
+    private Boolean keepAlive;
     /**
      * Setting to improve TCP protocol performance
      */
-    private Boolean tcpNoDelay = false;
+    private Boolean tcpNoDelay;
     /**
      * Setting to facilitate socket multiplexing
      */
-    private Boolean reuseAddress = false;
+    private Boolean reuseAddress;
     /**
      * Time to wait for a socket connection to be available. Value is in millis.
      */
@@ -184,14 +184,14 @@ public class NettyHttpComponentConfiguration {
     /**
      * Setting to specify whether SSL encryption is applied to this endpoint
      */
-    private Boolean ssl = false;
+    private Boolean ssl;
     /**
      * When enabled and in SSL mode then the Netty consumer will enrich the
      * Camel Message with headers having information about the client
      * certificate such as subject name issuer name serial number and the valid
      * date range.
      */
-    private Boolean sslClientCertHeaders = false;
+    private Boolean sslClientCertHeaders;
     /**
      * Reference to a class that could be used to return an SSL Handler
      */
@@ -203,7 +203,7 @@ public class NettyHttpComponentConfiguration {
     /**
      * Configures whether the server needs client authentication when using SSL.
      */
-    private Boolean needClientAuth = false;
+    private Boolean needClientAuth;
     /**
      * Client side certificate keystore to be used for encryption. Is loaded by
      * default from classpath but you can prefix with classpath: file: or http:
@@ -249,7 +249,7 @@ public class NettyHttpComponentConfiguration {
     /**
      * Setting to set endpoint as one-way or request-response
      */
-    private Boolean sync = false;
+    private Boolean sync;
     /**
      * Allows to configure additional netty options using option. as prefix. For
      * example option.child.keepAlive=false to set the netty option
@@ -306,12 +306,12 @@ public class NettyHttpComponentConfiguration {
      * Whether or not to disconnect(close) from Netty Channel right after use.
      * Can be used for both consumer and producer.
      */
-    private Boolean disconnect = false;
+    private Boolean disconnect;
     /**
      * Channels can be lazily created to avoid exceptions if the remote server
      * is not up and running when the Camel producer is started.
      */
-    private Boolean lazyChannelCreation = false;
+    private Boolean lazyChannelCreation;
     /**
      * Only used for TCP. You can transfer the exchange over the wire instead of
      * just the body. The following fields are transferred: In body Out body
@@ -319,12 +319,12 @@ public class NettyHttpComponentConfiguration {
      * exchange exception. This requires that the objects are serializable.
      * Camel will exclude any non-serializable objects and log it at WARN level.
      */
-    private Boolean transferExchange = false;
+    private Boolean transferExchange;
     /**
      * If sync is enabled then this option dictates NettyConsumer if it should
      * disconnect where there is no reply to send back.
      */
-    private Boolean disconnectOnNoReply = false;
+    private Boolean disconnectOnNoReply;
     /**
      * If sync is enabled this option dictates NettyConsumer which logging level
      * to use when logging a there is no reply to send back.

http://git-wip-us.apache.org/repos/asf/camel/blob/47ff272f/components/camel-netty/src/main/java/org/apache/camel/component/netty/springboot/NettyComponentConfiguration.java
----------------------------------------------------------------------
diff --git a/components/camel-netty/src/main/java/org/apache/camel/component/netty/springboot/NettyComponentConfiguration.java b/components/camel-netty/src/main/java/org/apache/camel/component/netty/springboot/NettyComponentConfiguration.java
index b4cc383..79e95db 100644
--- a/components/camel-netty/src/main/java/org/apache/camel/component/netty/springboot/NettyComponentConfiguration.java
+++ b/components/camel-netty/src/main/java/org/apache/camel/component/netty/springboot/NettyComponentConfiguration.java
@@ -56,7 +56,7 @@ public class NettyComponentConfiguration {
      * org.jboss.netty.handler.execution.OrderedMemoryAwareThreadPoolExecutor
      * for more details.
      */
-    private Boolean orderedThreadPoolExecutor = false;
+    private Boolean orderedThreadPoolExecutor;
     /**
      * Sets the cap on the number of objects that can be allocated by the pool
      * (checked out to clients or idle awaiting checkout) at a given time. Use a
@@ -83,23 +83,23 @@ public class NettyComponentConfiguration {
      * as the pooling is needed for handling concurrency and reliable
      * request/reply.
      */
-    private Boolean producerPoolEnabled = false;
+    private Boolean producerPoolEnabled;
     /**
      * This option supports connection less udp sending which is a real fire and
      * forget. A connected udp send receive the PortUnreachableException if no
      * one is listen on the receiving port.
      */
-    private Boolean udpConnectionlessSending = false;
+    private Boolean udpConnectionlessSending;
     /**
      * If the clientMode is true netty consumer will connect the address as a
      * TCP client.
      */
-    private Boolean clientMode = false;
+    private Boolean clientMode;
     /**
      * If the useChannelBuffer is true netty producer will turn the message body
      * into ChannelBuffer before sending it out.
      */
-    private Boolean useChannelBuffer = false;
+    private Boolean useChannelBuffer;
     /**
      * The maximum total size of the queued events per channel when using
      * orderedThreadPoolExecutor. Specify 0 to disable.
@@ -126,7 +126,7 @@ public class NettyComponentConfiguration {
     /**
      * Setting to choose Multicast over UDP
      */
-    private Boolean broadcast = false;
+    private Boolean broadcast;
     /**
      * The TCP/UDP buffer sizes to be used during outbound communication. Size
      * is bytes.
@@ -157,15 +157,15 @@ public class NettyComponentConfiguration {
     /**
      * Setting to ensure socket is not closed due to inactivity
      */
-    private Boolean keepAlive = false;
+    private Boolean keepAlive;
     /**
      * Setting to improve TCP protocol performance
      */
-    private Boolean tcpNoDelay = false;
+    private Boolean tcpNoDelay;
     /**
      * Setting to facilitate socket multiplexing
      */
-    private Boolean reuseAddress = false;
+    private Boolean reuseAddress;
     /**
      * Time to wait for a socket connection to be available. Value is in millis.
      */
@@ -181,14 +181,14 @@ public class NettyComponentConfiguration {
     /**
      * Setting to specify whether SSL encryption is applied to this endpoint
      */
-    private Boolean ssl = false;
+    private Boolean ssl;
     /**
      * When enabled and in SSL mode then the Netty consumer will enrich the
      * Camel Message with headers having information about the client
      * certificate such as subject name issuer name serial number and the valid
      * date range.
      */
-    private Boolean sslClientCertHeaders = false;
+    private Boolean sslClientCertHeaders;
     /**
      * Reference to a class that could be used to return an SSL Handler
      */
@@ -200,7 +200,7 @@ public class NettyComponentConfiguration {
     /**
      * Configures whether the server needs client authentication when using SSL.
      */
-    private Boolean needClientAuth = false;
+    private Boolean needClientAuth;
     /**
      * Client side certificate keystore to be used for encryption. Is loaded by
      * default from classpath but you can prefix with classpath: file: or http:
@@ -246,13 +246,13 @@ public class NettyComponentConfiguration {
     /**
      * Setting to set endpoint as one-way or request-response
      */
-    private Boolean sync = false;
+    private Boolean sync;
     /**
      * Only used for TCP. If no codec is specified you can use this flag to
      * indicate a text line based codec; if not specified or the value is false
      * then Object Serialization is assumed over TCP.
      */
-    private Boolean textline = false;
+    private Boolean textline;
     /**
      * Allows to configure additional netty options using option. as prefix. For
      * example option.child.keepAlive=false to set the netty option
@@ -279,7 +279,7 @@ public class NettyComponentConfiguration {
      * Whether or not to auto append missing end delimiter when sending using
      * the textline codec.
      */
-    private Boolean autoAppendDelimiter = false;
+    private Boolean autoAppendDelimiter;
     /**
      * To use a explicit org.jboss.netty.channel.socket.nio.WorkerPool as the
      * worker thread pool. For example to share a thread pool with multiple
@@ -333,12 +333,12 @@ public class NettyComponentConfiguration {
      * Whether or not to disconnect(close) from Netty Channel right after use.
      * Can be used for both consumer and producer.
      */
-    private Boolean disconnect = false;
+    private Boolean disconnect;
     /**
      * Channels can be lazily created to avoid exceptions if the remote server
      * is not up and running when the Camel producer is started.
      */
-    private Boolean lazyChannelCreation = false;
+    private Boolean lazyChannelCreation;
     /**
      * Only used for TCP. You can transfer the exchange over the wire instead of
      * just the body. The following fields are transferred: In body Out body
@@ -346,12 +346,12 @@ public class NettyComponentConfiguration {
      * exchange exception. This requires that the objects are serializable.
      * Camel will exclude any non-serializable objects and log it at WARN level.
      */
-    private Boolean transferExchange = false;
+    private Boolean transferExchange;
     /**
      * If sync is enabled then this option dictates NettyConsumer if it should
      * disconnect where there is no reply to send back.
      */
-    private Boolean disconnectOnNoReply = false;
+    private Boolean disconnectOnNoReply;
     /**
      * If sync is enabled this option dictates NettyConsumer which logging level
      * to use when logging a there is no reply to send back.
@@ -376,7 +376,7 @@ public class NettyComponentConfiguration {
      * the netty component from installing a default codec as the first element
      * in the filter chain.
      */
-    private Boolean allowDefaultCodec = false;
+    private Boolean allowDefaultCodec;
     /**
      * To use a custom ClientPipelineFactory
      */

http://git-wip-us.apache.org/repos/asf/camel/blob/47ff272f/components/camel-netty4-http/src/main/java/org/apache/camel/component/netty4/http/springboot/NettyHttpComponentConfiguration.java
----------------------------------------------------------------------
diff --git a/components/camel-netty4-http/src/main/java/org/apache/camel/component/netty4/http/springboot/NettyHttpComponentConfiguration.java b/components/camel-netty4-http/src/main/java/org/apache/camel/component/netty4/http/springboot/NettyHttpComponentConfiguration.java
index f82c385..462be0d 100644
--- a/components/camel-netty4-http/src/main/java/org/apache/camel/component/netty4/http/springboot/NettyHttpComponentConfiguration.java
+++ b/components/camel-netty4-http/src/main/java/org/apache/camel/component/netty4/http/springboot/NettyHttpComponentConfiguration.java
@@ -115,15 +115,15 @@ public class NettyHttpComponentConfiguration {
     /**
      * Setting to ensure socket is not closed due to inactivity
      */
-    private Boolean keepAlive = false;
+    private Boolean keepAlive;
     /**
      * Setting to improve TCP protocol performance
      */
-    private Boolean tcpNoDelay = false;
+    private Boolean tcpNoDelay;
     /**
      * Setting to facilitate socket multiplexing
      */
-    private Boolean reuseAddress = false;
+    private Boolean reuseAddress;
     /**
      * Time to wait for a socket connection to be available. Value is in millis.
      */
@@ -139,14 +139,14 @@ public class NettyHttpComponentConfiguration {
     /**
      * Setting to specify whether SSL encryption is applied to this endpoint
      */
-    private Boolean ssl = false;
+    private Boolean ssl;
     /**
      * When enabled and in SSL mode then the Netty consumer will enrich the
      * Camel Message with headers having information about the client
      * certificate such as subject name issuer name serial number and the valid
      * date range.
      */
-    private Boolean sslClientCertHeaders = false;
+    private Boolean sslClientCertHeaders;
     /**
      * Reference to a class that could be used to return an SSL Handler
      */
@@ -158,7 +158,7 @@ public class NettyHttpComponentConfiguration {
     /**
      * Configures whether the server needs client authentication when using SSL.
      */
-    private Boolean needClientAuth = false;
+    private Boolean needClientAuth;
     /**
      * Client side certificate keystore to be used for encryption. Is loaded by
      * default from classpath but you can prefix with classpath: file: or http:
@@ -204,7 +204,7 @@ public class NettyHttpComponentConfiguration {
     /**
      * Setting to set endpoint as one-way or request-response
      */
-    private Boolean sync = false;
+    private Boolean sync;
     /**
      * Allows to configure additional netty options using option. as prefix. For
      * example option.child.keepAlive=false to set the netty option
@@ -219,7 +219,7 @@ public class NettyHttpComponentConfiguration {
      * you are using. See more details at:
      * http://netty.io/wiki/native-transports.html
      */
-    private Boolean nativeTransport = false;
+    private Boolean nativeTransport;
     /**
      * Set the BossGroup which could be used for handling the new connection of
      * the server side across the NettyEndpoint
@@ -265,12 +265,12 @@ public class NettyHttpComponentConfiguration {
      * Whether or not to disconnect(close) from Netty Channel right after use.
      * Can be used for both consumer and producer.
      */
-    private Boolean disconnect = false;
+    private Boolean disconnect;
     /**
      * Channels can be lazily created to avoid exceptions if the remote server
      * is not up and running when the Camel producer is started.
      */
-    private Boolean lazyChannelCreation = false;
+    private Boolean lazyChannelCreation;
     /**
      * Only used for TCP. You can transfer the exchange over the wire instead of
      * just the body. The following fields are transferred: In body Out body
@@ -278,12 +278,12 @@ public class NettyHttpComponentConfiguration {
      * exchange exception. This requires that the objects are serializable.
      * Camel will exclude any non-serializable objects and log it at WARN level.
      */
-    private Boolean transferExchange = false;
+    private Boolean transferExchange;
     /**
      * If sync is enabled then this option dictates NettyConsumer if it should
      * disconnect where there is no reply to send back.
      */
-    private Boolean disconnectOnNoReply = false;
+    private Boolean disconnectOnNoReply;
     /**
      * If sync is enabled this option dictates NettyConsumer which logging level
      * to use when logging a there is no reply to send back.
@@ -310,7 +310,7 @@ public class NettyHttpComponentConfiguration {
      * Whether to use ordered thread pool to ensure events are processed orderly
      * on the same channel.
      */
-    private Boolean usingExecutorService = false;
+    private Boolean usingExecutorService;
     /**
      * Sets the cap on the number of objects that can be allocated by the pool
      * (checked out to clients or idle awaiting checkout) at a given time. Use a
@@ -337,7 +337,7 @@ public class NettyHttpComponentConfiguration {
      * as the pooling is needed for handling concurrency and reliable
      * request/reply.
      */
-    private Boolean producerPoolEnabled = false;
+    private Boolean producerPoolEnabled;
     /**
      * This option allows producers to reuse the same Netty Channel for the
      * lifecycle of processing the Exchange. This is useable if you need to call
@@ -348,7 +348,7 @@ public class NettyHttpComponentConfiguration {
      * exchange property with the key link NettyConstantsNETTY_CHANNEL which
      * allows you to obtain the channel during routing and use it as well.
      */
-    private Boolean reuseChannel = false;
+    private Boolean reuseChannel;
 
     public NettyHttpBinding getNettyHttpBinding() {
         return nettyHttpBinding;


[4/5] camel git commit: updated docs

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


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

Branch: refs/heads/master
Commit: 8ba133ecbcfebcf1c4b0e729bfe8fa101048a012
Parents: d36d015
Author: Claus Ibsen <da...@apache.org>
Authored: Tue Aug 2 10:35:25 2016 +0200
Committer: Claus Ibsen <da...@apache.org>
Committed: Tue Aug 2 10:47:53 2016 +0200

----------------------------------------------------------------------
 components/camel-ftp/src/main/docs/ftp.adoc | 4 +++-
 1 file changed, 3 insertions(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/camel/blob/8ba133ec/components/camel-ftp/src/main/docs/ftp.adoc
----------------------------------------------------------------------
diff --git a/components/camel-ftp/src/main/docs/ftp.adoc b/components/camel-ftp/src/main/docs/ftp.adoc
index 4afc4e6..c34451a 100644
--- a/components/camel-ftp/src/main/docs/ftp.adoc
+++ b/components/camel-ftp/src/main/docs/ftp.adoc
@@ -115,6 +115,7 @@ The FTP component has no options.
 
 
 
+
 // endpoint options: START
 The FTP component supports 103 endpoint options which are listed below:
 
@@ -129,6 +130,7 @@ The FTP component supports 103 endpoint options which are listed below:
 | charset | common |  | String | This option is used to specify the encoding of the file. You can use this on the consumer to specify the encodings of the files which allow Camel to know the charset it should load the file content in case the file content is being accessed. Likewise when writing a file you can use this option to specify which charset to write the file as well.
 | disconnect | common | false | boolean | Whether or not to disconnect from remote FTP server right after use. Disconnect will only disconnect the current connection to the FTP server. If you have a consumer which you want to stop then you need to stop the consumer/route instead.
 | disconnectOnBatchComplete | common | false | boolean | Whether or not to disconnect from remote FTP server right after a Batch is complete. disconnectOnBatchComplete will only disconnect the current connection to the FTP server. If you have a consumer which you want to stop then you need to stop the consumer/route instead.
+| doneFileName | common |  | String | If provided then Camel will write a 2nd done file when the original file has been written. The done file will be empty. This option configures what file name to use. Either you can specify a fixed name. Or you can use dynamic placeholders. The done file will always be written in the same folder as the original file. Only $file.name and $file.name.noext is supported as dynamic placeholders.
 | download | common | false | boolean | Whether the FTP consumer should download the file. If this option is set to false then the message body will be null but the consumer will still trigger a Camel Exchange that has details about the file such as file name file size etc. It's just that the file will not be downloaded.
 | fastExistsCheck | common | false | boolean | If set this option to be true camel-ftp will use the list file directly to check if the file exists. Since some FTP server may not support to list the file directly if the option is false camel-ftp will use the old way to list the directory and check if the file exists. This option also influences readLock=changed to control whether it performs a fast check to update file information or not. This can be used to speed up the process if the FTP server has a lot of files.
 | fileName | common |  | String | Use Expression such as File Language to dynamically set the filename. For consumers it's used as a filename filter. For producers it's used to evaluate the filename to write. If an expression is set it take precedence over the CamelFileName header. (Note: The header itself can also be an Expression). The expression options support both String and Expression types. If the expression is a String type it is always evaluated using the File Language. If the expression is an Expression type the specified Expression type is used - this allows you for instance to use OGNL expressions. For the consumer you can use it to filter filenames so you can for instance consume today's file using the File Language syntax: mydata-$date:now:yyyyMMdd.txt. The producers support the CamelOverruleFileName header which takes precedence over any existing CamelFileName header; the CamelOverruleFileName is a header that is used only once and makes it easier as this avoids to te
 mporary store CamelFileName and have to restore it afterwards.
@@ -155,7 +157,6 @@ The FTP component supports 103 endpoint options which are listed below:
 | receiveBufferSize | consumer (advanced) | 32768 | int | The receive (download) buffer size Used only by FTPClient
 | startingDirectoryMustExist | consumer (advanced) | false | boolean | Whether the starting directory must exist. Mind that the autoCreate option is default enabled which means the starting directory is normally auto created if it doesn't exist. You can disable autoCreate and enable this to ensure the starting directory must exist. Will thrown an exception if the directory doesn't exist.
 | useList | consumer (advanced) | true | boolean | Whether to allow using LIST command when downloading a file. Default is true. In some use cases you may want to download a specific file and are not allowed to use the LIST command and therefore you can set this option to false.
-| doneFileName | producer |  | String | If provided then Camel will write a 2nd done file when the original file has been written. The done file will be empty. This option configures what file name to use. Either you can specify a fixed name. Or you can use dynamic placeholders. The done file will always be written in the same folder as the original file. Only $file.name and $file.name.noext is supported as dynamic placeholders.
 | fileExist | producer | Override | GenericFileExist | What to do if a file already exists with the same name. Override which is the default replaces the existing file. Append - adds content to the existing file. Fail - throws a GenericFileOperationException indicating that there is already an existing file. Ignore - silently ignores the problem and does not override the existing file but assumes everything is okay. Move - option requires to use the moveExisting option to be configured as well. The option eagerDeleteTargetFile can be used to control what to do if an moving the file and there exists already an existing file otherwise causing the move operation to fail. The Move option will move any existing files before writing the target file. TryRename Camel is only applicable if tempFileName option is in use. This allows to try renaming the file from the temporary name to the actual name without doing any exists check.This check may be faster on some file systems and especially FT
 P servers.
 | flatten | producer | false | boolean | Flatten is used to flatten the file name path to strip any leading paths so it's just the file name. This allows you to consume recursively into sub-directories but when you eg write the files to another directory they will be written in a single directory. Setting this to true on the producer enforces that any file name in CamelFileName header will be stripped for any leading paths.
 | moveExisting | producer |  | String | Expression (such as File Language) used to compute file name to use when fileExist=Move is configured. To move files into a backup subdirectory just enter backup. This option only supports the following File Language tokens: file:name file:name.ext file:name.noext file:onlyname file:onlyname.noext file:ext and file:parent. Notice the file:parent is not supported by the FTP component as the FTP component can only move any existing files to a relative directory based on current dir as base.
@@ -235,6 +236,7 @@ The FTP component supports 103 endpoint options which are listed below:
 
 
 
+
 [Info]
 ====
 FTPS component default trust store


[3/5] camel git commit: Fixed potential NPE

Posted by da...@apache.org.
Fixed potential NPE


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

Branch: refs/heads/master
Commit: d36d015248f7c48a11010201e2032d3ee1abc2ca
Parents: b0c4dcd
Author: Claus Ibsen <da...@apache.org>
Authored: Tue Aug 2 09:57:08 2016 +0200
Committer: Claus Ibsen <da...@apache.org>
Committed: Tue Aug 2 10:47:53 2016 +0200

----------------------------------------------------------------------
 .../apache/camel/component/properties/DefaultPropertiesParser.java | 2 +-
 1 file changed, 1 insertion(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/camel/blob/d36d0152/camel-core/src/main/java/org/apache/camel/component/properties/DefaultPropertiesParser.java
----------------------------------------------------------------------
diff --git a/camel-core/src/main/java/org/apache/camel/component/properties/DefaultPropertiesParser.java b/camel-core/src/main/java/org/apache/camel/component/properties/DefaultPropertiesParser.java
index c7fb283..3ab0f73 100644
--- a/camel-core/src/main/java/org/apache/camel/component/properties/DefaultPropertiesParser.java
+++ b/camel-core/src/main/java/org/apache/camel/component/properties/DefaultPropertiesParser.java
@@ -256,7 +256,7 @@ public class DefaultPropertiesParser implements AugmentedPropertyNameAwareProper
 
             if (value == null) {
                 StringBuilder esb = new StringBuilder();
-                if (propertiesComponent.isDefaultCreated()) {
+                if (propertiesComponent == null || propertiesComponent.isDefaultCreated()) {
                     // if the component was auto created then include more information that the end user should define it
                     esb.append("PropertiesComponent with name properties must be defined in CamelContext to support property placeholders. ");
                 }


[5/5] camel git commit: Polished

Posted by da...@apache.org.
Polished


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

Branch: refs/heads/master
Commit: b0c4dcd9be618e79bdc5554ada5618d0face87fa
Parents: 0434eb8
Author: Claus Ibsen <da...@apache.org>
Authored: Tue Aug 2 09:45:13 2016 +0200
Committer: Claus Ibsen <da...@apache.org>
Committed: Tue Aug 2 10:47:53 2016 +0200

----------------------------------------------------------------------
 components/camel-spring-boot/pom.xml | 2 +-
 1 file changed, 1 insertion(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/camel/blob/b0c4dcd9/components/camel-spring-boot/pom.xml
----------------------------------------------------------------------
diff --git a/components/camel-spring-boot/pom.xml b/components/camel-spring-boot/pom.xml
index c8e2fb0..284ef18 100644
--- a/components/camel-spring-boot/pom.xml
+++ b/components/camel-spring-boot/pom.xml
@@ -30,7 +30,7 @@
   <description>Camel :: Spring Boot</description>
 
   <properties>
-    <camel.osgi.export.pkg />
+    <camel.osgi.export.pkg/>
   </properties>
 
   <dependencies>