You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@camel.apache.org by ac...@apache.org on 2019/08/21 08:41:41 UTC

[camel] branch master updated: Fixed CS for Camel-Core

This is an automated email from the ASF dual-hosted git repository.

acosentino pushed a commit to branch master
in repository https://gitbox.apache.org/repos/asf/camel.git


The following commit(s) were added to refs/heads/master by this push:
     new 69e6aa3  Fixed CS for Camel-Core
69e6aa3 is described below

commit 69e6aa3eab9b1caca431a0631410954f9632b845
Author: Andrea Cosentino <an...@gmail.com>
AuthorDate: Wed Aug 21 10:41:15 2019 +0200

    Fixed CS for Camel-Core
---
 .../apache/camel/builder/AdviceWithBuilder.java    |    9 +-
 .../camel/builder/AdviceWithRouteBuilder.java      |   97 +-
 .../org/apache/camel/builder/AdviceWithTask.java   |    3 +-
 .../org/apache/camel/builder/AdviceWithTasks.java  |  145 +-
 .../camel/builder/AggregationStrategies.java       |   49 +-
 .../camel/builder/AggregationStrategyClause.java   |   37 +-
 .../java/org/apache/camel/builder/Builder.java     |   65 +-
 .../org/apache/camel/builder/BuilderSupport.java   |   83 +-
 .../org/apache/camel/builder/DataFormatClause.java |  243 ++-
 .../camel/builder/DeadLetterChannelBuilder.java    |   20 +-
 .../camel/builder/DefaultErrorHandlerBuilder.java  |  183 +-
 .../camel/builder/EndpointConsumerBuilder.java     |   10 +-
 .../camel/builder/EndpointProducerBuilder.java     |   14 +-
 .../org/apache/camel/builder/EnrichClause.java     |    1 -
 .../apache/camel/builder/ErrorHandlerBuilder.java  |    5 +-
 .../camel/builder/ErrorHandlerBuilderRef.java      |    5 +-
 .../camel/builder/ErrorHandlerBuilderSupport.java  |   18 +-
 .../org/apache/camel/builder/ExchangeBuilder.java  |    9 +-
 .../apache/camel/builder/ExpressionBuilder.java    |    6 +-
 .../org/apache/camel/builder/ExpressionClause.java |  164 +-
 .../camel/builder/ExpressionClauseSupport.java     |  167 +-
 .../camel/builder/FlexibleAggregationStrategy.java |  156 +-
 .../camel/builder/NoErrorHandlerBuilder.java       |   11 +-
 .../org/apache/camel/builder/NotifyBuilder.java    |  301 +--
 .../org/apache/camel/builder/PredicateBuilder.java |    5 +-
 .../org/apache/camel/builder/PredicateClause.java  |   79 +-
 .../org/apache/camel/builder/ProcessClause.java    |   76 +-
 .../org/apache/camel/builder/ProxyBuilder.java     |   10 +-
 .../org/apache/camel/builder/RouteBuilder.java     |   92 +-
 .../org/apache/camel/builder/SimpleBuilder.java    |   15 +-
 .../apache/camel/builder/ThreadPoolBuilder.java    |   16 +-
 .../camel/builder/ThreadPoolProfileBuilder.java    |    5 +-
 .../apache/camel/builder/TransformerBuilder.java   |   48 +-
 .../org/apache/camel/builder/ValidatorBuilder.java |   42 +-
 .../camel/impl/AbstractModelCamelContext.java      |    6 +-
 .../org/apache/camel/impl/DefaultCamelContext.java |   29 +-
 .../camel/impl/DefaultExecutorServiceManager.java  |    3 +-
 .../camel/impl/DefaultModelJAXBContextFactory.java |    5 +-
 .../java/org/apache/camel/impl/RouteIdFactory.java |   15 +-
 .../java/org/apache/camel/impl/RouteService.java   |   23 +-
 .../impl/cluster/ClusteredRouteConfiguration.java  |    2 +-
 .../impl/cluster/ClusteredRouteController.java     |   11 +-
 .../camel/impl/cluster/ClusteredRouteFilter.java   |    2 +-
 .../camel/impl/cluster/ClusteredRoutePolicy.java   |   23 +-
 .../impl/cluster/ClusteredRoutePolicyFactory.java  |    3 +-
 .../apache/camel/model/AdviceWithDefinition.java   |    2 +-
 .../apache/camel/model/AggregateDefinition.java    |  375 ++--
 .../org/apache/camel/model/BeanDefinition.java     |    9 +-
 .../org/apache/camel/model/CatchDefinition.java    |   24 +-
 .../org/apache/camel/model/ChoiceDefinition.java   |   44 +-
 .../apache/camel/model/ClaimCheckDefinition.java   |   87 +-
 .../java/org/apache/camel/model/Constants.java     |   14 +-
 .../apache/camel/model/ContextScanDefinition.java  |    5 +-
 .../apache/camel/model/ConvertBodyDefinition.java  |    4 +-
 .../apache/camel/model/DataFormatDefinition.java   |    9 +-
 .../DefinitionPropertyPlaceholderConfigurer.java   |    9 +-
 .../org/apache/camel/model/DelayDefinition.java    |   17 +-
 .../camel/model/DynamicRouterDefinition.java       |   30 +-
 .../camel/model/EndpointRequiredDefinition.java    |    5 +-
 .../org/apache/camel/model/EnrichDefinition.java   |   59 +-
 .../model/ExecutorServiceAwareDefinition.java      |    8 +-
 .../org/apache/camel/model/ExpressionNode.java     |   28 +-
 .../apache/camel/model/ExpressionNodeHelper.java   |   48 +-
 .../model/ExpressionSubElementDefinition.java      |   15 +-
 .../org/apache/camel/model/FilterDefinition.java   |   12 +-
 .../org/apache/camel/model/FinallyDefinition.java  |    2 +-
 .../org/apache/camel/model/FromDefinition.java     |    3 +-
 .../camel/model/HystrixConfigurationCommon.java    |  152 +-
 .../model/HystrixConfigurationDefinition.java      |  137 +-
 .../org/apache/camel/model/HystrixDefinition.java  |   27 +-
 .../camel/model/IdempotentConsumerDefinition.java  |   61 +-
 .../org/apache/camel/model/IdentifiedType.java     |    7 +-
 .../org/apache/camel/model/InOnlyDefinition.java   |    4 +-
 .../org/apache/camel/model/InOutDefinition.java    |    4 +-
 .../apache/camel/model/InputTypeDefinition.java    |   28 +-
 .../apache/camel/model/InterceptDefinition.java    |   15 +-
 .../camel/model/InterceptFromDefinition.java       |    4 +-
 .../model/InterceptSendToEndpointDefinition.java   |   37 +-
 .../apache/camel/model/LoadBalanceDefinition.java  |   83 +-
 .../apache/camel/model/LoadBalancerDefinition.java |    3 +-
 .../java/org/apache/camel/model/LogDefinition.java |    5 +-
 .../org/apache/camel/model/LoopDefinition.java     |   28 +-
 .../org/apache/camel/model/MarshalDefinition.java  |   71 +-
 .../main/java/org/apache/camel/model/Model.java    |  125 +-
 .../java/org/apache/camel/model/ModelHelper.java   |  110 +-
 .../apache/camel/model/MulticastDefinition.java    |  188 +-
 .../apache/camel/model/OnCompletionDefinition.java |   75 +-
 .../apache/camel/model/OnExceptionDefinition.java  |  230 ++-
 .../apache/camel/model/OnFallbackDefinition.java   |   10 +-
 .../model/OptimisticLockRetryPolicyDefinition.java |   14 +-
 .../camel/model/OptionalIdentifiedDefinition.java  |   24 +-
 .../apache/camel/model/OtherAttributesAware.java   |    8 +-
 .../apache/camel/model/OutputTypeDefinition.java   |   28 +-
 .../apache/camel/model/PackageScanDefinition.java  |    3 +-
 .../org/apache/camel/model/PipelineDefinition.java |    2 +-
 .../org/apache/camel/model/PolicyDefinition.java   |    9 +-
 .../apache/camel/model/PollEnrichDefinition.java   |   73 +-
 .../org/apache/camel/model/ProcessDefinition.java  |    6 +-
 .../apache/camel/model/ProcessorDefinition.java    | 1986 ++++++++++++--------
 .../camel/model/ProcessorDefinitionHelper.java     |  310 +--
 .../org/apache/camel/model/PropertyDefinition.java |    6 +-
 .../camel/model/RecipientListDefinition.java       |  190 +-
 .../camel/model/RedeliveryPolicyDefinition.java    |  207 +-
 .../apache/camel/model/RemoveHeaderDefinition.java |    8 +-
 .../camel/model/RemoveHeadersDefinition.java       |   40 +-
 .../camel/model/RemovePropertiesDefinition.java    |   40 +-
 .../camel/model/RemovePropertyDefinition.java      |    8 +-
 .../apache/camel/model/ResequenceDefinition.java   |   55 +-
 .../camel/model/RestContextRefDefinition.java      |    2 +-
 .../model/RestContextRefDefinitionHelper.java      |   40 +-
 .../org/apache/camel/model/RollbackDefinition.java |    2 +-
 .../apache/camel/model/RouteBuilderDefinition.java |    9 +-
 .../camel/model/RouteContextRefDefinition.java     |    2 +-
 .../model/RouteContextRefDefinitionHelper.java     |   30 +-
 .../org/apache/camel/model/RouteDefinition.java    |  162 +-
 .../apache/camel/model/RouteDefinitionHelper.java  |  237 +--
 .../java/org/apache/camel/model/RouteFilters.java  |   32 +-
 .../org/apache/camel/model/RoutesDefinition.java   |   36 +-
 .../apache/camel/model/RoutingSlipDefinition.java  |   32 +-
 .../camel/model/SagaActionUriDefinition.java       |    1 -
 .../org/apache/camel/model/SagaDefinition.java     |   45 +-
 .../apache/camel/model/SagaOptionDefinition.java   |    7 +-
 .../org/apache/camel/model/SagaPropagation.java    |    6 +-
 .../org/apache/camel/model/SamplingDefinition.java |   28 +-
 .../org/apache/camel/model/ScriptDefinition.java   |    3 +-
 .../org/apache/camel/model/SendDefinition.java     |    3 +-
 .../camel/model/SetExchangePatternDefinition.java  |    5 +-
 .../apache/camel/model/SetHeaderDefinition.java    |    4 +-
 .../apache/camel/model/SetPropertyDefinition.java  |   15 +-
 .../org/apache/camel/model/SortDefinition.java     |    4 +-
 .../org/apache/camel/model/SplitDefinition.java    |  191 +-
 .../org/apache/camel/model/StepDefinition.java     |    5 +-
 .../org/apache/camel/model/StopDefinition.java     |    2 +-
 .../camel/model/ThreadPoolProfileDefinition.java   |    6 +-
 .../org/apache/camel/model/ThreadsDefinition.java  |   27 +-
 .../org/apache/camel/model/ThrottleDefinition.java |   44 +-
 .../camel/model/ThrowExceptionDefinition.java      |    7 +-
 .../java/org/apache/camel/model/ToDefinition.java  |    1 -
 .../apache/camel/model/ToDynamicDefinition.java    |   33 +-
 .../apache/camel/model/TransactedDefinition.java   |   12 +-
 .../apache/camel/model/TransformDefinition.java    |    3 +-
 .../java/org/apache/camel/model/TryDefinition.java |   21 +-
 .../apache/camel/model/UnmarshalDefinition.java    |   72 +-
 .../org/apache/camel/model/ValidateDefinition.java |   13 +-
 .../org/apache/camel/model/WhenDefinition.java     |    9 +-
 .../model/WhenSkipSendToEndpointDefinition.java    |    9 +-
 .../org/apache/camel/model/WireTapDefinition.java  |  122 +-
 ...klistServiceCallServiceFilterConfiguration.java |   23 +-
 ...ngServiceCallServiceDiscoveryConfiguration.java |   27 +-
 ...edServiceCallServiceDiscoveryConfiguration.java |   24 +-
 ...binedServiceCallServiceFilterConfiguration.java |   17 +-
 ...ulServiceCallServiceDiscoveryConfiguration.java |   14 +-
 ...ustomServiceCallServiceFilterConfiguration.java |    3 +-
 ...nsServiceCallServiceDiscoveryConfiguration.java |    5 +-
 ...cdServiceCallServiceDiscoveryConfiguration.java |   15 +-
 ...althyServiceCallServiceFilterConfiguration.java |    2 +-
 ...esServiceCallServiceDiscoveryConfiguration.java |   97 +-
 ...roughServiceCallServiceFilterConfiguration.java |    2 +-
 .../cloud/ServiceCallConfigurationDefinition.java  |   61 +-
 .../camel/model/cloud/ServiceCallDefinition.java   |   53 +-
 .../cloud/ServiceCallExpressionConfiguration.java  |   55 +-
 .../ServiceCallServiceChooserConfiguration.java    |   36 +-
 .../ServiceCallServiceDiscoveryConfiguration.java  |   46 +-
 .../ServiceCallServiceFilterConfiguration.java     |   36 +-
 ...erviceCallServiceLoadBalancerConfiguration.java |   36 +-
 ...icServiceCallServiceDiscoveryConfiguration.java |   21 +-
 ...erServiceCallServiceDiscoveryConfiguration.java |    9 +-
 .../camel/model/config/BatchResequencerConfig.java |   11 +-
 .../model/config/StreamResequencerConfig.java      |   69 +-
 .../apache/camel/model/config/package-info.java    |    4 +-
 .../camel/model/dataformat/ASN1DataFormat.java     |   20 +-
 .../camel/model/dataformat/Any23DataFormat.java    |  177 +-
 .../apache/camel/model/dataformat/Any23Type.java   |    2 +-
 .../camel/model/dataformat/AvroDataFormat.java     |    3 +-
 .../camel/model/dataformat/BarcodeDataFormat.java  |    7 +-
 .../camel/model/dataformat/Base64DataFormat.java   |    9 +-
 .../camel/model/dataformat/BeanioDataFormat.java   |   29 +-
 .../camel/model/dataformat/BindyDataFormat.java    |   14 +-
 .../camel/model/dataformat/CBORDataFormat.java     |   17 +-
 .../camel/model/dataformat/CryptoDataFormat.java   |   24 +-
 .../camel/model/dataformat/CsvDataFormat.java      |   48 +-
 .../camel/model/dataformat/CustomDataFormat.java   |    9 +-
 .../model/dataformat/DataFormatsDefinition.java    |   67 +-
 .../camel/model/dataformat/FhirDataformat.java     |  149 +-
 .../camel/model/dataformat/FhirJsonDataFormat.java |    3 +-
 .../camel/model/dataformat/FhirXmlDataFormat.java  |    3 +-
 .../camel/model/dataformat/FlatpackDataFormat.java |   29 +-
 .../camel/model/dataformat/GrokDataFormat.java     |   14 +-
 .../camel/model/dataformat/GzipDataFormat.java     |    3 +-
 .../camel/model/dataformat/HL7DataFormat.java      |    8 +-
 .../camel/model/dataformat/IcalDataFormat.java     |    2 +-
 .../model/dataformat/JacksonXMLDataFormat.java     |    8 +-
 .../camel/model/dataformat/JaxbDataFormat.java     |   66 +-
 .../camel/model/dataformat/LZFDataFormat.java      |    5 +-
 .../model/dataformat/MimeMultipartDataFormat.java  |   10 +-
 .../camel/model/dataformat/PGPDataFormat.java      |   83 +-
 .../camel/model/dataformat/ProtobufDataFormat.java |   20 +-
 .../camel/model/dataformat/RssDataFormat.java      |    5 +-
 .../camel/model/dataformat/SoapJaxbDataFormat.java |   81 +-
 .../camel/model/dataformat/SyslogDataFormat.java   |    3 +-
 .../camel/model/dataformat/TarFileDataFormat.java  |   20 +-
 .../camel/model/dataformat/ThriftDataFormat.java   |   22 +-
 .../model/dataformat/TidyMarkupDataFormat.java     |   14 +-
 .../dataformat/UniVocityAbstractDataFormat.java    |   35 +-
 .../model/dataformat/UniVocityCsvDataFormat.java   |   12 +-
 .../dataformat/UniVocityFixedWidthDataFormat.java  |    3 +-
 .../model/dataformat/UniVocityTsvDataFormat.java   |    6 +-
 .../model/dataformat/XMLSecurityDataFormat.java    |  122 +-
 .../camel/model/dataformat/XStreamDataFormat.java  |   76 +-
 .../camel/model/dataformat/XmlRpcDataFormat.java   |    4 +-
 .../camel/model/dataformat/YAMLDataFormat.java     |   12 +-
 .../camel/model/dataformat/YAMLTypeFilterType.java |    3 +-
 .../model/dataformat/ZipDeflaterDataFormat.java    |   12 +-
 .../camel/model/dataformat/ZipFileDataFormat.java  |   22 +-
 .../camel/model/dataformat/package-info.java       |    5 +-
 .../camel/model/language/ConstantExpression.java   |    7 +-
 .../model/language/ExchangePropertyExpression.java |    2 +-
 .../camel/model/language/ExpressionDefinition.java |   32 +-
 .../camel/model/language/HeaderExpression.java     |    2 +-
 .../camel/model/language/JsonPathExpression.java   |   17 +-
 .../camel/model/language/MethodCallExpression.java |   11 +-
 .../camel/model/language/MvelExpression.java       |    2 +-
 .../model/language/NamespaceAwareExpression.java   |   10 +-
 .../apache/camel/model/language/RefExpression.java |    3 +-
 .../camel/model/language/SimpleExpression.java     |    2 +-
 .../camel/model/language/TokenizerExpression.java  |   33 +-
 .../model/language/XMLTokenizerExpression.java     |   14 +-
 .../camel/model/language/XPathExpression.java      |   42 +-
 .../camel/model/language/XQueryExpression.java     |    2 +-
 .../apache/camel/model/language/package-info.java  |    5 +-
 .../FailoverLoadBalancerDefinition.java            |   60 +-
 .../loadbalancer/RandomLoadBalancerDefinition.java |    5 +-
 .../RoundRobinLoadBalancerDefinition.java          |    7 +-
 .../loadbalancer/StickyLoadBalancerDefinition.java |    7 +-
 .../loadbalancer/TopicLoadBalancerDefinition.java  |    5 +-
 .../WeightedLoadBalancerDefinition.java            |   21 +-
 .../camel/model/loadbalancer/package-info.java     |    5 +-
 .../java/org/apache/camel/model/package-info.java  |    5 +-
 .../camel/model/rest/RestBindingDefinition.java    |   41 +-
 .../model/rest/RestConfigurationDefinition.java    |  286 +--
 .../apache/camel/model/rest/RestDefinition.java    |   77 +-
 .../model/rest/RestOperationParamDefinition.java   |   14 +-
 .../RestOperationResponseHeaderDefinition.java     |   15 +-
 .../rest/RestOperationResponseMsgDefinition.java   |    5 +-
 .../org/apache/camel/model/rest/RestParamType.java |    2 +-
 .../camel/model/rest/RestPropertyDefinition.java   |    4 +-
 .../camel/model/rest/RestSecuritiesDefinition.java |    7 +-
 .../camel/model/rest/RestSecurityApiKey.java       |    3 +-
 .../camel/model/rest/RestSecurityDefinition.java   |    3 +-
 .../camel/model/rest/RestSecurityOAuth2.java       |   15 +-
 .../apache/camel/model/rest/RestsDefinition.java   |    6 +-
 .../camel/model/rest/SecurityDefinition.java       |    3 +-
 .../apache/camel/model/rest/VerbDefinition.java    |   70 +-
 .../transformer/CustomTransformerDefinition.java   |    9 +-
 .../DataFormatTransformerDefinition.java           |   75 +-
 .../transformer/EndpointTransformerDefinition.java |   13 +-
 .../model/transformer/TransformerDefinition.java   |   53 +-
 .../model/transformer/TransformersDefinition.java  |    8 +-
 .../camel/model/transformer/package-info.java      |    5 +-
 .../model/validator/CustomValidatorDefinition.java |    9 +-
 .../validator/EndpointValidatorDefinition.java     |   15 +-
 .../validator/PredicateValidatorDefinition.java    |   20 +-
 .../camel/model/validator/ValidatorDefinition.java |   28 +-
 .../model/validator/ValidatorsDefinition.java      |    8 +-
 .../apache/camel/model/validator/package-info.java |    5 +-
 .../org/apache/camel/reifier/AggregateReifier.java |   31 +-
 .../org/apache/camel/reifier/CatchReifier.java     |    6 +-
 .../org/apache/camel/reifier/ChoiceReifier.java    |   21 +-
 .../apache/camel/reifier/ClaimCheckReifier.java    |    4 +-
 .../apache/camel/reifier/DynamicRouterReifier.java |    6 +-
 .../org/apache/camel/reifier/EnrichReifier.java    |    4 +-
 .../apache/camel/reifier/ExpressionReifier.java    |    4 +-
 .../org/apache/camel/reifier/FilterReifier.java    |    1 -
 .../camel/reifier/IdempotentConsumerReifier.java   |    3 +-
 .../apache/camel/reifier/InterceptFromReifier.java |    9 +-
 .../org/apache/camel/reifier/InterceptReifier.java |   10 +-
 .../reifier/InterceptSendToEndpointReifier.java    |   25 +-
 .../apache/camel/reifier/LoadBalanceReifier.java   |   15 +-
 .../java/org/apache/camel/reifier/LogReifier.java  |    5 +-
 .../java/org/apache/camel/reifier/LoopReifier.java |    2 +-
 .../org/apache/camel/reifier/MarshalReifier.java   |    2 +-
 .../org/apache/camel/reifier/MulticastReifier.java |   14 +-
 .../apache/camel/reifier/OnCompletionReifier.java  |   19 +-
 .../apache/camel/reifier/OnExceptionReifier.java   |   17 +-
 .../apache/camel/reifier/OnFallbackReifier.java    |    2 +-
 .../org/apache/camel/reifier/PolicyReifier.java    |    5 +-
 .../apache/camel/reifier/PollEnrichReifier.java    |    6 +-
 .../org/apache/camel/reifier/ProcessReifier.java   |    2 +-
 .../org/apache/camel/reifier/ProcessorReifier.java |  152 +-
 .../apache/camel/reifier/RecipientListReifier.java |   12 +-
 .../apache/camel/reifier/RemoveHeaderReifier.java  |    2 +-
 .../apache/camel/reifier/RemoveHeadersReifier.java |    4 +-
 .../camel/reifier/RemovePropertiesReifier.java     |    4 +-
 .../camel/reifier/RemovePropertyReifier.java       |    2 +-
 .../apache/camel/reifier/ResequenceReifier.java    |   21 +-
 .../org/apache/camel/reifier/RollbackReifier.java  |    2 +-
 .../org/apache/camel/reifier/RouteReifier.java     |  113 +-
 .../apache/camel/reifier/RoutingSlipReifier.java   |    7 +-
 .../java/org/apache/camel/reifier/SagaReifier.java |   20 +-
 .../org/apache/camel/reifier/SamplingReifier.java  |    2 +-
 .../org/apache/camel/reifier/ScriptReifier.java    |    2 +-
 .../java/org/apache/camel/reifier/SendReifier.java |    4 +-
 .../org/apache/camel/reifier/SetBodyReifier.java   |    2 +-
 .../camel/reifier/SetExchangePatternReifier.java   |    2 +-
 .../org/apache/camel/reifier/SetHeaderReifier.java |    2 +-
 .../apache/camel/reifier/SetPropertyReifier.java   |    2 +-
 .../java/org/apache/camel/reifier/SortReifier.java |    2 +-
 .../org/apache/camel/reifier/SplitReifier.java     |   12 +-
 .../java/org/apache/camel/reifier/StopReifier.java |    2 +-
 .../org/apache/camel/reifier/ThreadsReifier.java   |   13 +-
 .../org/apache/camel/reifier/ThrottleReifier.java  |    2 +-
 .../camel/reifier/ThrowExceptionReifier.java       |    2 +-
 .../org/apache/camel/reifier/ToDynamicReifier.java |    8 +-
 .../apache/camel/reifier/TransactedReifier.java    |   34 +-
 .../org/apache/camel/reifier/TransformReifier.java |    2 +-
 .../java/org/apache/camel/reifier/TryReifier.java  |    2 +-
 .../org/apache/camel/reifier/UnmarshalReifier.java |    2 +-
 .../org/apache/camel/reifier/ValidateReifier.java  |    2 +-
 .../java/org/apache/camel/reifier/WhenReifier.java |    2 +-
 .../reifier/WhenSkipSendToEndpointReifier.java     |    5 +-
 .../org/apache/camel/reifier/WireTapReifier.java   |    2 +-
 .../reifier/dataformat/ASN1DataFormatReifier.java  |    2 +-
 .../reifier/dataformat/Any23DataFormatReifier.java |   42 +-
 .../reifier/dataformat/AvroDataFormatReifier.java  |    2 +-
 .../dataformat/BarcodeDataFormatReifier.java       |    2 +-
 .../dataformat/Base64DataFormatReifier.java        |    2 +-
 .../dataformat/BeanioDataFormatReifier.java        |    2 +-
 .../reifier/dataformat/BindyDataFormatReifier.java |    2 +-
 .../reifier/dataformat/CBORDataFormatReifier.java  |    2 +-
 .../dataformat/CryptoDataFormatReifier.java        |    6 +-
 .../reifier/dataformat/CsvDataFormatReifier.java   |    3 +-
 .../dataformat/CustomDataFormatReifier.java        |    2 +-
 .../reifier/dataformat/DataFormatReifier.java      |   27 +-
 .../reifier/dataformat/FhirDataFormatReifier.java  |    2 +-
 .../dataformat/FlatpackDataFormatReifier.java      |    2 +-
 .../reifier/dataformat/GrokDataFormatReifier.java  |    2 +-
 .../reifier/dataformat/GzipDataFormatReifier.java  |    2 +-
 .../reifier/dataformat/HL7DataFormatReifier.java   |    2 +-
 .../reifier/dataformat/IcalDataFormatReifier.java  |    2 +-
 .../dataformat/JacksonXMLDataFormatReifier.java    |    2 +-
 .../reifier/dataformat/JaxbDataFormatReifier.java  |    2 +-
 .../dataformat/JsonApiDataFormatReifier.java       |    2 +-
 .../reifier/dataformat/JsonDataFormatReifier.java  |    2 +-
 .../reifier/dataformat/LZFDataFormatReifier.java   |    2 +-
 .../dataformat/MimeMultipartDataFormatReifier.java |    2 +-
 .../reifier/dataformat/PGPDataFormatReifier.java   |    2 +-
 .../dataformat/ProtobufDataFormatReifier.java      |    2 +-
 .../reifier/dataformat/RssDataFormatReifier.java   |    2 +-
 .../dataformat/SoapJaxbDataFormatReifier.java      |    2 +-
 .../dataformat/SyslogDataFormatReifier.java        |    2 +-
 .../dataformat/TarFileDataFormatReifier.java       |    2 +-
 .../dataformat/ThriftDataFormatReifier.java        |    2 +-
 .../dataformat/TidyMarkupDataFormatReifier.java    |    2 +-
 .../UniVocityAbstractDataFormatReifier.java        |    5 +-
 .../dataformat/XMLSecurityDataFormatReifier.java   |    2 +-
 .../dataformat/XStreamDataFormatReifier.java       |    2 +-
 .../dataformat/XmlRpcDataFormatReifier.java        |    2 +-
 .../reifier/dataformat/YAMLDataFormatReifier.java  |    4 +-
 .../reifier/dataformat/ZipDataFormatReifier.java   |    2 +-
 .../dataformat/ZipFileDataFormatReifier.java       |    2 +-
 .../errorhandler/DeadLetterChannelReifier.java     |   15 +-
 .../errorhandler/DefaultErrorHandlerReifier.java   |   26 +-
 .../errorhandler/ErrorHandlerRefReifier.java       |    2 +-
 .../reifier/errorhandler/ErrorHandlerReifier.java  |   85 +-
 .../errorhandler/NoErrorHandlerReifier.java        |    2 +-
 .../loadbalancer/CustomLoadBalancerReifier.java    |    2 +-
 .../loadbalancer/FailoverLoadBalancerReifier.java  |    2 +-
 .../reifier/loadbalancer/LoadBalancerReifier.java  |    7 +-
 .../loadbalancer/RandomLoadBalancerReifier.java    |    2 +-
 .../RoundRobinLoadBalancerReifier.java             |    2 +-
 .../loadbalancer/StickyLoadBalancerReifier.java    |    2 +-
 .../loadbalancer/TopicLoadBalancerReifier.java     |    2 +-
 .../loadbalancer/WeightedLoadBalancerReifier.java  |    2 +-
 .../camel/reifier/rest/RestBindingReifier.java     |   24 +-
 .../transformer/CustomTransformeReifier.java       |    6 +-
 .../transformer/DataFormatTransformeReifier.java   |    8 +-
 .../transformer/EndpointTransformeReifier.java     |   11 +-
 .../reifier/transformer/TransformerReifier.java    |    2 +-
 .../reifier/validator/CustomValidatorReifier.java  |    2 +-
 .../validator/EndpointValidatorReifier.java        |    9 +-
 .../validator/PredicateValidatorReifier.java       |    6 +-
 .../camel/reifier/validator/ValidatorReifier.java  |    2 +-
 core/camel-core/src/main/schema/constant.json      |    2 +-
 .../java/org/apache/camel/CamelExceptionsTest.java |    6 +-
 .../java/org/apache/camel/ContextTestSupport.java  |   53 +-
 .../java/org/apache/camel/ExchangeTestSupport.java |   10 +-
 .../org/apache/camel/InjectorDefaultsTest.java     |    1 -
 .../java/org/apache/camel/LanguageTestSupport.java |   22 +-
 .../test/java/org/apache/camel/TestSupport.java    |   91 +-
 .../org/apache/camel/TestSupportJmxCleanup.java    |    7 +-
 .../camel/builder/BuilderWithScopesTest.java       |   50 +-
 .../org/apache/camel/builder/ErrorHandlerTest.java |    8 +-
 .../apache/camel/builder/ExceptionBuilderTest.java |   44 +-
 .../ExceptionBuilderWithHandledExceptionTest.java  |   12 +-
 .../apache/camel/builder/ExchangeBuilderTest.java  |   11 +-
 .../camel/builder/ExpressionBuilderTest.java       |   32 +-
 .../builder/ExpressionClauseSupplierTest.java      |    4 +-
 .../camel/builder/ExpressionFunctionTest.java      |   12 +-
 .../camel/builder/FluentProducerTemplateTest.java  |  191 +-
 .../java/org/apache/camel/builder/MyProcessor.java |    2 +-
 .../camel/builder/NotifyBuilderFromRouteTest.java  |   20 +-
 .../apache/camel/builder/NotifyBuilderTest.java    |  216 +--
 .../builder/NotifyBuilderWhenDoneByIndexTest.java  |   11 +-
 .../builder/PredicateBinaryCoerceRouteTest.java    |   18 +-
 .../builder/PredicateBinaryCoerceTypeTest.java     |    1 +
 .../apache/camel/builder/PredicateBuilderTest.java |    1 +
 .../ProxyBuilderSkipJavaLangObjectMethodsTest.java |    4 +-
 .../org/apache/camel/builder/ProxyBuilderTest.java |    4 +-
 .../RouteBuilderAddRoutesOnlyInterceptTest.java    |    2 +-
 .../org/apache/camel/builder/RouteBuilderTest.java |   61 +-
 .../apache/camel/builder/SimpleBuilderTest.java    |    8 +-
 .../camel/builder/ThreadPoolBuilderTest.java       |   17 +-
 .../builder/xml/DefaultNamespaceContextTest.java   |    2 +-
 .../builder/xml/ExtractXPathWithNamespaceTest.java |    6 +-
 .../builder/xml/XPathContentBasedRouterTest.java   |    6 +-
 .../apache/camel/builder/xml/XPathFeatureTest.java |   36 +-
 .../camel/builder/xml/XPathFunctionsTest.java      |   17 +-
 .../XPathHeaderNameResultTypeAndNamespaceTest.java |    7 +-
 .../camel/builder/xml/XPathHeaderNameTest.java     |   25 +-
 .../apache/camel/builder/xml/XPathHeaderTest.java  |   12 +-
 .../builder/xml/XPathNamespaceResultTypeTest.java  |    9 +-
 .../camel/builder/xml/XPathNamespaceTest.java      |    9 +-
 .../builder/xml/XPathNestedNamespaceTest.java      |   10 +-
 .../org/apache/camel/builder/xml/XPathTest.java    |   34 +-
 .../camel/builder/xml/XPathTransformRouteTest.java |    1 -
 .../camel/builder/xml/XPathTransformTest.java      |    8 +-
 .../xml/XPathWithNamespacesFromDomTest.java        |    3 +-
 .../apache/camel/builder/xml/XsltBuilderTest.java  |    3 +-
 .../camel/builder/xml/XsltOutputFileTest.java      |    2 +-
 .../apache/camel/component/bar/BarProducer.java    |    4 +-
 .../camel/component/bar/BarSendDynamicAware.java   |    3 +-
 .../component/bean/BeanByteArrayBodyTest.java      |    7 +-
 ...seMethodWithMatchingTypeAndSkipSettersTest.java |   15 +-
 .../bean/BeanComponentMissingParenthesisTest.java  |   12 +-
 .../camel/component/bean/BeanConcurrentTest.java   |    5 +-
 .../BeanExchangeAsReturnTypeNotAllowedTest.java    |    4 +-
 .../bean/BeanExplicitMethodAmbiguousTest.java      |    6 +-
 .../component/bean/BeanExplicitMethodTest.java     |    4 +-
 .../bean/BeanExpressionConcurrentTest.java         |    5 +-
 .../bean/BeanHandlerMethodPredicateTest.java       |    6 +-
 .../component/bean/BeanHandlerMethodTest.java      |    2 +-
 .../component/bean/BeanImplicitMethodTest.java     |    2 +-
 .../camel/component/bean/BeanInPipelineTest.java   |    5 +-
 .../bean/BeanInfoAMoreComplexOverloadedTest.java   |    2 +-
 .../component/bean/BeanInfoInheritanceTest.java    |    2 -
 .../component/bean/BeanInfoSelectMethodTest.java   |    2 -
 .../camel/component/bean/BeanInvokeAsyncTest.java  |   13 +-
 .../BeanInvokeSimpleOgnlToStringMethodTest.java    |    4 +-
 .../bean/BeanInvokeSingleMethodNoBodyTest.java     |    6 +-
 .../camel/component/bean/BeanInvokeStaticTest.java |    2 +-
 .../camel/component/bean/BeanInvokeTest.java       |    2 +-
 .../bean/BeanInvokeToStringMethodTest.java         |    4 +-
 .../camel/component/bean/BeanLifecycleTest.java    |   14 +-
 .../camel/component/bean/BeanMapPutTest.java       |    3 +-
 .../bean/BeanMethodNameHeaderIssueTest.java        |   11 +-
 .../bean/BeanMethodValueWithCommaTest.java         |   16 +-
 .../bean/BeanMethodValueWithExchangeTest.java      |    8 +-
 ...rameterAndNoMethodWithNoParameterIssueTest.java |    8 +-
 .../bean/BeanMethodWithStringParameterTest.java    |   10 +-
 .../camel/component/bean/BeanNoCacheTest.java      |    4 +-
 .../bean/BeanNoTypeConvertionPossibleTest.java     |    3 +-
 ...BeanNoTypeConvertionPossibleWhenHeaderTest.java |    7 +-
 .../BeanOgnlBodyMethodReturnNullValueTest.java     |    3 +-
 .../component/bean/BeanOgnlPerformanceTest.java    |   17 +-
 .../component/bean/BeanOnglStaticMethodTest.java   |    4 +-
 .../bean/BeanOverloadedCovariantMethodTest.java    |   46 +-
 .../bean/BeanOverloadedMethodFQNTest.java          |   24 +-
 .../BeanOverloadedMethodParameterValueTest.java    |   34 +-
 .../component/bean/BeanOverloadedMethodTest.java   |   45 +-
 .../bean/BeanPackageScopeOutsideTest.java          |    4 +-
 .../camel/component/bean/BeanPackageScopeTest.java |    4 +-
 .../BeanParameterBindingStreamCachingTest.java     |    7 +-
 .../bean/BeanParameterInvalidSyntaxTest.java       |    3 +-
 .../bean/BeanParameterInvalidValueTest.java        |   16 +-
 .../BeanParameterMethodCallThreeBodyOgnlTest.java  |    6 +-
 .../bean/BeanParameterNoBeanBindingTest.java       |    4 +-
 .../bean/BeanParameterThreeBodyOgnlTest.java       |    4 +-
 .../component/bean/BeanParameterValueOgnlTest.java |   13 +-
 .../bean/BeanParameterValueOverloadedTest.java     |    8 +-
 .../component/bean/BeanParameterValueTest.java     |   32 +-
 .../camel/component/bean/BeanPerformanceTest.java  |    3 +-
 .../camel/component/bean/BeanPipelineTest.java     |    4 +-
 .../BeanPrivateClassWithInterfaceMethodTest.java   |   11 +-
 .../component/bean/BeanPropagateHeaderTest.java    |    6 +-
 .../component/bean/BeanProxyNoBindingTest.java     |   13 +-
 .../apache/camel/component/bean/BeanProxyTest.java |   14 +-
 .../component/bean/BeanRefMethodNotFoundTest.java  |    2 +-
 .../camel/component/bean/BeanRefNoCacheTest.java   |    4 +-
 .../camel/component/bean/BeanRegistryBeanTest.java |    1 -
 .../bean/BeanReturnCallableReturnNullTest.java     |    5 +-
 .../component/bean/BeanReturnCallableTest.java     |    5 +-
 .../camel/component/bean/BeanReturnNullTest.java   |    3 +-
 .../bean/BeanWithAnnotationAndExchangeTest.java    |    5 +-
 .../bean/BeanWithAnnotationInheritedTest.java      |   51 +-
 .../BeanWithExchangeExceptionAnnotationTest.java   |   22 +-
 ...ngeExceptionAnnotationWrappedExceptionTest.java |    5 +-
 .../camel/component/bean/BeanWithHeaderTest.java   |    9 +-
 .../bean/BeanWithInputStreamBodyTest.java          |   20 +-
 .../component/bean/BeanWithMethodHeaderTest.java   |   19 +-
 ...thPropertiesAndHeadersAndBodyInjectionTest.java |    6 +-
 ...BeanWithXPathInjectionUsingHeaderValueTest.java |   12 +-
 .../BeanWithXPathInjectionUsingResultTypeTest.java |    3 +-
 .../apache/camel/component/bean/CamelCustomer.java |    1 +
 .../bean/CamelSimpleExpressionPerfTestRunner.java  |    4 +-
 .../ClassComponentInvalidConfigurationTest.java    |   10 +-
 ...entWithPropertiesLookupSetFromEndpointTest.java |    6 +-
 ...ComponentWithPropertiesSetFromEndpointTest.java |    6 +-
 .../bean/CustomParameterMappingStrategyTest.java   |    2 +-
 .../bean/FileBeanParameterBindingTest.java         |   14 +-
 .../bean/MethodCallBeanRefMethodNotFoundTest.java  |    2 +-
 .../bean/MethodCallBeanRefNotFoundTest.java        |    2 +-
 .../bean/MethodCallMissingParenthesisTest.java     |   12 +-
 .../bean/MethodCallRefOrBeanPrefixTest.java        |    8 +-
 .../component/bean/MethodCallStaticMethodTest.java |    6 +-
 .../component/bean/MyAuditServiceProxyTest.java    |    3 +-
 .../camel/component/bean/MyCurrencyBeanTest.java   |    8 +-
 .../apache/camel/component/bean/MyDummyBean.java   |    6 +-
 .../apache/camel/component/bean/MyPrefixBean.java  |    2 +-
 .../org/apache/camel/component/bean/MyService.java |    2 +-
 .../camel/component/bean/MyServiceProxyTest.java   |   15 +-
 .../bean/ProxyReturnFutureExceptionTest.java       |    4 +-
 .../component/bean/ProxyReturnFutureListTest.java  |   18 +-
 .../component/bean/ProxyReturnFutureTest.java      |    4 +-
 .../component/bean/RouteMethodCallStaticTest.java  |    7 +-
 .../SimpleLanguageBeanBodyParenthesisTest.java     |    7 +-
 ...nguageBeanFunctionMethodValueWithCommaTest.java |   34 +-
 ...BeanFunctionMethodValueWithParenthesisTest.java |   34 +-
 .../camel/component/bean/issues/BaseClass.java     |    3 +-
 .../bean/issues/BeanAbstractMethodIssueTest.java   |    3 +-
 .../issues/BeanInfoSingleMethodServiceTest.java    |    4 +-
 .../bean/issues/BeanRouteToDerivedClassTest.java   |   19 +-
 .../bean/issues/BeanThisAdviceWithIssueTest.java   |   18 +-
 .../issues/BeanVsProcessorPerformanceTest.java     |    6 +-
 .../issues/FilterBeanLanguageNonRegistryTest.java  |    4 +-
 .../bean/issues/FilterBeanNonRegistryTest.java     |   10 +-
 .../bean/issues/FilterBeanRegistryTest.java        |   10 +-
 .../component/bean/issues/FilterPojoIssueTest.java |    7 +-
 .../bean/issues/MyMessageToProcessorConverter.java |    2 +-
 .../component/bean/issues/PrivateClasses.java      |    2 +-
 .../bean/issues/TransformerIssueTest.java          |    4 +-
 .../camel/component/bean/pojomessage/Person.java   |    2 +-
 .../pojomessage/PojoProxyHelperOneWayTest.java     |   12 +-
 .../PojoProxyHelperRequestReplyTest.java           |    8 +-
 .../camel/component/browse/BrowseEndpointTest.java |    2 +-
 .../component/browse/BrowseRouteConsumeTest.java   |    2 +-
 .../camel/component/browse/BrowseRouteTest.java    |    2 +-
 .../apache/camel/component/browse/BrowseTest.java  |    2 +-
 .../ControlBusLanguageSimpleStartRouteTest.java    |    3 +-
 .../controlbus/ControlBusRestartRouteTest.java     |    3 +-
 .../controlbus/ControlBusStartRouteAsyncTest.java  |    3 +-
 .../controlbus/ControlBusStartRouteTest.java       |    7 +-
 .../camel/component/dataset/BigDataSetTest.java    |    3 +-
 .../component/dataset/DataSetConsumerTest.java     |   43 +-
 .../component/dataset/DataSetPreloadTest.java      |    2 +-
 .../component/dataset/DataSetProducerTest.java     |   95 +-
 .../camel/component/dataset/DataSetSedaTest.java   |    2 +-
 .../camel/component/dataset/DataSetTest.java       |    3 +-
 .../component/dataset/DataSetTestAnyOrderTest.java |    3 +-
 .../component/dataset/DataSetTestEndpointTest.java |    3 +-
 .../dataset/DataSetTestFileSplitTest.java          |    3 +-
 .../component/dataset/DataSetTestFileTest.java     |    3 +-
 .../component/dataset/DataSetTestSedaTest.java     |    3 +-
 .../component/dataset/FileDataSetConsumerTest.java |    7 +-
 .../dataset/FileDataSetConsumerWithSplitTest.java  |    7 +-
 .../component/dataset/FileDataSetProducerTest.java |    3 +-
 .../dataset/FileDataSetProducerWithSplitTest.java  |    3 +-
 .../component/dataset/ListDataSetConsumerTest.java |    7 +-
 .../component/dataset/ListDataSetProducerTest.java |    3 +-
 .../component/dataset/RoutePerformanceTest.java    |   11 +-
 .../component/direct/DirectNoConsumerTest.java     |    2 +-
 .../direct/DirectNoMultipleConsumersTest.java      |    2 +-
 .../direct/DirectProducerBlockingTest.java         |    3 +-
 .../camel/component/direct/DirectQueueTest.java    |    2 +-
 .../direct/DirectShouldUseSameThreadTest.java      |    2 +-
 .../SendToNonExistingDirectEndpointTest.java       |    6 +-
 ...SendingToAlotOfDifferentDirectEndpointTest.java |    3 +-
 .../direct/TwoCamelContextDirectEndpointTest.java  |    1 +
 .../directvm/DirectVmConsumerExpressionTest.java   |   16 +-
 .../directvm/DirectVmHeaderFilterStrategyTest.java |   34 +-
 ...DirectVmNoPropertyPropagationComponentTest.java |   21 +-
 .../DirectVmNoPropertyPropagationTest.java         |   30 +-
 .../directvm/DirectVmProducerBlockingTest.java     |    3 +-
 .../directvm/DirectVmShouldUseSameThreadTest.java  |    2 +-
 .../DirectVmTwoCamelContextAdviceWithTest.java     |   10 +-
 ...rectVmTwoCamelContextDuplicateConsumerTest.java |   14 +-
 .../directvm/DirectVmTwoCamelContextTest.java      |   12 +-
 .../extension/verifier/ComponentVerifierTest.java  |    5 +-
 .../file/AntPathMatcherGenericFileFilterTest.java  |   29 +-
 .../camel/component/file/BeanToFileTest.java       |    5 +-
 .../file/ConsumerTemplateFileShutdownTest.java     |    8 +-
 .../component/file/DirectoryCreateIssueTest.java   |   12 +-
 .../file/FileAbsoluteAndRelativeConsumerTest.java  |    1 +
 .../component/file/FileAbsolutePathIssueTest.java  |    1 +
 .../file/FileBatchConsumerMemoryLeakTest.java      |   36 +-
 .../file/FileBeginFailureOneTimeTest.java          |   25 +-
 .../component/file/FileBrowsableEndpointTest.java  |    6 +-
 .../FileConcurrentWriteAppendSameFileTest.java     |   12 +-
 .../camel/component/file/FileConfigureTest.java    |   28 +-
 .../FileConsumeAlterFileNameHeaderIssueTest.java   |   25 +-
 .../file/FileConsumeBackoffMultiplierTest.java     |    4 +-
 .../component/file/FileConsumeCharsetTest.java     |    5 +-
 .../file/FileConsumeDoneFileIssueTest.java         |   24 +-
 ...eConsumeDynamicDoneFileNameWithTwoDotsTest.java |    4 +-
 .../file/FileConsumeFilesAndDeleteTest.java        |    4 +-
 .../file/FileConsumeMaxMessagesPerPollTest.java    |    7 +-
 .../file/FileConsumeMoveRelativeNameTest.java      |    7 +-
 .../file/FileConsumeMultipleDirectoriesTest.java   |   15 +-
 .../file/FileConsumeNoopIdempotentAutoTest.java    |    2 +-
 .../FileConsumeNoopIdempotentDisabledTest.java     |    1 +
 .../file/FileConsumeNoopIdempotentEnabledTest.java |    3 +-
 .../FileConsumeNotEagerMaxMessagesPerPollTest.java |    9 +-
 .../file/FileConsumePollEnrichFileTest.java        |    9 +-
 ...ileConsumePollEnrichFileUsingProcessorTest.java |   51 +-
 .../file/FileConsumeRootDirManualTest.java         |    4 +-
 .../file/FileConsumeRunLoggingLevelTest.java       |    4 +-
 ...ileConsumeSimpleAbsoluteMoveToAbsoluteTest.java |    6 +-
 ...ileConsumeSimpleAbsoluteMoveToRelativeTest.java |    6 +-
 ...ileConsumeSimpleRelativeMoveToAbsoluteTest.java |    6 +-
 ...ileConsumeSimpleRelativeMoveToRelativeTest.java |    4 +-
 .../file/FileConsumeSingleDirectoryOnlyTest.java   |    4 +-
 .../component/file/FileConsumeTemplateTest.java    |    1 +
 .../file/FileConsumeWithDollarInPathTest.java      |    1 +
 .../FileConsumerAbsolutePathDefaultMoveTest.java   |    3 +-
 .../file/FileConsumerAbsolutePathTest.java         |    3 +-
 ...leConsumerAbsolutePathWithAbsoluteMoveTest.java |    3 +-
 ...leConsumerAbsolutePathWithRelativeMoveTest.java |    3 +-
 ...ileConsumerAbsoluteRootPathDefaultMoveTest.java |    5 +-
 .../file/FileConsumerAutoCreateDirectoryTest.java  |    1 -
 .../component/file/FileConsumerBatchTest.java      |    6 +-
 ...BeginAndCommitExpressionRenameStrategyTest.java |   24 +-
 ...leConsumerBeginAndCommitRenameStrategyTest.java |   21 +-
 ...eConsumerBeginExpressionRenameStrategyTest.java |   21 +-
 .../file/FileConsumerBeginRenameStrategyTest.java  |   21 +-
 ...ileConsumerBridgeRouteExceptionHandlerTest.java |   17 +-
 ...nsumerCommitRenameAbsolutePathStrategyTest.java |    6 +-
 .../file/FileConsumerCommitRenameStrategyTest.java |    4 +-
 .../file/FileConsumerConsumedFileNameTest.java     |    1 +
 .../FileConsumerCustomExceptionHandlerTest.java    |   36 +-
 .../file/FileConsumerCustomSchedulerTest.java      |    4 +-
 .../file/FileConsumerDeleteAndFailureTest.java     |   19 +-
 .../file/FileConsumerDeleteAndMoveFailedTest.java  |   16 +-
 .../file/FileConsumerDirectoryFilterTest.java      |   20 +-
 ...erDirectoryMustExistBridgeErrorHandlerTest.java |    4 +-
 .../file/FileConsumerDirectoryNotMatchedTest.java  |   13 +-
 .../file/FileConsumerExcludeNameTest.java          |    3 +-
 .../file/FileConsumerExtendedAttributesTest.java   |   18 +-
 .../file/FileConsumerFailureHandledTest.java       |   16 +-
 .../file/FileConsumerFileExpressionTest.java       |   15 +-
 ...leConsumerFileExpressionThrowExceptionTest.java |    9 +-
 .../component/file/FileConsumerFileFilterTest.java |   12 +-
 .../file/FileConsumerFilterDirectoryTest.java      |   12 +-
 .../component/file/FileConsumerFilterFileTest.java |    5 +-
 ...FileConsumerIdempotentKeyChangedIssue2Test.java |   11 +-
 .../FileConsumerIdempotentKeyChangedIssueTest.java |    7 +-
 .../FileConsumerIdempotentKeyNameAndSizeTest.java  |    5 +-
 .../file/FileConsumerIdempotentKeyTest.java        |    6 +-
 ...leConsumerIdempotentOnExceptionHandledTest.java |    8 +-
 .../file/FileConsumerIdempotentRefTest.java        |   13 +-
 .../component/file/FileConsumerIdempotentTest.java |   11 +-
 .../file/FileConsumerIdleMessageTest.java          |    8 +-
 .../FileConsumerIncludeAndExcludeNameTest.java     |    6 +-
 .../file/FileConsumerIncludeNameTest.java          |    6 +-
 .../file/FileConsumerInterceptEmptyFileTest.java   |    6 +-
 .../file/FileConsumerMoveAndMoveFailureTest.java   |   18 +-
 .../file/FileConsumerMoveExpressionTest.java       |   18 +-
 .../FileConsumerMoveFailureOnCompletionTest.java   |    4 +-
 .../file/FileConsumerMoveFailureTest.java          |   16 +-
 .../camel/component/file/FileConsumerNoopTest.java |    4 +-
 .../file/FileConsumerPathWithAmpersandTest.java    |    1 +
 .../file/FileConsumerPollStrategyNotBeginTest.java |    3 +-
 ...FileConsumerPollStrategyPolledMessagesTest.java |    6 +-
 ...umerPollStrategyRollbackThrowExceptionTest.java |    3 +-
 ...FileConsumerPollStrategyStopOnRollbackTest.java |    4 +-
 .../file/FileConsumerPollStrategyTest.java         |    3 +-
 ...rPreMoveCopyAndDeleteOnRenameFailFalseTest.java |    3 +-
 .../file/FileConsumerPreMoveDeleteTest.java        |    5 +-
 .../file/FileConsumerPreMoveIssueTest.java         |    6 +-
 .../file/FileConsumerPreMoveLastModifiedTest.java  |    7 +-
 .../file/FileConsumerPreMoveNoopTest.java          |    5 +-
 .../component/file/FileConsumerPreMoveTest.java    |    5 +-
 ...ileConsumerPreMoveWithProbeContentTypeTest.java |    4 +-
 .../file/FileConsumerProducerRouteTest.java        |    3 +-
 .../file/FileConsumerRelativeFileNameTest.java     |   11 +-
 .../file/FileConsumerRestartNotLeakThreadTest.java |    4 +-
 .../file/FileConsumerSharedThreadPollTest.java     |   22 +-
 .../file/FileConsumerSkipDotFilesTest.java         |   10 +-
 .../file/FileConsumerSpringSchedulerTest.java      |    4 +-
 .../file/FileConsumerSuspendAndResumeTest.java     |    8 +-
 .../component/file/FileConsumerSuspendTest.java    |    6 +-
 .../component/file/FileConsumerTemplateTest.java   |    3 +-
 .../FileConsumerThreadsInProgressIssueTest.java    |    7 +-
 .../component/file/FileContentBasedRouterTest.java |   17 +-
 .../component/file/FileConvertBodyToUTF8Test.java  |    5 +-
 .../file/FileEagerDeleteTargetFileTest.java        |   10 +-
 .../file/FileExclusiveReadLockCopyTest.java        |    2 +-
 .../file/FileExclusiveReadManuelTest.java          |    8 +-
 .../file/FileExclusiveReadNoneStrategyTest.java    |    4 +-
 .../file/FileHeaderFileNameProducedTest.java       |   16 +-
 .../file/FileIdempotentReadSameFileAgainTest.java  |    5 +-
 .../component/file/FileKeepLastModifiedTest.java   |   13 +-
 .../camel/component/file/FileLanguageCBRTest.java  |    9 +-
 .../camel/component/file/FileMEPInOutTest.java     |    7 +-
 .../file/FileMarkerFileDeleteOldLockFilesTest.java |    4 +-
 ...eMarkerFileRecursiveDeleteOldLockFilesTest.java |    7 +-
 ...erFileRecursiveDoNotDeleteOldLockFilesTest.java |    5 +-
 ...cursiveFilterDeleteOldLockFilesIncludeTest.java |    5 +-
 ...rFileRecursiveFilterDeleteOldLockFilesTest.java |    7 +-
 .../file/FileMoveAndMoveFailedIssueTest.java       |    7 +-
 .../FileMoveErrorOnExceptionNotHandledTest.java    |   10 +-
 .../component/file/FileMulticastDeleteTest.java    |   19 +-
 .../camel/component/file/FileNoOpLockFileTest.java |   13 +-
 .../component/file/FilePollEnrichNoWaitTest.java   |   13 +-
 .../camel/component/file/FilePollEnrichTest.java   |   13 +-
 .../component/file/FilePollingConsumerTest.java    |   12 +-
 .../component/file/FileProduceAppendCharsTest.java |    6 +-
 .../component/file/FileProduceAppendTest.java      |    7 +-
 .../file/FileProduceOverruleExpressionTest.java    |    6 +-
 .../file/FileProduceOverruleOnlyOnceTest.java      |    7 +-
 .../component/file/FileProduceOverruleTest.java    |    6 +-
 .../file/FileProduceTempFileNameTest.java          |    9 +-
 .../component/file/FileProduceTempPrefixTest.java  |    9 +-
 ...ProducerAllowNullBodyFileAlreadyExistsTest.java |   23 +-
 .../file/FileProducerAllowNullBodyTest.java        |   12 +-
 .../file/FileProducerCharsetUTFOptimizedTest.java  |    1 +
 .../FileProducerCharsetUTFtoISOConfiguredTest.java |    4 +-
 ...leProducerCharsetUTFtoISOConvertBodyToTest.java |    5 +-
 .../file/FileProducerCharsetUTFtoISOTest.java      |    4 +-
 .../file/FileProducerCharsetUTFtoUTFTest.java      |    4 +-
 .../file/FileProducerChmodOptionTest.java          |   21 +-
 .../file/FileProducerDirectoryChmodOptionTest.java |   13 +-
 .../component/file/FileProducerExpressionTest.java |   10 +-
 .../file/FileProducerFileBodyGetsMovedTest.java    |    5 +-
 ...ileProducerFileExistAppendNoFileBeforeTest.java |    6 +-
 .../file/FileProducerFileExistAppendTest.java      |    6 +-
 .../file/FileProducerFileExistFailTest.java        |    3 +-
 .../file/FileProducerFileExistIgnoreTest.java      |    3 +-
 ...eProducerFileExistOverrideNoFileBeforeTest.java |    3 +-
 .../file/FileProducerFileExistOverrideTest.java    |    4 +-
 .../file/FileProducerFileExistTryRenameTest.java   |    6 +-
 .../file/FileProducerFilenameConstantTest.java     |    1 +
 .../FileProducerJailStartingDirectoryTest.java     |    5 +-
 .../file/FileProducerMoveExistingStrategyTest.java |   40 +-
 .../file/FileProducerMoveExistingTest.java         |   37 +-
 .../file/FileProducerNoForcedWritesTest.java       |    7 +-
 .../file/FileProducerRenameUsingCopyTest.java      |    3 +-
 .../component/file/FileProducerStreamTest.java     |    4 +-
 .../file/FileProducerTempFileExistsIssueTest.java  |    1 +
 .../file/FileProducerToDMoveExistingTest.java      |    4 +-
 .../component/file/FileRecursiveDepthTest.java     |   13 +-
 .../component/file/FileRecursiveNoopTest.java      |    5 +-
 .../file/FileRenameFileOnCommitIssueTest.java      |   11 +-
 .../FileRenameReadLockMustUseMarkerFileTest.java   |   24 +-
 .../file/FileRouteOnDosWithNoVolTest.java          |   11 +-
 .../component/file/FileSortByExpressionTest.java   |   15 +-
 .../file/FileSortByIgnoreCaseExpressionTest.java   |   21 +-
 .../file/FileSortByNestedExpressionTest.java       |   21 +-
 .../camel/component/file/FileSorterRefTest.java    |   14 +-
 .../camel/component/file/FileSplitInSplitTest.java |   32 +-
 .../component/file/FileSplitXPathCharsetTest.java  |   12 +-
 .../component/file/FileToFileNioLowBufferTest.java |    4 +-
 .../component/file/FileToFileWithFlattenTest.java  |    7 +-
 .../camel/component/file/FileURLDecodingTest.java  |   31 +-
 .../file/FilerConsumerDoneFileNameDeleteTest.java  |    4 +-
 .../file/FilerConsumerDoneFileNamePrefixTest.java  |    4 +-
 .../FilerConsumerDoneFileNameSimplePrefixTest.java |    7 +-
 .../file/FilerConsumerDoneFileNameSuffixTest.java  |    4 +-
 .../file/FilerConsumerDoneFileNameTest.java        |    4 +-
 .../file/FilerConsumerDoneFileNoopTest.java        |    4 +-
 .../file/FilerConsumerDualDoneFileNameTest.java    |    1 +
 .../FilerConsumerMoveFailedDoneFileNameTest.java   |    5 +-
 .../file/FilerConsumerPreMoveDoneFileNameTest.java |    4 +-
 .../file/FilerConsumerRetryDoneFileNameTest.java   |   28 +-
 .../FilerConsumerShouldSkipDoneFilePrefixTest.java |    8 +-
 .../FilerConsumerShouldSkipDoneFileSuffixTest.java |    8 +-
 .../file/FilerConsumerShouldSkipDoneFileTest.java  |    8 +-
 .../component/file/FilerProducerAbsoluteTest.java  |    3 +-
 .../file/FilerProducerDoneFileNameRouteTest.java   |    5 +-
 .../component/file/FilerProducerFileNamesTest.java |    4 +-
 .../FromFileDoNotDeleteFileIfProcessFailsTest.java |    8 +-
 .../FromFileDoNotMoveFileIfProcessFailsTest.java   |   10 +-
 .../file/FromFileMoveDoneCustomHeaderTest.java     |    5 +-
 .../file/FromFileMoveFileIfProcessFailsTest.java   |   16 +-
 .../file/FromFileMulticastToFilesTest.java         |   35 +-
 .../file/FromFilePollThirdTimeOkTest.java          |   26 +-
 .../component/file/GenericFileConverterTest.java   |   38 +-
 .../component/file/GenericFileMessageTest.java     |    4 +-
 ...kerFileExclusiveReadLockStrategyUnlockTest.java |    4 +-
 .../camel/component/file/NewFileConsumeTest.java   |    3 +-
 .../camel/component/file/NewFileConsumerTest.java  |    1 +
 .../camel/component/file/ToFileRouteTest.java      |    6 +-
 .../camel/component/file/XPathToFileTest.java      |   11 +-
 .../FileLockClusteredRoutePolicyFactoryTest.java   |    5 +-
 .../cluster/FileLockClusteredRoutePolicyTest.java  |    5 +-
 .../FileChangedReadLockLoggingLevelTest.java       |    6 +-
 .../FileChangedReadLockMarkerFileFalseTest.java    |    4 +-
 .../FileChangedReadLockMinAgeShortCircuitTest.java |    3 +-
 .../strategy/FileChangedReadLockMinAgeTest.java    |    3 +-
 .../file/strategy/FileChangedReadLockTest.java     |    4 +-
 .../strategy/FileChangedReadLockTimeoutTest.java   |    6 +-
 .../FileChangedReadLockZeroTimeoutTest.java        |   17 +-
 .../FileChangedZeroLengthReadLockTest.java         |    5 +-
 .../FileIdempotentChangedReadLockTest.java         |    3 +-
 .../FileIdempotentReadLockDelayedAsyncTest.java    |    7 +-
 .../FileIdempotentReadLockDelayedTest.java         |    7 +-
 .../file/strategy/FileIdempotentReadLockTest.java  |   22 +-
 .../strategy/FileIdempotentRenameReadLockTest.java |    3 +-
 .../GenericFileDeleteProcessStrategyTest.java      |    5 +-
 .../MarkerFileExclusiveReadLockStrategyTest.java   |   16 +-
 .../file/stress/FileAsyncStressFileDropper.java    |    9 +-
 .../file/stress/FileAsyncStressManually.java       |   21 +-
 .../FileAsyncStressReadLockLockFileTest.java       |   23 +-
 .../stress/FileAsyncStressReadLockNoneTest.java    |   23 +-
 .../stress/FileAsyncStressReadLockRenameTest.java  |   23 +-
 .../component/file/stress/FileAsyncStressTest.java |   24 +-
 .../file/stress/FileConsumerPollManyFilesTest.java |    5 +-
 .../FileProducerAppendManyMessagesFastTest.java    |   54 +-
 .../stress/FileProducerAppendManyMessagesTest.java |    9 +-
 .../language/LanguageCacheScriptTest.java          |    4 +-
 .../LanguageLoadScriptFromClasspathHeaderTest.java |    7 +-
 .../LanguageLoadScriptFromClasspathTest.java       |    3 +-
 .../LanguageLoadScriptFromFileUpdateTest.java      |    7 +-
 .../language/LanguageNoCacheScriptTest.java        |    4 +-
 ...guageResourceLoadConstantFromClasspathTest.java |    4 +-
 ...anguageResourceLoadScriptFromClasspathTest.java |    3 +-
 .../language/LanguageRouteNoTransformTest.java     |    4 +-
 .../camel/component/log/ConsumingAppender.java     |   19 +-
 .../log/DefaultExchangeFormatterTest.java          |    9 +-
 .../component/log/LogBodyWithNewLineTest.java      |   18 +-
 .../component/log/LogCustomFormatterTest.java      |   39 +-
 .../camel/component/log/LogCustomLoggerTest.java   |   33 +-
 .../component/log/LogEndpointOptionsTest.java      |    3 +-
 .../camel/component/log/LogEndpointTest.java       |    7 +-
 .../camel/component/log/LogInputStreamTest.java    |   16 +-
 .../apache/camel/component/log/LogMaskTest.java    |    1 +
 .../camel/component/log/ThroughputLoggerTest.java  |    6 +-
 .../camel/component/mock/MockAsBeanTest.java       |   12 +-
 .../camel/component/mock/MockEndpointTest.java     |   62 +-
 .../component/mock/MockEndpointTimeClauseTest.java |    2 +-
 .../mock/MockEndpointWithParametersTest.java       |    3 +-
 .../component/mock/MockStreamCachingTest.java      |    4 +-
 .../apache/camel/component/mock/MockXpathTest.java |    6 +-
 .../ComponentResolvePropertyPlaceholdersTest.java  |    5 +-
 .../OptionalPropertiesDslInvalidSyntaxTest.java    |    8 +-
 .../properties/OptionalPropertiesDslTest.java      |    9 +-
 ...opertiesComponentConcatenatePropertiesTest.java |    1 +
 .../PropertiesComponentDefaultFunctionsTest.java   |    9 +-
 .../PropertiesComponentDisableDefaultsTest.java    |    6 +-
 ...pertiesComponentEIPChoiceConvertBodyToTest.java |   10 +-
 .../PropertiesComponentEIPChoiceSimpleTest.java    |    9 +-
 .../PropertiesComponentEIPConvertBodyToTest.java   |    6 +-
 .../PropertiesComponentEIPRoutingSlipTest.java     |    5 +-
 .../PropertiesComponentEncodingTest.java           |    4 +-
 .../PropertiesComponentEndpointMandatoryTest.java  |    6 +-
 .../PropertiesComponentEndpointTest.java           |    6 +-
 .../PropertiesComponentFunctionTest.java           |    5 +-
 .../PropertiesComponentGetOrElseTest.java          |    7 +-
 .../PropertiesComponentInitialPropertiesTest.java  |    7 +-
 .../PropertiesComponentInterceptFromTest.java      |   11 +-
 ...ponentLoadPropertiesFromFileTrimValuesTest.java |    3 +-
 .../PropertiesComponentNestPropertiesTest.java     |   17 +-
 ...ertiesComponentOnExceptionDelayPatternTest.java |   13 +-
 .../PropertiesComponentOnExceptionTest.java        |   12 +-
 ...ropertiesComponentOnlyUseDefaultValuesTest.java |   12 +-
 .../PropertiesComponentOverridePropertiesTest.java |    6 +-
 .../PropertiesComponentPropertiesSourceTest.java   |   10 +-
 .../properties/PropertiesComponentRefTest.java     |    4 +-
 .../PropertiesComponentRegistryTest.java           |    4 +-
 .../PropertiesComponentServiceHostPortTest.java    |   10 +-
 .../PropertiesComponentServiceHostTest.java        |   10 +-
 .../PropertiesComponentServicePortTest.java        |   10 +-
 .../properties/PropertiesComponentServiceTest.java |   10 +-
 .../PropertiesComponentSetHeaderSimpleTest.java    |    8 +-
 .../PropertiesComponentSimpleLanguageTest.java     |    8 +-
 ...rtiesComponentSomethingElseBoundToJndiTest.java |    3 +-
 .../properties/PropertiesComponentTest.java        |   13 +-
 .../PropertiesEnvironmentVariableOverrideTest.java |    6 +-
 .../properties/PropertiesRouteFromTest.java        |    5 +-
 .../properties/PropertiesRouteIdTest.java          |    3 +-
 .../properties/XPathPropertyPlaceholderTest.java   |   21 +-
 .../camel/component/ref/RefFileEndpointTest.java   |    2 +-
 .../component/rest/DummyRestConsumerFactory.java   |   12 +-
 .../component/rest/DummyRestProcessorFactory.java  |    5 +-
 .../component/rest/FromRestAdviceWithTest.java     |    9 +-
 .../camel/component/rest/FromRestApiTest.java      |    3 +-
 .../component/rest/FromRestConfigurationTest.java  |   13 +-
 .../component/rest/FromRestDefaultValueTest.java   |   10 +-
 .../component/rest/FromRestDuplicateTest.java      |   13 +-
 .../rest/FromRestExplicitComponentTest.java        |   35 +-
 .../component/rest/FromRestGetContentTypeTest.java |    3 +-
 .../rest/FromRestGetCorsAllowCredentialsTest.java  |   19 +-
 .../component/rest/FromRestGetCorsCustomTest.java  |   16 +-
 .../camel/component/rest/FromRestGetCorsTest.java  |   16 +-
 .../rest/FromRestGetEmbeddedRouteTest.java         |   18 +-
 .../component/rest/FromRestGetEndPathTest.java     |   16 +-
 .../rest/FromRestGetHttpErrorCodeTest.java         |   11 +-
 .../component/rest/FromRestGetInterceptTest.java   |    6 +-
 .../component/rest/FromRestGetOnExceptionTest.java |    5 +-
 .../component/rest/FromRestGetPolicyTest.java      |    3 +-
 .../rest/FromRestGetRouteOnExceptionTest.java      |    7 +-
 .../camel/component/rest/FromRestGetTest.java      |   38 +-
 .../rest/FromRestIdAndDescriptionTest.java         |   29 +-
 .../component/rest/FromRestUriPrefixTest.java      |   17 +-
 .../camel/component/rest/RestComponentTest.java    |    6 +-
 .../rest/RestComponentVerifierExtensionTest.java   |   45 +-
 .../component/rest/RestComponentVerifierTest.java  |   45 +-
 .../camel/component/rest/RestEndpointTest.java     |   19 +-
 .../rest/RestProducerBindingProcessorTest.java     |   12 +-
 .../camel/component/rest/RestProducerTest.java     |   12 +-
 .../camel/component/saga/SagaComponentTest.java    |   32 +-
 .../scheduler/SchedulerNoPolledMessagesTest.java   |   18 +-
 .../component/scheduler/SchedulerRouteTest.java    |    4 +-
 .../TwoSchedulerConcurrentTasksOneRouteTest.java   |   24 +-
 .../scheduler/TwoSchedulerConcurrentTasksTest.java |    8 +-
 .../component/scheduler/TwoSchedulerTest.java      |    6 +-
 .../seda/DirectRequestReplyAndSedaInOnlyTest.java  |    5 +-
 .../seda/FileSedaShutdownCompleteAllTasksTest.java |   35 +-
 ...meSedaQueueMultipleConsumersDifferenceTest.java |    3 +-
 .../seda/SameSedaQueueSizeAndNoSizeTest.java       |    7 +-
 .../component/seda/SedaAsyncProducerTest.java      |   25 +-
 .../SedaBlockWhenFullInvalidConfigurationTest.java |    3 +-
 .../component/seda/SedaBlockWhenFullTest.java      |   11 +-
 .../seda/SedaComponentReferenceEndpointTest.java   |    4 +-
 .../seda/SedaConcurrentConsumersNPEIssueTest.java  |    8 +-
 .../camel/component/seda/SedaConcurrentTest.java   |   11 +-
 .../camel/component/seda/SedaConfigureTest.java    |    1 -
 .../seda/SedaConsumerSuspendResumeTest.java        |   16 +-
 .../seda/SedaDefaultBlockWhenFullTest.java         |    6 +-
 .../camel/component/seda/SedaEndpointTest.java     |   22 +-
 .../apache/camel/component/seda/SedaErrorTest.java |    4 +-
 .../camel/component/seda/SedaFromRouteIdTest.java  |   10 +-
 .../component/seda/SedaInOnlyChainedTest.java      |    2 +-
 .../component/seda/SedaInOutBigChainedTest.java    |    2 +-
 .../seda/SedaInOutChainedTimeoutTest.java          |   13 +-
 .../seda/SedaInOutChainedWithOnCompletionTest.java |    5 +-
 .../apache/camel/component/seda/SedaInOutTest.java |    2 +-
 .../SedaInOutWithErrorDeadLetterChannelTest.java   |    6 +-
 .../component/seda/SedaInOutWithErrorTest.java     |    6 +-
 .../component/seda/SedaMultipleConsumersTest.java  |   21 +-
 .../camel/component/seda/SedaNoConsumerTest.java   |    4 -
 .../component/seda/SedaPurgeWhenStoppingTest.java  |   16 +-
 .../apache/camel/component/seda/SedaQueueTest.java |    4 +-
 .../seda/SedaRemoveRouteThenAddAgainTest.java      |    2 +-
 .../apache/camel/component/seda/SedaRouteTest.java |    3 +-
 .../seda/SedaShouldNotUseSameThreadTest.java       |    2 +-
 .../camel/component/seda/SedaSimpleSizeTest.java   |    4 +-
 .../seda/SedaSuspendConsumerStopRouteTest.java     |    3 +-
 .../component/seda/SedaTimeoutDisabledTest.java    |    2 +-
 .../camel/component/seda/SedaTimeoutTest.java      |    6 +-
 .../camel/component/seda/SedaUnitOfWorkTest.java   |   46 +-
 .../seda/SedaWaitForTaskAsPropertyTest.java        |    5 +-
 .../SedaWaitForTaskCompleteOnCompletionTest.java   |   55 +-
 .../seda/SedaWaitForTaskCompleteTest.java          |    5 +-
 .../seda/SedaWaitForTaskIfReplyExpectedTest.java   |    5 +-
 .../seda/SedaWaitForTaskNewerOnCompletionTest.java |   56 +-
 .../component/seda/SedaWaitForTaskNewerTest.java   |    2 +-
 .../camel/component/seda/TracingWithDelayTest.java |   14 +-
 .../camel/component/stub/StubConsumerTest.java     |   15 +-
 .../camel/component/stub/StubInOnlyTest.java       |    4 +-
 .../apache/camel/component/stub/StubInOutTest.java |    4 +-
 .../org/apache/camel/component/stub/StubTest.java  |   12 +-
 .../camel/component/timer/TimerAsyncTest.java      |   17 +-
 .../camel/component/timer/TimerDelayTest.java      |    2 +-
 .../component/timer/TimerGracefulShutdownTest.java |    6 +-
 .../timer/TimerMultipleConsumerStopRouteTest.java  |    2 +-
 .../component/timer/TimerMultipleConsumerTest.java |    2 +-
 .../camel/component/timer/TimerNameTest.java       |    3 +-
 .../component/timer/TimerNegativeDelayTest.java    |    4 +-
 .../timer/TimerNegativeNoRepeatCountDelayTest.java |    2 +-
 .../timer/TimerReferenceConfigurationTest.java     |   26 +-
 .../component/timer/TimerRepeatCountTest.java      |    3 +-
 .../camel/component/timer/TimerRestartTest.java    |    2 +-
 .../camel/component/timer/TimerRouteTest.java      |    4 +-
 .../timer/TimerSuspendCamelContextTest.java        |    2 +-
 .../validator/CustomSchemaFactoryFeatureTest.java  |    5 +-
 .../validator/FileValidatorRouteTest.java          |   21 +-
 .../component/validator/ValidatorBeanCallTest.java |   15 +-
 .../validator/ValidatorDtdAccessAbstractTest.java  |   27 +-
 .../validator/ValidatorDtdAccessOffTest.java       |   10 +-
 .../validator/ValidatorDtdAccessOnTest.java        |   23 +-
 .../validator/ValidatorIllegalImportTest.java      |   40 +-
 .../ValidatorIncludeEncodingRouteTest.java         |   23 +-
 .../ValidatorIncludeRelativeRouteTest.java         |   32 +-
 .../validator/ValidatorIncludeRouteTest.java       |   62 +-
 .../validator/ValidatorLazyStartProducerTest.java  |    8 +-
 .../ValidatorResourceResolverFactoryTest.java      |    1 -
 .../component/validator/ValidatorRootPathTest.java |   13 +-
 .../component/validator/ValidatorRouteTest.java    |   71 +-
 .../ValidatorWithResourceResolverRouteTest.java    |   25 +-
 .../camel/component/vm/AbstractVmTestSupport.java  |   12 +-
 .../component/vm/SameVmQueueSizeAndNoSizeTest.java |    7 +-
 .../apache/camel/component/vm/VMSplitterTest.java  |    8 +-
 .../vm/VmComponentReferenceEndpointTest.java       |    4 +-
 .../component/vm/VmConcurrentConsumersTest.java    |    4 +-
 ...mDifferentOptionsOnConsumerAndProducerTest.java |   13 +-
 .../camel/component/vm/VmInOnlyChainedTest.java    |    4 +-
 .../apache/camel/component/vm/VmInOnlyTest.java    |    4 +-
 .../camel/component/vm/VmInOutChainedTest.java     |    4 +-
 .../component/vm/VmInOutChainedTimeoutTest.java    |   21 +-
 .../org/apache/camel/component/vm/VmInOutTest.java |    4 +-
 .../camel/component/vm/VmInOutWithErrorTest.java   |    8 +-
 .../component/vm/VmMultipleConsumersIssueTest.java |   12 +-
 .../vm/VmMultipleConsumersKeepRouteTest.java       |    4 +-
 .../vm/VmMultipleConsumersMultipleContextTest.java |   13 +-
 .../vm/VmMultipleConsumersRemoteRouteTest.java     |    7 +-
 .../vm/VmMultipleContextsStartStopTest.java        |   14 +-
 .../component/vm/VmShouldNotUseSameThreadTest.java |    2 +-
 .../component/vm/VmShouldUseConsumerContext.java   |    8 +-
 .../camel/component/vm/VmTimeoutIssueTest.java     |   25 +-
 .../camel/component/vm/VmUseSameQueueTest.java     |    4 +-
 .../component/vm/VmWaitForTaskCompleteTest.java    |    7 +-
 .../vm/VmWaitForTaskIfReplyExpectedTest.java       |    7 +-
 .../camel/component/vm/VmWaitForTaskNewerTest.java |    4 +-
 .../org/apache/camel/component/xslt/MyEcho.java    |    2 +-
 .../org/apache/camel/component/xslt/MyXPath.java   |    4 +-
 .../camel/component/xslt/SAXSourceLogBodyTest.java |   28 +-
 .../xslt/XsltCustomizeEntityResolverTest.java      |    5 +-
 .../xslt/XsltCustomizeURIResolverTest.java         |    3 +-
 .../apache/camel/component/xslt/XsltDTDTest.java   |   32 +-
 .../camel/component/xslt/XsltFeatureRouteTest.java |   15 +-
 .../component/xslt/XsltFromFileExceptionTest.java  |   11 +-
 .../XsltIncludeClasspathDotInDirectoryTest.java    |   12 +-
 .../component/xslt/XsltIncludeClasspathTest.java   |    8 +-
 .../xslt/XsltIncludeRelativeFileSchemeTest.java    |    6 +-
 .../xslt/XsltIncludeRelativeNestedTest.java        |    6 +-
 .../xslt/XsltIncludeRelativeOtherTest.java         |    8 +-
 .../component/xslt/XsltIncludeRelativeTest.java    |    6 +-
 .../camel/component/xslt/XsltIncludeTest.java      |    4 +-
 .../component/xslt/XsltMessageTerminateTest.java   |    7 +-
 .../camel/component/xslt/XsltOutputBytesTest.java  |    4 +-
 .../camel/component/xslt/XsltOutputDOMTest.java    |    4 +-
 .../component/xslt/XsltOutputFileDeleteTest.java   |    6 +-
 .../camel/component/xslt/XsltOutputFileTest.java   |    4 +-
 .../camel/component/xslt/XsltOutputStringTest.java |    4 +-
 .../component/xslt/XsltRouteAllowStAXTest.java     |    6 +-
 .../camel/component/xslt/XsltRouteFileTest.java    |    6 +-
 .../apache/camel/component/xslt/XsltRouteTest.java |   22 +-
 .../component/xslt/XsltRouteXsltWithErrorTest.java |    6 +-
 .../xslt/XsltTransformingExceptionTest.java        |    4 +-
 .../camel/converter/CollectionConverterTest.java   |    6 +-
 .../camel/converter/ConverterBenchmarkTest.java    |   31 +-
 .../org/apache/camel/converter/ConverterTest.java  |   15 +-
 .../camel/converter/DateTimeConverterTest.java     |    4 +-
 .../apache/camel/converter/IOConverterTest.java    |   12 +-
 .../java/org/apache/camel/converter/JaxpTest.java  |    7 +-
 .../apache/camel/converter/NIOConverterTest.java   |   11 +-
 .../camel/converter/ObjectConverterNaNTest.java    |    4 +-
 .../camel/converter/ObjectConverterTest.java       |   18 +-
 .../PropertyEditorTypeConverterIssueTest.java      |    6 +-
 .../converter/StaticFallbackConverterTest.java     |    2 +-
 .../apache/camel/converter/StringSourceTest.java   |    7 +-
 .../camel/converter/TimePatternConverterTest.java  |   20 +-
 .../converter/TimePatternTypeConversionTest.java   |    6 +-
 .../TimerDrivenTimePatternConverterTest.java       |   12 +-
 .../camel/converter/jaxp/DomConverterTest.java     |   10 +-
 .../camel/converter/jaxp/StAX2SAXSourceTest.java   |    3 +-
 .../camel/converter/jaxp/StaxConverterTest.java    |   28 +-
 .../camel/converter/jaxp/XmlConverterTest.java     |   28 +-
 .../InstanceMethodWithExchangeTestConverter.java   |    3 +-
 .../myconverter/StaticDummyFallbackConverter.java  |    2 +-
 .../stream/ByteArrayInputStreamCacheTest.java      |    2 +-
 .../converter/stream/CachedOutputStreamTest.java   |   49 +-
 .../converter/stream/FileInputStreamCacheTest.java |    2 +-
 .../converter/stream/InputStreamCacheTest.java     |    2 +-
 .../camel/converter/stream/ReaderCacheTest.java    |    2 +-
 .../camel/converter/stream/SourceCacheTest.java    |    2 +-
 .../converter/stream/StreamCacheConverterTest.java |   15 +-
 .../converter/stream/StreamSourceCacheTest.java    |    2 +-
 .../camel/impl/BeanInjectRouteBuilderTest.java     |   18 +-
 .../impl/BindToRegistryBeanPostProcessorTest.java  |    2 +-
 .../CamelContextAddRestDefinitionsFromXmlTest.java |    3 +-
 ...CamelContextAddRouteDefinitionsFromXmlTest.java |    1 +
 .../camel/impl/CamelContextDeadlockTest.java       |   17 +-
 .../CamelCustomDefaultThreadPoolProfileTest.java   |    4 +-
 .../camel/impl/CamelProduceInterfaceTest.java      |    6 +-
 .../camel/impl/ConsumerCacheZeroCapacityTest.java  |    7 +-
 .../impl/CustomHeadersMapFactoryRouteTest.java     |    3 +-
 .../org/apache/camel/impl/CustomIdFactoryTest.java |   30 +-
 .../camel/impl/CustomUnitOfWorkFactoryTest.java    |    4 +-
 .../DefaultAsyncProcessorAwaitManagerTest.java     |   11 +-
 ...melContextAllowUseOriginalMessageFalseTest.java |    5 +-
 ...amelContextAllowUseOriginalMessageTrueTest.java |    5 +-
 .../impl/DefaultCamelContextAutoStartupTest.java   |   13 +-
 .../impl/DefaultCamelContextResolverTest.java      |   19 +-
 .../camel/impl/DefaultCamelContextRestartTest.java |    3 +-
 ...lContextSuspendResumeRouteStartupOrderTest.java |    2 +-
 .../DefaultCamelContextSuspendResumeRouteTest.java |    2 +-
 ...melContextWithLifecycleStrategyRestartTest.java |    3 +-
 .../camel/impl/DefaultClassResolverTest.java       |    6 +-
 .../DefaultComponentReferencePropertiesTest.java   |   12 +-
 .../apache/camel/impl/DefaultComponentTest.java    |   10 +-
 .../impl/DefaultComponentValidateURITest.java      |    5 +-
 .../camel/impl/DefaultConsumerCacheTest.java       |    5 +-
 .../camel/impl/DefaultConsumerTemplateTest.java    |    7 +-
 ...ConsumerTemplateWithCustomCacheMaxSizeTest.java |    5 +-
 .../camel/impl/DefaultEndpointRegistryTest.java    |    2 +-
 .../camel/impl/DefaultExchangeHolderTest.java      |    9 +-
 .../org/apache/camel/impl/DefaultExchangeTest.java |   18 +-
 .../impl/DefaultExecutorServiceManagerTest.java    |   13 +-
 .../camel/impl/DefaultHeadersMapFactoryTest.java   |    2 +-
 .../camel/impl/DefaultMessageHeaderTest.java       |    2 +-
 .../camel/impl/DefaultProducerCacheTest.java       |    4 +-
 .../impl/DefaultProducerTemplateAsyncTest.java     |   27 +-
 ...efaultProducerTemplateNonBlockingAsyncTest.java |    1 +
 .../camel/impl/DefaultProducerTemplateTest.java    |    6 +-
 ...ProducerTemplateWithCustomCacheMaxSizeTest.java |    3 +-
 .../apache/camel/impl/DefaultUnitOfWorkTest.java   |    6 +-
 .../camel/impl/DefaultUuidGeneratorTest.java       |    2 +-
 .../apache/camel/impl/DummyLifecycleStrategy.java  |    3 +-
 .../camel/impl/DurationRoutePolicyFactoryTest.java |    6 +-
 .../impl/DurationRoutePolicyMaxMessagesTest.java   |    3 +-
 .../impl/DurationRoutePolicyMaxSecondsTest.java    |    6 +-
 .../EndpointRegistryKeepRouteEndpointsTest.java    |    2 +-
 .../EventDrivenPollingConsumerQueueSizeTest.java   |    5 +-
 .../apache/camel/impl/ExpressionAdapterTest.java   |    4 +-
 .../apache/camel/impl/ExpressionSupportTest.java   |    2 +-
 .../impl/ExtendedStartupListenerComponentTest.java |    3 +-
 .../apache/camel/impl/FileStateRepositoryTest.java |    2 +-
 .../camel/impl/FromMultipleEndpointTest.java       |    2 +-
 .../GracefulShutdownNoAutoStartOrderClashTest.java |    2 +-
 .../impl/HashMapHeadersMapFactoryRouteTest.java    |    3 +-
 .../InflightRepositoryBrowseFromRouteTest.java     |   33 +-
 .../camel/impl/InflightRepositoryBrowseTest.java   |   33 +-
 .../apache/camel/impl/JavaUuidGeneratorTest.java   |    2 +-
 .../camel/impl/LogDebugBodyMaxCharsOffTest.java    |    4 +-
 .../camel/impl/LogDebugBodyMaxCharsTest.java       |    1 +
 .../apache/camel/impl/LogDebugBodyStreamsTest.java |    4 +-
 .../org/apache/camel/impl/MessageSupportTest.java  |    8 +-
 .../camel/impl/MockScheduledPollConsumer.java      |    5 +-
 .../camel/impl/MultipleConsumersSupportTest.java   |    3 +-
 .../camel/impl/MultipleLifecycleStrategyTest.java  |    9 +-
 ...ingExchangesAsyncDelayShutdownGracefulTest.java |    7 +-
 .../impl/PendingExchangesShutdownGracefulTest.java |    5 +-
 ...ndingExchangesTwoRouteShutdownGracefulTest.java |    5 +-
 .../impl/PojoProduceInterceptEndpointTest.java     |   12 +-
 .../PojoProduceProxyInterceptEndpointTest.java     |   12 +-
 .../camel/impl/ProducerCacheNonSingletonTest.java  |    2 +-
 .../org/apache/camel/impl/RefDataFormatTest.java   |   10 +-
 .../camel/impl/RemoveRouteStopEndpointTest.java    |   33 +-
 .../camel/impl/RouteDirectSuspendResumeTest.java   |    4 +-
 .../camel/impl/RouteIdRestDefinitionTest.java      |    7 +-
 .../impl/RouteMustHaveOutputOnExceptionTest.java   |   30 +-
 .../org/apache/camel/impl/RouteNoOutputTest.java   |    1 +
 .../apache/camel/impl/RoutePolicyCallbackTest.java |    3 +-
 .../apache/camel/impl/RoutePolicyFactoryTest.java  |    7 +-
 .../camel/impl/RoutePolicyRefCallbackTest.java     |    3 +-
 .../apache/camel/impl/RoutePolicySupportTest.java  |   30 +-
 .../org/apache/camel/impl/RoutePolicyTest.java     |    6 +-
 .../org/apache/camel/impl/RouteRemoveTest.java     |   11 +-
 .../apache/camel/impl/RouteSedaStopStartTest.java  |    6 +-
 .../camel/impl/RouteSedaSuspendResumeTest.java     |    6 +-
 .../camel/impl/RouteSetRouteIdTwoTimesTest.java    |    4 +-
 .../impl/RouteWithMistypedComponentNameTest.java   |    1 -
 .../camel/impl/RuntimeEndpointRegistryTest.java    |   11 +-
 .../camel/impl/ScheduledPollConsumerTest.java      |    7 +-
 .../ShutdownGracefulNoAutoStartedRoutesTest.java   |    2 +-
 .../impl/ShutdownGracefulTimeoutTriggerTest.java   |    2 +-
 ...ownStrategyNotSuppressLoggingOnTimeoutTest.java |    4 +-
 ...utdownStrategySuppressLoggingOnTimeoutTest.java |    4 +-
 .../org/apache/camel/impl/SimpleRegistryTest.java  |    7 +-
 .../apache/camel/impl/SimpleRegistryWrapTest.java  |    5 +-
 .../SimpleShutdownGracefulNoAtuoStartedTest.java   |    2 +-
 .../apache/camel/impl/SimpleUuidGeneratorTest.java |    2 +-
 .../apache/camel/impl/StartAndStopRoutesTest.java  |    5 +-
 .../camel/impl/StartStopAndShutdownRouteTest.java  |    1 -
 .../StartupListenerComponentFromRegistryTest.java  |    2 +-
 .../org/apache/camel/impl/StartupListenerTest.java |    8 +-
 .../camel/impl/StopRouteAbortAfterTimeoutTest.java |   22 +-
 .../camel/impl/TwoRouteSuspendResumeTest.java      |    2 +-
 .../camel/impl/TypeConverterAllowNullTest.java     |    2 +-
 .../TypeConverterRegistryMissesThenAddTest.java    |    2 +-
 ...TypeConverterRegistryStatisticsEnabledTest.java |    4 +-
 .../camel/impl/TypeConverterRegistryTest.java      |    8 +-
 .../camel/impl/VetoCamelContextStartTest.java      |    3 +-
 .../impl/cluster/ClusterServiceSelectorTest.java   |    2 -
 .../camel/impl/cluster/ClusterServiceViewTest.java |   42 +-
 .../impl/engine/CustomThreadPoolFactoryTest.java   |    5 +-
 .../camel/impl/engine/DefaultCamelContextTest.java |   10 +-
 .../impl/engine/DefaultFactoryFinderTest.java      |    6 +-
 .../apache/camel/impl/engine/RouteRemove2Test.java |    2 +-
 .../camel/impl/event/EventNotifierEventsTest.java  |    1 +
 .../event/EventNotifierExchangeCompletedTest.java  |    4 +-
 .../EventNotifierExchangeSentParallelTest.java     |    2 +-
 .../impl/event/EventNotifierExchangeSentTest.java  |   10 +-
 .../EventNotifierFailureHandledEventsTest.java     |   16 +-
 .../event/EventNotifierRedeliveryEventsTest.java   |    5 +-
 ...ventNotifierServiceStoppingFailedEventTest.java |    3 +-
 .../event/MultipleEventNotifierEventsTest.java     |    3 +-
 .../health/DefaultHealthCheckRegistryTest.java     |   12 +-
 .../impl/health/DefaultHealthCheckServiceTest.java |    1 -
 .../apache/camel/impl/health/HealthCheckTest.java  |    1 -
 .../impl/transformer/TransformerContractTest.java  |   41 +-
 .../impl/transformer/TransformerRouteTest.java     |  122 +-
 .../validator/BeanValidatorInputValidateTest.java  |   18 +-
 .../validator/BeanValidatorOutputValidateTest.java |   18 +-
 ...InflightRepositoryWithFailedValidationTest.java |   10 +-
 .../impl/validator/ValidatorContractTest.java      |   29 +-
 .../camel/impl/validator/ValidatorRouteTest.java   |   53 +-
 .../impl/validator/ValidatorXmlSchemaTest.java     |    3 +-
 .../verifier/DefaultComponentVerifierTest.java     |    1 +
 .../camel/impl/verifier/ResultErrorHelperTest.java |    7 +-
 .../org/apache/camel/issues/AdviceWithCBRTest.java |    7 +-
 ...viceWithContextScopedErrorHandlerIssueTest.java |    4 +-
 .../issues/AdviceWithErrorHandlerRemoveTest.java   |   11 +-
 .../issues/AdviceWithInterceptFromRemoveTest.java  |    6 +-
 .../issues/AdviceWithInterceptRemoveTest.java      |    6 +-
 ...dviceWithInterceptSendToEndpointRemoveTest.java |   10 +-
 ...nterceptSendToEndpointWithLoadbalancerTest.java |    8 +-
 .../issues/AdviceWithInvalidConfiguredTest.java    |    4 +-
 .../apache/camel/issues/AdviceWithIssueTest.java   |    8 +-
 .../issues/AdviceWithOnCompletionRemoveTest.java   |   10 +-
 .../camel/issues/AdviceWithOnCompletionTest.java   |    4 +-
 .../AdviceWithOnExceptionAndInterceptTest.java     |   27 +-
 .../issues/AdviceWithOnExceptionRemoveTest.java    |   15 +-
 .../camel/issues/AdviceWithOnExceptionTest.java    |    4 +-
 .../apache/camel/issues/AdviceWithPolicyTest.java  |    5 +-
 .../camel/issues/AdviceWithRoutePolicyTest.java    |    4 +-
 ...AdviceWithRouteScopedErrorHandlerIssueTest.java |    8 +-
 .../issues/AdviceWithStartTargetIssueTest.java     |   18 +-
 .../camel/issues/AdviceWithTransactedTest.java     |    4 +-
 .../AdviceWithTwoRoutesOnExceptionIssueTest.java   |   11 +-
 .../camel/issues/AdviceWithUrlIssueTest.java       |    4 +-
 .../issues/AdviceWithWeaveByToUriCBRTest.java      |    6 +-
 .../camel/issues/AdviceWithWeaveByTypeCBRTest.java |   11 +-
 .../AggregatorWithBatchConsumingIssueTest.java     |    7 +-
 .../apache/camel/issues/AmahDeadLetterTest.java    |    2 +-
 .../camel/issues/CBRConcurrencyIssueTest.java      |    9 +-
 .../apache/camel/issues/CBRContainsIssueTest.java  |    7 +-
 .../issues/CBRCustomPredicateAsFilterTest.java     |    5 +-
 .../CacheInputStreamInDeadLetterIssue520Test.java  |    8 +-
 .../apache/camel/issues/Camel4857UriIssueTest.java |   17 +-
 .../CharlesSplitAndTryCatchRollbackIssueTest.java  |   13 +-
 ...CharlesSplitUseBeanAsErrorHandlerIssueTest.java |   15 +-
 .../issues/ChoiceEndOrEndChoiceIssueTest.java      |   29 +-
 .../issues/ChoicePredicateSimpleHeaderTest.java    |    7 +-
 .../camel/issues/ComponentUseRawUriTest.java       |    4 +-
 ...tScopedOnExceptionErrorHandlerRefIssueTest.java |   11 +-
 ...ExceptionErrorHandlerRefIssueTwoRoutesTest.java |   17 +-
 ...nExceptionMultipleRouteBuildersReverseTest.java |   35 +-
 ...ScopedOnExceptionMultipleRouteBuildersTest.java |   35 +-
 ...xceptionNotHandledErrorHandlerRefIssueTest.java |   11 +-
 ...otHandledErrorHandlerRefIssueTwoRoutesTest.java |   15 +-
 ...HandledRouteScopedErrorHandlerRefIssueTest.java |   12 +-
 ...uteScopedErrorHandlerRefIssueTwoRoutesTest.java |   17 +-
 ...ceptionRouteScopedErrorHandlerRefIssueTest.java |   12 +-
 ...uteScopedErrorHandlerRefIssueTwoRoutesTest.java |   17 +-
 .../camel/issues/CustomFailveOverProcessor.java    |    5 +-
 .../issues/DoCatchCaughExceptionIssueTest.java     |   19 +-
 .../issues/DynamicRouterWithInterceptorTest.java   |   15 +-
 .../issues/EndpointWithRawUriParameterTest.java    |   28 +-
 .../camel/issues/ErrorHandlerAdviceIssueTest.java  |   29 +-
 .../camel/issues/ExceptionCamel4022Test.java       |   17 +-
 .../camel/issues/ExceptionPolicyIssueTest.java     |    5 +-
 .../org/apache/camel/issues/ExceptionTest.java     |   13 +-
 ...tionThrownFromOnExceptionNoEndlessLoopTest.java |   71 +-
 .../issues/ExceptionThrownFromOnExceptionTest.java |  253 +--
 .../camel/issues/FilePollingConsumerIssueTest.java |    1 +
 .../issues/FileSplitStreamingWithChoiceTest.java   |   10 +-
 .../issues/FilterCustomPredicateAsFilterTest.java  |   10 +-
 .../org/apache/camel/issues/GertJBIIssueTest.java  |   10 +-
 .../InterceptCustomPredicateAsFilterTest.java      |    2 +-
 .../InterceptFromPredicateProceedAndStopTest.java  |    2 +-
 .../java/org/apache/camel/issues/Issue170Test.java |    2 +-
 .../camel/issues/MethodClassByTypeIssueTest.java   |   12 +-
 .../camel/issues/MockExpectedHeadersIssueTest.java |    7 +-
 .../camel/issues/MockValueBuilderIssueTest.java    |    4 +-
 ...ticastAggregationStrategyInputExchangeTest.java |   16 +-
 ...icastAggregationStrategyThrowExceptionTest.java |    8 +-
 ...essageBodyAndEnrichedHeadersClaimCheckTest.java |   38 +-
 ...xOriginalMessageBodyAndEnrichedHeadersTest.java |   29 +-
 ...eBodyAndEnrichedHeadersUseOriginalBodyTest.java |   23 +-
 ...lelStopOnExceptionWithOnExceptionIssueTest.java |   19 +-
 ...thAggregationStrategyThrowingExceptionTest.java |    6 +-
 .../MulticastParallelWithOnExceptionIssueTest.java |   13 +-
 .../MulticastPipelineAggregateIssueTest.java       |   25 +-
 ...UnitOfWorkOnExceptionHandledFalseIssueTest.java |   18 +-
 .../issues/MulticastSingleAggregateIssueTest.java  |    8 +-
 ...astStopOnExceptionWithOnExceptionIssueTest.java |   15 +-
 .../issues/MulticastWithOnExceptionIssueTest.java  |   15 +-
 .../MultipleErrorHandlerOnExceptionIssueTest.java  |   17 +-
 .../org/apache/camel/issues/MultipleFromTest.java  |    4 +-
 .../java/org/apache/camel/issues/MyCamelBean.java  |    2 +-
 .../org/apache/camel/issues/MyTransformBean.java   |    2 +-
 .../org/apache/camel/issues/NeilSplitterTest.java  |   12 +-
 ...derExactlyDoneSplitterWhereSentToIssueTest.java |   10 +-
 ...tifyBuilderOnFailureShutdownCamelIssueTest.java |    3 +-
 .../apache/camel/issues/OnCompletionIssueTest.java |   35 +-
 .../OnExceptionBeforeErrorHandlerIssueTest.java    |   30 +-
 .../issues/OnExceptionContinuedIssueTest.java      |   60 +-
 ...OnExceptionContinuedNoFailureProcessorTest.java |   19 +-
 .../OnExceptionErrorHandlerRefIssueTest.java       |    9 +-
 ...ExceptionErrorHandlerRefIssueTwoRoutesTest.java |   13 +-
 .../OnExceptionHandledNoFailureProcessorTest.java  |   22 +-
 ...xceptionNotHandledErrorHandlerRefIssueTest.java |    9 +-
 ...otHandledErrorHandlerRefIssueTwoRoutesTest.java |   13 +-
 ...nExceptionNotHandledNoFailureProcessorTest.java |   22 +-
 ...HandledRouteScopedErrorHandlerRefIssueTest.java |   12 +-
 ...uteScopedErrorHandlerRefIssueTwoRoutesTest.java |   17 +-
 .../camel/issues/OnExceptionProcessIssueTest.java  |   22 +-
 ...ceptionRouteScopedErrorHandlerRefIssueTest.java |   12 +-
 ...uteScopedErrorHandlerRefIssueTwoRoutesTest.java |   17 +-
 .../camel/issues/OnExceptionWithTwoBeansTest.java  |   28 +-
 .../issues/PropertiesAvailableEverywhereTest.java  |   15 +-
 .../camel/issues/ProxyReturnNullIssueTest.java     |    1 -
 ...ntListAggregationStrategyInputExchangeTest.java |   14 +-
 .../RecipientListDirectNoConsumerIssueTest.java    |    8 +-
 ...thAggregationStrategyThrowingExceptionTest.java |   10 +-
 ...UnitOfWorkOnExceptionHandledFalseIssueTest.java |   15 +-
 ...eOriginalMessageEndpointExceptionIssueTest.java |   10 +-
 .../RecipientListUseOriginalMessageIssueTest.java  |    7 +-
 .../issues/RecipientListWithInterceptorTest.java   |   15 +-
 ...andlerAsyncDelayedTwoCamelContextIssueTest.java |   11 +-
 ...olicyOnExceptionWhileRedeliveringIssueTest.java |   20 +-
 .../camel/issues/RegExPredicateIssueTest.java      |    6 +-
 ...ryContextScopedUntilRecipientListIssueTest.java |    6 +-
 ...tScopedUntilRecipientListParallelIssueTest.java |    6 +-
 ...etryRouteScopedUntilRecipientListIssueTest.java |   12 +-
 ...eScopedUntilRecipientListParallelIssueTest.java |    8 +-
 .../RetryWhilePredicateExpressionIssueTest.java    |   22 +-
 .../RetryWhileSimpleExpressionIssueTest.java       |    9 +-
 .../apache/camel/issues/RomeksExceptionTest.java   |   18 +-
 .../issues/RouteIdAnonymousAndFixedClashTest.java  |    8 +-
 .../camel/issues/RouteIdAutoAssignClashIssue.java  |    9 +-
 .../RouteScopedErrorHandlerAndOnExceptionTest.java |   22 +-
 ...ScopedOnExceptionMultipleRouteBuildersTest.java |   43 +-
 ...eptionWithInterceptSendToEndpointIssueTest.java |   17 +-
 ...erceptSendToEndpointIssueWithPredicateTest.java |   35 +-
 .../RouteStartupFailShouldStopAlsoIssueTest.java   |    9 +-
 .../apache/camel/issues/RouteWithCustomIdTest.java |    7 +-
 .../camel/issues/RoutingSlipMemoryLeakTest.java    |    6 +-
 .../issues/RoutingSlipNotStopErrorHandlerTest.java |   10 +-
 .../issues/RoutingSlipWithInterceptorTest.java     |   15 +-
 ...RouteAndContextScopedErrorHandlerIssueTest.java |   23 +-
 .../camel/issues/SedaFileIdempotentIssueTest.java  |    8 +-
 .../SedaFileIdempotentNoTimeoutIssueTest.java      |    7 +-
 .../issues/SedaFileIdempotentTimeoutIssueTest.java |    7 +-
 .../issues/SentExchangeEventNotifierIssueTest.java |   13 +-
 .../SentExchangeEventNotifierTwoIssueTest.java     |   13 +-
 .../camel/issues/SetBodyTryCatchIssueTest.java     |   19 +-
 .../camel/issues/SetHeaderInDoCatchIssueTest.java  |   16 +-
 .../camel/issues/SplitContinuedLogIssueTest.java   |   16 +-
 .../camel/issues/SplitListListIssueTest.java       |   12 +-
 .../camel/issues/SplitPropertiesFileIssueTest.java |   16 +-
 ...UnitOfWorkOnExceptionHandledFalseIssueTest.java |   15 +-
 .../issues/SplitStopOnExceptionIssueTest.java      |   15 +-
 .../SplitWithCustomAggregationStrategyTest.java    |   36 +-
 .../camel/issues/SplitWithInterceptorTest.java     |   10 +-
 ...litterAggregationStrategyInputExchangeTest.java |   21 +-
 .../issues/SplitterCorrelationIdIssueTest.java     |    4 +-
 .../camel/issues/SplitterParallelIssueTest.java    |   24 +-
 ...thAggregationStrategyThrowingExceptionTest.java |    8 +-
 ...rParallelWithIteratorThrowingExceptionTest.java |    9 +-
 .../SplitterThrowExceptionInExpressionTest.java    |   14 +-
 .../SplitterThrowExceptionInExpressionTwoTest.java |   15 +-
 ...terUsingBeanReturningCloseableIteratorTest.java |    5 +-
 .../SplitterUsingBeanReturningMessageTest.java     |    3 +-
 .../camel/issues/StopCamelFromRouteTest.java       |   18 +-
 .../camel/issues/StopRouteFromRouteTest.java       |   57 +-
 .../issues/StopRouteImpactsErrorHandlerTest.java   |   28 +-
 ...dNotStopContextScopedErrorHandlerIssueTest.java |   12 +-
 ...uldNotStopRouteScopedErrorHandlerIssueTest.java |   12 +-
 ...ryCatchInterceptSendToAllEndpointIssueTest.java |   16 +-
 ...ThreadsRejectedExecutionWithDeadLetterTest.java |   66 +-
 .../issues/TimerAndErrorHandlerIssueTest.java      |    6 +-
 .../TransactedPropertyPlaceholderIssueTest.java    |    5 +-
 .../TryCatchFinallyOnExceptionIssueTest.java       |   18 +-
 .../camel/issues/TryCatchSetHeaderIssueTest.java   |   22 +-
 .../camel/issues/TryCatchWithSplitIssueTest.java   |   14 +-
 ...erceptSendToEndpointIssueWithPredicateTest.java |   46 +-
 .../apache/camel/issues/TwoTimerWithJMXIssue.java  |    3 +-
 .../issues/TypeConverterConcurrencyIssueTest.java  |    9 +-
 .../apache/camel/issues/XPathSplitStreamTest.java  |    6 +-
 .../language/BeanAnnotationParameterTest.java      |   25 +-
 .../language/BeanAnnotationParameterTwoTest.java   |   29 +-
 .../language/BeanLanguageInvalidOGNLTest.java      |    5 +-
 .../BeanLanguageMethodMissingParenthesisTest.java  |   16 +-
 .../camel/language/BeanLanguageOGNLTest.java       |    3 +-
 ...LWithDotInParameterPropertyPlaceholderTest.java |    4 +-
 .../BeanLanguageOGNLWithDotInParameterTest.java    |    4 +-
 .../ConstantLanguageBinaryResourceTest.java        |    3 +-
 .../org/apache/camel/language/ConstantTest.java    |    4 +-
 .../java/org/apache/camel/language/HeaderTest.java |    2 +-
 .../apache/camel/language/LanguageServiceTest.java |    4 +-
 .../apache/camel/language/NoSuchLanguageTest.java  |    2 +-
 .../PropertyInjectAnnotationParameterTest.java     |   12 +-
 .../apache/camel/language/RefPredicateTest.java    |    2 +-
 .../java/org/apache/camel/language/RefTest.java    |    2 +-
 .../camel/language/SimpleLanguageRouteTest.java    |    3 +-
 .../SimpleLanguageTransformRandomTest.java         |    6 +-
 .../camel/language/SimpleOgnlMapIssueTest.java     |    7 +-
 ...okenPairIteratorSplitChoicePerformanceTest.java |  111 +-
 .../camel/language/TokenPairPredicateTest.java     |   14 +-
 .../TokenXMLPairMultiNamespaceSplitTest.java       |    2 +-
 .../TokenXMLPairNamespaceMultilineSplitTest.java   |    2 +-
 ...kenXMLPairNamespaceSplitChildNamespaceTest.java |   15 +-
 .../language/TokenXMLPairNamespaceSplitTest.java   |   15 +-
 .../org/apache/camel/language/TokenizerTest.java   |   32 +-
 .../apache/camel/language/XMLTokenSplitTest.java   |   15 +-
 .../language/XPathAnotherRouteConcurrentTest.java  |   13 +-
 .../camel/language/XPathFromFileExceptionTest.java |   14 +-
 .../apache/camel/language/XPathFunctionTest.java   |   33 +-
 .../language/XPathLanguageSingleNodeListTest.java  |   32 +-
 .../apache/camel/language/XPathResourceTest.java   |    4 +-
 .../language/XPathRouteConcurrentBigTest.java      |   67 +-
 .../camel/language/XPathRouteConcurrentTest.java   |    8 +-
 .../language/XPathSplitChoicePerformanceTest.java  |  111 +-
 .../camel/language/simple/SimpleDecHeaderTest.java |    4 +-
 .../camel/language/simple/SimpleIncHeaderTest.java |    4 +-
 .../SimpleMessageHistoryNotDetailedTest.java       |    7 +-
 .../language/simple/SimpleMessageHistoryTest.java  |    8 +-
 .../camel/language/simple/SimpleOperatorTest.java  |   18 +-
 .../simple/SimpleParserExpressionInvalidTest.java  |    5 +-
 .../simple/SimpleParserExpressionTest.java         |    3 +-
 .../simple/SimpleParserRegexpPredicateTest.java    |    2 +-
 .../simple/SimplePropertiesNestedTest.java         |    6 +-
 .../language/simple/SimpleResourceDynamicTest.java |    4 +-
 .../camel/language/simple/SimpleResourceTest.java  |    4 +-
 .../SimpleRouteExpressionAsPredicateTest.java      |    6 +-
 .../simple/SimpleSetHeaderPredicateTest.java       |   12 +-
 .../apache/camel/language/simple/SimpleTest.java   |   40 +-
 .../language/simple/SimpleWithPropertiesTest.java  |   12 +-
 .../language/tokenizer/TokenizeLanguageTest.java   |   71 +-
 .../tokenizer/TokenizeWrapLanguageTest.java        |   90 +-
 .../tokenizer/XMLTokenizeLanguageGroupingTest.java |   93 +-
 .../XMLTokenizeLanguageStreamingFileTest.java      |   24 +-
 .../XMLTokenizeLanguageStreamingTest.java          |    6 +-
 .../tokenizer/XMLTokenizeLanguageTest.java         |   91 +-
 .../XMLTokenizeWrapLanguageGroupingTest.java       |  118 +-
 .../tokenizer/XMLTokenizeWrapLanguageTest.java     |  129 +-
 .../model/GatherAllStaticEndpointUrisTest.java     |   13 +-
 .../apache/camel/model/LoadRestFromXmlTest.java    |    5 +-
 .../apache/camel/model/LoadRouteFromXmlTest.java   |    3 +-
 .../model/LoadRouteFromXmlWithNamespaceTest.java   |    3 +-
 .../model/LoadRouteFromXmlWithPolicyTest.java      |    3 +-
 .../model/ModelRouteFilterPatternExcludeTest.java  |    6 +-
 .../ModelRouteFilterPatternIncludeExcludeTest.java |    9 +-
 .../model/ModelRouteFilterPatternIncludeTest.java  |    6 +-
 .../apache/camel/model/ModelSanityCheckerTest.java |    9 +-
 .../camel/model/ProcessDefinitionSetBodyTest.java  |    7 +-
 .../camel/model/ProcessorDefinitionHelperTest.java |    8 +-
 .../org/apache/camel/model/RouteGroupTest.java     |    7 +-
 .../apache/camel/model/RoutePropertiesTest.java    |   11 +-
 .../model/StartingRoutesErrorReportedTest.java     |   10 +-
 .../org/apache/camel/model/XmlRestParseTest.java   |    3 +-
 .../apache/camel/model/XmlRestParseToDTest.java    |    2 +-
 .../apache/camel/model/XmlRoutePropertiesTest.java |    8 +-
 .../apache/camel/processor/AsyncLoopCopyTest.java  |   31 +-
 .../org/apache/camel/processor/AsyncLoopTest.java  |   43 +-
 .../BatchResequencerAllowDuplicatesTest.java       |    8 +-
 .../processor/BatchResequencerJMSPriorityTest.java |   11 +-
 .../BatchResequencerWithDuplicateTest.java         |    2 +-
 .../processor/BeanCachedProcessorGlobalTest.java   |    6 +-
 .../camel/processor/BeanCachedProcessorTest.java   |    7 +-
 .../org/apache/camel/processor/BeanCachedTest.java |    7 +-
 .../BeanInvocationThrowsExceptionTest.java         |    5 +-
 .../BeanOgnMethodWithXPathInjectionTest.java       |   12 +-
 .../BeanProcessorSpecializedMessageTest.java       |    7 +-
 .../BeanRecipientListInterfaceAnnotationTest.java  |    7 +-
 .../camel/processor/BeanRecipientListTest.java     |    3 +-
 .../processor/BeanRecipientListTimeoutTest.java    |   14 +-
 .../org/apache/camel/processor/BeanRouteTest.java  |    1 +
 .../camel/processor/BeanWithExceptionTest.java     |    6 +-
 .../processor/BeanWithXPathInjectionTest.java      |    9 +-
 .../camel/processor/BreadcrumbDisabledTest.java    |   24 +-
 .../org/apache/camel/processor/BreadcrumbTest.java |   24 +-
 .../camel/processor/CBRHeaderPredicateTest.java    |   11 +-
 .../CBRPredicateBeanThrowExceptionTest.java        |   16 +-
 .../processor/CBRSimplePredicateEmptyBodyTest.java |    9 +-
 .../apache/camel/processor/CBRSimpleTypeTest.java  |   10 +-
 .../camel/processor/CBRWithLoadBalancerTest.java   |   11 +-
 .../camel/processor/CBRWithMulticastTest.java      |   11 +-
 .../camel/processor/CBRWithRecipientListTest.java  |   12 +-
 .../apache/camel/processor/CBRWithWireTapTest.java |   10 +-
 .../processor/Camel715ThreadProcessorTest.java     |   17 +-
 .../CamelContextLogExhaustedMessageBodyTest.java   |    4 +-
 .../org/apache/camel/processor/ChannelTest.java    |   14 +-
 .../apache/camel/processor/ChoiceAsyncTest.java    |   11 +-
 .../processor/ChoiceCompoundPredicateTest.java     |   27 +-
 .../apache/camel/processor/ChoiceNoActionTest.java |    8 +-
 .../camel/processor/ChoiceNoErrorHandlerTest.java  |   18 +-
 .../org/apache/camel/processor/ChoiceTest.java     |    9 +-
 .../processor/ChoiceWhenBeanExpressionTest.java    |   42 +-
 .../ChoiceWhenBeanExpressionWithExceptionTest.java |   48 +-
 .../processor/ChoiceWhenNotPredicateTest.java      |    8 +-
 .../apache/camel/processor/ChoiceWithEndTest.java  |   35 +-
 .../processor/ChoiceWithSimpleExpressionTest.java  |    8 +-
 .../camel/processor/ChoiceWithTranfromTest.java    |   30 +-
 .../ClaimCheckEipDynamicKeyGetSetTest.java         |   14 +-
 .../ClaimCheckEipGetAndRemoveSetTest.java          |   14 +-
 .../camel/processor/ClaimCheckEipGetSetTest.java   |   13 +-
 .../processor/ClaimCheckEipPushPopBodyTest.java    |   10 +-
 .../ClaimCheckEipPushPopExcludeBodyTest.java       |   13 +-
 .../ClaimCheckEipPushPopHeadersPatternTest.java    |   10 +-
 .../processor/ClaimCheckEipPushPopHeadersTest.java |   10 +-
 .../ClaimCheckEipPushPopRemoveHeaderTest.java      |   13 +-
 .../camel/processor/ClaimCheckEipPushPopTest.java  |    7 +-
 .../org/apache/camel/processor/ClaimCheckTest.java |   40 +-
 .../processor/ComposedMessageProcessorTest.java    |   91 +-
 .../apache/camel/processor/ConvertBodyTest.java    |    8 +-
 .../apache/camel/processor/CorrectRouteIdTest.java |   19 +-
 .../CreateRouteWithNonExistingEndpointTest.java    |    1 +
 .../CustomConsumerExceptionHandlerTest.java        |    9 +-
 .../camel/processor/CustomLoadBalanceTest.java     |    6 +-
 .../processor/CustomProcessorFactoryTest.java      |   20 +-
 .../camel/processor/CustomRefLoadBalanceTest.java  |    6 +-
 .../camel/processor/CustomRoutePolicyTest.java     |    1 -
 .../processor/CustomScheduledRoutePolicyTest.java  |    2 +-
 .../processor/DataFormatServiceCustomRefTest.java  |   10 +-
 .../camel/processor/DataFormatServiceTest.java     |    3 +-
 .../DeadLetterChannelAlwaysHandledTest.java        |   11 +-
 .../DeadLetterChannelCatchThrowableTest.java       |   13 +-
 ...dLetterChannelExceptionCausePropagatedTest.java |    8 +-
 ...CausePropagatedWithDefaultErrorHandlerTest.java |   10 +-
 .../DeadLetterChannelFailureRouteIdTest.java       |   18 +-
 .../DeadLetterChannelHandleNewExceptionTest.java   |   16 +-
 .../DeadLetterChannelHandledExampleTest.java       |   36 +-
 ...lHandledExampleWithDefaultErrorHandlerTest.java |   17 +-
 ...etterChannelLogExhaustedMessageHistoryTest.java |    9 +-
 ...nnelLogExhaustedMessageHistoryWithBodyTest.java |    7 +-
 .../DeadLetterChannelNewExceptionTest.java         |    6 +-
 .../DeadLetterChannelNoRedeliveryTest.java         |    9 +-
 ...DeadLetterChannelNotHandleNewExceptionTest.java |    9 +-
 ...adLetterChannelOnExceptionOnRedeliveryTest.java |   35 +-
 .../processor/DeadLetterChannelOnPrepareTest.java  |    6 +-
 .../DeadLetterChannelOnRedeliveryTest.java         |   15 +-
 ...dLetterChannelPropagateCausedExceptionTest.java |   57 +-
 ...etterChannelRedeliverWithDelayBlockingTest.java |   25 +-
 ...LetterChannelRedeliveringWhileShutdownTest.java |    2 +-
 ...eadLetterChannelRedeliveryDelayPatternTest.java |   13 +-
 .../processor/DeadLetterChannelRedeliveryTest.java |   42 +-
 .../DeadLetterChannelRestartFromBeginningTest.java |   29 +-
 .../processor/DeadLetterChannelSetHeaderTest.java  |    9 +-
 .../camel/processor/DeadLetterChannelTest.java     |   15 +-
 .../DeadLetterChannelUnmarshalSetHeaderTest.java   |    9 +-
 .../DeadLetterChannelUseOriginalInBodyTest.java    |   16 +-
 ...LetterChannelUseOriginalInBodyWithFileTest.java |    5 +-
 ...tConsumerBridgeErrorHandlerOnExceptionTest.java |   20 +-
 ...ltConsumerBridgeErrorHandlerRedeliveryTest.java |   30 +-
 .../DefaultConsumerBridgeErrorHandlerTest.java     |   10 +-
 .../DefaultErrorHandlerCatchThrowableTest.java     |   13 +-
 .../DefaultErrorHandlerExplicitConfiguredTest.java |    2 +-
 .../DefaultErrorHandlerFailureRouteIdTest.java     |   14 +-
 ...ErrorHandlerLogExhaustedMessageHistoryTest.java |    4 +-
 .../DefaultErrorHandlerOnExceptionTest.java        |    2 +-
 .../DefaultErrorHandlerOnPrepareTest.java          |    6 +-
 .../DefaultErrorHandlerRedeliveryTest.java         |   43 +-
 .../camel/processor/DefaultErrorHandlerTest.java   |    5 +-
 ...cheduledPollConsumerBridgeErrorHandlerTest.java |    7 +-
 .../DefinitionPolicyPerProcessorTest.java          |    7 +-
 .../camel/processor/DelayInterceptorTest.java      |   14 +-
 .../camel/processor/DelayerAsyncDelayedTest.java   |    5 +-
 .../camel/processor/DelayerPerRouteTest.java       |    2 +-
 .../org/apache/camel/processor/DelayerTest.java    |    3 +-
 .../camel/processor/DelayerWhileShutdownTest.java  |    2 +-
 .../org/apache/camel/processor/DetourTest.java     |   40 +-
 .../processor/DoTryCatchWithSplitterTest.java      |   16 +-
 .../DoubleLoadBalancerMisconfigurationTest.java    |   12 +-
 .../apache/camel/processor/DualPipelineTest.java   |   17 +-
 .../apache/camel/processor/DynamicRouter4Test.java |    4 +-
 .../processor/DynamicRouterAnnotationTest.java     |    3 +-
 .../DynamicRouterExchangeHeaders2Test.java         |    3 +-
 .../DynamicRouterExchangeHeadersTest.java          |    3 +-
 .../DynamicRouterExchangePropertiesTest.java       |    6 +-
 .../processor/DynamicRouterOnExceptionTest.java    |    7 +-
 ...amicRouterThrowExceptionFromExpressionTest.java |   10 +-
 ...point2MustBeStartedBeforeSendProcessorTest.java |   17 +-
 ...dpointMustBeStartedBeforeSendProcessorTest.java |   14 +-
 .../camel/processor/EnrichSubUnitOfWorkTest.java   |   20 +-
 ...HandlerOnExceptionRedeliveryAndHandledTest.java |   44 +-
 .../apache/camel/processor/ErrorHandlerTest.java   |   19 +-
 .../processor/ErrorHandlerWrappedEachNodeTest.java |    7 +-
 .../processor/EvaluateExpressionProcessorTest.java |   18 +-
 .../EventNotifierExchangeSentExampleTest.java      |    4 +-
 .../processor/EventNotifierExchangeSentTest.java   |    8 +-
 .../processor/ExceptionHandlerStreamCacheTest.java |    4 +-
 .../processor/ExchangeAwareDelayCalcBean.java      |    2 +-
 .../processor/ExchangeIdempotentConsumerTest.java  |    8 +-
 .../processor/FailOverAllFailedExceptionTest.java  |    7 +-
 .../FailOverLoadBalanceAutoStartupFalseTest.java   |    8 +-
 .../FailOverLoadBalanceMultipleExceptionTest.java  |    7 +-
 ...verLoadBalanceNotInheritedErrorHandlerTest.java |   11 +-
 .../camel/processor/FailOverLoadBalanceTest.java   |   32 +-
 .../FailOverLoadBalanceWithRedeliveryTest.java     |   29 +-
 ...lOverLoadBalanceWrappedExceptionNoLuckTest.java |    6 +-
 .../FailOverLoadBalanceWrappedExceptionTest.java   |    6 +-
 .../FailOverLoadBalancerSetFaultTest.java          |   35 +-
 .../processor/FailOverNotCatchedExceptionTest.java |   15 +-
 ...overLoadBalancerBreakoutDuringShutdownTest.java |   34 +-
 .../FailoverMaximumFailoverAttemptsTest.java       |   33 +-
 .../processor/FailoverRoundRobinGoodBadTest.java   |   13 +-
 .../processor/FailoverRoundRobinStickyTest.java    |   29 +-
 .../camel/processor/FailoverRoundRobinTest.java    |   23 +-
 .../apache/camel/processor/FailoverStickyTest.java |   23 +-
 .../camel/processor/FileIdempotentClearTest.java   |    7 +-
 .../FileIdempotentConsumerCreateRepoTest.java      |    3 +-
 .../FileIdempotentConsumerLoadStoreTest.java       |    5 +-
 .../processor/FileIdempotentConsumerTest.java      |    5 +-
 .../camel/processor/FileIdempotentRemoveTest.java  |    5 +-
 .../processor/FileIdempotentTrunkStoreTest.java    |   14 +-
 .../processor/FileRollbackOnCompletionTest.java    |   26 +-
 .../camel/processor/FilterBeforeSplitTest.java     |   15 +-
 .../camel/processor/FilterNotMatchedTest.java      |    6 +-
 .../org/apache/camel/processor/FilterNotTest.java  |    4 +-
 .../apache/camel/processor/FlipRoutePolicy.java    |    3 +-
 .../camel/processor/FlipRoutePolicyTest.java       |   12 +-
 .../apache/camel/processor/FromToInOutTest.java    |   17 +-
 .../processor/IdempotentConsumerAsyncTest.java     |   15 +-
 .../IdempotentConsumerCompletionEagerTest.java     |   29 +-
 .../IdempotentConsumerConcurrentTest.java          |   44 +-
 .../camel/processor/IdempotentConsumerDslTest.java |    6 +-
 .../processor/IdempotentConsumerEagerTest.java     |   43 +-
 .../IdempotentConsumerNoMessageIdTest.java         |    5 +-
 .../IdempotentConsumerRemoveOnFailureTest.java     |   21 +-
 .../IdempotentConsumerRepoExceptionTest.java       |    4 +-
 .../camel/processor/IdempotentConsumerTest.java    |   34 +-
 ...dempotentConsumerUsingCustomRepositoryTest.java |   14 +-
 .../processor/InheritErrorHandlerDefaultTest.java  |    6 +-
 .../processor/InheritErrorHandlerFalseTest.java    |    4 +-
 .../processor/InheritErrorHandlerTrueTest.java     |    6 +-
 .../camel/processor/InlinedProcessorIdTest.java    |   15 +-
 .../org/apache/camel/processor/JoinRoutesTest.java |    6 +-
 .../camel/processor/LanguageBuilderTest.java       |    3 +-
 .../org/apache/camel/processor/LogEipMaskTest.java |    1 +
 .../processor/LogEipPropagateExceptionTest.java    |   23 +-
 .../apache/camel/processor/LogProcessorTest.java   |    4 +-
 .../LogProcessorWithProvidedLoggerTest.java        |    8 +-
 .../apache/camel/processor/LoopAsyncCopyTest.java  |   14 +-
 .../camel/processor/LoopAsyncNoCopyTest.java       |   14 +-
 .../apache/camel/processor/LoopCopyErrorTest.java  |   24 +-
 .../org/apache/camel/processor/LoopCopyTest.java   |   12 +-
 .../apache/camel/processor/LoopDoWhileTest.java    |   15 +-
 .../apache/camel/processor/LoopExceptionTest.java  |    7 +-
 .../org/apache/camel/processor/LoopNoCopyTest.java |   12 +-
 .../java/org/apache/camel/processor/LoopTest.java  |    1 +
 .../apache/camel/processor/LoopTestProcessor.java  |    6 +-
 .../camel/processor/LoopWithAggregatorTest.java    |   22 +-
 .../org/apache/camel/processor/MDCAsyncTest.java   |   50 +-
 .../processor/MDCOnCompletionOnCompletionTest.java |   39 +-
 .../camel/processor/MDCOnCompletionTest.java       |   44 +-
 .../org/apache/camel/processor/MDCResetTest.java   |   62 +-
 .../java/org/apache/camel/processor/MDCTest.java   |   59 +-
 .../org/apache/camel/processor/MDCWireTapTest.java |   51 +-
 .../camel/processor/MDCWithBreadcrumbTest.java     |   32 +-
 .../camel/processor/MarkRollbackOnlyTest.java      |    2 +-
 .../processor/MessageHistoryCopyExchangeTest.java  |   14 +-
 .../processor/MessageHistoryCopyMessageTest.java   |   17 +-
 .../processor/MessageHistoryDumpRoutingTest.java   |   25 +-
 .../processor/MessageHistoryStepOnlyTest.java      |   16 +-
 .../apache/camel/processor/MethodFilterTest.java   |    8 +-
 .../MultiCastParallelAndStreamCachingTest.java     |   50 +-
 .../MultiCastStreamCachingInSubRouteTest.java      |   15 +-
 .../MultiErrorHandlerInRouteNotHandledTest.java    |   12 +-
 .../processor/MultiErrorHandlerInRouteTest.java    |   12 +-
 .../processor/MulticastCompletedPropertyTest.java  |    5 +-
 .../MulticastCopyOfSplitSubUnitOfWorkTest.java     |   25 +-
 .../apache/camel/processor/MulticastDslTest.java   |   19 +-
 .../MulticastFineGrainedErrorHandlingTest.java     |   10 +-
 .../MulticastGroupedExchangeExceptionTest.java     |    6 +-
 .../MulticastKeepOriginalMessageUnchangedTest.java |   14 +-
 .../camel/processor/MulticastNoOnPrepareTest.java  |    6 +-
 .../processor/MulticastNoStopOnExceptionTest.java  |    8 +-
 .../camel/processor/MulticastOnPrepareTest.java    |    3 +-
 .../MulticastParallelAllTimeoutAwareTest.java      |   24 +-
 .../MulticastParallelFailureEndpointTest.java      |   18 +-
 ...ticastParallelFineGrainedErrorHandlingTest.java |   16 +-
 .../MulticastParallelLastTimeoutTest.java          |   25 +-
 .../MulticastParallelMiddleTimeoutTest.java        |   25 +-
 .../MulticastParallelNoStopOnExceptionTest.java    |   40 +-
 .../MulticastParallelStopOnExceptionTest.java      |   38 +-
 .../processor/MulticastParallelStreamingTest.java  |   27 +-
 .../MulticastParallelStreamingTimeoutTest.java     |   25 +-
 .../MulticastParallelStreamingTwoTimeoutTest.java  |   25 +-
 .../processor/MulticastParallelStressTest.java     |   28 +-
 .../camel/processor/MulticastParallelTest.java     |   25 +-
 .../processor/MulticastParallelTimeout2Test.java   |   25 +-
 .../processor/MulticastParallelTimeout3Test.java   |   25 +-
 .../MulticastParallelTimeoutAwareTest.java         |   21 +-
 .../processor/MulticastParallelTimeoutTest.java    |   25 +-
 .../MulticastParallelTwoTimeoutMiddleTest.java     |   31 +-
 .../processor/MulticastParallelTwoTimeoutTest.java |   25 +-
 .../camel/processor/MulticastPipelineTest.java     |   24 +-
 .../camel/processor/MulticastRedeliverTest.java    |   76 +-
 ...castStopOnExceptionLastWithOnExceptionTest.java |   11 +-
 .../processor/MulticastStopOnExceptionTest.java    |    9 +-
 ...ulticastStopOnExceptionWithOnExceptionTest.java |   14 +-
 .../processor/MulticastStreamCachingTest.java      |    5 +-
 .../processor/MulticastSubUnitOfWorkTest.java      |   35 +-
 .../org/apache/camel/processor/MulticastTest.java  |    1 +
 .../processor/MulticastThreadPoolProfileTest.java  |   28 +-
 .../camel/processor/MulticastUnitOfWorkTest.java   |   30 +-
 .../MulticastWithOnExceptionFirstTest.java         |   13 +-
 .../MulticastWithOnExceptionLastTest.java          |   13 +-
 .../processor/MulticastWithOnExceptionTest.java    |   11 +-
 .../apache/camel/processor/MyDelayCalcBean.java    |    2 +-
 .../camel/processor/MyLoggingSentEventNotifer.java |    2 +-
 .../org/apache/camel/processor/MyNormalizer.java   |    6 +-
 .../apache/camel/processor/NavigateRouteTest.java  |   13 +-
 .../camel/processor/NestedChoiceIssueTest.java     |   14 +-
 .../org/apache/camel/processor/NormalizerTest.java |   31 +-
 ...deliveryWhileStoppingDeadLetterChannelTest.java |    7 +-
 .../NotAllowRedeliveryWhileStoppingTest.java       |    7 +-
 ...letionAndInterceptAndOnExceptionGlobalTest.java |   11 +-
 ...nCompletionAndInterceptGlobalSSEnabledTest.java |    2 +-
 .../OnCompletionAndInterceptGlobalTest.java        |    9 +-
 .../processor/OnCompletionAndInterceptTest.java    |   11 +-
 .../camel/processor/OnCompletionAsyncTest.java     |   70 +-
 .../camel/processor/OnCompletionContainsTest.java  |    9 +-
 .../OnCompletionGlobalCustomPoolTest.java          |   13 +-
 .../camel/processor/OnCompletionGlobalTest.java    |    9 +-
 .../camel/processor/OnCompletionModeTest.java      |   20 +-
 .../OnCompletionMoreGlobalRouteCompletionTest.java |   12 +-
 .../processor/OnCompletionMoreGlobalTest.java      |   12 +-
 .../processor/OnCompletionOnCompleteOnlyTest.java  |   15 +-
 .../processor/OnCompletionOnFailureOnlyTest.java   |   12 +-
 .../OnCompletionParallelProcessingTest.java        |    7 +-
 ...ompletionRouteScopeOverrideGlobalScopeTest.java |   18 +-
 .../processor/OnCompletionShouldBeLastTest.java    |   72 +-
 .../OnCompletionShutdownProcessorTest.java         |    5 +-
 .../apache/camel/processor/OnCompletionTest.java   |   14 +-
 .../processor/OnCompletionUseOriginalBodyTest.java |   12 +-
 .../camel/processor/OnCompletionWhenTest.java      |   17 +-
 .../processor/OnExceptionContinueToRouteTest.java  |   14 +-
 .../processor/OnExceptionFailureRouteIdTest.java   |   18 +-
 .../camel/processor/PipelineConcurrentTest.java    |   19 +-
 .../apache/camel/processor/PipelineMEPTest.java    |   24 +-
 .../camel/processor/PipelineStepWithEventTest.java |   41 +-
 .../org/apache/camel/processor/PipelineTest.java   |   18 +-
 .../camel/processor/PolicyPerProcessorTest.java    |   11 +-
 .../apache/camel/processor/PolicyPerRouteTest.java |   18 +-
 .../ProcessorMutateExchangeRedeliverTest.java      |   64 +-
 .../ProducerTemplateDisableEventNotifierTest.java  |    4 +-
 .../RandomLoadBalanceJavaDSLBuilderTest.java       |   20 +-
 .../camel/processor/RandomLoadBalanceTest.java     |    9 +-
 .../RecipientListAggregationStrategyTest.java      |    6 +-
 .../processor/RecipientListBeanOnPrepareTest.java  |    3 +-
 .../RecipientListBeanSubUnitOfWorkTest.java        |   17 +-
 .../camel/processor/RecipientListBeanTest.java     |    2 +-
 ...pientListContextScopedOnExceptionIssueTest.java |   64 +-
 .../RecipientListDoNotStopOnExceptionTest.java     |    6 +-
 .../RecipientListExchangePatternOptionTest.java    |    7 +-
 ...istExchangePropertyAggregationStrategyTest.java |    6 +-
 .../RecipientListExchangePropertyTest.java         |    4 +-
 .../RecipientListFineGrainedErrorHandlingTest.java |   23 +-
 .../processor/RecipientListFunctionalTest.java     |    6 +-
 .../RecipientListIgnoreInvalidEndpointsTest.java   |   19 +-
 ...cipientListInvalidEndpointErrorHandlerTest.java |   10 +-
 ...tInvalidEndpointIgnoreInvalidEndpointsTest.java |   10 +-
 .../camel/processor/RecipientListLeakTest.java     |    2 +-
 .../camel/processor/RecipientListMEPTest.java      |    8 +-
 .../processor/RecipientListMEPWithRawTest.java     |    8 +-
 .../camel/processor/RecipientListNoCacheTest.java  |    6 +-
 .../processor/RecipientListNoErrorHandlerTest.java |   21 +-
 .../processor/RecipientListOnPrepareTest.java      |    3 +-
 ...ntListParallelAggregateThreadPoolIssueTest.java |    6 +-
 ...ntListParallelFineGrainedErrorHandlingTest.java |   20 +-
 ...ParallelStopOnExceptionWithOnExceptionTest.java |   14 +-
 .../RecipientListParallelStreamingTest.java        |   10 +-
 .../camel/processor/RecipientListParallelTest.java |    3 +-
 .../RecipientListParallelTimeoutTest.java          |   24 +-
 .../processor/RecipientListRedeliverTest.java      |   63 +-
 .../processor/RecipientListReturnValueTest.java    |    8 +-
 .../RecipientListStopOnExceptionTest.java          |    6 +-
 ...ientListStopOnExceptionWithOnExceptionTest.java |   11 +-
 .../processor/RecipientListSubUnitOfWorkTest.java  |   17 +-
 .../apache/camel/processor/RecipientListTest.java  |    6 +-
 ...ipientListThrowExceptionFromExpressionTest.java |   10 +-
 .../RecipientListThrowExceptionSubRouteTest.java   |   16 +-
 .../RecipientListWithArrayHeaderTest.java          |    3 +-
 .../processor/RecipientListWithDelimiterTest.java  |    2 +-
 .../RecipientListWithSimpleExpressionTest.java     |    5 +-
 ...RecipientListWithStringDelimitedHeaderTest.java |    2 +-
 ...cipientListWithStringDelimitedPropertyTest.java |    6 +-
 .../camel/processor/RedeliverToSubRouteTest.java   |   16 +-
 ...tterErrorHandlerNoRedeliveryOnShutdownTest.java |   10 +-
 .../RedeliveryErrorHandlerBlockedDelayTest.java    |   37 +-
 ...veryErrorHandlerBreakoutDuringShutdownTest.java |   16 +-
 .../RedeliveryErrorHandlerLogHandledTest.java      |   73 +-
 ...veryErrorHandlerNoRedeliveryOnShutdownTest.java |   14 +-
 .../RedeliveryErrorHandlerNonBlockedDelayTest.java |   34 +-
 ...ErrorHandlerNonBlockedRedeliveryHeaderTest.java |   37 +-
 .../RedeliveryOnExceptionBlockedDelayTest.java     |   37 +-
 .../RedeliveryPolicyPerExceptionTest.java          |    3 +-
 .../org/apache/camel/processor/RegExRouteTest.java |    8 +-
 .../apache/camel/processor/RemoveHeaderTest.java   |   13 +-
 .../camel/processor/RemoveHeadersExcludeTest.java  |   12 +-
 .../apache/camel/processor/RemoveHeadersTest.java  |    8 +-
 .../RemovePropertiesWithExclusionTest.java         |   17 +-
 .../RemovePropertiesWithoutExclusionTest.java      |   14 +-
 .../apache/camel/processor/RemovePropertyTest.java |   11 +-
 .../ResequenceBatchIgnoreInvalidExchangesTest.java |    8 +-
 ...sequenceBatchNotIgnoreInvalidExchangesTest.java |    4 +-
 ...ResequenceStreamIgnoreInvalidExchangesTest.java |    8 +-
 ...equenceStreamNotIgnoreInvalidExchangesTest.java |    4 +-
 .../ResequenceStreamRejectOldExchangesTest.java    |   10 +-
 .../apache/camel/processor/ResequencerTest.java    |    9 +-
 .../camel/processor/RollbackCustomMessageTest.java |    2 +-
 .../processor/RollbackDefaultErrorHandlerTest.java |   20 +-
 .../org/apache/camel/processor/RollbackTest.java   |    9 +-
 .../camel/processor/RoundRobinLoadBalanceTest.java |   10 +-
 .../camel/processor/RouteAutoStartupTest.java      |    2 +-
 .../camel/processor/RouteAwareRouteTest.java       |    4 +-
 .../processor/RouteAwareSynchronizationTest.java   |    8 +-
 .../camel/processor/RouteContextProcessorTest.java |   22 +-
 .../camel/processor/RouteFormattedUriTest.java     |    1 +
 .../org/apache/camel/processor/RouteIdTest.java    |   10 +-
 .../camel/processor/RoutePerformanceCountTest.java |    6 +-
 .../camel/processor/RoutePoliciesRefTest.java      |    5 +-
 .../apache/camel/processor/RoutePoliciesTest.java  |    5 +-
 .../processor/RouteServicesStartupOrderTest.java   |    4 +-
 .../RouteShutdownNotReverseOrderTest.java          |    4 +-
 .../processor/RouteShutdownReverseOrderTest.java   |    4 +-
 .../processor/RouteStartupOrderClashTest.java      |    2 +-
 .../RouteStartupOrderDirectReverseTest.java        |    4 +-
 .../processor/RouteStartupOrderDirectTest.java     |    4 +-
 .../camel/processor/RouteStartupOrderLastTest.java |    2 +-
 .../processor/RouteStartupOrderSimpleTest.java     |    4 +-
 ...StartupOrderSuspendResumeNoAutoStartupTest.java |    6 +-
 .../RouteStartupOrderSuspendResumeTest.java        |    4 +-
 .../camel/processor/RouteStartupOrderTest.java     |    4 +-
 .../RouteStartupOrderWithDefaultTest.java          |    4 +-
 .../org/apache/camel/processor/RouteStopTest.java  |   12 +-
 .../processor/RouteTopLevelMisconfiguredTest.java  |   22 +-
 ...RouteWithConstantFieldFromExchangeFailTest.java |    4 +-
 .../RouteWithConstantFieldFromExchangeTest.java    |    4 +-
 ...utingSlipContextScopedOnExceptionIssueTest.java |   54 +-
 .../apache/camel/processor/RoutingSlipDslTest.java |    4 +-
 .../processor/RoutingSlipInOutAndInOnlyTest.java   |   13 +-
 .../camel/processor/RoutingSlipNoCacheTest.java    |    6 +-
 .../processor/RoutingSlipNoErrorHandlerTest.java   |   21 +-
 .../RoutingSlipNoSuchEndpointExceptionTest.java    |   16 +-
 .../processor/RoutingSlipOnExceptionTest.java      |    8 +-
 .../camel/processor/RoutingSlipRedeliverTest.java  |   65 +-
 ...outingSlipThrowExceptionFromExpressionTest.java |   10 +-
 .../apache/camel/processor/SagaFailuresTest.java   |   49 +-
 .../apache/camel/processor/SagaOptionsTest.java    |   26 +-
 .../camel/processor/SagaPropagationTest.java       |   68 +-
 .../java/org/apache/camel/processor/SagaTest.java  |   59 +-
 .../apache/camel/processor/SagaTimeoutTest.java    |   21 +-
 .../camel/processor/SamplingThrottlerTest.java     |   36 +-
 .../apache/camel/processor/ScriptExternalTest.java |    4 +-
 .../org/apache/camel/processor/ScriptTest.java     |    4 +-
 .../processor/SendExchangePatternOptionTest.java   |    7 +-
 .../camel/processor/SendToNoErrorHandlerTest.java  |   21 +-
 .../camel/processor/SetBodyProcessorTest.java      |   14 +-
 .../camel/processor/SetExchangePatternTest.java    |   20 +-
 .../SetHeaderUsingDslExpressionsTest.java          |   44 +-
 .../apache/camel/processor/SetPropertyTest.java    |    5 +-
 .../processor/ShutdownCompleteAllTasksTest.java    |    7 +-
 .../ShutdownCompleteCurrentTaskOnlyTest.java       |    6 +-
 .../apache/camel/processor/ShutdownDeferTest.java  |   17 +-
 .../camel/processor/ShutdownNotDeferTest.java      |   10 +-
 .../ShutdownSedaAndDirectEndpointTest.java         |   10 +-
 .../processor/SimpleProcessorIdAwareTest.java      |   13 +-
 .../camel/processor/SimpleResultTypeRouteTest.java |    8 +-
 .../processor/SimpleSingleOutputMockTest.java      |    1 -
 .../camel/processor/SimpleTryCatchFinallyTest.java |   14 +-
 .../camel/processor/SimpleTryFinallyTest.java      |    8 +-
 .../SimpleTryThrowExceptionFinallyTest.java        |   11 +-
 .../org/apache/camel/processor/SimulatorTest.java  |    8 +-
 .../org/apache/camel/processor/SortBodyTest.java   |    4 +-
 .../apache/camel/processor/SortExpressionTest.java |    2 +-
 .../camel/processor/SplitAggregateInOutTest.java   |   48 +-
 .../camel/processor/SplitCustomExpressionTest.java |    6 +-
 .../camel/processor/SplitGroupMultiLinesTest.java  |    3 +-
 .../camel/processor/SplitGroupMultiXmlTest.java    |    8 +-
 .../processor/SplitGroupMultiXmlTokenTest.java     |   14 +-
 .../camel/processor/SplitGroupSkipFirstTest.java   |    8 +-
 .../SplitGroupWrappedMultiXmlTokenTest.java        |   19 +-
 .../camel/processor/SplitIteratorNullTest.java     |    4 +-
 .../camel/processor/SplitParallelTimeoutTest.java  |   23 +-
 .../processor/SplitRefCustomExpressionTest.java    |    6 +-
 ...ubUnitOfWorkStopOnExceptionAndParallelTest.java |   21 +-
 ...SplitSubUnitOfWorkStopOnExceptionIssueTest.java |   23 +-
 .../SplitSubUnitOfWorkStopOnExceptionTest.java     |   21 +-
 .../camel/processor/SplitSubUnitOfWorkTest.java    |   25 +-
 .../processor/SplitTokenizerGroupDynamicTest.java  |   12 +-
 .../camel/processor/SplitTokenizerGroupTest.java   |   12 +-
 .../processor/SplitTokenizerNamespaceTest.java     |   46 +-
 .../processor/SplitTokenizerRegexpGroupTest.java   |    4 +-
 .../apache/camel/processor/SplitTokenizerTest.java |   48 +-
 .../processor/SplitTokenizerXmlMultilineTest.java  |   13 +-
 .../camel/processor/SplitTwoSubUnitOfWorkTest.java |   41 +-
 .../apache/camel/processor/SplitWithEndTest.java   |   32 +-
 .../camel/processor/SplitterCollateTest.java       |    4 +-
 .../processor/SplitterCompletedPropertyTest.java   |   10 +-
 .../camel/processor/SplitterMethodCallTest.java    |    8 +-
 .../SplitterNoAggregationStrategyTest.java         |    7 +-
 .../processor/SplitterNoStopOnExceptionTest.java   |   10 +-
 .../processor/SplitterNullBodyParallelTest.java    |   12 +-
 .../camel/processor/SplitterNullBodyTest.java      |   14 +-
 .../camel/processor/SplitterOnCompletionTest.java  |    5 +-
 .../SplitterOnPrepareExceptionStreamingTest.java   |    4 +-
 .../processor/SplitterOnPrepareExceptionTest.java  |    4 +-
 .../camel/processor/SplitterOnPrepareTest.java     |    4 +-
 .../processor/SplitterParallelAggregateTest.java   |   14 +-
 .../processor/SplitterParallelBigFileTest.java     |    8 +-
 .../SplitterParallelNoStopOnExceptionTest.java     |   30 +-
 .../SplitterParallelStopOnExceptionTest.java       |   27 +-
 ...ParallelStopOnExceptionWithOnExceptionTest.java |   21 +-
 .../apache/camel/processor/SplitterPojoTest.java   |   35 +-
 .../processor/SplitterPropertyContinuedTest.java   |   29 +-
 ...SplitterShareUnitOfWorkCompletionAwareTest.java |    8 +-
 .../apache/camel/processor/SplitterSkipTest.java   |    4 +-
 .../processor/SplitterStopOnExceptionTest.java     |    8 +-
 ...SplitterStopOnExceptionWithOnExceptionTest.java |   21 +-
 .../camel/processor/SplitterStreamCacheTest.java   |   12 +-
 .../SplitterStreamCachingInSubRouteTest.java       |   16 +-
 .../SplitterStreamingErrorHandlingTest.java        |   28 +-
 ...rStreamingStopOnExceptionErrorHandlingTest.java |   22 +-
 .../processor/SplitterStreamingUoWIssueTest.java   |   13 +-
 .../org/apache/camel/processor/SplitterTest.java   |   36 +-
 .../SplitterThrowExceptionFromExpressionTest.java  |   11 +-
 .../camel/processor/SplitterUoWIssueTest.java      |   13 +-
 .../processor/SplitterUseOriginalLoopTest.java     |   12 +-
 ...litterUseOriginalNotPropagateExceptionTest.java |   13 +-
 .../processor/SplitterWireTapStreamCacheTest.java  |   22 +-
 .../SplitterWithCustomThreadPoolExecutorTest.java  |   21 +-
 .../processor/SplitterWithDualMulticastTest.java   |   26 +-
 .../camel/processor/SplitterWithMulticastTest.java |   17 +-
 .../SplitterWithScannerIoExceptionTest.java        |   10 +-
 .../camel/processor/SplitterWithXqureyTest.java    |   26 +-
 .../camel/processor/StepEventNotifierTest.java     |   19 +-
 .../java/org/apache/camel/processor/StepTest.java  |   11 +-
 .../camel/processor/StickyLoadBalanceTest.java     |    6 +-
 .../StreamCachingCustomShouldSpoolRuleTest.java    |   12 +-
 .../camel/processor/StreamCachingInOutTest.java    |    2 +-
 .../processor/StreamCachingOnlyRouteTest.java      |    2 +-
 .../camel/processor/StreamCachingPerRouteTest.java |    2 +-
 .../processor/StreamCachingRecipientListTest.java  |    4 +-
 .../processor/StreamCachingRoutingSlipTest.java    |    4 +-
 .../StreamCachingSpoolDirectoryQuarkusTest.java    |   11 +-
 .../processor/StreamCachingXPathRouteTest.java     |    7 +-
 ...SourceContentBasedRouterNoErrorHandlerTest.java |   10 +-
 ...tentBasedRouterSSEnabledOnCamelContextTest.java |   11 +-
 .../StreamSourceContentBasedRouterTest.java        |   15 +-
 .../ThreadsCoreAndMaxPoolInvalidTest.java          |    6 +-
 .../ThreadsCoreAndMaxPoolKeepAliveTimeTest.java    |    8 +-
 .../camel/processor/ThreadsCoreAndMaxPoolTest.java |   11 +-
 .../camel/processor/ThreadsCorePoolTest.java       |   41 +-
 .../apache/camel/processor/ThreadsDefaultTest.java |    4 +-
 .../camel/processor/ThreadsInvalidConfigTest.java  |   34 +-
 .../camel/processor/ThreadsMaxQueueSizeTest.java   |   11 +-
 .../processor/ThreadsRejectedExecutionTest.java    |   77 +-
 .../camel/processor/ThreadsRejectedPolicyTest.java |    9 +-
 .../camel/processor/ThreadsRequestReplyTest.java   |   27 +-
 .../processor/ThreadsZeroInCoreAndMaxPoolTest.java |   16 +-
 .../ThrottlerAsyncDelayedCallerRunsTest.java       |    9 +-
 .../camel/processor/ThrottlerAsyncDelayedTest.java |    4 +-
 .../apache/camel/processor/ThrottlerDslTest.java   |    8 +-
 .../processor/ThrottlerInvalidConfiguredTest.java  |    2 +-
 .../camel/processor/ThrottlerMethodCallTest.java   |    6 +-
 .../camel/processor/ThrottlerNullEvalTest.java     |    2 +-
 .../org/apache/camel/processor/ThrottlerTest.java  |   40 +-
 .../processor/ThrottlerThreadPoolProfileTest.java  |    6 +-
 ...xceptionRoutePolicyHalfOpenHandlerSedaTest.java |   36 +-
 ...ingExceptionRoutePolicyHalfOpenHandlerTest.java |   38 +-
 ...ThrottlingExceptionRoutePolicyHalfOpenTest.java |   31 +-
 ...lingExceptionRoutePolicyKeepOpenOnInitTest.java |    6 +-
 ...tlingExceptionRoutePolicyOpenViaConfigTest.java |    8 +-
 .../ThrottlingExceptionRoutePolicyTest.java        |   30 +-
 .../camel/processor/ThrottlingGroupingTest.java    |   44 +-
 .../ThrottlingInflightRoutePolicyTest.java         |    5 +-
 .../camel/processor/ThrowExceptionMessageTest.java |    5 +-
 .../processor/ThrowExceptionNullMessageTest.java   |    5 +-
 .../apache/camel/processor/ThrowExceptionTest.java |    5 +-
 .../apache/camel/processor/ToDynamicEmptyTest.java |    3 +-
 .../camel/processor/ToDynamicIgnoreTest.java       |    3 +-
 ...DynamicLanguageSimpleAndXPathAndHeaderTest.java |    3 +-
 .../ToDynamicLanguageSimpleAndXPathTest.java       |    3 +-
 .../processor/ToDynamicLanguageXPathTest.java      |    3 +-
 .../camel/processor/ToDynamicRawAndXPathTest.java  |    3 +-
 .../apache/camel/processor/ToDynamicRawTest.java   |    3 +-
 .../processor/ToDynamicSendDynamicAwareTest.java   |    4 +-
 .../org/apache/camel/processor/ToDynamicTest.java  |    3 +-
 .../camel/processor/ToEndpointPropertyTest.java    |    2 -
 .../camel/processor/TopicLoadBalanceTest.java      |    6 +-
 .../apache/camel/processor/TraceDelayerTest.java   |    2 +-
 .../camel/processor/TraceInterceptorTest.java      |   23 +-
 .../camel/processor/TracePerRouteManualTest.java   |    2 +-
 .../camel/processor/TracerConfigurationTest.java   |    2 +-
 .../processor/TransformBeanExceptionTest.java      |   15 +-
 .../processor/TransformExternalScriptTest.java     |    4 +-
 .../TransformProcessorWithHeaderTest.java          |    9 +-
 .../org/apache/camel/processor/TransformTest.java  |    1 +
 .../camel/processor/TransformViaDSLTest.java       |    1 +
 .../apache/camel/processor/TransformXpathTest.java |    6 +-
 .../processor/TripleNestedChoiceIssueTest.java     |   19 +-
 .../TryCatchCaughtExceptionFinallyTest.java        |   35 +-
 .../processor/TryCatchCaughtExceptionTest.java     |   21 +-
 .../TryCatchCaughtExceptionTwoTimesTest.java       |   40 +-
 .../processor/TryCatchContinueToRouteTest.java     |   20 +-
 .../TryCatchMustHaveExceptionConfiguredTest.java   |   10 +-
 .../camel/processor/TryCatchNestedChoiceTest.java  |   31 +-
 .../camel/processor/TryCatchRecipientListTest.java |  135 +-
 .../processor/TryFinallyCaughtExceptionTest.java   |    9 +-
 .../TryProcessorHandleWrappedExceptionTest.java    |   16 +-
 .../TryProcessorMultipleExceptionTest.java         |   13 +-
 .../camel/processor/TryProcessorOnWhenTest.java    |   28 +-
 .../apache/camel/processor/TryProcessorTest.java   |   49 +-
 .../TypeConverterRegistryStatsPerformanceTest.java |    6 +-
 .../camel/processor/UnitOfWorkProducerTest.java    |    3 +-
 .../UnitOfWorkSynchronizationAdapterTest.java      |    2 +-
 .../org/apache/camel/processor/UnitOfWorkTest.java |    5 +-
 .../processor/UnitOfWorkWithAsyncFlowTest.java     |    1 +
 .../org/apache/camel/processor/ValidateIdTest.java |    7 +-
 .../apache/camel/processor/ValidateRegExpTest.java |   19 +-
 .../camel/processor/ValidateSimpleRegExpTest.java  |    8 +-
 .../apache/camel/processor/ValidateSimpleTest.java |    8 +-
 .../processor/ValidatingDomProcessorTest.java      |    8 +-
 .../ValidatingProcessorFromSourceTest.java         |    2 +-
 .../processor/ValidatingProcessorFromUrlTest.java  |    3 +-
 .../ValidatingProcessorNotUseSharedSchemaTest.java |   24 +-
 .../camel/processor/ValidatingProcessorTest.java   |   34 +-
 .../ValidationFinallyBlockNoCatchTest.java         |   13 +-
 .../processor/ValidationFinallyBlockTest.java      |    5 +-
 .../org/apache/camel/processor/ValidationTest.java |   24 +-
 ...dationWithErrorInHandleAndFinallyBlockTest.java |   16 +-
 .../processor/ValidationWithExceptionTest.java     |    6 +-
 .../ValidationWithFinallyBlockPipelineTest.java    |   15 +-
 ...lidationWithHandlePipelineAndExceptionTest.java |    8 +-
 .../ValidationWithHandlePipelineTest.java          |   10 +-
 .../ValidationWithInFlowExceptionTest.java         |    6 +-
 .../ValidationWithMultipleHandlesTest.java         |   12 +-
 ...lidationWithNestedFinallyBlockPipelineTest.java |   15 +-
 .../camel/processor/VerySimpleDirectTest.java      |    2 +-
 .../processor/WeightedRandomLoadBalanceTest.java   |   38 +-
 .../WeightedRoundRobinLoadBalanceTest.java         |   39 +-
 .../processor/WireTapBeanAsProcessorTest.java      |    9 +-
 .../apache/camel/processor/WireTapBeanTest.java    |   12 +-
 .../camel/processor/WireTapCustomPool2Test.java    |   15 +-
 .../camel/processor/WireTapCustomPoolTest.java     |   15 +-
 .../camel/processor/WireTapExpressionTest.java     |    5 +-
 .../camel/processor/WireTapLogEndpointTest.java    |    8 +-
 .../org/apache/camel/processor/WireTapLogTest.java |    8 +-
 .../camel/processor/WireTapNewExchangeTest.java    |   10 +-
 .../camel/processor/WireTapOnExceptionTest.java    |    4 +-
 .../camel/processor/WireTapOnPrepareRefTest.java   |    4 +-
 .../camel/processor/WireTapOnPrepareTest.java      |    4 +-
 .../camel/processor/WireTapShutdownBeanTest.java   |   11 +-
 .../camel/processor/WireTapShutdownRouteTest.java  |   14 +-
 .../camel/processor/WireTapStreamCachingTest.java  |   15 +-
 .../org/apache/camel/processor/WireTapTest.java    |   18 +-
 ...WireTapUsingFireAndForgetCopyAsDefaultTest.java |   32 +-
 .../WireTapUsingFireAndForgetCopyTest.java         |   34 +-
 .../processor/WireTapUsingFireAndForgetTest.java   |   14 +-
 .../camel/processor/WireTapUsingMulticastTest.java |    1 +
 .../camel/processor/WireTapVoidBeanTest.java       |    8 +-
 .../apache/camel/processor/XPathChoiceTest.java    |    9 +-
 .../apache/camel/processor/XPathFilterTest.java    |    4 +-
 ...ithNamespaceBuilderFilterAndResultTypeTest.java |    9 +-
 .../XPathWithNamespaceBuilderFilterTest.java       |   13 +-
 .../processor/XPathWithNamespacesFilterTest.java   |   10 +-
 ...ggregateAggregationStrategyIsPredicateTest.java |    4 +-
 .../AggregateClosedCorrelationKeyTest.java         |   13 +-
 .../aggregator/AggregateCompleteAllOnStopTest.java |    6 +-
 ...yBatchConsumerSendEmptyMessageWhenIdleTest.java |    5 +-
 ...gateCompletionAwareAggregationStrategyTest.java |    7 +-
 .../AggregateCompletionIntervalTest.java           |   15 +-
 ...gregateCompletionOnNewCorrelationGroupTest.java |    9 +-
 .../aggregator/AggregateCompletionOnlyOneTest.java |    5 +-
 .../aggregator/AggregateCompletionOnlyTwoTest.java |    5 +-
 .../AggregateCompletionPredicateTest.java          |    6 +-
 ...ggregateCompletionSizeAndBatchConsumerTest.java |    6 +-
 ...gateCompletionSizeExpressionAndTimeoutTest.java |    9 +-
 .../AggregateConcurrentPerCorrelationKeyTest.java  |    4 +-
 .../aggregator/AggregateControllerTest.java        |    8 +-
 .../aggregator/AggregateDiscardOnFailureTest.java  |   10 +-
 .../aggregator/AggregateDiscardOnTimeoutTest.java  |   18 +-
 .../processor/aggregator/AggregateDslTest.java     |   26 +-
 .../AggregateEagerCheckCompletionTest.java         |   14 +-
 .../AggregateExpressionSizeFallbackTest.java       |   12 +-
 .../AggregateExpressionSizeOverrideFixedTest.java  |    7 +-
 ...gateExpressionSizeOverrideFixedTimeoutTest.java |    9 +-
 .../aggregator/AggregateExpressionSizeTest.java    |   11 +-
 .../aggregator/AggregateExpressionTest.java        |    6 +-
 .../AggregateExpressionTimeoutFallbackTest.java    |   10 +-
 .../AggregateExpressionTimeoutPerGroupTest.java    |   13 +-
 .../aggregator/AggregateExpressionTimeoutTest.java |   11 +-
 ...eCompletionHeaderInAggregationStrategyTest.java |   13 +-
 .../AggregateForceCompletionHeaderTest.java        |   16 +-
 ...AggregateForceCompletionOnStopParallelTest.java |   10 +-
 .../AggregateForceCompletionOnStopTest.java        |    8 +-
 .../aggregator/AggregateFromWireTapTest.java       |   23 +-
 .../aggregator/AggregateGroupMessageTest.java      |    7 +-
 .../AggregateGroupedExchangeBatchSizeTest.java     |   18 +-
 ...roupedExchangeCompletionExpressionSizeTest.java |    8 +-
 ...AggregateGroupedExchangeCompletionSizeTest.java |    6 +-
 ...gateGroupedExchangeMultipleCorrelationTest.java |   12 +-
 .../AggregateGroupedExchangeSizePredicateTest.java |    9 +-
 .../AggregateGroupedExchangeSizeTest.java          |    7 +-
 .../aggregator/AggregateGroupedExchangeTest.java   |   13 +-
 .../AggregateIgnoreInvalidCorrelationKeysTest.java |   12 +-
 .../aggregator/AggregateLostGroupIssueTest.java    |   17 +-
 .../aggregator/AggregateMultipleSourceTest.java    |    6 +-
 .../AggregateNewExchangeAndConfirmTest.java        |    8 +-
 .../AggregateParallelProcessingTest.java           |   12 +-
 .../AggregatePreCompleteAwareStrategyTest.java     |    6 +-
 ...gregatePreCompleteAwareStrategyTimeoutTest.java |    7 +-
 .../aggregator/AggregateProcessorTest.java         |    5 +-
 ...egateProcessorTimeoutCompletionRestartTest.java |   21 +-
 .../AggregateRepositoryReturnNullTest.java         |    4 +-
 .../AggregateShouldSkipFilteredExchangesTest.java  |   12 +-
 .../AggregateShutdownThreadPoolTest.java           |   10 +-
 .../AggregateSimpleExpressionIssueTest.java        |   11 +-
 .../AggregateSimplePredicateEagerTest.java         |   15 +-
 .../aggregator/AggregateSimplePredicateTest.java   |   11 +-
 .../aggregator/AggregateSimpleSizeTest.java        |   11 +-
 .../aggregator/AggregateSimpleTimeoutTest.java     |    9 +-
 .../aggregator/AggregateStrategyServiceTest.java   |    5 +-
 .../aggregator/AggregateThreadPoolProfileTest.java |   11 +-
 .../aggregator/AggregateTimeoutManualTest.java     |    5 +-
 .../aggregator/AggregateTimeoutOnlyTest.java       |    6 +-
 .../processor/aggregator/AggregateTimeoutTest.java |   25 +-
 .../AggregateTimeoutWithExecutorServiceTest.java   |   13 +-
 .../AggregateTimeoutWithNoExecutorServiceTest.java |   18 +-
 .../AggregateUnknownExecutorServiceRefTest.java    |   11 +-
 .../AggregationStrategyAsPredicateTest.java        |    7 +-
 ...trategyBeanAdapterAllowNullOldExchangeTest.java |    5 +-
 ...ggregationStrategyBeanAdapterAllowNullTest.java |    5 +-
 ...tionStrategyBeanAdapterNonStaticMethodTest.java |    5 +-
 ...ggregationStrategyBeanAdapterOneMethodTest.java |    5 +-
 ...nAdapterPollEnrichAllowNullNewExchangeTest.java |    4 +-
 ...gregationStrategyBeanAdapterPollEnrichTest.java |    4 +-
 ...gationStrategyBeanAdapterRefMethodNameTest.java |    5 +-
 .../AggregationStrategyBeanAdapterRefTest.java     |    5 +-
 ...egationStrategyBeanAdapterStaticMethodTest.java |    5 +-
 .../AggregationStrategyBeanAdapterTest.java        |    5 +-
 ...egyBeanAdapterWithHeadersAndPropertiesTest.java |   11 +-
 ...regationStrategyBeanAdapterWithHeadersTest.java |    5 +-
 .../AggregationStrategyCompleteByPropertyTest.java |    7 +-
 .../AggregationStrategyLifecycleTest.java          |    7 +-
 .../aggregator/AggregatorAndOnExceptionTest.java   |   13 +-
 .../aggregator/AggregatorConcurrencyTest.java      |   24 +-
 .../aggregator/AggregatorExceptionHandleTest.java  |    6 +-
 .../AggregatorExceptionInPredicateTest.java        |   47 +-
 .../aggregator/AggregatorExceptionTest.java        |   13 +-
 .../aggregator/AggregatorLockingTest.java          |   23 +-
 .../camel/processor/aggregator/AggregatorTest.java |   20 +-
 .../aggregator/AlbertoAggregatorTest.java          |   61 +-
 .../aggregator/BeanBeforeAggregateIssueTest.java   |    8 +-
 .../CustomAggregationStrategyServiceTest.java      |    5 +-
 .../aggregator/CustomAggregationStrategyTest.java  |   14 +-
 ...ionStrategyCompletionFromBatchConsumerTest.java |    6 +-
 ...ustomListAggregationStrategyEmptySplitTest.java |   13 +-
 .../CustomListAggregationStrategySplitTest.java    |    6 +-
 .../CustomListAggregationStrategyTest.java         |    5 +-
 .../DefaultAggregatorCollectionTest.java           |   11 +-
 .../DistributedCompletionIntervalTest.java         |   20 +-
 ...DistributedConcurrentPerCorrelationKeyTest.java |    8 +-
 .../DistributedOptimisticLockFailingTest.java      |   26 +-
 .../aggregator/DistributedTimeoutTest.java         |   23 +-
 .../EnricherRouteNumberOfProcessorTest.java        |   82 +-
 .../aggregator/OptimisticLockRetryPolicyTest.java  |    2 +-
 .../PredicateAggregatorCollectionTest.java         |   13 +-
 .../SplitRouteNumberOfProcessorTest.java           |   77 +-
 .../aggregator/StringAggregationStrategyTest.java  |   29 +-
 ...yncDeadLetterChannelExecutorServiceRefTest.java |   19 +-
 .../async/AsyncDeadLetterChannelTest.java          |   16 +-
 .../async/AsyncDefaultErrorHandlerTest.java        |   15 +-
 .../processor/async/AsyncEndpointCBRTest.java      |   31 +-
 .../AsyncEndpointCustomAsyncInterceptorTest.java   |   35 +-
 .../async/AsyncEndpointCustomInterceptorTest.java  |   36 +-
 .../async/AsyncEndpointCustomRoutePolicyTest.java  |   26 +-
 .../processor/async/AsyncEndpointDelayUoWTest.java |   31 +-
 .../async/AsyncEndpointDoWhileLoopTest.java        |   15 +-
 .../async/AsyncEndpointDualMulticastTest.java      |   21 +-
 .../AsyncEndpointDualTopicLoadBalanceTest.java     |   12 +-
 .../async/AsyncEndpointDynamicRouterTest.java      |   17 +-
 .../processor/async/AsyncEndpointEnricherTest.java |   28 +-
 .../AsyncEndpointEventNotifierSendingTest.java     |    7 +-
 .../async/AsyncEndpointEventNotifierTest.java      |   11 +-
 ...AsyncEndpointFailOverLoadBalanceMixed2Test.java |   36 +-
 ...AsyncEndpointFailOverLoadBalanceMixed3Test.java |   42 +-
 .../AsyncEndpointFailOverLoadBalanceMixedTest.java |   36 +-
 ...ncEndpointFailOverLoadBalanceOnlyAsyncTest.java |   28 +-
 ...ncEndpointFailedAfterDeadLetterChannelTest.java |   29 +-
 ...EndpointFailedAfterOnExceptionContinueTest.java |   32 +-
 ...cEndpointFailedAfterOnExceptionHandledTest.java |   29 +-
 .../async/AsyncEndpointFailedAfterTest.java        |   29 +-
 .../AsyncEndpointFailureProcessorContinueTest.java |   35 +-
 .../async/AsyncEndpointFailureProcessorTest.java   |   35 +-
 .../processor/async/AsyncEndpointFilterTest.java   |   30 +-
 .../async/AsyncEndpointIdempotentConsumerTest.java |   29 +-
 .../processor/async/AsyncEndpointLoopTest.java     |   31 +-
 ...pointMulticastFineGrainedErrorHandlingTest.java |   13 +-
 .../async/AsyncEndpointMulticastTest.java          |   30 +-
 .../processor/async/AsyncEndpointPipelineTest.java |    5 +-
 .../processor/async/AsyncEndpointPolicyTest.java   |   38 +-
 .../async/AsyncEndpointRecipientList2Test.java     |   31 +-
 .../async/AsyncEndpointRecipientList3Test.java     |   32 +-
 .../async/AsyncEndpointRecipientList4Test.java     |   32 +-
 .../async/AsyncEndpointRecipientListBean3Test.java |   32 +-
 .../async/AsyncEndpointRecipientListBean4Test.java |   32 +-
 .../async/AsyncEndpointRecipientListBeanTest.java  |   28 +-
 ...tRecipientListFineGrainedErrorHandlingTest.java |   10 +-
 .../AsyncEndpointRecipientListParallel2Test.java   |   31 +-
 .../AsyncEndpointRecipientListParallel3Test.java   |   32 +-
 .../AsyncEndpointRecipientListParallel4Test.java   |   32 +-
 .../AsyncEndpointRecipientListParallel5Test.java   |   33 +-
 .../AsyncEndpointRecipientListParallelTest.java    |   28 +-
 .../async/AsyncEndpointRecipientListTest.java      |   28 +-
 ...RedeliveryErrorHandlerNonBlockedDelay2Test.java |   50 +-
 ...RedeliveryErrorHandlerNonBlockedDelay3Test.java |   27 +-
 ...tRedeliveryErrorHandlerNonBlockedDelayTest.java |   50 +-
 .../AsyncEndpointRoundRobinLoadBalanceTest.java    |   31 +-
 .../async/AsyncEndpointRoutingSlip2Test.java       |    5 +-
 .../async/AsyncEndpointRoutingSlip3Test.java       |   36 +-
 .../async/AsyncEndpointRoutingSlipBean2Test.java   |    5 +-
 .../async/AsyncEndpointRoutingSlipBean3Test.java   |   36 +-
 ...syncEndpointRoutingSlipBeanNonBlockingTest.java |    8 +-
 .../async/AsyncEndpointRoutingSlipBeanTest.java    |    6 +-
 .../async/AsyncEndpointRoutingSlipTest.java        |    5 +-
 .../processor/async/AsyncEndpointSamplingTest.java |   30 +-
 .../async/AsyncEndpointSedaInOnlyTest.java         |   43 +-
 .../processor/async/AsyncEndpointSedaTest.java     |   29 +-
 .../AsyncEndpointSingleTopicLoadBalanceTest.java   |   12 +-
 ...cEndpointSplitFineGrainedErrorHandlingTest.java |   23 +-
 .../processor/async/AsyncEndpointSplitTest.java    |   30 +-
 ...pointSplitUseLatestAggregationStrategyTest.java |   30 +-
 .../processor/async/AsyncEndpointStopTest.java     |   29 +-
 .../async/AsyncEndpointSynchronousFalseTest.java   |   26 +-
 .../async/AsyncEndpointSynchronousTest.java        |   26 +-
 .../camel/processor/async/AsyncEndpointTest.java   |   26 +-
 .../async/AsyncEndpointTransformTest.java          |   30 +-
 .../async/AsyncEndpointTryCatchFinally2Test.java   |   45 +-
 .../async/AsyncEndpointTryCatchFinally3Test.java   |   55 +-
 .../async/AsyncEndpointTryCatchFinally4Test.java   |   15 +-
 .../async/AsyncEndpointTryCatchFinally5Test.java   |   21 +-
 .../async/AsyncEndpointTryCatchFinallyTest.java    |   33 +-
 .../async/AsyncEndpointUoWFailedTest.java          |   31 +-
 .../processor/async/AsyncEndpointUoWTest.java      |   30 +-
 .../async/AsyncEndpointWithDelayerTest.java        |   28 +-
 .../async/AsyncEndpointWithStreamCachingTest.java  |   28 +-
 .../async/AsyncEndpointWithTracingTest.java        |   28 +-
 ...FailureProcessorWithRedeliveryAndDelayTest.java |   33 +-
 .../AsyncFailureProcessorWithRedeliveryTest.java   |   33 +-
 .../processor/async/AsyncInOnlyEndpointTest.java   |   28 +-
 .../apache/camel/processor/async/AsyncMDCTest.java |   41 +-
 .../async/AsyncNestedTripleChoiceIssueTest.java    |   22 +-
 ...xceptionFailureProcessorWithRedeliveryTest.java |   21 +-
 .../AsyncProcessorAwaitManagerInterruptTest.java   |   34 +-
 ...sorAwaitManagerInterruptWithRedeliveryTest.java |   13 +-
 .../async/AsyncProcessorAwaitManagerTest.java      |   37 +-
 .../camel/processor/async/AsyncProducerTest.java   |   24 +-
 .../processor/async/AsyncRouteWithErrorTest.java   |   38 +-
 .../async/AsyncSedaInOnlyEndpointTest.java         |   28 +-
 .../processor/async/AsyncTwoEndpointTest.java      |   40 +-
 .../camel/processor/async/MyAsyncComponent.java    |    2 +-
 .../camel/processor/async/MyAsyncProducer.java     |    2 +-
 .../EnrichExpressionIgnoreInvalidEndpointTest.java |    4 +-
 .../enricher/EnrichExpressionNoCacheTest.java      |    4 +-
 .../processor/enricher/EnrichExpressionTest.java   |    4 +-
 .../enricher/EnricherAggregateOnExceptionTest.java |   11 +-
 .../EnricherAsyncUnhandledExceptionTest.java       |   21 +-
 .../EnricherDefaultAggregationStrategyTest.java    |    4 +-
 .../camel/processor/enricher/EnricherDslTest.java  |    9 +-
 .../processor/enricher/EnricherNoResourceTest.java |    9 +-
 .../processor/enricher/EnricherSendEventTest.java  |   39 +-
 .../camel/processor/enricher/EnricherTest.java     |   33 +-
 .../camel/processor/enricher/FailureProcessor.java |    1 -
 .../enricher/PollEnrichBridgeErrorHandlerTest.java |    5 +-
 ...lEnrichExpressionIgnoreInvalidEndpointTest.java |    4 +-
 .../enricher/PollEnrichExpressionNoCacheTest.java  |    4 +-
 .../enricher/PollEnrichExpressionTest.java         |    4 +-
 ...ollEnrichFileCustomAggregationStrategyTest.java |   15 +-
 ...llEnrichFileDefaultAggregationStrategyTest.java |   13 +-
 .../processor/enricher/PollEnrichNullBodyTest.java |    4 +-
 .../PollEnricherAggregateOnExceptionTest.java      |    8 +-
 .../enricher/PollEnricherNoResourceTest.java       |   10 +-
 .../processor/enricher/PollEnricherRefTest.java    |    2 +-
 .../camel/processor/enricher/PollEnricherTest.java |   31 +-
 .../camel/processor/enricher/SampleAggregator.java |    4 +-
 .../errorhandler/ErrorHandlerSupportTest.java      |    3 +-
 .../CustomExceptionPolicyStrategyTest.java         |   22 +-
 .../DefaultExceptionPolicyStrategyTest.java        |    4 +-
 ...ltExceptionPolicyStrategyUsingOnlyWhenTest.java |    6 +-
 ...efaultExceptionPolicyStrategyUsingWhenTest.java |   14 +-
 .../intercept/FromFileInterceptSendToIssue.java    |    6 +-
 .../intercept/IntercepFromWithPredicateTest.java   |    6 +-
 .../InterceptFromEndpointInstanceTest.java         |    4 +-
 .../InterceptFromEndpointRefFixedTest.java         |    2 +-
 .../intercept/InterceptFromEndpointRefTest.java    |    2 +-
 .../InterceptFromEndpointRefUriFixedTest.java      |    4 +-
 .../intercept/InterceptFromEndpointRefUriTest.java |    4 +-
 .../intercept/InterceptFromRouteTest.java          |    5 +-
 .../intercept/InterceptFromSimpleLogTest.java      |    4 +-
 .../InterceptFromSimplePredicateTest.java          |    7 +-
 .../InterceptFromSimplePredicateWithStopTest.java  |    8 +-
 .../intercept/InterceptFromSimpleRouteTest.java    |    3 +-
 .../intercept/InterceptFromUriRegexTest.java       |    5 +-
 .../intercept/InterceptFromUriSimpleLogTest.java   |    2 +-
 .../InterceptFromUriWildcardHeaderUriTest.java     |    2 +-
 .../intercept/InterceptFromUriWildcardTest.java    |    5 +-
 .../intercept/InterceptFromWhenNoStopTest.java     |    2 +-
 .../processor/intercept/InterceptFromWhenTest.java |    2 +-
 .../intercept/InterceptFromWhenWithChoiceTest.java |    9 +-
 ...erceptFromWithPredicateAndProceedRouteTest.java |    2 +-
 .../InterceptFromWithPredicateRouteTest.java       |    2 +-
 .../intercept/InterceptFromWithStopRouteTest.java  |    4 +-
 .../InterceptFromWithoutProceedRouteTest.java      |    2 +-
 .../InterceptSendToEndpointAfterTest.java          |   27 +-
 ...nterceptSendToEndpointConditionalSkip2Test.java |   19 +-
 ...nterceptSendToEndpointConditionalSkip3Test.java |   14 +-
 ...InterceptSendToEndpointConditionalSkipTest.java |   61 +-
 .../InterceptSendToEndpointDynamicTest.java        |   62 +-
 .../InterceptSendToEndpointInOnException.java      |   12 +-
 .../InterceptSendToEndpointMultipleRoutesTest.java |   16 +-
 ...nterceptSendToEndpointNormalizePatternTest.java |    4 +-
 .../intercept/InterceptSendToEndpointTest.java     |   66 +-
 .../InterceptSendToEndpointWithStopTest.java       |   10 +-
 .../intercept/InterceptSendToExceptionTest.java    |    1 -
 .../processor/intercept/InterceptSendToIssue.java  |    4 +-
 .../intercept/InterceptSimpleRouteStopTest.java    |    5 +-
 .../intercept/InterceptSimpleRouteTest.java        |    3 +-
 .../InterceptSimpleRouteWhenStopTest.java          |    5 +-
 .../intercept/InterceptSimpleRouteWhenTest.java    |    5 +-
 .../ParentChildInterceptStrategyTest.java          |   20 +-
 ...ipientListInterceptSendToEndpointException.java |    8 +-
 .../interceptor/AdviceWithAutoStartupTest.java     |    2 +-
 .../interceptor/AdviceWithLambdaTest.java          |   14 +-
 ...AdviceWithMockEndpointsHavingParameterTest.java |   11 +-
 .../interceptor/AdviceWithMockEndpointsTest.java   |    1 -
 .../AdviceWithMockEndpointsWithSkipTest.java       |    3 +-
 ...dviceWithMockMultipleEndpointsWithSkipTest.java |    3 +-
 .../AdviceWithRecipientListMockEndpointsTest.java  |    3 +-
 .../interceptor/AdviceWithReplaceFromTest.java     |    2 +-
 .../interceptor/AdviceWithRouteIdTest.java         |    7 +-
 .../interceptor/AdviceWithTasksMatchTest.java      |    8 +-
 .../AdviceWithTasksOnExceptionTest.java            |    8 +-
 .../interceptor/AdviceWithTasksSelectTest.java     |   11 +-
 .../processor/interceptor/AdviceWithTasksTest.java |    7 +-
 .../AdviceWithTasksToStringPatternTest.java        |   10 +-
 .../processor/interceptor/AdviceWithTest.java      |   14 +-
 .../interceptor/AdviceWithTryCatchTest.java        |   11 +-
 ...eWithTwoRoutesContextScopedOnExceptionTest.java |   12 +-
 .../AdviceWithTwoRoutesOnExceptionTest.java        |   34 +-
 .../interceptor/AdviceWithTwoRoutesTest.java       |   27 +-
 .../processor/interceptor/AdviceWithTypeTest.java  |    7 +-
 .../AdviceWithWeaveAfterLastSplitTest.java         |    2 +-
 .../AdviceWithWeaveByTypeOnExceptionTest.java      |   10 +-
 .../interceptor/AdviceWithWeaveFirstLastTest.java  |   13 +-
 .../interceptor/AdviceWithWeaveLastCBRTest.java    |   13 +-
 .../AdviceWithWeaveToUriAndAddLastTest.java        |    8 +-
 .../AuditInterceptorAsyncDelegateIssueTest.java    |    5 +-
 .../AuditInterceptorDelegateIssueTest.java         |    5 +-
 .../processor/interceptor/ConditionSupport.java    |    3 +-
 .../CustomInterceptorRouteWithChildOutputTest.java |   12 +-
 .../interceptor/DebugExceptionBreakpointTest.java  |   10 +-
 .../DebugExceptionEventBreakpointTest.java         |   10 +-
 .../interceptor/DebugSingleStepConditionTest.java  |    3 +-
 .../processor/interceptor/DebugSingleStepTest.java |    3 +-
 .../camel/processor/interceptor/DebugTest.java     |    3 +-
 .../InterceptorStrategyNotOrderedTest.java         |    3 +-
 .../InterceptorStrategyOrderedTest.java            |    3 +-
 .../processor/interceptor/NoStreamCachingTest.java |    1 +
 ...xtScopedOnExceptionCorrectRouteContextTest.java |   65 +-
 ...ScopedOnExceptionLoadBalancerStopRouteTest.java |   26 +-
 .../ContextScopedOnExceptionLogRouteTest.java      |   29 +-
 ...efaultErrorHandlerExchangeFormatterRefTest.java |    4 +-
 .../DefaultErrorHandlerRetryWhileTest.java         |    2 +-
 .../onexception/DoCatchDirectDynamicRouteTest.java |   18 +-
 .../DoCatchDirectRecipientListStreamingTest.java   |   18 +-
 .../DoCatchDirectRecipientListTest.java            |   24 +-
 .../onexception/DoCatchDirectRouteTest.java        |   18 +-
 .../onexception/MyFunctionalException.java         |    2 +-
 .../processor/onexception/OnCatchHandledTest.java  |    8 +-
 .../onexception/OnExceptionAfterRouteTest.java     |    7 +-
 ...xceptionAndDLCErrorHandlerIssueReverseTest.java |   11 +-
 .../OnExceptionAndDLCErrorHandlerIssueTest.java    |   11 +-
 .../OnExceptionCallSubRouteNoErrorHandlerTest.java |   17 +-
 .../onexception/OnExceptionComplexRouteTest.java   |   24 +-
 ...tionComplexWithNestedErrorHandlerRouteTest.java |   44 +-
 ...rorHandlerRouteWithDefaultErrorHandlerTest.java |   35 +-
 .../OnExceptionContinuePredicateTest.java          |   25 +-
 .../OnExceptionContinueSubRouteTest.java           |   15 +-
 .../OnExceptionContinueSubSubRouteTest.java        |   19 +-
 .../onexception/OnExceptionContinueTest.java       |   10 +-
 .../OnExceptionContinueTwoPredicateTest.java       |   31 +-
 .../onexception/OnExceptionContinueTwoTest.java    |   16 +-
 .../onexception/OnExceptionFromChoiceTest.java     |   10 +-
 .../OnExceptionFromChoiceUseOriginalBodyTest.java  |   19 +-
 ...ptionFromChoiceWithDefaultErrorHandlerTest.java |    9 +-
 ...onGlobalAndDLCErrorHandlerIssueReverseTest.java |   15 +-
 ...ExceptionGlobalAndDLCErrorHandlerIssueTest.java |   15 +-
 .../OnExceptionGlobalScopedRecursionTest.java      |  121 +-
 .../OnExceptionHandleAndThrowNewExceptionTest.java |   22 +-
 .../OnExceptionHandleAndTransformTest.java         |   33 +-
 ...dleAndTransformWithDefaultErrorHandlerTest.java |   35 +-
 .../OnExceptionHandledAndContinueTest.java         |    7 +-
 .../onexception/OnExceptionHandledTest.java        |    3 +-
 .../OnExceptionLoadBalancerDoubleIssueTest.java    |   10 +-
 .../onexception/OnExceptionMisconfiguredTest.java  |   11 +-
 ...nExceptionOccurredProcessorOnExceptionTest.java |    3 +-
 .../OnExceptionOccurredProcessorTest.java          |    3 +-
 ...ceptionProcessorInspectCausedExceptionTest.java |   14 +-
 ...CausedExceptionWithDefaultErrorHandlerTest.java |   14 +-
 .../onexception/OnExceptionRecursionTest.java      |   42 +-
 .../onexception/OnExceptionRetryUntilTest.java     |   25 +-
 ...ptionRetryUntilWithDefaultErrorHandlerTest.java |   17 +-
 .../onexception/OnExceptionRouteIdTest.java        |   13 +-
 .../OnExceptionRouteScopedRecursionTest.java       |   99 +-
 .../onexception/OnExceptionRouteTest.java          |   25 +-
 ...nExceptionRouteWithDefaultErrorHandlerTest.java |   10 +-
 .../onexception/OnExceptionSubRouteTest.java       |   26 +-
 ...ceptionSubRouteWithDefaultErrorHandlerTest.java |   13 +-
 .../OnExceptionUseOriginalBodyTest.java            |   14 +-
 .../OnExceptionUseOriginalMessageTest.java         |   34 +-
 .../onexception/OnExceptionWhenSimpleOgnlTest.java |    7 +-
 .../OnExceptionWireTapNewExchangeBodyTest.java     |    8 +-
 .../OnExceptionWithRouteAndContinueTest.java       |    7 +-
 .../OnExceptionWrappedExceptionTest.java           |    5 +-
 .../onexception/OnExceptionsPerRouteTest.java      |   11 +-
 .../onexception/RedeliverEntireRouteTest.java      |   20 +-
 ...ScopedOnExceptionLoadBalancerStopRouteTest.java |   18 +-
 .../RouteScopedOnExceptionSameTypeTest.java        |  163 +-
 .../resequencer/MyFileNameExpression.java          |    5 +-
 .../resequencer/ResequencerBatchOrderTest.java     |    9 +-
 .../resequencer/ResequencerEngineSync.java         |   22 +-
 .../resequencer/ResequencerEngineTest.java         |   25 +-
 .../resequencer/ResequencerFileNameTest.java       |    3 +-
 .../processor/resequencer/SequenceBuffer.java      |   10 +-
 .../camel/processor/resequencer/SequenceTest.java  |    3 +-
 .../processor/resequencer/TestComparatorTest.java  |    9 +-
 .../camel/processor/resequencer/TestObject.java    |    6 +-
 .../RoutingSlipCreateProducerFailedTest.java       |    3 +-
 .../RoutingSlipDataModificationTest.java           |    7 +-
 .../RoutingSlipIgnoreInvalidEndpointsTest.java     |   26 +-
 .../processor/routingslip/RoutingSlipPOJOTest.java |   14 +-
 .../processor/routingslip/RoutingSlipTest.java     |   16 +-
 .../RoutingSlipWithErrorHandlerTest.java           |    2 +-
 .../routingslip/RoutingSlipWithExceptionTest.java  |   27 +-
 .../validation/CatalogLSResourceResolver.java      |    8 +-
 .../impl/AbstractCamelCatalogTest.java             |   48 +-
 .../impl/RuntimeCamelCatalogTest.java              |    3 +-
 .../DefaultCamelContextEndpointCacheLimitTest.java |    5 +-
 .../DefaultCamelContextEndpointCacheTest.java      |    5 +-
 .../apache/camel/support/DefaultEndpointTest.java  |    6 +-
 .../camel/support/DefaultTimeoutMapTest.java       |    4 +-
 .../camel/support/GroupTokenIteratorTest.java      |    4 +-
 .../camel/support/IntrospectionSupportTest.java    |   36 +-
 ...opertyBindingSupportAutowireNestedDeepTest.java |    1 -
 .../PropertyBindingSupportAutowireNestedTest.java  |    1 -
 .../PropertyBindingSupportAutowireTest.java        |    1 -
 .../support/PropertyBindingSupportListTest.java    |    1 -
 .../support/PropertyBindingSupportMapTest.java     |    4 +-
 .../camel/support/PropertyBindingSupportTest.java  |   18 +-
 .../support/builder/RecordableInputStreamTest.java |   18 +-
 .../support/builder/RecordableReaderTest.java      |   18 +-
 .../support/component/ApiMethodHelperTest.java     |   33 +-
 .../component/ApiMethodPropertiesHelperTest.java   |    5 +-
 .../org/apache/camel/support/jndi/ExampleBean.java |    4 +-
 ...ndiCamelSingletonInitialContextFactoryTest.java |   19 +-
 .../support/jsse/AbstractJsseParametersTest.java   |    9 +-
 .../camel/support/jsse/FilterParametersTest.java   |   56 +-
 .../support/jsse/KeyManagersParametersTest.java    |   61 +-
 .../camel/support/jsse/KeyStoreParametersTest.java |   58 +-
 .../support/jsse/SSLContextParametersTest.java     |  231 ++-
 .../support/jsse/SecureRandomParametersTest.java   |   28 +-
 .../support/jsse/TrustManagersParametersTest.java  |   45 +-
 .../processor/DefaultExchangeFormatterTest.java    |    8 +-
 .../FileIdempotentStoreOrderingTest.java           |   62 +-
 .../org/apache/camel/urlhandler/pd/Handler.java    |   46 +-
 .../org/apache/camel/util/AnotherExampleBean.java  |    2 +-
 .../apache/camel/util/CaseInsensitiveMapTest.java  |   11 +-
 .../apache/camel/util/CreateModelFromXmlTest.java  |    4 +-
 .../util/DumpModelAsXmlAggregateRouteTest.java     |    8 +-
 ...mlChoiceFilterRoutePropertyPlaceholderTest.java |   25 +-
 .../util/DumpModelAsXmlChoiceFilterRouteTest.java  |   24 +-
 .../util/DumpModelAsXmlDanishCharactersTest.java   |    5 +-
 .../camel/util/DumpModelAsXmlNamespaceTest.java    |    5 +-
 .../camel/util/DumpModelAsXmlPlaceholdersTest.java |    3 +-
 .../util/DumpModelAsXmlRouteExpressionTest.java    |   16 +-
 .../util/DumpModelAsXmlRoutePredicateTest.java     |   16 +-
 .../util/DumpModelAsXmlSplitBodyRouteTest.java     |    5 +-
 ...elAsXmlSplitNestedChoiceEndChoiceRouteTest.java |   29 +-
 ...umpModelAsXmlSplitNestedChoiceEndRouteTest.java |   17 +-
 .../DumpModelAsXmlTransformRouteConstantTest.java  |    4 +-
 .../DumpModelAsXmlTransformRouteLanguageTest.java  |    4 +-
 .../util/DumpModelAsXmlTransformRouteTest.java     |    4 +-
 .../org/apache/camel/util/EndpointHelperTest.java  |    2 +-
 .../org/apache/camel/util/EventHelperTest.java     |   39 +-
 .../org/apache/camel/util/ExchangeHelperTest.java  |    1 +
 .../camel/util/ExpressionListComparatorTest.java   |    4 +-
 .../java/org/apache/camel/util/FileUtilTest.java   |   10 +-
 .../java/org/apache/camel/util/GZIPHelperTest.java |   12 +-
 .../org/apache/camel/util/IOHelperCharsetTest.java |   19 +-
 .../java/org/apache/camel/util/IOHelperTest.java   |   14 +-
 .../org/apache/camel/util/MessageHelperTest.java   |   26 +-
 .../java/org/apache/camel/util/MyDummyObject.java  |    2 +-
 .../NoClassDefFoundErrorWrapExceptionTest.java     |    5 +-
 .../org/apache/camel/util/ObjectHelperTest.java    |   16 +-
 .../java/org/apache/camel/util/OgnlHelperTest.java |    2 +-
 .../org/apache/camel/util/PlatformHelperTest.java  |    8 +-
 .../org/apache/camel/util/ReflectionInjector.java  |    2 +-
 .../apache/camel/util/StingQuoteHelperTest.java    |    2 +-
 .../org/apache/camel/util/StringHelperTest.java    |   20 +-
 .../camel/util/UnsafeCharactersEncoderTest.java    |    4 +-
 .../toolbox/FlexibleAggregationStrategiesTest.java |  202 +-
 2497 files changed, 18795 insertions(+), 24240 deletions(-)

diff --git a/core/camel-core/src/main/java/org/apache/camel/builder/AdviceWithBuilder.java b/core/camel-core/src/main/java/org/apache/camel/builder/AdviceWithBuilder.java
index a5f3b9a..d54e857 100644
--- a/core/camel-core/src/main/java/org/apache/camel/builder/AdviceWithBuilder.java
+++ b/core/camel-core/src/main/java/org/apache/camel/builder/AdviceWithBuilder.java
@@ -21,7 +21,8 @@ import org.apache.camel.model.ProcessorDefinition;
 import org.apache.camel.model.RouteDefinition;
 
 /**
- * A builder when using the <a href="http://camel.apache.org/advicewith.html">advice with</a> feature.
+ * A builder when using the
+ * <a href="http://camel.apache.org/advicewith.html">advice with</a> feature.
  */
 public class AdviceWithBuilder<T extends ProcessorDefinition<?>> {
 
@@ -107,11 +108,13 @@ public class AdviceWithBuilder<T extends ProcessorDefinition<?>> {
     /**
      * Will only apply for nodes maximum levels deep.
      * <p/>
-     * The first level is <tt>1</tt>, and level <tt>2</tt> is the children of the first level nodes, and so on.
+     * The first level is <tt>1</tt>, and level <tt>2</tt> is the children of
+     * the first level nodes, and so on.
      * <p/>
      * Use zero or negative value for unbounded level.
      *
-     * @param maxDeep the maximum levels to traverse deep in the Camel route tree.
+     * @param maxDeep the maximum levels to traverse deep in the Camel route
+     *            tree.
      * @return the builder to build the nodes.
      */
     public AdviceWithBuilder<T> maxDeep(int maxDeep) {
diff --git a/core/camel-core/src/main/java/org/apache/camel/builder/AdviceWithRouteBuilder.java b/core/camel-core/src/main/java/org/apache/camel/builder/AdviceWithRouteBuilder.java
index d29061c..06c782e 100644
--- a/core/camel-core/src/main/java/org/apache/camel/builder/AdviceWithRouteBuilder.java
+++ b/core/camel-core/src/main/java/org/apache/camel/builder/AdviceWithRouteBuilder.java
@@ -33,11 +33,13 @@ import org.apache.camel.util.ObjectHelper;
 import org.apache.camel.util.function.ThrowingConsumer;
 
 /**
- * A {@link RouteBuilder} which has extended capabilities when using
- * the <a href="http://camel.apache.org/advicewith.html">advice with</a> feature.
+ * A {@link RouteBuilder} which has extended capabilities when using the
+ * <a href="http://camel.apache.org/advicewith.html">advice with</a> feature.
  * <p/>
- * <b>Important:</b> It is recommended to only advice a given route once (you can of course advice multiple routes).
- * If you do it multiple times, then it may not work as expected, especially when any kind of error handling is involved.
+ * <b>Important:</b> It is recommended to only advice a given route once (you
+ * can of course advice multiple routes). If you do it multiple times, then it
+ * may not work as expected, especially when any kind of error handling is
+ * involved.
  */
 public abstract class AdviceWithRouteBuilder extends RouteBuilder {
 
@@ -46,27 +48,35 @@ public abstract class AdviceWithRouteBuilder extends RouteBuilder {
     private boolean logRouteAsXml = true;
 
     /**
-     * Advices this route with the route builder using a lambda expression.
-     * It can be used as following:
+     * Advices this route with the route builder using a lambda expression. It
+     * can be used as following:
+     * 
      * <pre>
      * AdviceWithRouteBuilder.adviceWith(context, "myRoute", a ->
      *     a.weaveAddLast().to("mock:result");
      * </pre>
      * <p/>
-     * <b>Important:</b> It is recommended to only advice a given route once (you can of course advice multiple routes).
-     * If you do it multiple times, then it may not work as expected, especially when any kind of error handling is involved.
-     * The Camel team plan for Camel 3.0 to support this as internal refactorings in the routing engine is needed to support this properly.
+     * <b>Important:</b> It is recommended to only advice a given route once
+     * (you can of course advice multiple routes). If you do it multiple times,
+     * then it may not work as expected, especially when any kind of error
+     * handling is involved. The Camel team plan for Camel 3.0 to support this
+     * as internal refactorings in the routing engine is needed to support this
+     * properly.
      * <p/>
-     * The advice process will add the interceptors, on exceptions, on completions etc. configured
-     * from the route builder to this route.
+     * The advice process will add the interceptors, on exceptions, on
+     * completions etc. configured from the route builder to this route.
      * <p/>
-     * This is mostly used for testing purpose to add interceptors and the likes to an existing route.
+     * This is mostly used for testing purpose to add interceptors and the likes
+     * to an existing route.
      * <p/>
-     * Will stop and remove the old route from camel context and add and start this new advised route.
+     * Will stop and remove the old route from camel context and add and start
+     * this new advised route.
      *
      * @param camelContext the camel context
-     * @param routeId      either the route id as a string value, or <tt>null</tt> to chose the 1st route, or you can specify a number for the n'th route.
-     * @param builder      the advice with route builder
+     * @param routeId either the route id as a string value, or <tt>null</tt> to
+     *            chose the 1st route, or you can specify a number for the n'th
+     *            route.
+     * @param builder the advice with route builder
      * @return a new route which is this route merged with the route builder
      * @throws Exception can be thrown from the route builder
      */
@@ -122,34 +132,31 @@ public abstract class AdviceWithRouteBuilder extends RouteBuilder {
     }
 
     /**
-     * Whether to log the adviced routes before/after as XML.
-     * This is usable to know how the route was adviced and changed.
-     * However marshalling the route model to XML costs CPU resources
-     * and you can then turn this off by not logging.
-     *
-     * This is default enabled.
+     * Whether to log the adviced routes before/after as XML. This is usable to
+     * know how the route was adviced and changed. However marshalling the route
+     * model to XML costs CPU resources and you can then turn this off by not
+     * logging. This is default enabled.
      */
     public boolean isLogRouteAsXml() {
         return logRouteAsXml;
     }
 
     /**
-     * Sets whether to log the adviced routes before/after as XML.
-     * This is usable to know how the route was adviced and changed.
-     * However marshalling the route model to XML costs CPU resources
-     * and you can then turn this off by not logging.
-     *
-     * This is default enabled.
+     * Sets whether to log the adviced routes before/after as XML. This is
+     * usable to know how the route was adviced and changed. However marshalling
+     * the route model to XML costs CPU resources and you can then turn this off
+     * by not logging. This is default enabled.
      */
     public void setLogRouteAsXml(boolean logRouteAsXml) {
         this.logRouteAsXml = logRouteAsXml;
     }
 
     /**
-     * Gets a list of additional tasks to execute after the {@link #configure()} method has been executed
-     * during the advice process.
+     * Gets a list of additional tasks to execute after the {@link #configure()}
+     * method has been executed during the advice process.
      *
-     * @return a list of additional {@link AdviceWithTask} tasks to be executed during the advice process.
+     * @return a list of additional {@link AdviceWithTask} tasks to be executed
+     *         during the advice process.
      */
     public List<AdviceWithTask> getAdviceWithTasks() {
         return adviceWithTasks;
@@ -169,7 +176,8 @@ public abstract class AdviceWithRouteBuilder extends RouteBuilder {
      *
      * @param pattern the pattern(s).
      * @throws Exception can be thrown if error occurred
-     * @see EndpointHelper#matchEndpoint(org.apache.camel.CamelContext, String, String)
+     * @see EndpointHelper#matchEndpoint(org.apache.camel.CamelContext, String,
+     *      String)
      */
     public void mockEndpoints(String... pattern) throws Exception {
         for (String s : pattern) {
@@ -178,11 +186,13 @@ public abstract class AdviceWithRouteBuilder extends RouteBuilder {
     }
 
     /**
-     * Mock all endpoints matching the given pattern, and <b>skips</b> sending to the original endpoint (detour messages).
+     * Mock all endpoints matching the given pattern, and <b>skips</b> sending
+     * to the original endpoint (detour messages).
      *
      * @param pattern the pattern(s).
      * @throws Exception can be thrown if error occurred
-     * @see EndpointHelper#matchEndpoint(org.apache.camel.CamelContext, String, String)
+     * @see EndpointHelper#matchEndpoint(org.apache.camel.CamelContext, String,
+     *      String)
      */
     public void mockEndpointsAndSkip(String... pattern) throws Exception {
         for (String s : pattern) {
@@ -213,7 +223,8 @@ public abstract class AdviceWithRouteBuilder extends RouteBuilder {
     /**
      * Weaves by matching id of the nodes in the route (incl onException etc).
      * <p/>
-     * Uses the {@link PatternHelper#matchPattern(String, String)} matching algorithm.
+     * Uses the {@link PatternHelper#matchPattern(String, String)} matching
+     * algorithm.
      *
      * @param pattern the pattern
      * @return the builder
@@ -225,9 +236,11 @@ public abstract class AdviceWithRouteBuilder extends RouteBuilder {
     }
 
     /**
-     * Weaves by matching the to string representation of the nodes in the route (incl onException etc).
+     * Weaves by matching the to string representation of the nodes in the route
+     * (incl onException etc).
      * <p/>
-     * Uses the {@link PatternHelper#matchPattern(String, String)} matching algorithm.
+     * Uses the {@link PatternHelper#matchPattern(String, String)} matching
+     * algorithm.
      *
      * @param pattern the pattern
      * @return the builder
@@ -239,9 +252,11 @@ public abstract class AdviceWithRouteBuilder extends RouteBuilder {
     }
 
     /**
-     * Weaves by matching sending to endpoints with the given uri of the nodes in the route (incl onException etc).
+     * Weaves by matching sending to endpoints with the given uri of the nodes
+     * in the route (incl onException etc).
      * <p/>
-     * Uses the {@link PatternHelper#matchPattern(String, String)} matching algorithm.
+     * Uses the {@link PatternHelper#matchPattern(String, String)} matching
+     * algorithm.
      *
      * @param pattern the pattern
      * @return the builder
@@ -264,7 +279,8 @@ public abstract class AdviceWithRouteBuilder extends RouteBuilder {
     }
 
     /**
-     * Weaves by adding the nodes to the start of the route (excl onException etc).
+     * Weaves by adding the nodes to the start of the route (excl onException
+     * etc).
      *
      * @return the builder
      */
@@ -274,7 +290,8 @@ public abstract class AdviceWithRouteBuilder extends RouteBuilder {
     }
 
     /**
-     * Weaves by adding the nodes to the end of the route (excl onException etc).
+     * Weaves by adding the nodes to the end of the route (excl onException
+     * etc).
      *
      * @return the builder
      */
diff --git a/core/camel-core/src/main/java/org/apache/camel/builder/AdviceWithTask.java b/core/camel-core/src/main/java/org/apache/camel/builder/AdviceWithTask.java
index 325e714..6b8c1cf 100644
--- a/core/camel-core/src/main/java/org/apache/camel/builder/AdviceWithTask.java
+++ b/core/camel-core/src/main/java/org/apache/camel/builder/AdviceWithTask.java
@@ -24,7 +24,8 @@ public interface AdviceWithTask {
     /**
      * The task to execute
      *
-     * @throws Exception is thrown if error during executing the task, or invalid input.
+     * @throws Exception is thrown if error during executing the task, or
+     *             invalid input.
      */
     void task() throws Exception;
 
diff --git a/core/camel-core/src/main/java/org/apache/camel/builder/AdviceWithTasks.java b/core/camel-core/src/main/java/org/apache/camel/builder/AdviceWithTasks.java
index 01e5539..626e9ca 100644
--- a/core/camel-core/src/main/java/org/apache/camel/builder/AdviceWithTasks.java
+++ b/core/camel-core/src/main/java/org/apache/camel/builder/AdviceWithTasks.java
@@ -39,7 +39,8 @@ import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
 /**
- * {@link AdviceWithTask} tasks which are used by the {@link AdviceWithRouteBuilder}.
+ * {@link AdviceWithTask} tasks which are used by the
+ * {@link AdviceWithRouteBuilder}.
  */
 public final class AdviceWithTasks {
 
@@ -108,7 +109,8 @@ public final class AdviceWithTasks {
     }
 
     /**
-     * Will match by the sending to endpoint uri representation of the processor.
+     * Will match by the sending to endpoint uri representation of the
+     * processor.
      */
     private static final class MatchByToUri implements MatchBy {
 
@@ -126,7 +128,7 @@ public final class AdviceWithTasks {
         @Override
         public boolean match(ProcessorDefinition<?> processor) {
             if (processor instanceof EndpointRequiredDefinition) {
-                String uri = ((EndpointRequiredDefinition) processor).getEndpointUri();
+                String uri = ((EndpointRequiredDefinition)processor).getEndpointUri();
                 return PatternHelper.matchPattern(uri, toUri);
             }
             return false;
@@ -155,32 +157,32 @@ public final class AdviceWithTasks {
         }
     }
 
-    public static AdviceWithTask replaceByToString(final RouteDefinition route, final String toString, final ProcessorDefinition<?> replace,
-                                                   boolean selectFirst, boolean selectLast, int selectFrom, int selectTo, int maxDeep) {
+    public static AdviceWithTask replaceByToString(final RouteDefinition route, final String toString, final ProcessorDefinition<?> replace, boolean selectFirst,
+                                                   boolean selectLast, int selectFrom, int selectTo, int maxDeep) {
         MatchBy matchBy = new MatchByToString(toString);
         return doReplace(route, matchBy, replace, selectFirst, selectLast, selectFrom, selectTo, maxDeep);
     }
 
-    public static AdviceWithTask replaceByToUri(final RouteDefinition route, final String toUri, final ProcessorDefinition<?> replace,
-                                                boolean selectFirst, boolean selectLast, int selectFrom, int selectTo, int maxDeep) {
+    public static AdviceWithTask replaceByToUri(final RouteDefinition route, final String toUri, final ProcessorDefinition<?> replace, boolean selectFirst, boolean selectLast,
+                                                int selectFrom, int selectTo, int maxDeep) {
         MatchBy matchBy = new MatchByToUri(toUri);
         return doReplace(route, matchBy, replace, selectFirst, selectLast, selectFrom, selectTo, maxDeep);
     }
 
-    public static AdviceWithTask replaceById(final RouteDefinition route, final String id, final ProcessorDefinition<?> replace,
-                                             boolean selectFirst, boolean selectLast, int selectFrom, int selectTo, int maxDeep) {
+    public static AdviceWithTask replaceById(final RouteDefinition route, final String id, final ProcessorDefinition<?> replace, boolean selectFirst, boolean selectLast,
+                                             int selectFrom, int selectTo, int maxDeep) {
         MatchBy matchBy = new MatchById(id);
         return doReplace(route, matchBy, replace, selectFirst, selectLast, selectFrom, selectTo, maxDeep);
     }
 
-    public static AdviceWithTask replaceByType(final RouteDefinition route, final Class<?> type, final ProcessorDefinition<?> replace,
-                                               boolean selectFirst, boolean selectLast, int selectFrom, int selectTo, int maxDeep) {
+    public static AdviceWithTask replaceByType(final RouteDefinition route, final Class<?> type, final ProcessorDefinition<?> replace, boolean selectFirst, boolean selectLast,
+                                               int selectFrom, int selectTo, int maxDeep) {
         MatchBy matchBy = new MatchByType(type);
         return doReplace(route, matchBy, replace, selectFirst, selectLast, selectFrom, selectTo, maxDeep);
     }
 
-    private static AdviceWithTask doReplace(final RouteDefinition route, final MatchBy matchBy, final ProcessorDefinition<?> replace,
-                                            boolean selectFirst, boolean selectLast, int selectFrom, int selectTo, int maxDeep) {
+    private static AdviceWithTask doReplace(final RouteDefinition route, final MatchBy matchBy, final ProcessorDefinition<?> replace, boolean selectFirst, boolean selectLast,
+                                            int selectFrom, int selectTo, int maxDeep) {
         return new AdviceWithTask() {
             public void task() throws Exception {
                 Iterator<ProcessorDefinition<?>> it = AdviceWithTasks.createMatchByIterator(route, matchBy, selectFirst, selectLast, selectFrom, selectTo, maxDeep);
@@ -193,11 +195,13 @@ public final class AdviceWithTasks {
                             int index = outputs.indexOf(output);
                             if (index != -1) {
                                 match = true;
-                                // flattern as replace uses a pipeline as temporary holder
+                                // flattern as replace uses a pipeline as
+                                // temporary holder
                                 ProcessorDefinition<?> flattern = flatternOutput(replace);
                                 outputs.add(index + 1, flattern);
                                 Object old = outputs.remove(index);
-                                // must set parent on the node we added in the route
+                                // must set parent on the node we added in the
+                                // route
                                 ProcessorDefinition parent = output.getParent() != null ? output.getParent() : route;
                                 flattern.setParent(parent);
                                 LOG.info("AdviceWith ({}) : [{}] --> replace [{}]", matchBy.getId(), old, flattern);
@@ -213,32 +217,30 @@ public final class AdviceWithTasks {
         };
     }
 
-    public static AdviceWithTask removeByToString(final RouteDefinition route, final String toString,
-                                                  boolean selectFirst, boolean selectLast, int selectFrom, int selectTo, int maxDeep) {
+    public static AdviceWithTask removeByToString(final RouteDefinition route, final String toString, boolean selectFirst, boolean selectLast, int selectFrom, int selectTo,
+                                                  int maxDeep) {
         MatchBy matchBy = new MatchByToString(toString);
         return doRemove(route, matchBy, selectFirst, selectLast, selectFrom, selectTo, maxDeep);
     }
 
-    public static AdviceWithTask removeByToUri(final RouteDefinition route, final String toUri,
-                                               boolean selectFirst, boolean selectLast, int selectFrom, int selectTo, int maxDeep) {
+    public static AdviceWithTask removeByToUri(final RouteDefinition route, final String toUri, boolean selectFirst, boolean selectLast, int selectFrom, int selectTo,
+                                               int maxDeep) {
         MatchBy matchBy = new MatchByToUri(toUri);
         return doRemove(route, matchBy, selectFirst, selectLast, selectFrom, selectTo, maxDeep);
     }
 
-    public static AdviceWithTask removeById(final RouteDefinition route, final String id,
-                                            boolean selectFirst, boolean selectLast, int selectFrom, int selectTo, int maxDeep) {
+    public static AdviceWithTask removeById(final RouteDefinition route, final String id, boolean selectFirst, boolean selectLast, int selectFrom, int selectTo, int maxDeep) {
         MatchBy matchBy = new MatchById(id);
         return doRemove(route, matchBy, selectFirst, selectLast, selectFrom, selectTo, maxDeep);
     }
 
-    public static AdviceWithTask removeByType(final RouteDefinition route, final Class<?> type,
-                                              boolean selectFirst, boolean selectLast, int selectFrom, int selectTo, int maxDeep) {
+    public static AdviceWithTask removeByType(final RouteDefinition route, final Class<?> type, boolean selectFirst, boolean selectLast, int selectFrom, int selectTo,
+                                              int maxDeep) {
         MatchBy matchBy = new MatchByType(type);
         return doRemove(route, matchBy, selectFirst, selectLast, selectFrom, selectTo, maxDeep);
     }
 
-    private static AdviceWithTask doRemove(final RouteDefinition route, final MatchBy matchBy,
-                                           boolean selectFirst, boolean selectLast, int selectFrom, int selectTo, int maxDeep) {
+    private static AdviceWithTask doRemove(final RouteDefinition route, final MatchBy matchBy, boolean selectFirst, boolean selectLast, int selectFrom, int selectTo, int maxDeep) {
         return new AdviceWithTask() {
             public void task() throws Exception {
                 boolean match = false;
@@ -265,32 +267,32 @@ public final class AdviceWithTasks {
         };
     }
 
-    public static AdviceWithTask beforeByToString(final RouteDefinition route, final String toString, final ProcessorDefinition<?> before,
-                                                  boolean selectFirst, boolean selectLast, int selectFrom, int selectTo, int maxDeep) {
+    public static AdviceWithTask beforeByToString(final RouteDefinition route, final String toString, final ProcessorDefinition<?> before, boolean selectFirst, boolean selectLast,
+                                                  int selectFrom, int selectTo, int maxDeep) {
         MatchBy matchBy = new MatchByToString(toString);
         return doBefore(route, matchBy, before, selectFirst, selectLast, selectFrom, selectTo, maxDeep);
     }
 
-    public static AdviceWithTask beforeByToUri(final RouteDefinition route, final String toUri, final ProcessorDefinition<?> before,
-                                               boolean selectFirst, boolean selectLast, int selectFrom, int selectTo, int maxDeep) {
+    public static AdviceWithTask beforeByToUri(final RouteDefinition route, final String toUri, final ProcessorDefinition<?> before, boolean selectFirst, boolean selectLast,
+                                               int selectFrom, int selectTo, int maxDeep) {
         MatchBy matchBy = new MatchByToUri(toUri);
         return doBefore(route, matchBy, before, selectFirst, selectLast, selectFrom, selectTo, maxDeep);
     }
 
-    public static AdviceWithTask beforeById(final RouteDefinition route, final String id, final ProcessorDefinition<?> before,
-                                            boolean selectFirst, boolean selectLast, int selectFrom, int selectTo, int maxDeep) {
+    public static AdviceWithTask beforeById(final RouteDefinition route, final String id, final ProcessorDefinition<?> before, boolean selectFirst, boolean selectLast,
+                                            int selectFrom, int selectTo, int maxDeep) {
         MatchBy matchBy = new MatchById(id);
         return doBefore(route, matchBy, before, selectFirst, selectLast, selectFrom, selectTo, maxDeep);
     }
 
-    public static AdviceWithTask beforeByType(final RouteDefinition route, final Class<?> type, final ProcessorDefinition<?> before,
-                                              boolean selectFirst, boolean selectLast, int selectFrom, int selectTo, int maxDeep) {
+    public static AdviceWithTask beforeByType(final RouteDefinition route, final Class<?> type, final ProcessorDefinition<?> before, boolean selectFirst, boolean selectLast,
+                                              int selectFrom, int selectTo, int maxDeep) {
         MatchBy matchBy = new MatchByType(type);
         return doBefore(route, matchBy, before, selectFirst, selectLast, selectFrom, selectTo, maxDeep);
     }
 
-    private static AdviceWithTask doBefore(final RouteDefinition route, final MatchBy matchBy, final ProcessorDefinition<?> before,
-                                           boolean selectFirst, boolean selectLast, int selectFrom, int selectTo, int maxDeep) {
+    private static AdviceWithTask doBefore(final RouteDefinition route, final MatchBy matchBy, final ProcessorDefinition<?> before, boolean selectFirst, boolean selectLast,
+                                           int selectFrom, int selectTo, int maxDeep) {
         return new AdviceWithTask() {
             public void task() throws Exception {
                 boolean match = false;
@@ -303,11 +305,13 @@ public final class AdviceWithTasks {
                             int index = outputs.indexOf(output);
                             if (index != -1) {
                                 match = true;
-                                // flattern as before uses a pipeline as temporary holder
+                                // flattern as before uses a pipeline as
+                                // temporary holder
                                 ProcessorDefinition<?> flattern = flatternOutput(before);
                                 Object existing = outputs.get(index);
                                 outputs.add(index, flattern);
-                                // must set parent on the node we added in the route
+                                // must set parent on the node we added in the
+                                // route
                                 ProcessorDefinition parent = output.getParent() != null ? output.getParent() : route;
                                 flattern.setParent(parent);
                                 LOG.info("AdviceWith ({}) : [{}] --> before [{}]", matchBy.getId(), existing, flattern);
@@ -323,32 +327,32 @@ public final class AdviceWithTasks {
         };
     }
 
-    public static AdviceWithTask afterByToString(final RouteDefinition route, final String toString, final ProcessorDefinition<?> after,
-                                                 boolean selectFirst, boolean selectLast, int selectFrom, int selectTo, int maxDeep) {
+    public static AdviceWithTask afterByToString(final RouteDefinition route, final String toString, final ProcessorDefinition<?> after, boolean selectFirst, boolean selectLast,
+                                                 int selectFrom, int selectTo, int maxDeep) {
         MatchBy matchBy = new MatchByToString(toString);
         return doAfter(route, matchBy, after, selectFirst, selectLast, selectFrom, selectTo, maxDeep);
     }
 
-    public static AdviceWithTask afterByToUri(final RouteDefinition route, final String toUri, final ProcessorDefinition<?> after,
-                                              boolean selectFirst, boolean selectLast, int selectFrom, int selectTo, int maxDeep) {
+    public static AdviceWithTask afterByToUri(final RouteDefinition route, final String toUri, final ProcessorDefinition<?> after, boolean selectFirst, boolean selectLast,
+                                              int selectFrom, int selectTo, int maxDeep) {
         MatchBy matchBy = new MatchByToUri(toUri);
         return doAfter(route, matchBy, after, selectFirst, selectLast, selectFrom, selectTo, maxDeep);
     }
 
-    public static AdviceWithTask afterById(final RouteDefinition route, final String id, final ProcessorDefinition<?> after,
-                                           boolean selectFirst, boolean selectLast, int selectFrom, int selectTo, int maxDeep) {
+    public static AdviceWithTask afterById(final RouteDefinition route, final String id, final ProcessorDefinition<?> after, boolean selectFirst, boolean selectLast,
+                                           int selectFrom, int selectTo, int maxDeep) {
         MatchBy matchBy = new MatchById(id);
         return doAfter(route, matchBy, after, selectFirst, selectLast, selectFrom, selectTo, maxDeep);
     }
 
-    public static AdviceWithTask afterByType(final RouteDefinition route, final Class<?> type, final ProcessorDefinition<?> after,
-                                             boolean selectFirst, boolean selectLast, int selectFrom, int selectTo, int maxDeep) {
+    public static AdviceWithTask afterByType(final RouteDefinition route, final Class<?> type, final ProcessorDefinition<?> after, boolean selectFirst, boolean selectLast,
+                                             int selectFrom, int selectTo, int maxDeep) {
         MatchBy matchBy = new MatchByType(type);
         return doAfter(route, matchBy, after, selectFirst, selectLast, selectFrom, selectTo, maxDeep);
     }
 
-    private static AdviceWithTask doAfter(final RouteDefinition route, final MatchBy matchBy, final ProcessorDefinition<?> after,
-                                          boolean selectFirst, boolean selectLast, int selectFrom, int selectTo, int maxDeep) {
+    private static AdviceWithTask doAfter(final RouteDefinition route, final MatchBy matchBy, final ProcessorDefinition<?> after, boolean selectFirst, boolean selectLast,
+                                          int selectFrom, int selectTo, int maxDeep) {
         return new AdviceWithTask() {
             public void task() throws Exception {
                 boolean match = false;
@@ -361,11 +365,13 @@ public final class AdviceWithTasks {
                             int index = outputs.indexOf(output);
                             if (index != -1) {
                                 match = true;
-                                // flattern as after uses a pipeline as temporary holder
+                                // flattern as after uses a pipeline as
+                                // temporary holder
                                 ProcessorDefinition<?> flattern = flatternOutput(after);
                                 Object existing = outputs.get(index);
                                 outputs.add(index + 1, flattern);
-                                // must set parent on the node we added in the route
+                                // must set parent on the node we added in the
+                                // route
                                 ProcessorDefinition parent = output.getParent() != null ? output.getParent() : route;
                                 flattern.setParent(parent);
                                 LOG.info("AdviceWith ({}) : [{}] --> after [{}]", matchBy.getId(), existing, flattern);
@@ -384,7 +390,8 @@ public final class AdviceWithTasks {
     /**
      * Gets the outputs to use with advice with from the given child/parent
      * <p/>
-     * This implementation deals with that outputs can be abstract and retrieves the <i>correct</i> parent output.
+     * This implementation deals with that outputs can be abstract and retrieves
+     * the <i>correct</i> parent output.
      *
      * @param node the node
      * @return <tt>null</tt> if not outputs to be used
@@ -393,7 +400,8 @@ public final class AdviceWithTasks {
         if (node == null) {
             return null;
         }
-        // for intercept/onException/onCompletion then we want to work on the route outputs as they are top-level
+        // for intercept/onException/onCompletion then we want to work on the
+        // route outputs as they are top-level
         if (node instanceof InterceptDefinition) {
             return route.getOutputs();
         } else if (node instanceof InterceptSendToEndpointDefinition) {
@@ -444,21 +452,20 @@ public final class AdviceWithTasks {
     }
 
     /**
-     * Create iterator which walks the route, and only returns nodes which matches the given set of criteria.
-     *
-     * @param route        the route
-     * @param matchBy      match by which must match
-     * @param selectFirst  optional to select only the first
-     * @param selectLast   optional to select only the last
-     * @param selectFrom   optional to select index/range
-     * @param selectTo     optional to select index/range
-     * @param maxDeep      maximum levels deep (is unbounded by default)
+     * Create iterator which walks the route, and only returns nodes which
+     * matches the given set of criteria.
      *
+     * @param route the route
+     * @param matchBy match by which must match
+     * @param selectFirst optional to select only the first
+     * @param selectLast optional to select only the last
+     * @param selectFrom optional to select index/range
+     * @param selectTo optional to select index/range
+     * @param maxDeep maximum levels deep (is unbounded by default)
      * @return the iterator
      */
-    private static Iterator<ProcessorDefinition<?>> createMatchByIterator(final RouteDefinition route, final MatchBy matchBy,
-                                                               final boolean selectFirst, final boolean selectLast,
-                                                               final int selectFrom, final int selectTo, int maxDeep) {
+    private static Iterator<ProcessorDefinition<?>> createMatchByIterator(final RouteDefinition route, final MatchBy matchBy, final boolean selectFirst, final boolean selectLast,
+                                                                          final int selectFrom, final int selectTo, int maxDeep) {
 
         // first iterator and apply match by
         List<ProcessorDefinition<?>> matched = new ArrayList<>();
@@ -466,8 +473,10 @@ public final class AdviceWithTasks {
         List<ProcessorDefinition<?>> outputs = new ArrayList<>();
 
         // if we are in first|last mode then we should
-        // skip abstract nodes in the beginning as they are cross cutting functionality such as onException, onCompletion etc
-        // and the user want to select first or last outputs in the route (not cross cutting functionality)
+        // skip abstract nodes in the beginning as they are cross cutting
+        // functionality such as onException, onCompletion etc
+        // and the user want to select first or last outputs in the route (not
+        // cross cutting functionality)
         boolean skip = selectFirst || selectLast;
 
         for (ProcessorDefinition output : route.getOutputs()) {
@@ -498,8 +507,8 @@ public final class AdviceWithTasks {
         return createSelectorIterator(matched, selectFirst, selectLast, selectFrom, selectTo);
     }
 
-    private static Iterator<ProcessorDefinition<?>> createSelectorIterator(final List<ProcessorDefinition<?>> list, final boolean selectFirst,
-                                                                           final boolean selectLast, final int selectFrom, final int selectTo) {
+    private static Iterator<ProcessorDefinition<?>> createSelectorIterator(final List<ProcessorDefinition<?>> list, final boolean selectFirst, final boolean selectLast,
+                                                                           final int selectFrom, final int selectTo) {
         return new Iterator<ProcessorDefinition<?>>() {
             private int current;
             private boolean done;
@@ -555,7 +564,7 @@ public final class AdviceWithTasks {
 
     private static ProcessorDefinition<?> flatternOutput(ProcessorDefinition<?> output) {
         if (output instanceof AdviceWithDefinition) {
-            AdviceWithDefinition advice = (AdviceWithDefinition) output;
+            AdviceWithDefinition advice = (AdviceWithDefinition)output;
             if (advice.getOutputs().size() == 1) {
                 return advice.getOutputs().get(0);
             } else {
diff --git a/core/camel-core/src/main/java/org/apache/camel/builder/AggregationStrategies.java b/core/camel-core/src/main/java/org/apache/camel/builder/AggregationStrategies.java
index 01c569e..ab17c8e 100644
--- a/core/camel-core/src/main/java/org/apache/camel/builder/AggregationStrategies.java
+++ b/core/camel-core/src/main/java/org/apache/camel/builder/AggregationStrategies.java
@@ -25,28 +25,32 @@ import org.apache.camel.processor.aggregate.UseLatestAggregationStrategy;
 import org.apache.camel.processor.aggregate.UseOriginalAggregationStrategy;
 
 /**
- * Toolbox class to create commonly used Aggregation Strategies in a fluent manner.
- * For more information about the supported {@link AggregationStrategy}, see links to the Javadocs of the relevant class below.
+ * Toolbox class to create commonly used Aggregation Strategies in a fluent
+ * manner. For more information about the supported {@link AggregationStrategy},
+ * see links to the Javadocs of the relevant class below.
  * 
  * @since 2.12
  */
 public final class AggregationStrategies {
 
-    private AggregationStrategies() { }
+    private AggregationStrategies() {
+    }
 
     /**
-     * Creates a {@link FlexibleAggregationStrategy} pivoting around a particular type, e.g. it casts all <tt>pick expression</tt> 
-     * results to the desired type.
+     * Creates a {@link FlexibleAggregationStrategy} pivoting around a
+     * particular type, e.g. it casts all <tt>pick expression</tt> results to
+     * the desired type.
      * 
      * @param type The type the {@link FlexibleAggregationStrategy} deals with.
      */
     public static <T> FlexibleAggregationStrategy<T> flexible(Class<T> type) {
         return new FlexibleAggregationStrategy<>(type);
     }
-    
+
     /**
-     * Creates a {@link FlexibleAggregationStrategy} with no particular type, i.e. performing no casts or type conversion of 
-     * <tt>pick expression</tt> results.
+     * Creates a {@link FlexibleAggregationStrategy} with no particular type,
+     * i.e. performing no casts or type conversion of <tt>pick expression</tt>
+     * results.
      */
     public static FlexibleAggregationStrategy<Object> flexible() {
         return new FlexibleAggregationStrategy<>();
@@ -60,7 +64,7 @@ public final class AggregationStrategies {
     public static AggregationStrategy useLatest() {
         return new UseLatestAggregationStrategy();
     }
-    
+
     /**
      * Use the original exchange.
      *
@@ -73,8 +77,8 @@ public final class AggregationStrategies {
     /**
      * Use the original exchange.
      *
-     * @param propagateException whether to propgate exception if errors was thrown during processing splitted messages.
-     *
+     * @param propagateException whether to propgate exception if errors was
+     *            thrown during processing splitted messages.
      * @see org.apache.camel.processor.aggregate.UseOriginalAggregationStrategy
      */
     public static AggregationStrategy useOriginal(boolean propagateException) {
@@ -82,7 +86,8 @@ public final class AggregationStrategies {
     }
 
     /**
-     * Creates a {@link GroupedExchangeAggregationStrategy} aggregation strategy.
+     * Creates a {@link GroupedExchangeAggregationStrategy} aggregation
+     * strategy.
      */
     public static AggregationStrategy groupedExchange() {
         return new GroupedExchangeAggregationStrategy();
@@ -96,21 +101,24 @@ public final class AggregationStrategies {
     }
 
     /**
-     * Creates a {@link AggregationStrategyBeanAdapter} for using a POJO as the aggregation strategy.
+     * Creates a {@link AggregationStrategyBeanAdapter} for using a POJO as the
+     * aggregation strategy.
      */
     public static AggregationStrategy bean(Object bean) {
         return new AggregationStrategyBeanAdapter(bean);
     }
 
     /**
-     * Creates a {@link AggregationStrategyBeanAdapter} for using a POJO as the aggregation strategy.
+     * Creates a {@link AggregationStrategyBeanAdapter} for using a POJO as the
+     * aggregation strategy.
      */
     public static AggregationStrategy bean(Object bean, String methodName) {
         return new AggregationStrategyBeanAdapter(bean, methodName);
     }
 
     /**
-     * Creates a {@link AggregationStrategyBeanAdapter} for using a POJO as the aggregation strategy.
+     * Creates a {@link AggregationStrategyBeanAdapter} for using a POJO as the
+     * aggregation strategy.
      */
     public static AggregationStrategy beanAllowNull(Object bean, String methodName) {
         AggregationStrategyBeanAdapter adapter = new AggregationStrategyBeanAdapter(bean, methodName);
@@ -120,21 +128,24 @@ public final class AggregationStrategies {
     }
 
     /**
-     * Creates a {@link AggregationStrategyBeanAdapter} for using a POJO as the aggregation strategy.
+     * Creates a {@link AggregationStrategyBeanAdapter} for using a POJO as the
+     * aggregation strategy.
      */
     public static AggregationStrategy bean(Class<?> type) {
         return new AggregationStrategyBeanAdapter(type);
     }
 
     /**
-     * Creates a {@link AggregationStrategyBeanAdapter} for using a POJO as the aggregation strategy.
+     * Creates a {@link AggregationStrategyBeanAdapter} for using a POJO as the
+     * aggregation strategy.
      */
     public static AggregationStrategy bean(Class<?> type, String methodName) {
         return new AggregationStrategyBeanAdapter(type, methodName);
     }
 
     /**
-     * Creates a {@link AggregationStrategyBeanAdapter} for using a POJO as the aggregation strategy.
+     * Creates a {@link AggregationStrategyBeanAdapter} for using a POJO as the
+     * aggregation strategy.
      */
     public static AggregationStrategy beanAllowNull(Class<?> type, String methodName) {
         AggregationStrategyBeanAdapter adapter = new AggregationStrategyBeanAdapter(type, methodName);
@@ -145,6 +156,7 @@ public final class AggregationStrategies {
 
     /**
      * Creates a {@link StringAggregationStrategy}.
+     * 
      * @since 3.0.0
      */
     public static StringAggregationStrategy string() {
@@ -153,6 +165,7 @@ public final class AggregationStrategies {
 
     /**
      * Creates a {@link StringAggregationStrategy} with delimiter.
+     * 
      * @param delimiter The delimiter to join with.
      * @since 3.0.0
      */
diff --git a/core/camel-core/src/main/java/org/apache/camel/builder/AggregationStrategyClause.java b/core/camel-core/src/main/java/org/apache/camel/builder/AggregationStrategyClause.java
index 82a8c68..f962ff0 100644
--- a/core/camel-core/src/main/java/org/apache/camel/builder/AggregationStrategyClause.java
+++ b/core/camel-core/src/main/java/org/apache/camel/builder/AggregationStrategyClause.java
@@ -60,8 +60,10 @@ public class AggregationStrategyClause<T> implements AggregationStrategy {
 
     /**
      * Define an aggregation strategy which targets Exchanges In Message.
-     *
-     * <blockquote><pre>{@code
+     * <blockquote>
+     * 
+     * <pre>
+     * {@code
      * from("direct:aggregate")
      *     .aggregate()
      *         .message((old, new) -> {
@@ -76,7 +78,10 @@ public class AggregationStrategyClause<T> implements AggregationStrategy {
      *
      *             return old;
      *         });
-     * }</pre></blockquote>
+     * }
+     * </pre>
+     * 
+     * </blockquote>
      */
     public T message(final BiFunction<Message, Message, Message> function) {
         return exchange((Exchange oldExchange, Exchange newExchange) -> {
@@ -100,8 +105,10 @@ public class AggregationStrategyClause<T> implements AggregationStrategy {
 
     /**
      * Define an aggregation strategy which targets Exchanges In Body.
-     *
-     * <blockquote><pre>{@code
+     * <blockquote>
+     * 
+     * <pre>
+     * {@code
      * from("direct:aggregate")
      *     .aggregate()
      *         .body((old, new) -> {
@@ -111,7 +118,10 @@ public class AggregationStrategyClause<T> implements AggregationStrategy {
      *
      *             return old.toString() + new.toString();
      *         });
-     * }</pre></blockquote>
+     * }
+     * </pre>
+     * 
+     * </blockquote>
      */
     public T body(final BiFunction<Object, Object, Object> function) {
         return body(Object.class, function);
@@ -119,8 +129,10 @@ public class AggregationStrategyClause<T> implements AggregationStrategy {
 
     /**
      * Define an aggregation strategy which targets Exchanges In Body.
-     *
-     * <blockquote><pre>{@code
+     * <blockquote>
+     * 
+     * <pre>
+     * {@code
      * from("direct:aggregate")
      *     .aggregate()
      *         .body(String.class, (old, new) -> {
@@ -130,7 +142,10 @@ public class AggregationStrategyClause<T> implements AggregationStrategy {
      *
      *             return old + new;
      *         });
-     * }</pre></blockquote>
+     * }
+     * </pre>
+     * 
+     * </blockquote>
      */
     public <B> T body(final Class<B> type, final BiFunction<B, B, Object> function) {
         return body(type, type, function);
@@ -144,9 +159,7 @@ public class AggregationStrategyClause<T> implements AggregationStrategy {
             Message oldMessage = oldExchange != null ? oldExchange.getIn() : null;
             Message newMessage = ObjectHelper.notNull(newExchange, "NewExchange").getIn();
 
-            Object result = function.apply(
-                oldMessage != null ? oldMessage.getBody(oldType) : null,
-                newMessage != null ? newMessage.getBody(newType) : null);
+            Object result = function.apply(oldMessage != null ? oldMessage.getBody(oldType) : null, newMessage != null ? newMessage.getBody(newType) : null);
 
             if (oldExchange != null) {
                 oldExchange.getIn().setBody(result);
diff --git a/core/camel-core/src/main/java/org/apache/camel/builder/Builder.java b/core/camel-core/src/main/java/org/apache/camel/builder/Builder.java
index 6c5c1c2..a5aa14a 100644
--- a/core/camel-core/src/main/java/org/apache/camel/builder/Builder.java
+++ b/core/camel-core/src/main/java/org/apache/camel/builder/Builder.java
@@ -26,14 +26,15 @@ import org.apache.camel.model.language.SimpleExpression;
 import org.apache.camel.util.ObjectHelper;
 
 /**
- * A helper class for including portions of the <a
- * href="http://camel.apache.org/expression.html">expression</a> and
- * <a href="http://camel.apache.org/predicate.html">predicate</a> <a
- * href="http://camel.apache.org/dsl.html">Java DSL</a>
+ * A helper class for including portions of the
+ * <a href="http://camel.apache.org/expression.html">expression</a> and
+ * <a href="http://camel.apache.org/predicate.html">predicate</a>
+ * <a href="http://camel.apache.org/dsl.html">Java DSL</a>
  * <p/>
- * Implementation of this builder should favor build expressions using the definition classes
- * from the <tt>org.apache.camel.model.language</tt> package, to build the routes using the same
- * types as it would happen when using XML DSL.
+ * Implementation of this builder should favor build expressions using the
+ * definition classes from the <tt>org.apache.camel.model.language</tt> package,
+ * to build the routes using the same types as it would happen when using XML
+ * DSL.
  */
 public final class Builder {
 
@@ -44,12 +45,14 @@ public final class Builder {
     }
 
     /**
-     * Returns a <a href="http://camel.apache.org/bean-language.html">bean expression</a>
-     * value builder.
+     * Returns a <a href="http://camel.apache.org/bean-language.html">bean
+     * expression</a> value builder.
      * <p/>
-     * This method accepts dual parameters. Either an bean instance or a reference to a bean (String).
+     * This method accepts dual parameters. Either an bean instance or a
+     * reference to a bean (String).
      *
-     * @param beanOrBeanRef  either an instanceof a bean or a reference to bean to lookup in the Registry
+     * @param beanOrBeanRef either an instanceof a bean or a reference to bean
+     *            to lookup in the Registry
      * @return the builder
      */
     public static ValueBuilder bean(final Object beanOrBeanRef) {
@@ -57,31 +60,33 @@ public final class Builder {
     }
 
     /**
-     * Returns a <a href="http://camel.apache.org/bean-language.html">bean expression</a>
-     * value builder.
+     * Returns a <a href="http://camel.apache.org/bean-language.html">bean
+     * expression</a> value builder.
      * <p/>
-     * This method accepts dual parameters. Either an bean instance or a reference to a bean (String).
+     * This method accepts dual parameters. Either an bean instance or a
+     * reference to a bean (String).
      *
-     * @param beanOrBeanRef  either an instanceof a bean or a reference to bean to lookup in the Registry
+     * @param beanOrBeanRef either an instanceof a bean or a reference to bean
+     *            to lookup in the Registry
      * @param method the method name
      * @return the builder
      */
     public static ValueBuilder bean(Object beanOrBeanRef, String method) {
         Expression exp;
         if (beanOrBeanRef instanceof String) {
-            exp = new MethodCallExpression((String) beanOrBeanRef, method);
+            exp = new MethodCallExpression((String)beanOrBeanRef, method);
         } else {
             exp = new MethodCallExpression(beanOrBeanRef, method);
         }
         return new ValueBuilder(exp);
     }
-    
+
     /**
-     * Returns a <a href="http://camel.apache.org/bean-language.html">bean expression</a>
-     * value builder
+     * Returns a <a href="http://camel.apache.org/bean-language.html">bean
+     * expression</a> value builder
      *
      * @param beanType the bean class which will be invoked
-     * @param method   name of method to invoke
+     * @param method name of method to invoke
      * @return the builder
      */
     public static ValueBuilder bean(Class<?> beanType, String method) {
@@ -95,13 +100,13 @@ public final class Builder {
     public static ValueBuilder constant(Object value) {
         Expression exp;
         if (value instanceof String) {
-            exp = new ConstantExpression((String) value);
+            exp = new ConstantExpression((String)value);
         } else {
             exp = ExpressionBuilder.constantExpression(value);
         }
         return new ValueBuilder(exp);
     }
-    
+
     /**
      * Returns a constant expression
      */
@@ -111,13 +116,13 @@ public final class Builder {
     }
 
     /**
-     * Returns a simple expression  
+     * Returns a simple expression
      */
     public static ValueBuilder simple(String value) {
         Expression exp = new SimpleExpression(value);
         return new ValueBuilder(exp);
     }
-    
+
     /**
      * Returns a simple expression
      */
@@ -177,15 +182,17 @@ public final class Builder {
     }
 
     /**
-     * Returns a predicate and value builder for the exception message on an exchange
+     * Returns a predicate and value builder for the exception message on an
+     * exchange
      */
     public static ValueBuilder exceptionMessage() {
         Expression exp = new SimpleExpression("${exception.message}");
         return new ValueBuilder(exp);
     }
-    
+
     /**
-     * Returns a predicate and value builder for the exception stacktrace on an exchange
+     * Returns a predicate and value builder for the exception stacktrace on an
+     * exchange
      */
     public static ValueBuilder exceptionStackTrace() {
         Expression exp = new SimpleExpression("${exception.stacktrace}");
@@ -193,7 +200,7 @@ public final class Builder {
     }
 
     /**
-     * Returns an expression that replaces all occurrences of the regular 
+     * Returns an expression that replaces all occurrences of the regular
      * expression with the given replacement
      */
     public static ValueBuilder regexReplaceAll(Expression content, String regex, String replacement) {
@@ -202,7 +209,7 @@ public final class Builder {
     }
 
     /**
-     * Returns an expression that replaces all occurrences of the regular 
+     * Returns an expression that replaces all occurrences of the regular
      * expression with the given replacement
      */
     public static ValueBuilder regexReplaceAll(Expression content, String regex, Expression replacement) {
diff --git a/core/camel-core/src/main/java/org/apache/camel/builder/BuilderSupport.java b/core/camel-core/src/main/java/org/apache/camel/builder/BuilderSupport.java
index f2d137c..25400b8 100644
--- a/core/camel-core/src/main/java/org/apache/camel/builder/BuilderSupport.java
+++ b/core/camel-core/src/main/java/org/apache/camel/builder/BuilderSupport.java
@@ -33,8 +33,8 @@ import org.apache.camel.support.builder.Namespaces;
 import org.apache.camel.util.ObjectHelper;
 
 /**
- * Base class for implementation inheritance for different clauses in the <a
- * href="http://camel.apache.org/dsl.html">Java DSL</a>
+ * Base class for implementation inheritance for different clauses in the
+ * <a href="http://camel.apache.org/dsl.html">Java DSL</a>
  */
 public abstract class BuilderSupport {
     private CamelContext context;
@@ -113,8 +113,9 @@ public abstract class BuilderSupport {
     /**
      * Returns a JSonPath expression value builder
      *
-     * @param value      The JSonPath expression
-     * @param resultType The result type that the JSonPath expression will return.
+     * @param value The JSonPath expression
+     * @param resultType The result type that the JSonPath expression will
+     *            return.
      */
     public ValueBuilder jsonpath(String value, Class<?> resultType) {
         JsonPathExpression exp = new JsonPathExpression(value);
@@ -146,14 +147,14 @@ public abstract class BuilderSupport {
     /**
      * Returns a simple expression value builder, using String.format style
      */
-    public SimpleBuilder simpleF(String format, Object...values) {
+    public SimpleBuilder simpleF(String format, Object... values) {
         return SimpleBuilder.simpleF(format, values);
     }
 
     /**
      * Returns a simple expression value builder, using String.format style
      */
-    public SimpleBuilder simpleF(String format, Class<?> resultType, Object...values) {
+    public SimpleBuilder simpleF(String format, Class<?> resultType, Object... values) {
         return SimpleBuilder.simpleF(format, resultType, values);
     }
 
@@ -170,7 +171,7 @@ public abstract class BuilderSupport {
     /**
      * Returns a xpath expression value builder
      *
-     * @param value      the XPath expression
+     * @param value the XPath expression
      * @param resultType the result type that the XPath expression will return.
      * @return the builder
      */
@@ -181,7 +182,7 @@ public abstract class BuilderSupport {
     /**
      * Returns a xpath expression value builder
      *
-     * @param value      the XPath expression
+     * @param value the XPath expression
      * @param namespaces namespace mappings
      * @return the builder
      */
@@ -192,13 +193,14 @@ public abstract class BuilderSupport {
     /**
      * Returns a xpath expression value builder
      *
-     * @param value      the XPath expression
+     * @param value the XPath expression
      * @param resultType the result type that the XPath expression will return.
      * @param namespaces namespace mappings
      * @return the builder
      */
     public ValueBuilder xpath(String value, Class<?> resultType, Namespaces namespaces) {
-        // the value may contain property placeholders as it may be used directly from Java DSL
+        // the value may contain property placeholders as it may be used
+        // directly from Java DSL
         try {
             value = getContext().resolvePropertyPlaceholders(value);
         } catch (Exception e) {
@@ -213,12 +215,14 @@ public abstract class BuilderSupport {
     }
 
     /**
-     * Returns a <a href="http://camel.apache.org/bean-language.html">method call expression</a>
-     * value builder
+     * Returns a <a href="http://camel.apache.org/bean-language.html">method
+     * call expression</a> value builder
      * <p/>
-     * This method accepts dual parameters. Either an bean instance or a reference to a bean (String).
+     * This method accepts dual parameters. Either an bean instance or a
+     * reference to a bean (String).
      *
-     * @param beanOrBeanRef  either an instanceof a bean or a reference to bean to lookup in the Registry
+     * @param beanOrBeanRef either an instanceof a bean or a reference to bean
+     *            to lookup in the Registry
      * @return the builder
      */
     public ValueBuilder method(Object beanOrBeanRef) {
@@ -226,13 +230,15 @@ public abstract class BuilderSupport {
     }
 
     /**
-     * Returns a <a href="http://camel.apache.org/bean-language.html">method call expression</a>
-     * value builder
+     * Returns a <a href="http://camel.apache.org/bean-language.html">method
+     * call expression</a> value builder
      * <p/>
-     * This method accepts dual parameters. Either an bean instance or a reference to a bean (String).
+     * This method accepts dual parameters. Either an bean instance or a
+     * reference to a bean (String).
      *
-     * @param beanOrBeanRef  either an instanceof a bean or a reference to bean to lookup in the Registry
-     * @param method   name of method to invoke
+     * @param beanOrBeanRef either an instanceof a bean or a reference to bean
+     *            to lookup in the Registry
+     * @param method name of method to invoke
      * @return the builder
      */
     public ValueBuilder method(Object beanOrBeanRef, String method) {
@@ -240,8 +246,8 @@ public abstract class BuilderSupport {
     }
 
     /**
-     * Returns a <a href="http://camel.apache.org/bean-language.html">method call expression</a>
-     * value builder
+     * Returns a <a href="http://camel.apache.org/bean-language.html">method
+     * call expression</a> value builder
      *
      * @param beanType the Class of the bean which we want to invoke
      * @return the builder
@@ -251,11 +257,11 @@ public abstract class BuilderSupport {
     }
 
     /**
-     * Returns a <a href="http://camel.apache.org/bean-language.html">method call expression</a>
-     * value builder
+     * Returns a <a href="http://camel.apache.org/bean-language.html">method
+     * call expression</a> value builder
      *
      * @param beanType the Class of the bean which we want to invoke
-     * @param method   name of method to invoke
+     * @param method name of method to invoke
      * @return the builder
      */
     public ValueBuilder method(Class<?> beanType, String method) {
@@ -288,7 +294,7 @@ public abstract class BuilderSupport {
     /**
      * Resolves the given URI to an endpoint
      *
-     * @param uri  the uri to resolve
+     * @param uri the uri to resolve
      * @throws NoSuchEndpointException if the endpoint URI could not be resolved
      * @return the endpoint
      */
@@ -304,7 +310,7 @@ public abstract class BuilderSupport {
     /**
      * Resolves the given URI to an endpoint of the specified type
      *
-     * @param uri  the uri to resolve
+     * @param uri the uri to resolve
      * @param type the excepted type of the endpoint
      * @throws NoSuchEndpointException if the endpoint URI could not be resolved
      * @return the endpoint
@@ -321,7 +327,7 @@ public abstract class BuilderSupport {
     /**
      * Resolves the list of URIs into a list of {@link Endpoint} instances
      *
-     * @param uris  list of endpoints to resolve
+     * @param uris list of endpoints to resolve
      * @throws NoSuchEndpointException if an endpoint URI could not be resolved
      * @return list of endpoints
      */
@@ -336,7 +342,7 @@ public abstract class BuilderSupport {
     /**
      * Helper method to create a list of {@link Endpoint} instances
      *
-     * @param endpoints  endpoints
+     * @param endpoints endpoints
      * @return list of the given endpoints
      */
     public List<Endpoint> endpoints(Endpoint... endpoints) {
@@ -346,7 +352,8 @@ public abstract class BuilderSupport {
     }
 
     /**
-     * Creates a default <a href="http://camel.apache.org/error-handler.html">error handler</a>.
+     * Creates a default
+     * <a href="http://camel.apache.org/error-handler.html">error handler</a>.
      *
      * @return the builder
      */
@@ -355,7 +362,8 @@ public abstract class BuilderSupport {
     }
 
     /**
-     * Creates a disabled <a href="http://camel.apache.org/error-handler.html">error handler</a>
+     * Creates a disabled
+     * <a href="http://camel.apache.org/error-handler.html">error handler</a>
      * for removing the default error handler
      *
      * @return the builder
@@ -365,10 +373,12 @@ public abstract class BuilderSupport {
     }
 
     /**
-     * <a href="http://camel.apache.org/dead-letter-channel.html">Dead Letter Channel EIP:</a>
-     * is a error handler for handling messages that could not be delivered to it's intended destination.
+     * <a href="http://camel.apache.org/dead-letter-channel.html">Dead Letter
+     * Channel EIP:</a> is a error handler for handling messages that could not
+     * be delivered to it's intended destination.
      *
-     * @param deadLetterUri  uri to the dead letter endpoint storing dead messages
+     * @param deadLetterUri uri to the dead letter endpoint storing dead
+     *            messages
      * @return the builder
      */
     public DeadLetterChannelBuilder deadLetterChannel(String deadLetterUri) {
@@ -376,10 +386,11 @@ public abstract class BuilderSupport {
     }
 
     /**
-     * <a href="http://camel.apache.org/dead-letter-channel.html">Dead Letter Channel EIP:</a>
-     * is a error handler for handling messages that could not be delivered to it's intended destination.
+     * <a href="http://camel.apache.org/dead-letter-channel.html">Dead Letter
+     * Channel EIP:</a> is a error handler for handling messages that could not
+     * be delivered to it's intended destination.
      *
-     * @param deadLetterEndpoint  dead letter endpoint storing dead messages
+     * @param deadLetterEndpoint dead letter endpoint storing dead messages
      * @return the builder
      */
     public DeadLetterChannelBuilder deadLetterChannel(Endpoint deadLetterEndpoint) {
diff --git a/core/camel-core/src/main/java/org/apache/camel/builder/DataFormatClause.java b/core/camel-core/src/main/java/org/apache/camel/builder/DataFormatClause.java
index 048a286..4854cee 100644
--- a/core/camel-core/src/main/java/org/apache/camel/builder/DataFormatClause.java
+++ b/core/camel-core/src/main/java/org/apache/camel/builder/DataFormatClause.java
@@ -24,8 +24,8 @@ import org.w3c.dom.Node;
 
 import org.apache.camel.model.DataFormatDefinition;
 import org.apache.camel.model.ProcessorDefinition;
-import org.apache.camel.model.dataformat.Any23DataFormat;
 import org.apache.camel.model.dataformat.ASN1DataFormat;
+import org.apache.camel.model.dataformat.Any23DataFormat;
 import org.apache.camel.model.dataformat.Any23Type;
 import org.apache.camel.model.dataformat.AvroDataFormat;
 import org.apache.camel.model.dataformat.Base64DataFormat;
@@ -66,8 +66,8 @@ import org.apache.camel.support.jsse.KeyStoreParameters;
 import org.apache.camel.util.CollectionStringBuffer;
 
 /**
- * An expression for constructing the different possible {@link org.apache.camel.spi.DataFormat}
- * options.
+ * An expression for constructing the different possible
+ * {@link org.apache.camel.spi.DataFormat} options.
  */
 public class DataFormatClause<T extends ProcessorDefinition<?>> {
     private final T processorType;
@@ -85,27 +85,24 @@ public class DataFormatClause<T extends ProcessorDefinition<?>> {
         this.operation = operation;
     }
 
-
-
-
     /**
      * Uses the Any23 data format
      */
-  public T any23(String baseuri) {
-    return dataFormat(new Any23DataFormat(baseuri));
-  }
+    public T any23(String baseuri) {
+        return dataFormat(new Any23DataFormat(baseuri));
+    }
 
-  public T any23(String baseuri, Any23Type outputformat) {
-    return dataFormat(new Any23DataFormat(baseuri, outputformat));
-  }
+    public T any23(String baseuri, Any23Type outputformat) {
+        return dataFormat(new Any23DataFormat(baseuri, outputformat));
+    }
 
-  public T any23(String baseuri, Any23Type outputformat, Map<String, String> configurations) {
-    return dataFormat(new Any23DataFormat(baseuri, outputformat, configurations));
-  }
+    public T any23(String baseuri, Any23Type outputformat, Map<String, String> configurations) {
+        return dataFormat(new Any23DataFormat(baseuri, outputformat, configurations));
+    }
 
-  public T any23(String baseuri, Any23Type outputformat, Map<String, String> configurations, List<String> extractors) {
-    return dataFormat(new Any23DataFormat(baseuri, outputformat, configurations, extractors));
-  }
+    public T any23(String baseuri, Any23Type outputformat, Map<String, String> configurations, List<String> extractors) {
+        return dataFormat(new Any23DataFormat(baseuri, outputformat, configurations, extractors));
+    }
 
     /**
      * Uses the Avro data format
@@ -167,8 +164,7 @@ public class DataFormatClause<T extends ProcessorDefinition<?>> {
     /**
      * Uses the beanio data format
      */
-    public T beanio(String mapping, String streamName, String encoding,
-                    boolean ignoreUnidentifiedRecords, boolean ignoreUnexpectedRecords, boolean ignoreInvalidRecords) {
+    public T beanio(String mapping, String streamName, String encoding, boolean ignoreUnidentifiedRecords, boolean ignoreUnexpectedRecords, boolean ignoreInvalidRecords) {
         BeanioDataFormat dataFormat = new BeanioDataFormat();
         dataFormat.setMapping(mapping);
         dataFormat.setStreamName(streamName);
@@ -194,7 +190,7 @@ public class DataFormatClause<T extends ProcessorDefinition<?>> {
     /**
      * Uses the Bindy data format
      *
-     * @param type      the type of bindy data format to use
+     * @param type the type of bindy data format to use
      * @param classType the POJO class type
      */
     public T bindy(BindyType type, Class<?> classType) {
@@ -207,9 +203,10 @@ public class DataFormatClause<T extends ProcessorDefinition<?>> {
     /**
      * Uses the Bindy data format
      *
-     * @param type      the type of bindy data format to use
+     * @param type the type of bindy data format to use
      * @param classType the POJO class type
-     * @param unwrapSingleInstance whether unmarshal should unwrap if there is a single instance in the result
+     * @param unwrapSingleInstance whether unmarshal should unwrap if there is a
+     *            single instance in the result
      */
     public T bindy(BindyType type, Class<?> classType, boolean unwrapSingleInstance) {
         BindyDataFormat bindy = new BindyDataFormat();
@@ -218,7 +215,7 @@ public class DataFormatClause<T extends ProcessorDefinition<?>> {
         bindy.setUnwrapSingleInstance(unwrapSingleInstance);
         return dataFormat(bindy);
     }
-    
+
     /**
      * Uses the CBOR data format
      */
@@ -229,8 +226,7 @@ public class DataFormatClause<T extends ProcessorDefinition<?>> {
     /**
      * Uses the CBOR data format
      *
-     * @param unmarshalType
-     *            unmarshal type for cbor type
+     * @param unmarshalType unmarshal type for cbor type
      */
     public T cbor(Class<?> unmarshalType) {
         CBORDataFormat cborDataFormat = new CBORDataFormat();
@@ -246,8 +242,8 @@ public class DataFormatClause<T extends ProcessorDefinition<?>> {
     }
 
     /**
-     * Uses the CSV data format for a huge file.
-     * Sequential access through an iterator.
+     * Uses the CSV data format for a huge file. Sequential access through an
+     * iterator.
      */
     public T csvLazyLoad() {
         return dataFormat(new CsvDataFormat(true));
@@ -341,16 +337,16 @@ public class DataFormatClause<T extends ProcessorDefinition<?>> {
     /**
      * Uses the MIME Multipart data format
      *
-     * @param multipartSubType           the subtype of the MIME Multipart
-     * @param multipartWithoutAttachment defines whether a message without attachment is also marshaled
-     *                                   into a MIME Multipart (with only one body part).
-     * @param headersInline              define the MIME Multipart headers as part of the message body
-     *                                   or as Camel headers
-     * @param binaryContent              have binary encoding for binary content (true) or use Base-64
-     *                                   encoding for binary content (false)
-     */
-    public T mimeMultipart(String multipartSubType, boolean multipartWithoutAttachment, boolean headersInline,
-                           boolean binaryContent) {
+     * @param multipartSubType the subtype of the MIME Multipart
+     * @param multipartWithoutAttachment defines whether a message without
+     *            attachment is also marshaled into a MIME Multipart (with only
+     *            one body part).
+     * @param headersInline define the MIME Multipart headers as part of the
+     *            message body or as Camel headers
+     * @param binaryContent have binary encoding for binary content (true) or
+     *            use Base-64 encoding for binary content (false)
+     */
+    public T mimeMultipart(String multipartSubType, boolean multipartWithoutAttachment, boolean headersInline, boolean binaryContent) {
         MimeMultipartDataFormat mm = new MimeMultipartDataFormat();
         mm.setMultipartSubType(multipartSubType);
         mm.setMultipartWithoutAttachment(multipartWithoutAttachment);
@@ -362,18 +358,19 @@ public class DataFormatClause<T extends ProcessorDefinition<?>> {
     /**
      * Uses the MIME Multipart data format
      *
-     * @param multipartSubType           the subtype of the MIME Multipart
-     * @param multipartWithoutAttachment defines whether a message without attachment is also marshaled
-     *                                   into a MIME Multipart (with only one body part).
-     * @param headersInline              define the MIME Multipart headers as part of the message body
-     *                                   or as Camel headers
-     * @param includeHeaders            if headersInline is set to true all camel headers matching this
-     *                                   regex are also stored as MIME headers on the Multipart
-     * @param binaryContent              have binary encoding for binary content (true) or use Base-64
-     *                                   encoding for binary content (false)
-     */
-    public T mimeMultipart(String multipartSubType, boolean multipartWithoutAttachment, boolean headersInline,
-                           String includeHeaders, boolean binaryContent) {
+     * @param multipartSubType the subtype of the MIME Multipart
+     * @param multipartWithoutAttachment defines whether a message without
+     *            attachment is also marshaled into a MIME Multipart (with only
+     *            one body part).
+     * @param headersInline define the MIME Multipart headers as part of the
+     *            message body or as Camel headers
+     * @param includeHeaders if headersInline is set to true all camel headers
+     *            matching this regex are also stored as MIME headers on the
+     *            Multipart
+     * @param binaryContent have binary encoding for binary content (true) or
+     *            use Base-64 encoding for binary content (false)
+     */
+    public T mimeMultipart(String multipartSubType, boolean multipartWithoutAttachment, boolean headersInline, String includeHeaders, boolean binaryContent) {
         MimeMultipartDataFormat mm = new MimeMultipartDataFormat();
         mm.setMultipartSubType(multipartSubType);
         mm.setMultipartWithoutAttachment(multipartWithoutAttachment);
@@ -386,15 +383,15 @@ public class DataFormatClause<T extends ProcessorDefinition<?>> {
     /**
      * Uses the MIME Multipart data format
      *
-     * @param multipartWithoutAttachment defines whether a message without attachment is also marshaled
-     *                                   into a MIME Multipart (with only one body part).
-     * @param headersInline              define the MIME Multipart headers as part of the message body
-     *                                   or as Camel headers
-     * @param binaryContent              have binary encoding for binary content (true) or use Base-64
-     *                                   encoding for binary content (false)
-     */
-    public T mimeMultipart(boolean multipartWithoutAttachment, boolean headersInline,
-                           boolean binaryContent) {
+     * @param multipartWithoutAttachment defines whether a message without
+     *            attachment is also marshaled into a MIME Multipart (with only
+     *            one body part).
+     * @param headersInline define the MIME Multipart headers as part of the
+     *            message body or as Camel headers
+     * @param binaryContent have binary encoding for binary content (true) or
+     *            use Base-64 encoding for binary content (false)
+     */
+    public T mimeMultipart(boolean multipartWithoutAttachment, boolean headersInline, boolean binaryContent) {
         MimeMultipartDataFormat mm = new MimeMultipartDataFormat();
         mm.setMultipartWithoutAttachment(multipartWithoutAttachment);
         mm.setHeadersInline(headersInline);
@@ -446,8 +443,7 @@ public class DataFormatClause<T extends ProcessorDefinition<?>> {
     /**
      * Uses the Jackson XML data format
      *
-     * @param unmarshalType
-     *            unmarshal type for xml jackson type
+     * @param unmarshalType unmarshal type for xml jackson type
      */
     public T jacksonxml(Class<?> unmarshalType) {
         JacksonXMLDataFormat jacksonXMLDataFormat = new JacksonXMLDataFormat();
@@ -458,10 +454,8 @@ public class DataFormatClause<T extends ProcessorDefinition<?>> {
     /**
      * Uses the Jackson XML data format
      *
-     * @param unmarshalType
-     *            unmarshal type for xml jackson type
-     * @param jsonView
-     *            the view type for xml jackson type
+     * @param unmarshalType unmarshal type for xml jackson type
+     * @param jsonView the view type for xml jackson type
      */
     public T jacksonxml(Class<?> unmarshalType, Class<?> jsonView) {
         JacksonXMLDataFormat jacksonXMLDataFormat = new JacksonXMLDataFormat();
@@ -474,8 +468,7 @@ public class DataFormatClause<T extends ProcessorDefinition<?>> {
      * Uses the Jackson XML data format using the Jackson library turning pretty
      * printing on or off
      *
-     * @param prettyPrint
-     *            turn pretty printing on or off
+     * @param prettyPrint turn pretty printing on or off
      */
     public T jacksonxml(boolean prettyPrint) {
         JacksonXMLDataFormat jacksonXMLDataFormat = new JacksonXMLDataFormat();
@@ -486,10 +479,8 @@ public class DataFormatClause<T extends ProcessorDefinition<?>> {
     /**
      * Uses the Jackson XML data format
      *
-     * @param unmarshalType
-     *            unmarshal type for xml jackson type
-     * @param prettyPrint
-     *            turn pretty printing on or off
+     * @param unmarshalType unmarshal type for xml jackson type
+     * @param prettyPrint turn pretty printing on or off
      */
     public T jacksonxml(Class<?> unmarshalType, boolean prettyPrint) {
         JacksonXMLDataFormat jacksonXMLDataFormat = new JacksonXMLDataFormat();
@@ -501,12 +492,9 @@ public class DataFormatClause<T extends ProcessorDefinition<?>> {
     /**
      * Uses the Jackson XML data format
      *
-     * @param unmarshalType
-     *            unmarshal type for xml jackson type
-     * @param jsonView
-     *            the view type for xml jackson type
-     * @param prettyPrint
-     *            turn pretty printing on or off
+     * @param unmarshalType unmarshal type for xml jackson type
+     * @param jsonView the view type for xml jackson type
+     * @param prettyPrint turn pretty printing on or off
      */
     public T jacksonxml(Class<?> unmarshalType, Class<?> jsonView, boolean prettyPrint) {
         JacksonXMLDataFormat jacksonXMLDataFormat = new JacksonXMLDataFormat();
@@ -519,12 +507,9 @@ public class DataFormatClause<T extends ProcessorDefinition<?>> {
     /**
      * Uses the Jackson XML data format
      *
-     * @param unmarshalType
-     *            unmarshal type for xml jackson type
-     * @param jsonView
-     *            the view type for xml jackson type
-     * @param include
-     *            include such as <tt>ALWAYS</tt>, <tt>NON_NULL</tt>, etc.
+     * @param unmarshalType unmarshal type for xml jackson type
+     * @param jsonView the view type for xml jackson type
+     * @param include include such as <tt>ALWAYS</tt>, <tt>NON_NULL</tt>, etc.
      */
     public T jacksonxml(Class<?> unmarshalType, Class<?> jsonView, String include) {
         JacksonXMLDataFormat jacksonXMLDataFormat = new JacksonXMLDataFormat();
@@ -537,14 +522,10 @@ public class DataFormatClause<T extends ProcessorDefinition<?>> {
     /**
      * Uses the Jackson XML data format
      *
-     * @param unmarshalType
-     *            unmarshal type for xml jackson type
-     * @param jsonView
-     *            the view type for xml jackson type
-     * @param include
-     *            include such as <tt>ALWAYS</tt>, <tt>NON_NULL</tt>, etc.
-     * @param prettyPrint
-     *            turn pretty printing on or off
+     * @param unmarshalType unmarshal type for xml jackson type
+     * @param jsonView the view type for xml jackson type
+     * @param include include such as <tt>ALWAYS</tt>, <tt>NON_NULL</tt>, etc.
+     * @param prettyPrint turn pretty printing on or off
      */
     public T jacksonxml(Class<?> unmarshalType, Class<?> jsonView, String include, boolean prettyPrint) {
         JacksonXMLDataFormat jacksonXMLDataFormat = new JacksonXMLDataFormat();
@@ -586,7 +567,8 @@ public class DataFormatClause<T extends ProcessorDefinition<?>> {
     }
 
     /**
-     * Uses the JSON data format using the XStream json library turning pretty printing on or off
+     * Uses the JSON data format using the XStream json library turning pretty
+     * printing on or off
      *
      * @param prettyPrint turn pretty printing on or off
      */
@@ -608,7 +590,7 @@ public class DataFormatClause<T extends ProcessorDefinition<?>> {
     /**
      * Uses the JSON data format
      *
-     * @param library     the json library to use
+     * @param library the json library to use
      * @param prettyPrint turn pretty printing on or off
      */
     public T json(JsonLibrary library, boolean prettyPrint) {
@@ -620,7 +602,7 @@ public class DataFormatClause<T extends ProcessorDefinition<?>> {
     /**
      * Uses the JSON data format
      *
-     * @param type          the json type to use
+     * @param type the json type to use
      * @param unmarshalType unmarshal type for json jackson type
      */
     public T json(JsonLibrary type, Class<?> unmarshalType) {
@@ -632,9 +614,9 @@ public class DataFormatClause<T extends ProcessorDefinition<?>> {
     /**
      * Uses the JSON data format
      *
-     * @param type          the json type to use
+     * @param type the json type to use
      * @param unmarshalType unmarshal type for json jackson type
-     * @param prettyPrint   turn pretty printing on or off
+     * @param prettyPrint turn pretty printing on or off
      */
     public T json(JsonLibrary type, Class<?> unmarshalType, boolean prettyPrint) {
         JsonDataFormat json = new JsonDataFormat(type);
@@ -647,7 +629,7 @@ public class DataFormatClause<T extends ProcessorDefinition<?>> {
      * Uses the Jackson JSON data format
      *
      * @param unmarshalType unmarshal type for json jackson type
-     * @param jsonView      the view type for json jackson type
+     * @param jsonView the view type for json jackson type
      */
     public T json(Class<?> unmarshalType, Class<?> jsonView) {
         JsonDataFormat json = new JsonDataFormat(JsonLibrary.Jackson);
@@ -660,8 +642,8 @@ public class DataFormatClause<T extends ProcessorDefinition<?>> {
      * Uses the Jackson JSON data format
      *
      * @param unmarshalType unmarshal type for json jackson type
-     * @param jsonView      the view type for json jackson type
-     * @param prettyPrint   turn pretty printing on or off
+     * @param jsonView the view type for json jackson type
+     * @param prettyPrint turn pretty printing on or off
      */
     public T json(Class<?> unmarshalType, Class<?> jsonView, boolean prettyPrint) {
         JsonDataFormat json = new JsonDataFormat(JsonLibrary.Jackson);
@@ -675,8 +657,8 @@ public class DataFormatClause<T extends ProcessorDefinition<?>> {
      * Uses the Jackson JSON data format
      *
      * @param unmarshalType unmarshal type for json jackson type
-     * @param jsonView      the view type for json jackson type
-     * @param include       include such as <tt>ALWAYS</tt>, <tt>NON_NULL</tt>, etc.
+     * @param jsonView the view type for json jackson type
+     * @param include include such as <tt>ALWAYS</tt>, <tt>NON_NULL</tt>, etc.
      */
     public T json(Class<?> unmarshalType, Class<?> jsonView, String include) {
         JsonDataFormat json = new JsonDataFormat(JsonLibrary.Jackson);
@@ -690,9 +672,9 @@ public class DataFormatClause<T extends ProcessorDefinition<?>> {
      * Uses the Jackson JSON data format
      *
      * @param unmarshalType unmarshal type for json jackson type
-     * @param jsonView      the view type for json jackson type
-     * @param include       include such as <tt>ALWAYS</tt>, <tt>NON_NULL</tt>, etc.
-      * @param prettyPrint  turn pretty printing on or off
+     * @param jsonView the view type for json jackson type
+     * @param include include such as <tt>ALWAYS</tt>, <tt>NON_NULL</tt>, etc.
+     * @param prettyPrint turn pretty printing on or off
      */
     public T json(Class<?> unmarshalType, Class<?> jsonView, String include, boolean prettyPrint) {
         JsonDataFormat json = new JsonDataFormat(JsonLibrary.Jackson);
@@ -845,16 +827,15 @@ public class DataFormatClause<T extends ProcessorDefinition<?>> {
     }
 
     /**
-     * Return WellFormed HTML (an XML Document) either
-     * {@link java.lang.String} or {@link org.w3c.dom.Node}
+     * Return WellFormed HTML (an XML Document) either {@link java.lang.String}
+     * or {@link org.w3c.dom.Node}
      */
     public T tidyMarkup(Class<?> dataObjectType) {
         return dataFormat(new TidyMarkupDataFormat(dataObjectType));
     }
 
     /**
-     * Return TidyMarkup in the default format
-     * as {@link org.w3c.dom.Node}
+     * Return TidyMarkup in the default format as {@link org.w3c.dom.Node}
      */
     public T tidyMarkup() {
         return dataFormat(new TidyMarkupDataFormat(Node.class));
@@ -877,7 +858,7 @@ public class DataFormatClause<T extends ProcessorDefinition<?>> {
     public T xstream(String encodingOrPermission) {
         // is it an encoding? if not we assume its a permission
         if (Charset.isSupported(encodingOrPermission)) {
-            return xstream(encodingOrPermission, (String) null);
+            return xstream(encodingOrPermission, (String)null);
         } else {
             return xstream(null, encodingOrPermission);
         }
@@ -1000,7 +981,6 @@ public class DataFormatClause<T extends ProcessorDefinition<?>> {
         return dataFormat(xsdf);
     }
 
-
     /**
      * Uses the XML Security data format
      */
@@ -1014,7 +994,6 @@ public class DataFormatClause<T extends ProcessorDefinition<?>> {
         return dataFormat(xsdf);
     }
 
-
     /**
      * Uses the XML Security data format
      */
@@ -1050,7 +1029,6 @@ public class DataFormatClause<T extends ProcessorDefinition<?>> {
         return dataFormat(xsdf);
     }
 
-
     /**
      * Uses the XML Security data format
      */
@@ -1067,8 +1045,8 @@ public class DataFormatClause<T extends ProcessorDefinition<?>> {
     /**
      * Uses the XML Security data format
      */
-    public T secureXML(String secureTag, boolean secureTagContents, String recipientKeyAlias, String xmlCipherAlgorithm,
-            String keyCipherAlgorithm, String keyOrTrustStoreParametersId) {
+    public T secureXML(String secureTag, boolean secureTagContents, String recipientKeyAlias, String xmlCipherAlgorithm, String keyCipherAlgorithm,
+                       String keyOrTrustStoreParametersId) {
         XMLSecurityDataFormat xsdf = new XMLSecurityDataFormat();
         xsdf.setSecureTag(secureTag);
         xsdf.setSecureTagContents(secureTagContents);
@@ -1082,8 +1060,8 @@ public class DataFormatClause<T extends ProcessorDefinition<?>> {
     /**
      * Uses the XML Security data format
      */
-    public T secureXML(String secureTag, boolean secureTagContents, String recipientKeyAlias, String xmlCipherAlgorithm,
-            String keyCipherAlgorithm, String keyOrTrustStoreParametersId, String keyPassword) {
+    public T secureXML(String secureTag, boolean secureTagContents, String recipientKeyAlias, String xmlCipherAlgorithm, String keyCipherAlgorithm,
+                       String keyOrTrustStoreParametersId, String keyPassword) {
         XMLSecurityDataFormat xsdf = new XMLSecurityDataFormat();
         xsdf.setSecureTag(secureTag);
         xsdf.setSecureTagContents(secureTagContents);
@@ -1098,8 +1076,8 @@ public class DataFormatClause<T extends ProcessorDefinition<?>> {
     /**
      * Uses the XML Security data format
      */
-    public T secureXML(String secureTag, boolean secureTagContents, String recipientKeyAlias, String xmlCipherAlgorithm,
-            String keyCipherAlgorithm, KeyStoreParameters keyOrTrustStoreParameters) {
+    public T secureXML(String secureTag, boolean secureTagContents, String recipientKeyAlias, String xmlCipherAlgorithm, String keyCipherAlgorithm,
+                       KeyStoreParameters keyOrTrustStoreParameters) {
         XMLSecurityDataFormat xsdf = new XMLSecurityDataFormat();
         xsdf.setSecureTag(secureTag);
         xsdf.setSecureTagContents(secureTagContents);
@@ -1113,8 +1091,8 @@ public class DataFormatClause<T extends ProcessorDefinition<?>> {
     /**
      * Uses the XML Security data format
      */
-    public T secureXML(String secureTag, boolean secureTagContents, String recipientKeyAlias, String xmlCipherAlgorithm,
-            String keyCipherAlgorithm, KeyStoreParameters keyOrTrustStoreParameters, String keyPassword) {
+    public T secureXML(String secureTag, boolean secureTagContents, String recipientKeyAlias, String xmlCipherAlgorithm, String keyCipherAlgorithm,
+                       KeyStoreParameters keyOrTrustStoreParameters, String keyPassword) {
         XMLSecurityDataFormat xsdf = new XMLSecurityDataFormat();
         xsdf.setSecureTag(secureTag);
         xsdf.setSecureTagContents(secureTagContents);
@@ -1129,8 +1107,8 @@ public class DataFormatClause<T extends ProcessorDefinition<?>> {
     /**
      * Uses the XML Security data format
      */
-    public T secureXML(String secureTag, Map<String, String> namespaces, boolean secureTagContents, String recipientKeyAlias,
-            String xmlCipherAlgorithm, String keyCipherAlgorithm, String keyOrTrustStoreParametersId) {
+    public T secureXML(String secureTag, Map<String, String> namespaces, boolean secureTagContents, String recipientKeyAlias, String xmlCipherAlgorithm, String keyCipherAlgorithm,
+                       String keyOrTrustStoreParametersId) {
         XMLSecurityDataFormat xsdf = new XMLSecurityDataFormat();
         xsdf.setSecureTag(secureTag);
         xsdf.setSecureTagContents(secureTagContents);
@@ -1144,8 +1122,8 @@ public class DataFormatClause<T extends ProcessorDefinition<?>> {
     /**
      * Uses the XML Security data format
      */
-    public T secureXML(String secureTag, Map<String, String> namespaces, boolean secureTagContents, String recipientKeyAlias,
-            String xmlCipherAlgorithm, String keyCipherAlgorithm, String keyOrTrustStoreParametersId, String keyPassword) {
+    public T secureXML(String secureTag, Map<String, String> namespaces, boolean secureTagContents, String recipientKeyAlias, String xmlCipherAlgorithm, String keyCipherAlgorithm,
+                       String keyOrTrustStoreParametersId, String keyPassword) {
         XMLSecurityDataFormat xsdf = new XMLSecurityDataFormat();
         xsdf.setSecureTag(secureTag);
         xsdf.setSecureTagContents(secureTagContents);
@@ -1160,8 +1138,8 @@ public class DataFormatClause<T extends ProcessorDefinition<?>> {
     /**
      * Uses the XML Security data format
      */
-    public T secureXML(String secureTag, Map<String, String> namespaces, boolean secureTagContents, String recipientKeyAlias,
-            String xmlCipherAlgorithm, String keyCipherAlgorithm, KeyStoreParameters keyOrTrustStoreParameters) {
+    public T secureXML(String secureTag, Map<String, String> namespaces, boolean secureTagContents, String recipientKeyAlias, String xmlCipherAlgorithm, String keyCipherAlgorithm,
+                       KeyStoreParameters keyOrTrustStoreParameters) {
         XMLSecurityDataFormat xsdf = new XMLSecurityDataFormat();
         xsdf.setSecureTag(secureTag);
         xsdf.setNamespaces(namespaces);
@@ -1176,8 +1154,8 @@ public class DataFormatClause<T extends ProcessorDefinition<?>> {
     /**
      * Uses the XML Security data format
      */
-    public T secureXML(String secureTag, Map<String, String> namespaces, boolean secureTagContents, String recipientKeyAlias,
-            String xmlCipherAlgorithm, String keyCipherAlgorithm, KeyStoreParameters keyOrTrustStoreParameters, String keyPassword) {
+    public T secureXML(String secureTag, Map<String, String> namespaces, boolean secureTagContents, String recipientKeyAlias, String xmlCipherAlgorithm, String keyCipherAlgorithm,
+                       KeyStoreParameters keyOrTrustStoreParameters, String keyPassword) {
         XMLSecurityDataFormat xsdf = new XMLSecurityDataFormat();
         xsdf.setSecureTag(secureTag);
         xsdf.setNamespaces(namespaces);
@@ -1193,9 +1171,8 @@ public class DataFormatClause<T extends ProcessorDefinition<?>> {
     /**
      * Uses the XML Security data format
      */
-    public T secureXML(String secureTag, Map<String, String> namespaces, boolean secureTagContents, String recipientKeyAlias,
-            String xmlCipherAlgorithm, String keyCipherAlgorithm, KeyStoreParameters keyOrTrustStoreParameters, String keyPassword,
-            String digestAlgorithm) {
+    public T secureXML(String secureTag, Map<String, String> namespaces, boolean secureTagContents, String recipientKeyAlias, String xmlCipherAlgorithm, String keyCipherAlgorithm,
+                       KeyStoreParameters keyOrTrustStoreParameters, String keyPassword, String digestAlgorithm) {
         XMLSecurityDataFormat xsdf = new XMLSecurityDataFormat();
         xsdf.setSecureTag(secureTag);
         xsdf.setNamespaces(namespaces);
@@ -1316,9 +1293,9 @@ public class DataFormatClause<T extends ProcessorDefinition<?>> {
     private T dataFormat(DataFormatDefinition dataFormatType) {
         switch (operation) {
         case Unmarshal:
-            return (T) processorType.unmarshal(dataFormatType);
+            return (T)processorType.unmarshal(dataFormatType);
         case Marshal:
-            return (T) processorType.marshal(dataFormatType);
+            return (T)processorType.marshal(dataFormatType);
         default:
             throw new IllegalArgumentException("Unknown DataFormat operation: " + operation);
         }
diff --git a/core/camel-core/src/main/java/org/apache/camel/builder/DeadLetterChannelBuilder.java b/core/camel-core/src/main/java/org/apache/camel/builder/DeadLetterChannelBuilder.java
index e86ec83..4d1b3f5 100644
--- a/core/camel-core/src/main/java/org/apache/camel/builder/DeadLetterChannelBuilder.java
+++ b/core/camel-core/src/main/java/org/apache/camel/builder/DeadLetterChannelBuilder.java
@@ -30,8 +30,8 @@ import org.apache.camel.util.StringHelper;
 import org.slf4j.LoggerFactory;
 
 /**
- * A builder of a <a
- * href="http://camel.apache.org/dead-letter-channel.html">Dead Letter
+ * A builder of a
+ * <a href="http://camel.apache.org/dead-letter-channel.html">Dead Letter
  * Channel</a>
  */
 public class DeadLetterChannelBuilder extends DefaultErrorHandlerBuilder {
@@ -49,15 +49,15 @@ public class DeadLetterChannelBuilder extends DefaultErrorHandlerBuilder {
     public DeadLetterChannelBuilder(String uri) {
         setDeadLetterUri(uri);
     }
-    
+
     @Override
     public Processor createErrorHandler(RouteContext routeContext, Processor processor) throws Exception {
         validateDeadLetterUri(routeContext);
 
-        DeadLetterChannel answer = new DeadLetterChannel(routeContext.getCamelContext(), processor, getLogger(), getOnRedelivery(), 
-                getRedeliveryPolicy(), getExceptionPolicyStrategy(), getFailureProcessor(), getDeadLetterUri(), isDeadLetterHandleNewException(),
-                isUseOriginalMessage(), isUseOriginalBody(), getRetryWhilePolicy(routeContext.getCamelContext()), getExecutorService(routeContext.getCamelContext()),
-                getOnPrepareFailure(), getOnExceptionOccurred());
+        DeadLetterChannel answer = new DeadLetterChannel(routeContext.getCamelContext(), processor, getLogger(), getOnRedelivery(), getRedeliveryPolicy(),
+                                                         getExceptionPolicyStrategy(), getFailureProcessor(), getDeadLetterUri(), isDeadLetterHandleNewException(),
+                                                         isUseOriginalMessage(), isUseOriginalBody(), getRetryWhilePolicy(routeContext.getCamelContext()),
+                                                         getExecutorService(routeContext.getCamelContext()), getOnPrepareFailure(), getOnExceptionOccurred());
         // configure error handler before we can use it
         configure(routeContext, answer);
         return answer;
@@ -81,9 +81,11 @@ public class DeadLetterChannelBuilder extends DefaultErrorHandlerBuilder {
     @Override
     public Processor getFailureProcessor() {
         if (failureProcessor == null) {
-            // wrap in our special safe fallback error handler if sending to dead letter channel fails
+            // wrap in our special safe fallback error handler if sending to
+            // dead letter channel fails
             Processor child = new SendProcessor(deadLetter, ExchangePattern.InOnly);
-            // force MEP to be InOnly so when sending to DLQ we would not expect a reply if the MEP was InOut
+            // force MEP to be InOnly so when sending to DLQ we would not expect
+            // a reply if the MEP was InOut
             failureProcessor = new FatalFallbackErrorHandler(child, true);
         }
         return failureProcessor;
diff --git a/core/camel-core/src/main/java/org/apache/camel/builder/DefaultErrorHandlerBuilder.java b/core/camel-core/src/main/java/org/apache/camel/builder/DefaultErrorHandlerBuilder.java
index 8f79f39..67f5171 100644
--- a/core/camel-core/src/main/java/org/apache/camel/builder/DefaultErrorHandlerBuilder.java
+++ b/core/camel-core/src/main/java/org/apache/camel/builder/DefaultErrorHandlerBuilder.java
@@ -61,9 +61,9 @@ public class DefaultErrorHandlerBuilder extends ErrorHandlerBuilderSupport {
 
     @Override
     public Processor createErrorHandler(RouteContext routeContext, Processor processor) throws Exception {
-        DefaultErrorHandler answer = new DefaultErrorHandler(routeContext.getCamelContext(), processor, getLogger(), getOnRedelivery(), 
-            getRedeliveryPolicy(), getExceptionPolicyStrategy(), getRetryWhilePolicy(routeContext.getCamelContext()),
-                getExecutorService(routeContext.getCamelContext()), getOnPrepareFailure(), getOnExceptionOccurred());
+        DefaultErrorHandler answer = new DefaultErrorHandler(routeContext.getCamelContext(), processor, getLogger(), getOnRedelivery(), getRedeliveryPolicy(),
+                                                             getExceptionPolicyStrategy(), getRetryWhilePolicy(routeContext.getCamelContext()),
+                                                             getExecutorService(routeContext.getCamelContext()), getOnPrepareFailure(), getOnExceptionOccurred());
         // configure error handler before we can use it
         configure(routeContext, answer);
         return answer;
@@ -217,7 +217,7 @@ public class DefaultErrorHandlerBuilder extends ErrorHandlerBuilderSupport {
         getRedeliveryPolicy().setLogExhaustedMessageHistory(logExhaustedMessageHistory);
         return this;
     }
-    
+
     public DefaultErrorHandlerBuilder logExhaustedMessageBody(boolean logExhaustedMessageBody) {
         getRedeliveryPolicy().setLogExhaustedMessageBody(logExhaustedMessageBody);
         return this;
@@ -229,8 +229,9 @@ public class DefaultErrorHandlerBuilder extends ErrorHandlerBuilderSupport {
     }
 
     /**
-     * Will allow asynchronous delayed redeliveries. The route, in particular the consumer's component,
-     * must support the Asynchronous Routing Engine (e.g. seda)
+     * Will allow asynchronous delayed redeliveries. The route, in particular
+     * the consumer's component, must support the Asynchronous Routing Engine
+     * (e.g. seda)
      *
      * @see RedeliveryPolicy#setAsyncDelayedRedelivery(boolean)
      * @return the builder
@@ -241,9 +242,11 @@ public class DefaultErrorHandlerBuilder extends ErrorHandlerBuilderSupport {
     }
 
     /**
-     * Controls whether to allow redelivery while stopping/shutting down a route that uses error handling.
+     * Controls whether to allow redelivery while stopping/shutting down a route
+     * that uses error handling.
      *
-     * @param allowRedeliveryWhileStopping <tt>true</tt> to allow redelivery, <tt>false</tt> to reject redeliveries
+     * @param allowRedeliveryWhileStopping <tt>true</tt> to allow redelivery,
+     *            <tt>false</tt> to reject redeliveries
      * @return the builder
      */
     public DefaultErrorHandlerBuilder allowRedeliveryWhileStopping(boolean allowRedeliveryWhileStopping) {
@@ -316,9 +319,11 @@ public class DefaultErrorHandlerBuilder extends ErrorHandlerBuilderSupport {
     }
 
     /**
-     * Sets a processor that should be processed <b>before</b> a redelivery attempt.
+     * Sets a processor that should be processed <b>before</b> a redelivery
+     * attempt.
      * <p/>
-     * Can be used to change the {@link org.apache.camel.Exchange} <b>before</b> its being redelivered.
+     * Can be used to change the {@link org.apache.camel.Exchange} <b>before</b>
+     * its being redelivered.
      *
      * @param processor the processor
      * @return the builder
@@ -342,34 +347,43 @@ public class DefaultErrorHandlerBuilder extends ErrorHandlerBuilderSupport {
     }
 
     /**
-     * Will use the original input {@link org.apache.camel.Message} (original body and headers) when an {@link org.apache.camel.Exchange}
-     * is moved to the dead letter queue.
+     * Will use the original input {@link org.apache.camel.Message} (original
+     * body and headers) when an {@link org.apache.camel.Exchange} is moved to
+     * the dead letter queue.
      * <p/>
-     * <b>Notice:</b> this only applies when all redeliveries attempt have failed and the {@link org.apache.camel.Exchange}
-     * is doomed for failure.
+     * <b>Notice:</b> this only applies when all redeliveries attempt have
+     * failed and the {@link org.apache.camel.Exchange} is doomed for failure.
      * <br/>
-     * Instead of using the current inprogress {@link org.apache.camel.Exchange} IN message we use the original
-     * IN message instead. This allows you to store the original input in the dead letter queue instead of the inprogress
-     * snapshot of the IN message.
-     * For instance if you route transform the IN body during routing and then failed. With the original exchange
-     * store in the dead letter queue it might be easier to manually re submit the {@link org.apache.camel.Exchange}
-     * again as the IN message is the same as when Camel received it.
-     * So you should be able to send the {@link org.apache.camel.Exchange} to the same input.
+     * Instead of using the current inprogress {@link org.apache.camel.Exchange}
+     * IN message we use the original IN message instead. This allows you to
+     * store the original input in the dead letter queue instead of the
+     * inprogress snapshot of the IN message. For instance if you route
+     * transform the IN body during routing and then failed. With the original
+     * exchange store in the dead letter queue it might be easier to manually re
+     * submit the {@link org.apache.camel.Exchange} again as the IN message is
+     * the same as when Camel received it. So you should be able to send the
+     * {@link org.apache.camel.Exchange} to the same input.
      * <p/>
-     * The difference between useOriginalMessage and useOriginalBody is that the former includes both the original
-     * body and headers, where as the latter only includes the original body. You can use the latter to enrich
-     * the message with custom headers and include the original message body. The former wont let you do this, as its
-     * using the original message body and headers as they are.
-     * You cannot enable both useOriginalMessage and useOriginalBody.
+     * The difference between useOriginalMessage and useOriginalBody is that the
+     * former includes both the original body and headers, where as the latter
+     * only includes the original body. You can use the latter to enrich the
+     * message with custom headers and include the original message body. The
+     * former wont let you do this, as its using the original message body and
+     * headers as they are. You cannot enable both useOriginalMessage and
+     * useOriginalBody.
      * <p/>
-     * <b>Important:</b> The original input means the input message that are bounded by the current {@link org.apache.camel.spi.UnitOfWork}.
-     * An unit of work typically spans one route, or multiple routes if they are connected using internal
-     * endpoints such as direct or seda. When messages is passed via external endpoints such as JMS or HTTP
-     * then the consumer will create a new unit of work, with the message it received as input as the
-     * original input. Also some EIP patterns such as splitter, multicast, will create a new unit of work
-     * boundary for the messages in their sub-route (eg the splitted message); however these EIPs have
-     * an option named <tt>shareUnitOfWork</tt> which allows to combine with the parent unit of work in
-     * regard to error handling and therefore use the parent original message.
+     * <b>Important:</b> The original input means the input message that are
+     * bounded by the current {@link org.apache.camel.spi.UnitOfWork}. An unit
+     * of work typically spans one route, or multiple routes if they are
+     * connected using internal endpoints such as direct or seda. When messages
+     * is passed via external endpoints such as JMS or HTTP then the consumer
+     * will create a new unit of work, with the message it received as input as
+     * the original input. Also some EIP patterns such as splitter, multicast,
+     * will create a new unit of work boundary for the messages in their
+     * sub-route (eg the splitted message); however these EIPs have an option
+     * named <tt>shareUnitOfWork</tt> which allows to combine with the parent
+     * unit of work in regard to error handling and therefore use the parent
+     * original message.
      * <p/>
      * By default this feature is off.
      *
@@ -382,34 +396,43 @@ public class DefaultErrorHandlerBuilder extends ErrorHandlerBuilderSupport {
     }
 
     /**
-     * Will use the original input {@link org.apache.camel.Message} body (original body only) when an {@link org.apache.camel.Exchange}
-     * is moved to the dead letter queue.
+     * Will use the original input {@link org.apache.camel.Message} body
+     * (original body only) when an {@link org.apache.camel.Exchange} is moved
+     * to the dead letter queue.
      * <p/>
-     * <b>Notice:</b> this only applies when all redeliveries attempt have failed and the {@link org.apache.camel.Exchange}
-     * is doomed for failure.
+     * <b>Notice:</b> this only applies when all redeliveries attempt have
+     * failed and the {@link org.apache.camel.Exchange} is doomed for failure.
      * <br/>
-     * Instead of using the current inprogress {@link org.apache.camel.Exchange} IN message we use the original
-     * IN message instead. This allows you to store the original input in the dead letter queue instead of the inprogress
-     * snapshot of the IN message.
-     * For instance if you route transform the IN body during routing and then failed. With the original exchange
-     * store in the dead letter queue it might be easier to manually re submit the {@link org.apache.camel.Exchange}
-     * again as the IN message is the same as when Camel received it.
-     * So you should be able to send the {@link org.apache.camel.Exchange} to the same input.
+     * Instead of using the current inprogress {@link org.apache.camel.Exchange}
+     * IN message we use the original IN message instead. This allows you to
+     * store the original input in the dead letter queue instead of the
+     * inprogress snapshot of the IN message. For instance if you route
+     * transform the IN body during routing and then failed. With the original
+     * exchange store in the dead letter queue it might be easier to manually re
+     * submit the {@link org.apache.camel.Exchange} again as the IN message is
+     * the same as when Camel received it. So you should be able to send the
+     * {@link org.apache.camel.Exchange} to the same input.
      * <p/>
-     * The difference between useOriginalMessage and useOriginalBody is that the former includes both the original
-     * body and headers, where as the latter only includes the original body. You can use the latter to enrich
-     * the message with custom headers and include the original message body. The former wont let you do this, as its
-     * using the original message body and headers as they are.
-     * You cannot enable both useOriginalMessage and useOriginalBody.
+     * The difference between useOriginalMessage and useOriginalBody is that the
+     * former includes both the original body and headers, where as the latter
+     * only includes the original body. You can use the latter to enrich the
+     * message with custom headers and include the original message body. The
+     * former wont let you do this, as its using the original message body and
+     * headers as they are. You cannot enable both useOriginalMessage and
+     * useOriginalBody.
      * <p/>
-     * <b>Important:</b> The original input means the input message that are bounded by the current {@link org.apache.camel.spi.UnitOfWork}.
-     * An unit of work typically spans one route, or multiple routes if they are connected using internal
-     * endpoints such as direct or seda. When messages is passed via external endpoints such as JMS or HTTP
-     * then the consumer will create a new unit of work, with the message it received as input as the
-     * original input. Also some EIP patterns such as splitter, multicast, will create a new unit of work
-     * boundary for the messages in their sub-route (eg the splitted message); however these EIPs have
-     * an option named <tt>shareUnitOfWork</tt> which allows to combine with the parent unit of work in
-     * regard to error handling and therefore use the parent original message.
+     * <b>Important:</b> The original input means the input message that are
+     * bounded by the current {@link org.apache.camel.spi.UnitOfWork}. An unit
+     * of work typically spans one route, or multiple routes if they are
+     * connected using internal endpoints such as direct or seda. When messages
+     * is passed via external endpoints such as JMS or HTTP then the consumer
+     * will create a new unit of work, with the message it received as input as
+     * the original input. Also some EIP patterns such as splitter, multicast,
+     * will create a new unit of work boundary for the messages in their
+     * sub-route (eg the splitted message); however these EIPs have an option
+     * named <tt>shareUnitOfWork</tt> which allows to combine with the parent
+     * unit of work in regard to error handling and therefore use the parent
+     * original message.
      * <p/>
      * By default this feature is off.
      *
@@ -422,17 +445,23 @@ public class DefaultErrorHandlerBuilder extends ErrorHandlerBuilderSupport {
     }
 
     /**
-     * Whether the dead letter channel should handle (and ignore) any new exception that may been thrown during sending the
-     * message to the dead letter endpoint.
+     * Whether the dead letter channel should handle (and ignore) any new
+     * exception that may been thrown during sending the message to the dead
+     * letter endpoint.
      * <p/>
-     * The default value is <tt>true</tt> which means any such kind of exception is handled and ignored. Set this to <tt>false</tt>
-     * to let the exception be propagated back on the {@link org.apache.camel.Exchange}. This can be used in situations
-     * where you use transactions, and want to use Camel's dead letter channel to deal with exceptions during routing,
-     * but if the dead letter channel itself fails because of a new exception being thrown, then by setting this to <tt>false</tt>
-     * the new exceptions is propagated back and set on the {@link org.apache.camel.Exchange}, which allows the transaction
-     * to detect the exception, and rollback.
+     * The default value is <tt>true</tt> which means any such kind of exception
+     * is handled and ignored. Set this to <tt>false</tt> to let the exception
+     * be propagated back on the {@link org.apache.camel.Exchange}. This can be
+     * used in situations where you use transactions, and want to use Camel's
+     * dead letter channel to deal with exceptions during routing, but if the
+     * dead letter channel itself fails because of a new exception being thrown,
+     * then by setting this to <tt>false</tt> the new exceptions is propagated
+     * back and set on the {@link org.apache.camel.Exchange}, which allows the
+     * transaction to detect the exception, and rollback.
      *
-     * @param handleNewException <tt>true</tt> to handle (and ignore), <tt>false</tt> to catch and propagated the exception on the {@link org.apache.camel.Exchange}
+     * @param handleNewException <tt>true</tt> to handle (and ignore),
+     *            <tt>false</tt> to catch and propagated the exception on the
+     *            {@link org.apache.camel.Exchange}
      * @return the builder
      */
     public DefaultErrorHandlerBuilder deadLetterHandleNewException(boolean handleNewException) {
@@ -441,8 +470,9 @@ public class DefaultErrorHandlerBuilder extends ErrorHandlerBuilderSupport {
     }
 
     /**
-     * Sets a custom {@link org.apache.camel.Processor} to prepare the {@link org.apache.camel.Exchange} before
-     * handled by the failure processor / dead letter channel. This allows for example to enrich the message
+     * Sets a custom {@link org.apache.camel.Processor} to prepare the
+     * {@link org.apache.camel.Exchange} before handled by the failure processor
+     * / dead letter channel. This allows for example to enrich the message
      * before sending to a dead letter queue.
      *
      * @param processor the processor
@@ -454,8 +484,10 @@ public class DefaultErrorHandlerBuilder extends ErrorHandlerBuilderSupport {
     }
 
     /**
-     * Sets a custom {@link org.apache.camel.Processor} to process the {@link org.apache.camel.Exchange} just after an exception was thrown.
-     * This allows to execute the processor at the same time the exception was thrown.
+     * Sets a custom {@link org.apache.camel.Processor} to process the
+     * {@link org.apache.camel.Exchange} just after an exception was thrown.
+     * This allows to execute the processor at the same time the exception was
+     * thrown.
      * <p/>
      * Important: Any exception thrown from this processor will be ignored.
      *
@@ -633,7 +665,8 @@ public class DefaultErrorHandlerBuilder extends ErrorHandlerBuilderSupport {
 
     protected synchronized ScheduledExecutorService getExecutorService(CamelContext camelContext) {
         if (executorService == null || executorService.isShutdown()) {
-            // camel context will shutdown the executor when it shutdown so no need to shut it down when stopping
+            // camel context will shutdown the executor when it shutdown so no
+            // need to shut it down when stopping
             if (executorServiceRef != null) {
                 executorService = camelContext.getRegistry().lookupByNameAndType(executorServiceRef, ScheduledExecutorService.class);
                 if (executorService == null) {
@@ -645,8 +678,10 @@ public class DefaultErrorHandlerBuilder extends ErrorHandlerBuilderSupport {
                     throw new IllegalArgumentException("ExecutorServiceRef " + executorServiceRef + " not found in registry.");
                 }
             } else {
-                // no explicit configured thread pool, so leave it up to the error handler to decide if it need
-                // a default thread pool from CamelContext#getErrorHandlerExecutorService
+                // no explicit configured thread pool, so leave it up to the
+                // error handler to decide if it need
+                // a default thread pool from
+                // CamelContext#getErrorHandlerExecutorService
                 executorService = null;
             }
         }
diff --git a/core/camel-core/src/main/java/org/apache/camel/builder/EndpointConsumerBuilder.java b/core/camel-core/src/main/java/org/apache/camel/builder/EndpointConsumerBuilder.java
index 83f2ac2..b840071 100644
--- a/core/camel-core/src/main/java/org/apache/camel/builder/EndpointConsumerBuilder.java
+++ b/core/camel-core/src/main/java/org/apache/camel/builder/EndpointConsumerBuilder.java
@@ -30,21 +30,21 @@ public interface EndpointConsumerBuilder {
     /**
      * Builds and resolves this endpoint DSL as an endpoint.
      *
-     * @param context  the camel context
+     * @param context the camel context
      * @return a built {@link Endpoint}
      * @throws NoSuchEndpointException is thrown if the endpoint
      */
     Endpoint resolve(CamelContext context) throws NoSuchEndpointException;
 
     /**
-     * Builds the url of this endpoint.
-     * This API is only intended for Camel internally.
+     * Builds the url of this endpoint. This API is only intended for Camel
+     * internally.
      */
     String getUri();
 
     /**
-     * Adds an option to this endpoint.
-     * This API is only intended for Camel internally.
+     * Adds an option to this endpoint. This API is only intended for Camel
+     * internally.
      */
     void setProperty(String name, Object value);
 
diff --git a/core/camel-core/src/main/java/org/apache/camel/builder/EndpointProducerBuilder.java b/core/camel-core/src/main/java/org/apache/camel/builder/EndpointProducerBuilder.java
index 08543ae..6feb6af 100644
--- a/core/camel-core/src/main/java/org/apache/camel/builder/EndpointProducerBuilder.java
+++ b/core/camel-core/src/main/java/org/apache/camel/builder/EndpointProducerBuilder.java
@@ -31,27 +31,27 @@ public interface EndpointProducerBuilder {
     /**
      * Builds and resolves this endpoint DSL as an endpoint.
      *
-     * @param context  the camel context
+     * @param context the camel context
      * @return a built {@link Endpoint}
      * @throws NoSuchEndpointException is thrown if the endpoint
      */
     Endpoint resolve(CamelContext context) throws NoSuchEndpointException;
 
     /**
-     * Builds the url of this endpoint.
-     * This API is only intended for Camel internally.
+     * Builds the url of this endpoint. This API is only intended for Camel
+     * internally.
      */
     String getUri();
 
     /**
-     * Adds an option to this endpoint.
-     * This API is only intended for Camel internally.
+     * Adds an option to this endpoint. This API is only intended for Camel
+     * internally.
      */
     void setProperty(String name, Object value);
 
     /**
-     * Builds an expression of this endpoint url.
-     * This API is only intended for Camel internally.
+     * Builds an expression of this endpoint url. This API is only intended for
+     * Camel internally.
      */
     Expression expr();
 
diff --git a/core/camel-core/src/main/java/org/apache/camel/builder/EnrichClause.java b/core/camel-core/src/main/java/org/apache/camel/builder/EnrichClause.java
index ff77c27..83ff077 100644
--- a/core/camel-core/src/main/java/org/apache/camel/builder/EnrichClause.java
+++ b/core/camel-core/src/main/java/org/apache/camel/builder/EnrichClause.java
@@ -18,7 +18,6 @@ package org.apache.camel.builder;
 
 import org.apache.camel.model.ProcessorDefinition;
 
-
 public class EnrichClause<T extends ProcessorDefinition<?>> extends AggregationStrategyClause<T> {
 
     public EnrichClause(T parent) {
diff --git a/core/camel-core/src/main/java/org/apache/camel/builder/ErrorHandlerBuilder.java b/core/camel-core/src/main/java/org/apache/camel/builder/ErrorHandlerBuilder.java
index cc0ec74..5f666a5 100644
--- a/core/camel-core/src/main/java/org/apache/camel/builder/ErrorHandlerBuilder.java
+++ b/core/camel-core/src/main/java/org/apache/camel/builder/ErrorHandlerBuilder.java
@@ -23,7 +23,8 @@ import org.apache.camel.model.OnExceptionDefinition;
 import org.apache.camel.spi.RouteContext;
 
 /**
- * A builder of a <a href="http://camel.apache.org/error-handler.html">Error Handler</a>
+ * A builder of a <a href="http://camel.apache.org/error-handler.html">Error
+ * Handler</a>
  */
 public interface ErrorHandlerBuilder extends ErrorHandlerFactory {
 
@@ -42,5 +43,5 @@ public interface ErrorHandlerBuilder extends ErrorHandlerFactory {
      * @return a clone of this {@link ErrorHandlerBuilder}
      */
     ErrorHandlerBuilder cloneBuilder();
-    
+
 }
diff --git a/core/camel-core/src/main/java/org/apache/camel/builder/ErrorHandlerBuilderRef.java b/core/camel-core/src/main/java/org/apache/camel/builder/ErrorHandlerBuilderRef.java
index a8444de..74e5f56 100644
--- a/core/camel-core/src/main/java/org/apache/camel/builder/ErrorHandlerBuilderRef.java
+++ b/core/camel-core/src/main/java/org/apache/camel/builder/ErrorHandlerBuilderRef.java
@@ -28,7 +28,8 @@ import org.apache.camel.spi.RouteContext;
 import org.apache.camel.util.ObjectHelper;
 
 /**
- * Represents a proxy to an error handler builder which is resolved by named reference
+ * Represents a proxy to an error handler builder which is resolved by named
+ * reference
  */
 public class ErrorHandlerBuilderRef extends ErrorHandlerBuilderSupport {
     private final String ref;
@@ -69,7 +70,7 @@ public class ErrorHandlerBuilderRef extends ErrorHandlerBuilderSupport {
     }
 
     private ErrorHandlerBuilder lookupErrorHandler(RouteContext routeContext) {
-        ErrorHandlerBuilder handler = (ErrorHandlerBuilder) ErrorHandlerReifier.lookupErrorHandlerFactory(routeContext, getRef());
+        ErrorHandlerBuilder handler = (ErrorHandlerBuilder)ErrorHandlerReifier.lookupErrorHandlerFactory(routeContext, getRef());
         ObjectHelper.notNull(handler, "error handler '" + ref + "'");
 
         // configure if the handler support transacted
diff --git a/core/camel-core/src/main/java/org/apache/camel/builder/ErrorHandlerBuilderSupport.java b/core/camel-core/src/main/java/org/apache/camel/builder/ErrorHandlerBuilderSupport.java
index 3d9e22d..8bb166f 100644
--- a/core/camel-core/src/main/java/org/apache/camel/builder/ErrorHandlerBuilderSupport.java
+++ b/core/camel-core/src/main/java/org/apache/camel/builder/ErrorHandlerBuilderSupport.java
@@ -56,15 +56,15 @@ public abstract class ErrorHandlerBuilderSupport implements ErrorHandlerBuilder
      */
     public void configure(RouteContext routeContext, ErrorHandler handler) {
         if (handler instanceof ErrorHandlerSupport) {
-            ErrorHandlerSupport handlerSupport = (ErrorHandlerSupport) handler;
+            ErrorHandlerSupport handlerSupport = (ErrorHandlerSupport)handler;
 
             Set<NamedNode> list = routeContext.getErrorHandlers(this);
             for (NamedNode exception : list) {
-                addExceptionPolicy(handlerSupport, routeContext, (OnExceptionDefinition) exception);
+                addExceptionPolicy(handlerSupport, routeContext, (OnExceptionDefinition)exception);
             }
         }
         if (handler instanceof RedeliveryErrorHandler) {
-            RedeliveryErrorHandler reh = (RedeliveryErrorHandler) handler;
+            RedeliveryErrorHandler reh = (RedeliveryErrorHandler)handler;
             boolean original = reh.isUseOriginalMessagePolicy() || reh.isUseOriginalBodyPolicy();
             if (original) {
                 if (reh.isUseOriginalMessagePolicy() && reh.isUseOriginalBodyPolicy()) {
@@ -88,7 +88,8 @@ public abstract class ErrorHandlerBuilderSupport implements ErrorHandlerBuilder
                 list = createExceptionClasses(exceptionType, routeContext.getCamelContext().getClassResolver());
                 for (Class<? extends Throwable> clazz : list) {
                     String routeId = null;
-                    // only get the route id, if the exception type is route scoped
+                    // only get the route id, if the exception type is route
+                    // scoped
                     if (exceptionType.isRouteScoped()) {
                         RouteDefinition route = ProcessorDefinitionHelper.getRoute(exceptionType);
                         if (route != null) {
@@ -138,14 +139,15 @@ public abstract class ErrorHandlerBuilderSupport implements ErrorHandlerBuilder
     }
 
     /**
-     * Sets the exception policy strategy to use for resolving the {@link org.apache.camel.model.OnExceptionDefinition}
-     * to use for a given thrown exception
+     * Sets the exception policy strategy to use for resolving the
+     * {@link org.apache.camel.model.OnExceptionDefinition} to use for a given
+     * thrown exception
      *
-     * @param exceptionPolicyStrategy  the exception policy strategy
+     * @param exceptionPolicyStrategy the exception policy strategy
      */
     public void setExceptionPolicyStrategy(ExceptionPolicyStrategy exceptionPolicyStrategy) {
         ObjectHelper.notNull(exceptionPolicyStrategy, "ExceptionPolicyStrategy");
         this.exceptionPolicyStrategy = exceptionPolicyStrategy;
     }
-    
+
 }
diff --git a/core/camel-core/src/main/java/org/apache/camel/builder/ExchangeBuilder.java b/core/camel-core/src/main/java/org/apache/camel/builder/ExchangeBuilder.java
index 83820ec..cc8f5b4 100644
--- a/core/camel-core/src/main/java/org/apache/camel/builder/ExchangeBuilder.java
+++ b/core/camel-core/src/main/java/org/apache/camel/builder/ExchangeBuilder.java
@@ -26,7 +26,8 @@ import org.apache.camel.Message;
 import org.apache.camel.support.DefaultExchange;
 
 /**
- * Builder to create {@link Exchange} and add headers and set body on the Exchange {@link Message}.
+ * Builder to create {@link Exchange} and add headers and set body on the
+ * Exchange {@link Message}.
  * <p/>
  * Use the {@link #build()} method when done setting up the exchange.
  */
@@ -44,7 +45,7 @@ public final class ExchangeBuilder {
     /**
      * Create the exchange by setting the camel context
      *
-     * @param context the camel context 
+     * @param context the camel context
      * @return exchange builder
      */
     public static ExchangeBuilder anExchange(CamelContext context) {
@@ -84,7 +85,7 @@ public final class ExchangeBuilder {
         this.pattern = pattern;
         return this;
     }
-    
+
     /**
      * Set the exchange property
      *
@@ -100,7 +101,7 @@ public final class ExchangeBuilder {
     /**
      * Build up the exchange from the exchange builder
      *
-     * @return exchange 
+     * @return exchange
      */
     public Exchange build() {
         Exchange exchange = new DefaultExchange(context);
diff --git a/core/camel-core/src/main/java/org/apache/camel/builder/ExpressionBuilder.java b/core/camel-core/src/main/java/org/apache/camel/builder/ExpressionBuilder.java
index 8da8f8f..b253885 100644
--- a/core/camel-core/src/main/java/org/apache/camel/builder/ExpressionBuilder.java
+++ b/core/camel-core/src/main/java/org/apache/camel/builder/ExpressionBuilder.java
@@ -17,11 +17,13 @@
 package org.apache.camel.builder;
 
 /**
- * A helper class for working with <a href="http://camel.apache.org/expression.html">expressions</a>.
+ * A helper class for working with
+ * <a href="http://camel.apache.org/expression.html">expressions</a>.
  */
 public final class ExpressionBuilder extends org.apache.camel.support.builder.ExpressionBuilder {
 
-    // this class is included in camel-core to be backwards compatible by extending from camel-support
+    // this class is included in camel-core to be backwards compatible by
+    // extending from camel-support
 
     /**
      * Utility classes should not have a public constructor.
diff --git a/core/camel-core/src/main/java/org/apache/camel/builder/ExpressionClause.java b/core/camel-core/src/main/java/org/apache/camel/builder/ExpressionClause.java
index cdef4c2..a0cd5f2 100644
--- a/core/camel-core/src/main/java/org/apache/camel/builder/ExpressionClause.java
+++ b/core/camel-core/src/main/java/org/apache/camel/builder/ExpressionClause.java
@@ -52,10 +52,9 @@ public class ExpressionClause<T> implements Expression, Predicate {
     }
 
     /**
-     * Specify the constant expression value.
-     *
-     * <b>Important:</b> this is a fixed constant value that is only set once during starting up the route,
-     * do not use this if you want dynamic values during routing.
+     * Specify the constant expression value. <b>Important:</b> this is a fixed
+     * constant value that is only set once during starting up the route, do not
+     * use this if you want dynamic values during routing.
      */
     public T constant(Object value) {
         return delegate.constant(value);
@@ -146,9 +145,7 @@ public class ExpressionClause<T> implements Expression, Predicate {
     public T body(final BiFunction<Object, Map<String, Object>, Object> function) {
         return delegate.expression(new ExpressionAdapter() {
             public Object evaluate(Exchange exchange) {
-                return function.apply(
-                    exchange.getIn().getBody(),
-                    exchange.getIn().getHeaders());
+                return function.apply(exchange.getIn().getBody(), exchange.getIn().getHeaders());
             }
         });
     }
@@ -161,7 +158,8 @@ public class ExpressionClause<T> implements Expression, Predicate {
     }
 
     /**
-     * A functional expression of an inbound message body converted to the expected type
+     * A functional expression of an inbound message body converted to the
+     * expected type
      */
     public <B> T body(Class<B> expectedType, final Function<B, Object> function) {
         return delegate.expression(new ExpressionAdapter() {
@@ -172,14 +170,13 @@ public class ExpressionClause<T> implements Expression, Predicate {
     }
 
     /**
-     * A functional expression of an inbound message body converted to the expected type and headers
+     * A functional expression of an inbound message body converted to the
+     * expected type and headers
      */
     public <B> T body(Class<B> expectedType, final BiFunction<B, Map<String, Object>, Object> function) {
         return delegate.expression(new ExpressionAdapter() {
             public Object evaluate(Exchange exchange) {
-                return function.apply(
-                    exchange.getIn().getBody(expectedType),
-                    exchange.getIn().getHeaders());
+                return function.apply(exchange.getIn().getBody(expectedType), exchange.getIn().getHeaders());
             }
         });
     }
@@ -216,8 +213,8 @@ public class ExpressionClause<T> implements Expression, Predicate {
     // -------------------------------------------------------------------------
 
     /**
-     * Evaluates an expression using the <a
-     * href="http://camel.apache.org/bean-language.html">bean language</a>
+     * Evaluates an expression using the
+     * <a href="http://camel.apache.org/bean-language.html">bean language</a>
      * which basically means the bean is invoked to determine the expression
      * value.
      * 
@@ -227,10 +224,10 @@ public class ExpressionClause<T> implements Expression, Predicate {
     public T method(String bean) {
         return delegate.method(bean);
     }
-    
+
     /**
-     * Evaluates an expression using the <a
-     * href="http://camel.apache.org/bean-language.html">bean language</a>
+     * Evaluates an expression using the
+     * <a href="http://camel.apache.org/bean-language.html">bean language</a>
      * which basically means the bean is invoked to determine the expression
      * value.
      *
@@ -242,8 +239,8 @@ public class ExpressionClause<T> implements Expression, Predicate {
     }
 
     /**
-     * Evaluates an expression using the <a
-     * href="http://camel.apache.org/bean-language.html">bean language</a>
+     * Evaluates an expression using the
+     * <a href="http://camel.apache.org/bean-language.html">bean language</a>
      * which basically means the bean is invoked to determine the expression
      * value.
      * 
@@ -255,8 +252,8 @@ public class ExpressionClause<T> implements Expression, Predicate {
     }
 
     /**
-     * Evaluates an expression using the <a
-     * href="http://camel.apache.org/bean-language.html">bean language</a>
+     * Evaluates an expression using the
+     * <a href="http://camel.apache.org/bean-language.html">bean language</a>
      * which basically means the bean is invoked to determine the expression
      * value.
      * 
@@ -267,10 +264,10 @@ public class ExpressionClause<T> implements Expression, Predicate {
     public T method(String bean, String method) {
         return delegate.method(bean, method);
     }
-    
+
     /**
-     * Evaluates an expression using the <a
-     * href="http://camel.apache.org/bean-language.html">bean language</a>
+     * Evaluates an expression using the
+     * <a href="http://camel.apache.org/bean-language.html">bean language</a>
      * which basically means the bean is invoked to determine the expression
      * value.
      *
@@ -283,8 +280,8 @@ public class ExpressionClause<T> implements Expression, Predicate {
     }
 
     /**
-     * Evaluates an expression using the <a
-     * href="http://camel.apache.org/bean-language.html">bean language</a>
+     * Evaluates an expression using the
+     * <a href="http://camel.apache.org/bean-language.html">bean language</a>
      * which basically means the bean is invoked to determine the expression
      * value.
      * 
@@ -308,8 +305,7 @@ public class ExpressionClause<T> implements Expression, Predicate {
     }
 
     /**
-     * Evaluates a <a
-     * href="http://camel.apache.org/jsonpath.html">Json Path
+     * Evaluates a <a href="http://camel.apache.org/jsonpath.html">Json Path
      * expression</a>
      *
      * @param text the expression to be evaluated
@@ -320,12 +316,12 @@ public class ExpressionClause<T> implements Expression, Predicate {
     }
 
     /**
-     * Evaluates a <a
-     * href="http://camel.apache.org/jsonpath.html">Json Path
+     * Evaluates a <a href="http://camel.apache.org/jsonpath.html">Json Path
      * expression</a>
      *
      * @param text the expression to be evaluated
-     * @param suppressExceptions whether to suppress exceptions such as PathNotFoundException
+     * @param suppressExceptions whether to suppress exceptions such as
+     *            PathNotFoundException
      * @return the builder to continue processing the DSL
      */
     public T jsonpath(String text, boolean suppressExceptions) {
@@ -333,8 +329,7 @@ public class ExpressionClause<T> implements Expression, Predicate {
     }
 
     /**
-     * Evaluates a <a
-     * href="http://camel.apache.org/jsonpath.html">Json Path
+     * Evaluates a <a href="http://camel.apache.org/jsonpath.html">Json Path
      * expression</a>
      *
      * @param text the expression to be evaluated
@@ -346,12 +341,12 @@ public class ExpressionClause<T> implements Expression, Predicate {
     }
 
     /**
-     * Evaluates a <a
-     * href="http://camel.apache.org/jsonpath.html">Json Path
+     * Evaluates a <a href="http://camel.apache.org/jsonpath.html">Json Path
      * expression</a>
      *
      * @param text the expression to be evaluated
-     * @param suppressExceptions whether to suppress exceptions such as PathNotFoundException
+     * @param suppressExceptions whether to suppress exceptions such as
+     *            PathNotFoundException
      * @param resultType the return type expected by the expression
      * @return the builder to continue processing the DSL
      */
@@ -360,12 +355,12 @@ public class ExpressionClause<T> implements Expression, Predicate {
     }
 
     /**
-     * Evaluates a <a
-     * href="http://camel.apache.org/jsonpath.html">Json Path
+     * Evaluates a <a href="http://camel.apache.org/jsonpath.html">Json Path
      * expression</a>
      *
      * @param text the expression to be evaluated
-     * @param suppressExceptions whether to suppress exceptions such as PathNotFoundException
+     * @param suppressExceptions whether to suppress exceptions such as
+     *            PathNotFoundException
      * @param resultType the return type expected by the expression
      * @param headerName the name of the header to apply the expression to
      * @return the builder to continue processing the DSL
@@ -375,8 +370,7 @@ public class ExpressionClause<T> implements Expression, Predicate {
     }
 
     /**
-     * Evaluates a <a
-     * href="http://camel.apache.org/jsonpath.html">Json Path
+     * Evaluates a <a href="http://camel.apache.org/jsonpath.html">Json Path
      * expression</a> with writeAsString enabled.
      *
      * @param text the expression to be evaluated
@@ -387,12 +381,12 @@ public class ExpressionClause<T> implements Expression, Predicate {
     }
 
     /**
-     * Evaluates a <a
-     * href="http://camel.apache.org/jsonpath.html">Json Path
+     * Evaluates a <a href="http://camel.apache.org/jsonpath.html">Json Path
      * expression</a> with writeAsString enabled.
      *
      * @param text the expression to be evaluated
-     * @param suppressExceptions whether to suppress exceptions such as PathNotFoundException
+     * @param suppressExceptions whether to suppress exceptions such as
+     *            PathNotFoundException
      * @return the builder to continue processing the DSL
      */
     public T jsonpathWriteAsString(String text, boolean suppressExceptions) {
@@ -400,12 +394,12 @@ public class ExpressionClause<T> implements Expression, Predicate {
     }
 
     /**
-     * Evaluates a <a
-     * href="http://camel.apache.org/jsonpath.html">Json Path
+     * Evaluates a <a href="http://camel.apache.org/jsonpath.html">Json Path
      * expression</a> with writeAsString enabled.
      *
      * @param text the expression to be evaluated
-     * @param suppressExceptions whether to suppress exceptions such as PathNotFoundException
+     * @param suppressExceptions whether to suppress exceptions such as
+     *            PathNotFoundException
      * @param headerName the name of the header to apply the expression to
      * @return the builder to continue processing the DSL
      */
@@ -456,7 +450,7 @@ public class ExpressionClause<T> implements Expression, Predicate {
     public T spel(String text) {
         return delegate.spel(text);
     }
-    
+
     /**
      * Evaluates a <a href="http://camel.apache.org/simple.html">Simple
      * expression</a>
@@ -628,7 +622,7 @@ public class ExpressionClause<T> implements Expression, Predicate {
      * Tokens is not included.
      *
      * @param startToken the start token
-     * @param endToken   the end token
+     * @param endToken the end token
      * @return the builder to continue processing the DSL
      */
     public T tokenizePair(String startToken, String endToken) {
@@ -639,7 +633,7 @@ public class ExpressionClause<T> implements Expression, Predicate {
      * Evaluates a token pair expression on the message body
      *
      * @param startToken the start token
-     * @param endToken   the end token
+     * @param endToken the end token
      * @param includeTokens whether to include tokens
      * @return the builder to continue processing the DSL
      */
@@ -672,7 +666,8 @@ public class ExpressionClause<T> implements Expression, Predicate {
      * Evaluates a token pair expression on the message body with XML content
      *
      * @param tagName the tag name of the child nodes to tokenize
-     * @param inheritNamespaceTagName  parent or root tag name that contains namespace(s) to inherit
+     * @param inheritNamespaceTagName parent or root tag name that contains
+     *            namespace(s) to inherit
      * @return the builder to continue processing the DSL
      */
     public T tokenizeXML(String tagName, String inheritNamespaceTagName) {
@@ -683,7 +678,8 @@ public class ExpressionClause<T> implements Expression, Predicate {
      * Evaluates a token pair expression on the message body with XML content
      *
      * @param tagName the tag name of the child nodes to tokenize
-     * @param inheritNamespaceTagName  parent or root tag name that contains namespace(s) to inherit
+     * @param inheritNamespaceTagName parent or root tag name that contains
+     *            namespace(s) to inherit
      * @param group to group by the given number
      * @return the builder to continue processing the DSL
      */
@@ -713,7 +709,6 @@ public class ExpressionClause<T> implements Expression, Predicate {
     public T xpath(String text) {
         return delegate.xpath(text);
     }
-    
 
     /**
      * Evaluates an <a href="http://camel.apache.org/xpath.html">XPath
@@ -738,11 +733,11 @@ public class ExpressionClause<T> implements Expression, Predicate {
     public T xpath(String text, Class<?> resultType) {
         return delegate.xpath(text, resultType);
     }
-    
+
     /**
      * Evaluates an <a href="http://camel.apache.org/xpath.html">XPath
-     * expression</a> with the specified result type on the supplied
-     * header name's contents
+     * expression</a> with the specified result type on the supplied header
+     * name's contents
      * 
      * @param text the expression to be evaluated
      * @param resultType the return type expected by the expression
@@ -752,7 +747,7 @@ public class ExpressionClause<T> implements Expression, Predicate {
     public T xpath(String text, Class<?> resultType, String headerName) {
         return delegate.xpath(text, resultType, headerName);
     }
-    
+
     /**
      * Evaluates an <a href="http://camel.apache.org/xpath.html">XPath
      * expression</a> with the specified result type and set of namespace
@@ -776,13 +771,12 @@ public class ExpressionClause<T> implements Expression, Predicate {
      * @param resultType the return type expected by the expression
      * @param headerName the name of the header to apply the expression to
      * @param namespaces the namespace prefix and URIs to use
-     * 
      * @return the builder to continue processing the DSL
      */
     public T xpath(String text, Class<?> resultType, Namespaces namespaces, String headerName) {
         return delegate.xpath(text, resultType, namespaces, headerName);
     }
-    
+
     /**
      * Evaluates an <a href="http://camel.apache.org/xpath.html">XPath
      * expression</a> with the specified result type and set of namespace
@@ -822,8 +816,8 @@ public class ExpressionClause<T> implements Expression, Predicate {
     }
 
     /**
-     * Evaluates an <a
-     * href="http://camel.apache.org/xquery.html">XQuery expression</a>
+     * Evaluates an <a href="http://camel.apache.org/xquery.html">XQuery
+     * expression</a>
      * 
      * @param text the expression to be evaluated
      * @return the builder to continue processing the DSL
@@ -831,7 +825,7 @@ public class ExpressionClause<T> implements Expression, Predicate {
     public T xquery(String text) {
         return delegate.xquery(text);
     }
-    
+
     /**
      * Evaluates an <a href="http://camel.apache.org/xpath.html">XPath
      * expression</a> on the supplied header name's contents
@@ -844,11 +838,9 @@ public class ExpressionClause<T> implements Expression, Predicate {
         return delegate.xquery(text, headerName);
     }
 
-
     /**
-     * Evaluates an <a
-     * href="http://camel.apache.org/xquery.html">XQuery expression</a>
-     * with the specified result type
+     * Evaluates an <a href="http://camel.apache.org/xquery.html">XQuery
+     * expression</a> with the specified result type
      * 
      * @param text the expression to be evaluated
      * @param resultType the return type expected by the expression
@@ -857,11 +849,10 @@ public class ExpressionClause<T> implements Expression, Predicate {
     public T xquery(String text, Class<?> resultType) {
         return delegate.xquery(text, resultType);
     }
-    
+
     /**
-     * Evaluates an <a
-     * href="http://camel.apache.org/xquery.html">XQuery expression</a>
-     * with the specified result type
+     * Evaluates an <a href="http://camel.apache.org/xquery.html">XQuery
+     * expression</a> with the specified result type
      * 
      * @param text the expression to be evaluated
      * @param resultType the return type expected by the expression
@@ -871,11 +862,11 @@ public class ExpressionClause<T> implements Expression, Predicate {
     public T xquery(String text, Class<?> resultType, String headerName) {
         return delegate.xquery(text, resultType, headerName);
     }
-    
+
     /**
-     * Evaluates an <a
-     * href="http://camel.apache.org/xquery.html">XQuery expression</a>
-     * with the specified result type and set of namespace prefixes and URIs
+     * Evaluates an <a href="http://camel.apache.org/xquery.html">XQuery
+     * expression</a> with the specified result type and set of namespace
+     * prefixes and URIs
      * 
      * @param text the expression to be evaluated
      * @param resultType the return type expected by the expression
@@ -885,26 +876,25 @@ public class ExpressionClause<T> implements Expression, Predicate {
     public T xquery(String text, Class<?> resultType, Namespaces namespaces) {
         return delegate.xquery(text, resultType, namespaces);
     }
-    
+
     /**
-     * Evaluates an <a
-     * href="http://camel.apache.org/xquery.html">XQuery expression</a>
-     * with the specified result type
+     * Evaluates an <a href="http://camel.apache.org/xquery.html">XQuery
+     * expression</a> with the specified result type
      * 
      * @param text the expression to be evaluated
      * @param resultType the return type expected by the expression
      * @param headerName the name of the header to apply the expression to
      * @param namespaces the namespace prefix and URIs to use
-     * 
      * @return the builder to continue processing the DSL
      */
     public T xquery(String text, Class<?> resultType, Namespaces namespaces, String headerName) {
         return delegate.xquery(text, resultType, namespaces, headerName);
     }
+
     /**
-     * Evaluates an <a
-     * href="http://camel.apache.org/xquery.html">XQuery expression</a>
-     * with the specified result type and set of namespace prefixes and URIs
+     * Evaluates an <a href="http://camel.apache.org/xquery.html">XQuery
+     * expression</a> with the specified result type and set of namespace
+     * prefixes and URIs
      * 
      * @param text the expression to be evaluated
      * @param resultType the return type expected by the expression
@@ -916,9 +906,8 @@ public class ExpressionClause<T> implements Expression, Predicate {
     }
 
     /**
-     * Evaluates an <a
-     * href="http://camel.apache.org/xquery.html">XQuery expression</a>
-     * with the specified set of namespace prefixes and URIs
+     * Evaluates an <a href="http://camel.apache.org/xquery.html">XQuery
+     * expression</a> with the specified set of namespace prefixes and URIs
      * 
      * @param text the expression to be evaluated
      * @param namespaces the namespace prefix and URIs to use
@@ -929,9 +918,8 @@ public class ExpressionClause<T> implements Expression, Predicate {
     }
 
     /**
-     * Evaluates an <a
-     * href="http://camel.apache.org/xquery.html">XQuery expression</a>
-     * with the specified set of namespace prefixes and URIs
+     * Evaluates an <a href="http://camel.apache.org/xquery.html">XQuery
+     * expression</a> with the specified set of namespace prefixes and URIs
      * 
      * @param text the expression to be evaluated
      * @param namespaces the namespace prefix and URIs to use
diff --git a/core/camel-core/src/main/java/org/apache/camel/builder/ExpressionClauseSupport.java b/core/camel-core/src/main/java/org/apache/camel/builder/ExpressionClauseSupport.java
index 6ba1a5c..8abc2c5 100644
--- a/core/camel-core/src/main/java/org/apache/camel/builder/ExpressionClauseSupport.java
+++ b/core/camel-core/src/main/java/org/apache/camel/builder/ExpressionClauseSupport.java
@@ -45,8 +45,10 @@ import org.apache.camel.support.builder.Namespaces;
  */
 public class ExpressionClauseSupport<T> {
 
-    // Implementation detail: We must use the specific model.language.xxx classes to make the DSL use these specific types
-    // which ensures that the route model dumped as XML uses these types, eg <header> instead of <language name="header"> etc.
+    // Implementation detail: We must use the specific model.language.xxx
+    // classes to make the DSL use these specific types
+    // which ensures that the route model dumped as XML uses these types, eg
+    // <header> instead of <language name="header"> etc.
 
     private T result;
     private Expression expressionValue;
@@ -65,7 +67,7 @@ public class ExpressionClauseSupport<T> {
     public T expression(Expression expression) {
         setExpressionValue(expression);
         if (expression instanceof ExpressionFactory) {
-            setExpressionType((ExpressionFactory) expression);
+            setExpressionType((ExpressionFactory)expression);
         }
         return result;
     }
@@ -79,14 +81,13 @@ public class ExpressionClauseSupport<T> {
     }
 
     /**
-     * Specify the constant expression value.
-     *
-     * <b>Important:</b> this is a fixed constant value that is only set once during starting up the route,
-     * do not use this if you want dynamic values during routing.
+     * Specify the constant expression value. <b>Important:</b> this is a fixed
+     * constant value that is only set once during starting up the route, do not
+     * use this if you want dynamic values during routing.
      */
     public T constant(Object value) {
         if (value instanceof String) {
-            return expression(new ConstantExpression((String) value));
+            return expression(new ConstantExpression((String)value));
         } else {
             return expression(ExpressionBuilder.constantExpression(value));
         }
@@ -110,7 +111,8 @@ public class ExpressionClauseSupport<T> {
      * An expression of an inbound message body
      */
     public T body() {
-        // reuse simple as this allows the model to represent this as a known JAXB type
+        // reuse simple as this allows the model to represent this as a known
+        // JAXB type
         return expression(new SimpleExpression("${body}"));
     }
 
@@ -161,9 +163,8 @@ public class ExpressionClauseSupport<T> {
 
     /**
      * Evaluates an expression using the <a
-     * href="http://camel.apache.org/bean-language.html>bean language</a>
-     * which basically means the bean is invoked to determine the expression
-     * value.
+     * href="http://camel.apache.org/bean-language.html>bean language</a> which
+     * basically means the bean is invoked to determine the expression value.
      *
      * @param bean the name of the bean looked up the registry
      * @return the builder to continue processing the DSL
@@ -174,9 +175,8 @@ public class ExpressionClauseSupport<T> {
 
     /**
      * Evaluates an expression using the <a
-     * href="http://camel.apache.org/bean-language.html>bean language</a>
-     * which basically means the bean is invoked to determine the expression
-     * value.
+     * href="http://camel.apache.org/bean-language.html>bean language</a> which
+     * basically means the bean is invoked to determine the expression value.
      *
      * @param instance the instance of the bean
      * @return the builder to continue processing the DSL
@@ -187,9 +187,8 @@ public class ExpressionClauseSupport<T> {
 
     /**
      * Evaluates an expression using the <a
-     * href="http://camel.apache.org/bean-language.html>bean language</a>
-     * which basically means the bean is invoked to determine the expression
-     * value.
+     * href="http://camel.apache.org/bean-language.html>bean language</a> which
+     * basically means the bean is invoked to determine the expression value.
      *
      * @param beanType the Class of the bean which we want to invoke
      * @return the builder to continue processing the DSL
@@ -200,9 +199,8 @@ public class ExpressionClauseSupport<T> {
 
     /**
      * Evaluates an expression using the <a
-     * href="http://camel.apache.org/bean-language.html>bean language</a>
-     * which basically means the bean is invoked to determine the expression
-     * value.
+     * href="http://camel.apache.org/bean-language.html>bean language</a> which
+     * basically means the bean is invoked to determine the expression value.
      *
      * @param bean the name of the bean looked up the registry
      * @param method the name of the method to invoke on the bean
@@ -214,9 +212,8 @@ public class ExpressionClauseSupport<T> {
 
     /**
      * Evaluates an expression using the <a
-     * href="http://camel.apache.org/bean-language.html>bean language</a>
-     * which basically means the bean is invoked to determine the expression
-     * value.
+     * href="http://camel.apache.org/bean-language.html>bean language</a> which
+     * basically means the bean is invoked to determine the expression value.
      *
      * @param instance the instance of the bean
      * @param method the name of the method to invoke on the bean
@@ -228,9 +225,8 @@ public class ExpressionClauseSupport<T> {
 
     /**
      * Evaluates an expression using the <a
-     * href="http://camel.apache.org/bean-language.html>bean language</a>
-     * which basically means the bean is invoked to determine the expression
-     * value.
+     * href="http://camel.apache.org/bean-language.html>bean language</a> which
+     * basically means the bean is invoked to determine the expression value.
      *
      * @param beanType the Class of the bean which we want to invoke
      * @param method the name of the method to invoke on the bean
@@ -267,7 +263,8 @@ public class ExpressionClauseSupport<T> {
      * expression</a>
      *
      * @param text the expression to be evaluated
-     * @param suppressExceptions whether to suppress exceptions such as PathNotFoundException
+     * @param suppressExceptions whether to suppress exceptions such as
+     *            PathNotFoundException
      * @return the builder to continue processing the DSL
      */
     public T jsonpath(String text, boolean suppressExceptions) {
@@ -281,8 +278,10 @@ public class ExpressionClauseSupport<T> {
      * expression</a>
      *
      * @param text the expression to be evaluated
-     * @param suppressExceptions whether to suppress exceptions such as PathNotFoundException
-     * @param allowSimple whether to allow in inlined simple exceptions in the json path expression
+     * @param suppressExceptions whether to suppress exceptions such as
+     *            PathNotFoundException
+     * @param allowSimple whether to allow in inlined simple exceptions in the
+     *            json path expression
      * @return the builder to continue processing the DSL
      */
     public T jsonpath(String text, boolean suppressExceptions, boolean allowSimple) {
@@ -312,7 +311,8 @@ public class ExpressionClauseSupport<T> {
      * expression</a>
      *
      * @param text the expression to be evaluated
-     * @param suppressExceptions whether to suppress exceptions such as PathNotFoundException
+     * @param suppressExceptions whether to suppress exceptions such as
+     *            PathNotFoundException
      * @param resultType the return type expected by the expression
      * @return the builder to continue processing the DSL
      */
@@ -329,8 +329,10 @@ public class ExpressionClauseSupport<T> {
      * expression</a>
      *
      * @param text the expression to be evaluated
-     * @param suppressExceptions whether to suppress exceptions such as PathNotFoundException
-     * @param allowSimple whether to allow in inlined simple exceptions in the json path expression
+     * @param suppressExceptions whether to suppress exceptions such as
+     *            PathNotFoundException
+     * @param allowSimple whether to allow in inlined simple exceptions in the
+     *            json path expression
      * @param resultType the return type expected by the expression
      * @return the builder to continue processing the DSL
      */
@@ -348,8 +350,10 @@ public class ExpressionClauseSupport<T> {
      * expression</a>
      *
      * @param text the expression to be evaluated
-     * @param suppressExceptions whether to suppress exceptions such as PathNotFoundException
-     * @param allowSimple whether to allow in inlined simple exceptions in the json path expression
+     * @param suppressExceptions whether to suppress exceptions such as
+     *            PathNotFoundException
+     * @param allowSimple whether to allow in inlined simple exceptions in the
+     *            json path expression
      * @param resultType the return type expected by the expression
      * @param headerName the name of the header to apply the expression to
      * @return the builder to continue processing the DSL
@@ -380,7 +384,8 @@ public class ExpressionClauseSupport<T> {
      * expression</a> with writeAsString enabled.
      *
      * @param text the expression to be evaluated
-     * @param suppressExceptions whether to suppress exceptions such as PathNotFoundException
+     * @param suppressExceptions whether to suppress exceptions such as
+     *            PathNotFoundException
      * @return the builder to continue processing the DSL
      */
     public T jsonpathWriteAsString(String text, boolean suppressExceptions) {
@@ -395,8 +400,10 @@ public class ExpressionClauseSupport<T> {
      * expression</a> with writeAsString enabled.
      *
      * @param text the expression to be evaluated
-     * @param suppressExceptions whether to suppress exceptions such as PathNotFoundException
-     * @param allowSimple whether to allow in inlined simple exceptions in the json path expression
+     * @param suppressExceptions whether to suppress exceptions such as
+     *            PathNotFoundException
+     * @param allowSimple whether to allow in inlined simple exceptions in the
+     *            json path expression
      * @return the builder to continue processing the DSL
      */
     public T jsonpathWriteAsString(String text, boolean suppressExceptions, boolean allowSimple) {
@@ -412,8 +419,10 @@ public class ExpressionClauseSupport<T> {
      * expression</a> with writeAsString enabled.
      *
      * @param text the expression to be evaluated
-     * @param suppressExceptions whether to suppress exceptions such as PathNotFoundException
-     * @param allowSimple whether to allow in inlined simple exceptions in the json path expression
+     * @param suppressExceptions whether to suppress exceptions such as
+     *            PathNotFoundException
+     * @param allowSimple whether to allow in inlined simple exceptions in the
+     *            json path expression
      * @param headerName the name of the header to apply the expression to
      * @return the builder to continue processing the DSL
      */
@@ -678,7 +687,7 @@ public class ExpressionClauseSupport<T> {
      * Evaluates a token pair expression on the message body
      *
      * @param startToken the start token
-     * @param endToken   the end token
+     * @param endToken the end token
      * @param includeTokens whether to include tokens
      * @return the builder to continue processing the DSL
      */
@@ -695,7 +704,8 @@ public class ExpressionClauseSupport<T> {
      * Evaluates a token pair expression on the message body with XML content
      *
      * @param tagName the tag name of the child nodes to tokenize
-     * @param inheritNamespaceTagName  optional parent or root tag name that contains namespace(s) to inherit
+     * @param inheritNamespaceTagName optional parent or root tag name that
+     *            contains namespace(s) to inherit
      * @param group to group by the given number
      * @return the builder to continue processing the DSL
      */
@@ -707,7 +717,8 @@ public class ExpressionClauseSupport<T> {
      * Evaluates a token pair expression on the message body with XML content
      *
      * @param tagName the tag name of the child nodes to tokenize
-     * @param inheritNamespaceTagName  optional parent or root tag name that contains namespace(s) to inherit
+     * @param inheritNamespaceTagName optional parent or root tag name that
+     *            contains namespace(s) to inherit
      * @param group to group by the given number
      * @return the builder to continue processing the DSL
      */
@@ -724,10 +735,12 @@ public class ExpressionClauseSupport<T> {
     /**
      * Evaluates an XML token expression on the message body with XML content
      * 
-     * @param path the xpath like path notation specifying the child nodes to tokenize
-     * @param mode one of 'i', 'w', or 'u' to inject the namespaces to the token, to
-     *        wrap the token with its ancestor contet, or to unwrap to its element child
-     * @param namespaces the namespace map to the namespace bindings 
+     * @param path the xpath like path notation specifying the child nodes to
+     *            tokenize
+     * @param mode one of 'i', 'w', or 'u' to inject the namespaces to the
+     *            token, to wrap the token with its ancestor contet, or to
+     *            unwrap to its element child
+     * @param namespaces the namespace map to the namespace bindings
      * @param group to group by the given number
      * @return the builder to continue processing the DSL
      */
@@ -753,7 +766,7 @@ public class ExpressionClauseSupport<T> {
     public T xpath(String text) {
         return expression(new XPathExpression(text));
     }
-    
+
     /**
      * Evaluates an <a href="http://camel.apache.org/xpath.html">XPath
      * expression</a> on the supplied header name's contents
@@ -767,7 +780,7 @@ public class ExpressionClauseSupport<T> {
         expression.setHeaderName(headerName);
         return expression(expression);
     }
-    
+
     /**
      * Evaluates an <a href="http://camel.apache.org/xpath.html">XPath
      * expression</a> with the specified result type
@@ -783,11 +796,10 @@ public class ExpressionClauseSupport<T> {
         return result;
     }
 
-    
     /**
      * Evaluates an <a href="http://camel.apache.org/xpath.html">XPath
-     * expression</a> with the specified result type on the supplied
-     * header name's contents
+     * expression</a> with the specified result type on the supplied header
+     * name's contents
      *
      * @param text the expression to be evaluated
      * @param resultType the return type expected by the expression
@@ -800,7 +812,6 @@ public class ExpressionClauseSupport<T> {
         setExpressionType(expression);
         return result;
     }
-    
 
     /**
      * Evaluates an <a href="http://camel.apache.org/xpath.html">XPath
@@ -815,7 +826,7 @@ public class ExpressionClauseSupport<T> {
     public T xpath(String text, Class<?> resultType, Namespaces namespaces) {
         return xpath(text, resultType, namespaces.getNamespaces());
     }
-    
+
     /**
      * Evaluates an <a href="http://camel.apache.org/xpath.html">XPath
      * expression</a> with the specified result type and set of namespace
@@ -836,7 +847,6 @@ public class ExpressionClauseSupport<T> {
         return result;
     }
 
-
     /**
      * Evaluates an <a href="http://camel.apache.org/xpath.html">XPath
      * expression</a> with the specified result type and set of namespace
@@ -883,8 +893,8 @@ public class ExpressionClauseSupport<T> {
     }
 
     /**
-     * Evaluates an <a
-     * href="http://camel.apache.org/xquery.html">XQuery expression</a>
+     * Evaluates an <a href="http://camel.apache.org/xquery.html">XQuery
+     * expression</a>
      *
      * @param text the expression to be evaluated
      * @return the builder to continue processing the DSL
@@ -908,9 +918,8 @@ public class ExpressionClauseSupport<T> {
     }
 
     /**
-     * Evaluates an <a
-     * href="http://camel.apache.org/xquery.html">XQuery expression</a>
-     * with the specified result type
+     * Evaluates an <a href="http://camel.apache.org/xquery.html">XQuery
+     * expression</a> with the specified result type
      *
      * @param text the expression to be evaluated
      * @param resultType the return type expected by the expression
@@ -922,12 +931,10 @@ public class ExpressionClauseSupport<T> {
         setExpressionType(expression);
         return result;
     }
-    
-    
+
     /**
-     * Evaluates an <a
-     * href="http://camel.apache.org/xquery.html">XQuery expression</a>
-     * with the specified result type
+     * Evaluates an <a href="http://camel.apache.org/xquery.html">XQuery
+     * expression</a> with the specified result type
      *
      * @param text the expression to be evaluated
      * @param resultType the return type expected by the expression
@@ -942,9 +949,9 @@ public class ExpressionClauseSupport<T> {
     }
 
     /**
-     * Evaluates an <a
-     * href="http://camel.apache.org/xquery.html">XQuery expression</a>
-     * with the specified result type and set of namespace prefixes and URIs
+     * Evaluates an <a href="http://camel.apache.org/xquery.html">XQuery
+     * expression</a> with the specified result type and set of namespace
+     * prefixes and URIs
      *
      * @param text the expression to be evaluated
      * @param resultType the return type expected by the expression
@@ -954,11 +961,11 @@ public class ExpressionClauseSupport<T> {
     public T xquery(String text, Class<?> resultType, Namespaces namespaces) {
         return xquery(text, resultType, namespaces.getNamespaces());
     }
-    
+
     /**
-     * Evaluates an <a
-     * href="http://camel.apache.org/xquery.html">XQuery expression</a>
-     * with the specified result type and set of namespace prefixes and URIs
+     * Evaluates an <a href="http://camel.apache.org/xquery.html">XQuery
+     * expression</a> with the specified result type and set of namespace
+     * prefixes and URIs
      *
      * @param text the expression to be evaluated
      * @param resultType the return type expected by the expression
@@ -976,9 +983,9 @@ public class ExpressionClauseSupport<T> {
     }
 
     /**
-     * Evaluates an <a
-     * href="http://camel.apache.org/xquery.html">XQuery expression</a>
-     * with the specified result type and set of namespace prefixes and URIs
+     * Evaluates an <a href="http://camel.apache.org/xquery.html">XQuery
+     * expression</a> with the specified result type and set of namespace
+     * prefixes and URIs
      *
      * @param text the expression to be evaluated
      * @param resultType the return type expected by the expression
@@ -994,9 +1001,8 @@ public class ExpressionClauseSupport<T> {
     }
 
     /**
-     * Evaluates an <a
-     * href="http://camel.apache.org/xquery.html">XQuery expression</a>
-     * with the specified set of namespace prefixes and URIs
+     * Evaluates an <a href="http://camel.apache.org/xquery.html">XQuery
+     * expression</a> with the specified set of namespace prefixes and URIs
      *
      * @param text the expression to be evaluated
      * @param namespaces the namespace prefix and URIs to use
@@ -1007,9 +1013,8 @@ public class ExpressionClauseSupport<T> {
     }
 
     /**
-     * Evaluates an <a
-     * href="http://camel.apache.org/xquery.html">XQuery expression</a>
-     * with the specified set of namespace prefixes and URIs
+     * Evaluates an <a href="http://camel.apache.org/xquery.html">XQuery
+     * expression</a> with the specified set of namespace prefixes and URIs
      *
      * @param text the expression to be evaluated
      * @param namespaces the namespace prefix and URIs to use
diff --git a/core/camel-core/src/main/java/org/apache/camel/builder/FlexibleAggregationStrategy.java b/core/camel-core/src/main/java/org/apache/camel/builder/FlexibleAggregationStrategy.java
index be8ee06..53e7a14 100644
--- a/core/camel-core/src/main/java/org/apache/camel/builder/FlexibleAggregationStrategy.java
+++ b/core/camel-core/src/main/java/org/apache/camel/builder/FlexibleAggregationStrategy.java
@@ -29,20 +29,26 @@ import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
 /**
- * The Flexible Aggregation Strategy is a highly customizable, fluently configurable aggregation strategy. It allows you to quickly whip up an {@link AggregationStrategy} 
- * that is capable of performing the most typical aggregation duties, with zero Java code.
+ * The Flexible Aggregation Strategy is a highly customizable, fluently
+ * configurable aggregation strategy. It allows you to quickly whip up an
+ * {@link AggregationStrategy} that is capable of performing the most typical
+ * aggregation duties, with zero Java code.
  * <p/>
  * It can perform the following logic:
  * <ul>
- *   <li>Filtering results based on a defined {@link Predicate} written in any language, such as XPath, OGNL, Groovy, Simple, etc.</li>
- *   <li>Picking specific data elements for aggregation.</li>
- *   <li>Accumulating results in any designated {@link Collection} type, e.g. in a HashSet, LinkedList, ArrayList, etc.</li>
- *   <li>Storing the output in a specific place in the Exchange: a property, a header or in the body.</li>
+ * <li>Filtering results based on a defined {@link Predicate} written in any
+ * language, such as XPath, OGNL, Groovy, Simple, etc.</li>
+ * <li>Picking specific data elements for aggregation.</li>
+ * <li>Accumulating results in any designated {@link Collection} type, e.g. in a
+ * HashSet, LinkedList, ArrayList, etc.</li>
+ * <li>Storing the output in a specific place in the Exchange: a property, a
+ * header or in the body.</li>
  * </ul>
- * 
- * It also includes the ability to specify both aggregation batch completion actions and timeout actions, in an abbreviated manner.
+ * It also includes the ability to specify both aggregation batch completion
+ * actions and timeout actions, in an abbreviated manner.
  * <p/>
- * This Aggregation Strategy is suitable for usage in aggregate, split, multicast, enrich and recipient list EIPs.
+ * This Aggregation Strategy is suitable for usage in aggregate, split,
+ * multicast, enrich and recipient list EIPs.
  */
 public class FlexibleAggregationStrategy<E> implements AggregationStrategy {
 
@@ -53,7 +59,7 @@ public class FlexibleAggregationStrategy<E> implements AggregationStrategy {
     @SuppressWarnings("rawtypes")
     private Class<? extends Collection> collectionType;
     @SuppressWarnings("unchecked")
-    private Class<E> castAs = (Class<E>) Object.class;
+    private Class<E> castAs = (Class<E>)Object.class;
     private boolean storeNulls;
     private boolean ignoreInvalidCasts; // = false
     private FlexibleAggregationStrategyInjector injector = new BodyInjector(castAs);
@@ -61,24 +67,30 @@ public class FlexibleAggregationStrategy<E> implements AggregationStrategy {
     private CompletionAwareMixin completionMixin;
 
     /**
-     * Initializes a new instance with {@link Object} as the {@link FlexibleAggregationStrategy#castAs} type.
+     * Initializes a new instance with {@link Object} as the
+     * {@link FlexibleAggregationStrategy#castAs} type.
      */
     public FlexibleAggregationStrategy() {
     }
-    
+
     /**
-     * Initializes a new instance with the specified type as the {@link FlexibleAggregationStrategy#castAs} type.
+     * Initializes a new instance with the specified type as the
+     * {@link FlexibleAggregationStrategy#castAs} type.
+     * 
      * @param type The castAs type.
      */
     public FlexibleAggregationStrategy(Class<E> type) {
         this.castAs = type;
     }
-    
+
     /**
-     * Set an expression to extract the element to be aggregated from the incoming {@link Exchange}.
-     * All results are cast to the {@link FlexibleAggregationStrategy#castAs} type (or the type specified in the constructor).
+     * Set an expression to extract the element to be aggregated from the
+     * incoming {@link Exchange}. All results are cast to the
+     * {@link FlexibleAggregationStrategy#castAs} type (or the type specified in
+     * the constructor).
      * <p/>
-     * By default, it picks the full IN message body of the incoming exchange. 
+     * By default, it picks the full IN message body of the incoming exchange.
+     * 
      * @param expression The picking expression.
      * @return This instance.
      */
@@ -88,8 +100,9 @@ public class FlexibleAggregationStrategy<E> implements AggregationStrategy {
     }
 
     /**
-     * Set a filter condition such as only results satisfying it will be aggregated. 
-     * By default, all picked values will be processed.
+     * Set a filter condition such as only results satisfying it will be
+     * aggregated. By default, all picked values will be processed.
+     * 
      * @param predicate The condition.
      * @return This instance.
      */
@@ -99,8 +112,10 @@ public class FlexibleAggregationStrategy<E> implements AggregationStrategy {
     }
 
     /**
-     * Accumulate the result of the <i>pick expression</i> in a collection of the designated type. 
-     * No <tt>null</tt>s will stored unless the {@link FlexibleAggregationStrategy#storeNulls()} option is enabled.
+     * Accumulate the result of the <i>pick expression</i> in a collection of
+     * the designated type. No <tt>null</tt>s will stored unless the
+     * {@link FlexibleAggregationStrategy#storeNulls()} option is enabled.
+     * 
      * @param collectionType The type of the Collection to aggregate into.
      * @return This instance.
      */
@@ -111,8 +126,9 @@ public class FlexibleAggregationStrategy<E> implements AggregationStrategy {
     }
 
     /**
-     * Store the result of this Aggregation Strategy (whether an atomic element or a Collection) in a property with
-     * the designated name.
+     * Store the result of this Aggregation Strategy (whether an atomic element
+     * or a Collection) in a property with the designated name.
+     * 
      * @param propertyName The property name.
      * @return This instance.
      */
@@ -122,8 +138,9 @@ public class FlexibleAggregationStrategy<E> implements AggregationStrategy {
     }
 
     /**
-     * Store the result of this Aggregation Strategy (whether an atomic element or a Collection) in an IN message header with
-     * the designated name.
+     * Store the result of this Aggregation Strategy (whether an atomic element
+     * or a Collection) in an IN message header with the designated name.
+     * 
      * @param headerName The header name.
      * @return This instance.
      */
@@ -133,7 +150,9 @@ public class FlexibleAggregationStrategy<E> implements AggregationStrategy {
     }
 
     /**
-     * Store the result of this Aggregation Strategy (whether an atomic element or a Collection) in the body of the IN message.
+     * Store the result of this Aggregation Strategy (whether an atomic element
+     * or a Collection) in the body of the IN message.
+     * 
      * @return This instance.
      */
     public FlexibleAggregationStrategy<E> storeInBody() {
@@ -143,6 +162,7 @@ public class FlexibleAggregationStrategy<E> implements AggregationStrategy {
 
     /**
      * Cast the result of the <i>pick expression</i> to this type.
+     * 
      * @param castAs Type for the cast.
      * @return This instance.
      */
@@ -153,28 +173,32 @@ public class FlexibleAggregationStrategy<E> implements AggregationStrategy {
     }
 
     /**
-     * Enables storing null values in the resulting collection.
-     * By default, this aggregation strategy will drop null values.
+     * Enables storing null values in the resulting collection. By default, this
+     * aggregation strategy will drop null values.
+     * 
      * @return This instance.
      */
     public FlexibleAggregationStrategy<E> storeNulls() {
         this.storeNulls = true;
         return this;
     }
-    
+
     /**
-     * Ignores invalid casts instead of throwing an exception if the <i>pick expression</i> result cannot be casted to the 
-     * specified type.
-     * By default, this aggregation strategy will throw an exception if an invalid cast occurs.
+     * Ignores invalid casts instead of throwing an exception if the <i>pick
+     * expression</i> result cannot be casted to the specified type. By default,
+     * this aggregation strategy will throw an exception if an invalid cast
+     * occurs.
+     * 
      * @return This instance.
      */
     public FlexibleAggregationStrategy<E> ignoreInvalidCasts() {
         this.ignoreInvalidCasts = true;
         return this;
     }
-    
+
     /**
      * Plugs in logic to execute when a timeout occurs.
+     * 
      * @param timeoutMixin
      * @return This instance.
      */
@@ -185,6 +209,7 @@ public class FlexibleAggregationStrategy<E> implements AggregationStrategy {
 
     /**
      * Plugs in logic to execute when an aggregation batch completes.
+     * 
      * @param completionMixin
      * @return This instance.
      */
@@ -192,7 +217,7 @@ public class FlexibleAggregationStrategy<E> implements AggregationStrategy {
         this.completionMixin = completionMixin;
         return this;
     }
-    
+
     @Override
     public Exchange aggregate(Exchange oldExchange, Exchange newExchange) {
         Exchange exchange = oldExchange;
@@ -207,8 +232,9 @@ public class FlexibleAggregationStrategy<E> implements AggregationStrategy {
             return exchange;
         }
 
-        // 2. Pick the appropriate element of the incoming message, casting it to the specified class
-        //    If null, act accordingly based on storeNulls
+        // 2. Pick the appropriate element of the incoming message, casting it
+        // to the specified class
+        // If null, act accordingly based on storeNulls
         E picked = null;
         try {
             picked = pickExpression.evaluate(newExchange, castAs);
@@ -217,7 +243,7 @@ public class FlexibleAggregationStrategy<E> implements AggregationStrategy {
                 throw exception;
             }
         }
-        
+
         if (picked == null && !storeNulls) {
             LOG.trace("Dropped exchange {} from aggregation as pick expression returned null and storing nulls is not enabled", newExchange);
             return exchange;
@@ -231,7 +257,6 @@ public class FlexibleAggregationStrategy<E> implements AggregationStrategy {
 
         return exchange;
     }
-    
 
     @Override
     public void timeout(Exchange oldExchange, int index, int total, long timeout) {
@@ -274,11 +299,11 @@ public class FlexibleAggregationStrategy<E> implements AggregationStrategy {
             } else {
                 collection = collectionType.cast(oldValue);
             }
-            
+
             if (collection != null) {
                 collection.add(toInsert);
             }
-            
+
         } catch (ClassCastException exception) {
             if (!ignoreInvalidCasts) {
                 throw exception;
@@ -286,46 +311,50 @@ public class FlexibleAggregationStrategy<E> implements AggregationStrategy {
         }
         return collection;
     }
-    
+
     public interface TimeoutAwareMixin {
         void timeout(Exchange exchange, int index, int total, long timeout);
     }
-    
+
     public interface CompletionAwareMixin {
         void onCompletion(Exchange exchange);
     }
-    
+
     private abstract class FlexibleAggregationStrategyInjector {
         protected Class<E> type;
-        
+
         FlexibleAggregationStrategyInjector(Class<E> type) {
             this.type = type;
         }
-        
+
         public void setType(Class<E> type) {
             this.type = type;
         }
-        
+
         public abstract void prepareAggregationExchange(Exchange exchange);
+
         public abstract E getValue(Exchange exchange);
+
         public abstract void setValue(Exchange exchange, E obj);
+
         public abstract Collection<E> getValueAsCollection(Exchange exchange, Class<? extends Collection> type);
+
         public abstract void setValueAsCollection(Exchange exchange, Collection<E> obj);
     }
-    
+
     private class PropertyInjector extends FlexibleAggregationStrategyInjector {
         private String propertyName;
-        
+
         PropertyInjector(Class<E> type, String propertyName) {
             super(type);
             this.propertyName = propertyName;
         }
-        
+
         @Override
         public void prepareAggregationExchange(Exchange exchange) {
             exchange.removeProperty(propertyName);
         }
-        
+
         @Override
         public E getValue(Exchange exchange) {
             return exchange.getProperty(propertyName, type);
@@ -336,7 +365,8 @@ public class FlexibleAggregationStrategy<E> implements AggregationStrategy {
             exchange.setProperty(propertyName, obj);
         }
 
-        @Override @SuppressWarnings("unchecked")
+        @Override
+        @SuppressWarnings("unchecked")
         public Collection<E> getValueAsCollection(Exchange exchange, Class<? extends Collection> type) {
             Object value = exchange.getProperty(propertyName);
             if (value == null) {
@@ -353,20 +383,20 @@ public class FlexibleAggregationStrategy<E> implements AggregationStrategy {
         }
 
     }
-    
+
     private class HeaderInjector extends FlexibleAggregationStrategyInjector {
         private String headerName;
-        
+
         HeaderInjector(Class<E> type, String headerName) {
             super(type);
             this.headerName = headerName;
         }
-        
+
         @Override
         public void prepareAggregationExchange(Exchange exchange) {
             exchange.getIn().removeHeader(headerName);
         }
-        
+
         @Override
         public E getValue(Exchange exchange) {
             return exchange.getIn().getHeader(headerName, type);
@@ -377,7 +407,8 @@ public class FlexibleAggregationStrategy<E> implements AggregationStrategy {
             exchange.getIn().setHeader(headerName, obj);
         }
 
-        @Override @SuppressWarnings("unchecked")
+        @Override
+        @SuppressWarnings("unchecked")
         public Collection<E> getValueAsCollection(Exchange exchange, Class<? extends Collection> type) {
             Object value = exchange.getIn().getHeader(headerName);
             if (value == null) {
@@ -387,13 +418,13 @@ public class FlexibleAggregationStrategy<E> implements AggregationStrategy {
                 return exchange.getIn().getHeader(headerName, type);
             }
         }
-        
+
         @Override
         public void setValueAsCollection(Exchange exchange, Collection<E> obj) {
             exchange.getIn().setHeader(headerName, obj);
         }
     }
-    
+
     private class BodyInjector extends FlexibleAggregationStrategyInjector {
         BodyInjector(Class<E> type) {
             super(type);
@@ -403,7 +434,7 @@ public class FlexibleAggregationStrategy<E> implements AggregationStrategy {
         public void prepareAggregationExchange(Exchange exchange) {
             exchange.getIn().setBody(null);
         }
-        
+
         @Override
         public E getValue(Exchange exchange) {
             return exchange.getIn().getBody(type);
@@ -414,7 +445,8 @@ public class FlexibleAggregationStrategy<E> implements AggregationStrategy {
             exchange.getIn().setBody(obj);
         }
 
-        @Override @SuppressWarnings("unchecked")
+        @Override
+        @SuppressWarnings("unchecked")
         public Collection<E> getValueAsCollection(Exchange exchange, Class<? extends Collection> type) {
             Object value = exchange.getIn().getBody();
             if (value == null) {
@@ -424,11 +456,11 @@ public class FlexibleAggregationStrategy<E> implements AggregationStrategy {
                 return exchange.getIn().getBody(type);
             }
         }
-        
+
         @Override
         public void setValueAsCollection(Exchange exchange, Collection<E> obj) {
             exchange.getIn().setBody(obj);
         }
     }
-    
+
 }
diff --git a/core/camel-core/src/main/java/org/apache/camel/builder/NoErrorHandlerBuilder.java b/core/camel-core/src/main/java/org/apache/camel/builder/NoErrorHandlerBuilder.java
index e9f5959..6ccd34a 100644
--- a/core/camel-core/src/main/java/org/apache/camel/builder/NoErrorHandlerBuilder.java
+++ b/core/camel-core/src/main/java/org/apache/camel/builder/NoErrorHandlerBuilder.java
@@ -23,11 +23,12 @@ import org.apache.camel.spi.RouteContext;
 import org.apache.camel.support.processor.DelegateAsyncProcessor;
 
 /**
- * A builder to disable the use of an error handler so that any exceptions are thrown.
- * This not recommended in general, the
- * <a href="http://camel.apache.org/dead-letter-channel.html">Dead Letter Channel</a> should be used
- * if you are unsure; however it can be useful sometimes to disable an error handler inside a complex route
- * so that exceptions bubble up to the parent {@link Processor}
+ * A builder to disable the use of an error handler so that any exceptions are
+ * thrown. This not recommended in general, the
+ * <a href="http://camel.apache.org/dead-letter-channel.html">Dead Letter
+ * Channel</a> should be used if you are unsure; however it can be useful
+ * sometimes to disable an error handler inside a complex route so that
+ * exceptions bubble up to the parent {@link Processor}
  */
 public class NoErrorHandlerBuilder extends ErrorHandlerBuilderSupport {
 
diff --git a/core/camel-core/src/main/java/org/apache/camel/builder/NotifyBuilder.java b/core/camel-core/src/main/java/org/apache/camel/builder/NotifyBuilder.java
index 7b40f6a..ba32713 100644
--- a/core/camel-core/src/main/java/org/apache/camel/builder/NotifyBuilder.java
+++ b/core/camel-core/src/main/java/org/apache/camel/builder/NotifyBuilder.java
@@ -50,12 +50,15 @@ import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
 /**
- * A builder to build an expression based on {@link org.apache.camel.spi.EventNotifier} notifications
- * about {@link Exchange} being routed.
+ * A builder to build an expression based on
+ * {@link org.apache.camel.spi.EventNotifier} notifications about
+ * {@link Exchange} being routed.
  * <p/>
- * This builder can be used for testing purposes where you want to know when a test is supposed to be done.
- * The idea is that you can build an expression that explains when the test is done. For example when Camel
- * have finished routing 5 messages. You can then in your test await for this condition to occur.
+ * This builder can be used for testing purposes where you want to know when a
+ * test is supposed to be done. The idea is that you can build an expression
+ * that explains when the test is done. For example when Camel have finished
+ * routing 5 messages. You can then in your test await for this condition to
+ * occur.
  */
 public class NotifyBuilder {
 
@@ -72,7 +75,8 @@ public class NotifyBuilder {
     // latch to be used to signal predicates matches
     private CountDownLatch latch = new CountDownLatch(1);
 
-    // the current state while building an event predicate where we use a stack and the operation
+    // the current state while building an event predicate where we use a stack
+    // and the operation
     private final List<EventPredicate> stack = new ArrayList<>();
     private EventOperation operation;
     private boolean created;
@@ -101,12 +105,15 @@ public class NotifyBuilder {
     }
 
     /**
-     * Optionally a <tt>from</tt> endpoint which means that this expression should only be based
-     * on {@link Exchange} which is originated from the particular endpoint(s).
+     * Optionally a <tt>from</tt> endpoint which means that this expression
+     * should only be based on {@link Exchange} which is originated from the
+     * particular endpoint(s).
      *
-     * @param endpointUri uri of endpoint or pattern (see the EndpointHelper javadoc)
+     * @param endpointUri uri of endpoint or pattern (see the EndpointHelper
+     *            javadoc)
      * @return the builder
-     * @see EndpointHelper#matchEndpoint(org.apache.camel.CamelContext, String, String)
+     * @see EndpointHelper#matchEndpoint(org.apache.camel.CamelContext, String,
+     *      String)
      */
     public NotifyBuilder from(final String endpointUri) {
         stack.add(new EventPredicateSupport() {
@@ -141,12 +148,14 @@ public class NotifyBuilder {
     }
 
     /**
-     * Optionally a <tt>from</tt> route which means that this expression should only be based
-     * on {@link Exchange} which is originated from the particular route(s).
+     * Optionally a <tt>from</tt> route which means that this expression should
+     * only be based on {@link Exchange} which is originated from the particular
+     * route(s).
      *
      * @param routeId id of route or pattern (see the EndpointHelper javadoc)
      * @return the builder
-     * @see EndpointHelper#matchEndpoint(org.apache.camel.CamelContext, String, String)
+     * @see EndpointHelper#matchEndpoint(org.apache.camel.CamelContext, String,
+     *      String)
      */
     public NotifyBuilder fromRoute(final String routeId) {
         stack.add(new EventPredicateSupport() {
@@ -183,12 +192,13 @@ public class NotifyBuilder {
     }
 
     /**
-     * Optionally a <tt>from</tt> current route which means that this expression should only be based
-     * on {@link Exchange} which is the current route(s).
+     * Optionally a <tt>from</tt> current route which means that this expression
+     * should only be based on {@link Exchange} which is the current route(s).
      *
      * @param routeId id of route or pattern (see the EndpointHelper javadoc)
      * @return the builder
-     * @see EndpointHelper#matchEndpoint(org.apache.camel.CamelContext, String, String)
+     * @see EndpointHelper#matchEndpoint(org.apache.camel.CamelContext, String,
+     *      String)
      */
     public NotifyBuilder fromCurrentRoute(final String routeId) {
         stack.add(new EventPredicateSupport() {
@@ -236,10 +246,14 @@ public class NotifyBuilder {
 
             @Override
             public boolean onExchange(Exchange exchange) {
-                // always accept direct endpoints as they are a special case as it will create the UoW beforehand
-                // and just continue to route that on the consumer side, which causes the EventNotifier not to
-                // emit events when the consumer received the exchange, as its already done. For example by
-                // ProducerTemplate which creates the UoW before producing messages.
+                // always accept direct endpoints as they are a special case as
+                // it will create the UoW beforehand
+                // and just continue to route that on the consumer side, which
+                // causes the EventNotifier not to
+                // emit events when the consumer received the exchange, as its
+                // already done. For example by
+                // ProducerTemplate which creates the UoW before producing
+                // messages.
                 if (exchange.getFromEndpoint() != null && exchange.getFromEndpoint().getEndpointUri().startsWith("direct:")) {
                     return true;
                 }
@@ -253,7 +267,8 @@ public class NotifyBuilder {
 
             @Override
             public String toString() {
-                // we dont want any to string output as this is an internal predicate to match only from routes
+                // we dont want any to string output as this is an internal
+                // predicate to match only from routes
                 return "";
             }
         });
@@ -261,7 +276,8 @@ public class NotifyBuilder {
     }
 
     /**
-     * Optionally a filter to only allow matching {@link Exchange} to be used for matching.
+     * Optionally a filter to only allow matching {@link Exchange} to be used
+     * for matching.
      *
      * @param predicate the predicate to use for the filter
      * @return the builder
@@ -295,7 +311,8 @@ public class NotifyBuilder {
     }
 
     /**
-     * Optionally a filter to only allow matching {@link Exchange} to be used for matching.
+     * Optionally a filter to only allow matching {@link Exchange} to be used
+     * for matching.
      *
      * @return the builder
      */
@@ -330,15 +347,19 @@ public class NotifyBuilder {
     }
 
     /**
-     * Optionally a <tt>sent to</tt> endpoint which means that this expression should only be based
-     * on {@link Exchange} which has been sent to the given endpoint uri.
+     * Optionally a <tt>sent to</tt> endpoint which means that this expression
+     * should only be based on {@link Exchange} which has been sent to the given
+     * endpoint uri.
      * <p/>
-     * Notice the {@link Exchange} may have been sent to other endpoints as well. This condition will match
-     * if the {@link Exchange} has been sent at least once to the given endpoint.
+     * Notice the {@link Exchange} may have been sent to other endpoints as
+     * well. This condition will match if the {@link Exchange} has been sent at
+     * least once to the given endpoint.
      *
-     * @param endpointUri uri of endpoint or pattern (see the EndpointHelper javadoc)
+     * @param endpointUri uri of endpoint or pattern (see the EndpointHelper
+     *            javadoc)
      * @return the builder
-     * @see EndpointHelper#matchEndpoint(org.apache.camel.CamelContext, String, String)
+     * @see EndpointHelper#matchEndpoint(org.apache.camel.CamelContext, String,
+     *      String)
      */
     public NotifyBuilder wereSentTo(final String endpointUri) {
         // insert in start of stack but after the previous wereSentTo
@@ -385,10 +406,11 @@ public class NotifyBuilder {
     }
 
     /**
-     * Sets a condition when <tt>number</tt> of {@link Exchange} has been received.
+     * Sets a condition when <tt>number</tt> of {@link Exchange} has been
+     * received.
      * <p/>
-     * The number matching is <i>at least</i> based which means that if more messages received
-     * it will match also.
+     * The number matching is <i>at least</i> based which means that if more
+     * messages received it will match also.
      *
      * @param number at least number of messages
      * @return the builder
@@ -421,13 +443,15 @@ public class NotifyBuilder {
     }
 
     /**
-     * Sets a condition when <tt>number</tt> of {@link Exchange} is done being processed.
+     * Sets a condition when <tt>number</tt> of {@link Exchange} is done being
+     * processed.
      * <p/>
-     * The number matching is <i>at least</i> based which means that if more messages received
-     * it will match also.
+     * The number matching is <i>at least</i> based which means that if more
+     * messages received it will match also.
      * <p/>
-     * The difference between <i>done</i> and <i>completed</i> is that done can also include failed
-     * messages, where as completed is only successful processed messages.
+     * The difference between <i>done</i> and <i>completed</i> is that done can
+     * also include failed messages, where as completed is only successful
+     * processed messages.
      *
      * @param number at least number of messages
      * @return the builder
@@ -466,10 +490,12 @@ public class NotifyBuilder {
     }
 
     /**
-     * Sets a condition when tne <tt>n'th</tt> (by index) {@link Exchange} is done being processed.
+     * Sets a condition when tne <tt>n'th</tt> (by index) {@link Exchange} is
+     * done being processed.
      * <p/>
-     * The difference between <i>done</i> and <i>completed</i> is that done can also include failed
-     * messages, where as completed is only successful processed messages.
+     * The difference between <i>done</i> and <i>completed</i> is that done can
+     * also include failed messages, where as completed is only successful
+     * processed messages.
      *
      * @param index the message by index to be done
      * @return the builder
@@ -525,13 +551,15 @@ public class NotifyBuilder {
     }
 
     /**
-     * Sets a condition when <tt>number</tt> of {@link Exchange} has been completed.
+     * Sets a condition when <tt>number</tt> of {@link Exchange} has been
+     * completed.
      * <p/>
-     * The number matching is <i>at least</i> based which means that if more messages received
-     * it will match also.
+     * The number matching is <i>at least</i> based which means that if more
+     * messages received it will match also.
      * <p/>
-     * The difference between <i>done</i> and <i>completed</i> is that done can also include failed
-     * messages, where as completed is only successful processed messages.
+     * The difference between <i>done</i> and <i>completed</i> is that done can
+     * also include failed messages, where as completed is only successful
+     * processed messages.
      *
      * @param number at least number of messages
      * @return the builder
@@ -566,8 +594,8 @@ public class NotifyBuilder {
     /**
      * Sets a condition when <tt>number</tt> of {@link Exchange} has failed.
      * <p/>
-     * The number matching is <i>at least</i> based which means that if more messages received
-     * it will match also.
+     * The number matching is <i>at least</i> based which means that if more
+     * messages received it will match also.
      *
      * @param number at least number of messages
      * @return the builder
@@ -600,7 +628,8 @@ public class NotifyBuilder {
     }
 
     /**
-     * Sets a condition when <tt>number</tt> of {@link Exchange} is done being processed.
+     * Sets a condition when <tt>number</tt> of {@link Exchange} is done being
+     * processed.
      * <p/>
      * messages, where as completed is only successful processed messages.
      *
@@ -641,10 +670,12 @@ public class NotifyBuilder {
     }
 
     /**
-     * Sets a condition when <tt>number</tt> of {@link Exchange} has been completed.
+     * Sets a condition when <tt>number</tt> of {@link Exchange} has been
+     * completed.
      * <p/>
-     * The difference between <i>done</i> and <i>completed</i> is that done can also include failed
-     * messages, where as completed is only successful processed messages.
+     * The difference between <i>done</i> and <i>completed</i> is that done can
+     * also include failed messages, where as completed is only successful
+     * processed messages.
      *
      * @param number exactly number of messages
      * @return the builder
@@ -710,7 +741,8 @@ public class NotifyBuilder {
     }
 
     /**
-     * Sets a condition that <b>any received</b> {@link Exchange} should match the {@link Predicate}
+     * Sets a condition that <b>any received</b> {@link Exchange} should match
+     * the {@link Predicate}
      *
      * @param predicate the predicate
      * @return the builder
@@ -720,7 +752,8 @@ public class NotifyBuilder {
     }
 
     /**
-     * Sets a condition that <b>any done</b> {@link Exchange} should match the {@link Predicate}
+     * Sets a condition that <b>any done</b> {@link Exchange} should match the
+     * {@link Predicate}
      *
      * @param predicate the predicate
      * @return the builder
@@ -779,7 +812,8 @@ public class NotifyBuilder {
     }
 
     /**
-     * Sets a condition that <b>all received</b> {@link Exchange} should match the {@link Predicate}
+     * Sets a condition that <b>all received</b> {@link Exchange} should match
+     * the {@link Predicate}
      *
      * @param predicate the predicate
      * @return the builder
@@ -789,7 +823,8 @@ public class NotifyBuilder {
     }
 
     /**
-     * Sets a condition that <b>all done</b> {@link Exchange} should match the {@link Predicate}
+     * Sets a condition that <b>all done</b> {@link Exchange} should match the
+     * {@link Predicate}
      *
      * @param predicate the predicate
      * @return the builder
@@ -848,10 +883,11 @@ public class NotifyBuilder {
     }
 
     /**
-     * Sets a condition that the bodies is expected to be <b>received</b> in the order as well.
+     * Sets a condition that the bodies is expected to be <b>received</b> in the
+     * order as well.
      * <p/>
-     * This condition will discard any additional messages. If you need a more strict condition
-     * then use {@link #whenExactBodiesReceived(Object...)}
+     * This condition will discard any additional messages. If you need a more
+     * strict condition then use {@link #whenExactBodiesReceived(Object...)}
      *
      * @param bodies the expected bodies
      * @return the builder
@@ -864,10 +900,11 @@ public class NotifyBuilder {
     }
 
     /**
-     * Sets a condition that the bodies is expected to be <b>done</b> in the order as well.
+     * Sets a condition that the bodies is expected to be <b>done</b> in the
+     * order as well.
      * <p/>
-     * This condition will discard any additional messages. If you need a more strict condition
-     * then use {@link #whenExactBodiesDone(Object...)}
+     * This condition will discard any additional messages. If you need a more
+     * strict condition then use {@link #whenExactBodiesDone(Object...)}
      *
      * @param bodies the expected bodies
      * @return the builder
@@ -880,9 +917,11 @@ public class NotifyBuilder {
     }
 
     /**
-     * Sets a condition that the bodies is expected to be <b>received</b> in the order as well.
+     * Sets a condition that the bodies is expected to be <b>received</b> in the
+     * order as well.
      * <p/>
-     * This condition is strict which means that it only expect that exact number of bodies
+     * This condition is strict which means that it only expect that exact
+     * number of bodies
      *
      * @param bodies the expected bodies
      * @return the builder
@@ -895,9 +934,11 @@ public class NotifyBuilder {
     }
 
     /**
-     * Sets a condition that the bodies is expected to be <b>done</b> in the order as well.
+     * Sets a condition that the bodies is expected to be <b>done</b> in the
+     * order as well.
      * <p/>
-     * This condition is strict which means that it only expect that exact number of bodies
+     * This condition is strict which means that it only expect that exact
+     * number of bodies
      *
      * @param bodies the expected bodies
      * @return the builder
@@ -976,14 +1017,16 @@ public class NotifyBuilder {
     }
 
     /**
-     * Sets a condition when the provided matcher (such as mock endpoint) is satisfied based on {@link Exchange}
-     * being sent to it when they are <b>done</b>.
+     * Sets a condition when the provided matcher (such as mock endpoint) is
+     * satisfied based on {@link Exchange} being sent to it when they are
+     * <b>done</b>.
      * <p/>
-     * The idea is that you can use mock endpoints (or other matchers) for setting fine grained expectations
-     * and then use that together with this builder. The mock provided does <b>NOT</b>
-     * have to already exist in the route. You can just create a new pseudo mock
-     * and this builder will send the done {@link Exchange} to it. So its like
-     * adding the mock to the end of your route(s).
+     * The idea is that you can use mock endpoints (or other matchers) for
+     * setting fine grained expectations and then use that together with this
+     * builder. The mock provided does <b>NOT</b> have to already exist in the
+     * route. You can just create a new pseudo mock and this builder will send
+     * the done {@link Exchange} to it. So its like adding the mock to the end
+     * of your route(s).
      *
      * @param matcher the matcher such as mock endpoint
      * @return the builder
@@ -993,14 +1036,16 @@ public class NotifyBuilder {
     }
 
     /**
-     * Sets a condition when the provided matcher (such as mock endpoint) is satisfied based on {@link Exchange}
-     * being sent to it when they are <b>received</b>.
+     * Sets a condition when the provided matcher (such as mock endpoint) is
+     * satisfied based on {@link Exchange} being sent to it when they are
+     * <b>received</b>.
      * <p/>
-     * The idea is that you can use mock endpoints (or other matchers) for setting fine grained expectations
-     * and then use that together with this builder. The mock provided does <b>NOT</b>
-     * have to already exist in the route. You can just create a new pseudo mock
-     * and this builder will send the done {@link Exchange} to it. So its like
-     * adding the mock to the end of your route(s).
+     * The idea is that you can use mock endpoints (or other matchers) for
+     * setting fine grained expectations and then use that together with this
+     * builder. The mock provided does <b>NOT</b> have to already exist in the
+     * route. You can just create a new pseudo mock and this builder will send
+     * the done {@link Exchange} to it. So its like adding the mock to the end
+     * of your route(s).
      *
      * @param matcher the matcher such as mock endpoint
      * @return the builder
@@ -1058,14 +1103,16 @@ public class NotifyBuilder {
     }
 
     /**
-     * Sets a condition when the provided matcher (such as mock endpoint) is <b>not</b> satisfied based on {@link Exchange}
-     * being sent to it when they are <b>received</b>.
+     * Sets a condition when the provided matcher (such as mock endpoint) is
+     * <b>not</b> satisfied based on {@link Exchange} being sent to it when they
+     * are <b>received</b>.
      * <p/>
-     * The idea is that you can use  mock endpoints (or other matchers) for setting fine grained expectations
-     * and then use that together with this builder. The mock provided does <b>NOT</b>
-     * have to already exist in the route. You can just create a new pseudo mock
-     * and this builder will send the done {@link Exchange} to it. So its like
-     * adding the mock to the end of your route(s).
+     * The idea is that you can use mock endpoints (or other matchers) for
+     * setting fine grained expectations and then use that together with this
+     * builder. The mock provided does <b>NOT</b> have to already exist in the
+     * route. You can just create a new pseudo mock and this builder will send
+     * the done {@link Exchange} to it. So its like adding the mock to the end
+     * of your route(s).
      *
      * @param matcher the matcher such as mock endpoint
      * @return the builder
@@ -1075,14 +1122,16 @@ public class NotifyBuilder {
     }
 
     /**
-     * Sets a condition when the provided matcher (such as mock endpoint) is <b>not</b> satisfied based on {@link Exchange}
-     * being sent to it when they are <b>done</b>.
+     * Sets a condition when the provided matcher (such as mock endpoint) is
+     * <b>not</b> satisfied based on {@link Exchange} being sent to it when they
+     * are <b>done</b>.
      * <p/>
-     * The idea is that you can use  mock endpoints (or other matchers) for setting fine grained expectations
-     * and then use that together with this builder. The mock provided does <b>NOT</b>
-     * have to already exist in the route. You can just create a new pseudo mock
-     * and this builder will send the done {@link Exchange} to it. So its like
-     * adding the mock to the end of your route(s).
+     * The idea is that you can use mock endpoints (or other matchers) for
+     * setting fine grained expectations and then use that together with this
+     * builder. The mock provided does <b>NOT</b> have to already exist in the
+     * route. You can just create a new pseudo mock and this builder will send
+     * the done {@link Exchange} to it. So its like adding the mock to the end
+     * of your route(s).
      *
      * @param matcher the matcher such as mock endpoint
      * @return the builder
@@ -1140,7 +1189,8 @@ public class NotifyBuilder {
     }
 
     /**
-     * Prepares to append an additional expression using the <i>and</i> operator.
+     * Prepares to append an additional expression using the <i>and</i>
+     * operator.
      *
      * @return the builder
      */
@@ -1160,7 +1210,8 @@ public class NotifyBuilder {
     }
 
     /**
-     * Prepares to append an additional expression using the <i>not</i> operator.
+     * Prepares to append an additional expression using the <i>not</i>
+     * operator.
      *
      * @return the builder
      */
@@ -1170,7 +1221,8 @@ public class NotifyBuilder {
     }
 
     /**
-     * Specifies the wait time in millis to use in the {@link #matchesWaitTime()} method.
+     * Specifies the wait time in millis to use in the
+     * {@link #matchesWaitTime()} method.
      */
     public NotifyBuilder waitTime(long waitTime) {
         this.waitTime = waitTime;
@@ -1211,7 +1263,8 @@ public class NotifyBuilder {
     /**
      * Does all the expression match?
      * <p/>
-     * This operation will return immediately which means it can be used for testing at this very moment.
+     * This operation will return immediately which means it can be used for
+     * testing at this very moment.
      *
      * @return <tt>true</tt> if matching, <tt>false</tt> otherwise
      */
@@ -1225,12 +1278,13 @@ public class NotifyBuilder {
     /**
      * Does all the expression match?
      * <p/>
-     * This operation will wait until the match is <tt>true</tt> or otherwise a timeout occur
-     * which means <tt>false</tt> will be returned.
+     * This operation will wait until the match is <tt>true</tt> or otherwise a
+     * timeout occur which means <tt>false</tt> will be returned.
      *
-     * @param timeout  the timeout value
+     * @param timeout the timeout value
      * @param timeUnit the time unit
-     * @return <tt>true</tt> if matching, <tt>false</tt> otherwise due to timeout
+     * @return <tt>true</tt> if matching, <tt>false</tt> otherwise due to
+     *         timeout
      */
     public boolean matches(long timeout, TimeUnit timeUnit) {
         if (!created) {
@@ -1247,12 +1301,13 @@ public class NotifyBuilder {
     /**
      * Does all the expressions match?
      * <p/>
-     * This operation will wait until the match is <tt>true</tt> or otherwise a timeout occur
-     * which means <tt>false</tt> will be returned.
+     * This operation will wait until the match is <tt>true</tt> or otherwise a
+     * timeout occur which means <tt>false</tt> will be returned.
      * <p/>
      * The timeout value is by default 10 seconds.
      *
-     * @return <tt>true</tt> if matching, <tt>false</tt> otherwise due to timeout
+     * @return <tt>true</tt> if matching, <tt>false</tt> otherwise due to
+     *         timeout
      * @deprecated use {@link #matchesWaitTime()} instead
      */
     @Deprecated
@@ -1263,12 +1318,13 @@ public class NotifyBuilder {
     /**
      * Does all the expressions match?
      * <p/>
-     * This operation will wait until the match is <tt>true</tt> or otherwise a timeout occur
-     * which means <tt>false</tt> will be returned.
+     * This operation will wait until the match is <tt>true</tt> or otherwise a
+     * timeout occur which means <tt>false</tt> will be returned.
      * <p/>
      * The timeout value is by default 10 seconds.
      *
-     * @return <tt>true</tt> if matching, <tt>false</tt> otherwise due to timeout
+     * @return <tt>true</tt> if matching, <tt>false</tt> otherwise due to
+     *         timeout
      */
     public boolean matchesWaitTime() {
         if (!created) {
@@ -1305,7 +1361,8 @@ public class NotifyBuilder {
     private void doCreate(EventOperation newOperation) {
         // init operation depending on the newOperation
         if (operation == null) {
-            // if the first new operation is an or then this operation must be an or as well
+            // if the first new operation is an or then this operation must be
+            // an or as well
             // otherwise it should be and based
             operation = newOperation == EventOperation.or ? EventOperation.or : EventOperation.and;
         }
@@ -1339,20 +1396,21 @@ public class NotifyBuilder {
     }
 
     /**
-     * Notifier which hooks into Camel to listen for {@link Exchange} relevant events for this builder
+     * Notifier which hooks into Camel to listen for {@link Exchange} relevant
+     * events for this builder
      */
     private final class ExchangeNotifier extends EventNotifierSupport {
 
         @Override
         public void notify(CamelEvent event) throws Exception {
             if (event instanceof ExchangeCreatedEvent) {
-                onExchangeCreated((ExchangeCreatedEvent) event);
+                onExchangeCreated((ExchangeCreatedEvent)event);
             } else if (event instanceof ExchangeCompletedEvent) {
-                onExchangeCompleted((ExchangeCompletedEvent) event);
+                onExchangeCompleted((ExchangeCompletedEvent)event);
             } else if (event instanceof ExchangeFailedEvent) {
-                onExchangeFailed((ExchangeFailedEvent) event);
+                onExchangeFailed((ExchangeFailedEvent)event);
             } else if (event instanceof ExchangeSentEvent) {
-                onExchangeSent((ExchangeSentEvent) event);
+                onExchangeSent((ExchangeSentEvent)event);
             }
 
             // now compute whether we matched
@@ -1463,7 +1521,8 @@ public class NotifyBuilder {
          * Callback for {@link Exchange} lifecycle
          *
          * @param exchange the exchange
-         * @return <tt>true</tt> to allow continue evaluating, <tt>false</tt> to stop immediately
+         * @return <tt>true</tt> to allow continue evaluating, <tt>false</tt> to
+         *         stop immediately
          */
         boolean onExchangeCreated(Exchange exchange);
 
@@ -1471,7 +1530,8 @@ public class NotifyBuilder {
          * Callback for {@link Exchange} lifecycle
          *
          * @param exchange the exchange
-         * @return <tt>true</tt> to allow continue evaluating, <tt>false</tt> to stop immediately
+         * @return <tt>true</tt> to allow continue evaluating, <tt>false</tt> to
+         *         stop immediately
          */
         boolean onExchangeCompleted(Exchange exchange);
 
@@ -1479,7 +1539,8 @@ public class NotifyBuilder {
          * Callback for {@link Exchange} lifecycle
          *
          * @param exchange the exchange
-         * @return <tt>true</tt> to allow continue evaluating, <tt>false</tt> to stop immediately
+         * @return <tt>true</tt> to allow continue evaluating, <tt>false</tt> to
+         *         stop immediately
          */
         boolean onExchangeFailed(Exchange exchange);
 
@@ -1489,7 +1550,8 @@ public class NotifyBuilder {
          * @param exchange the exchange
          * @param endpoint the endpoint sent to
          * @param timeTaken time taken in millis to send the to endpoint
-         * @return <tt>true</tt> to allow continue evaluating, <tt>false</tt> to stop immediately
+         * @return <tt>true</tt> to allow continue evaluating, <tt>false</tt> to
+         *         stop immediately
          */
         boolean onExchangeSent(Exchange exchange, Endpoint endpoint, long timeTaken);
     }
@@ -1523,7 +1585,8 @@ public class NotifyBuilder {
 
         @Override
         public boolean onExchangeSent(Exchange exchange, Endpoint endpoint, long timeTaken) {
-            // no need to invoke onExchange as this is a special case when the Exchange
+            // no need to invoke onExchange as this is a special case when the
+            // Exchange
             // was sent to a specific endpoint
             return true;
         }
@@ -1665,4 +1728,4 @@ public class NotifyBuilder {
         }
     }
 
-}
\ No newline at end of file
+}
diff --git a/core/camel-core/src/main/java/org/apache/camel/builder/PredicateBuilder.java b/core/camel-core/src/main/java/org/apache/camel/builder/PredicateBuilder.java
index 43b62bd..a32fa73 100644
--- a/core/camel-core/src/main/java/org/apache/camel/builder/PredicateBuilder.java
+++ b/core/camel-core/src/main/java/org/apache/camel/builder/PredicateBuilder.java
@@ -21,12 +21,13 @@ package org.apache.camel.builder;
  */
 public final class PredicateBuilder extends org.apache.camel.support.builder.PredicateBuilder {
 
-    // this class is included in camel-core to be backwards compatible by extending from camel-support
+    // this class is included in camel-core to be backwards compatible by
+    // extending from camel-support
 
     /**
      * Utility classes should not have a public constructor.
      */
     private PredicateBuilder() {
     }
-    
+
 }
diff --git a/core/camel-core/src/main/java/org/apache/camel/builder/PredicateClause.java b/core/camel-core/src/main/java/org/apache/camel/builder/PredicateClause.java
index dcfac6d..544c4e4 100644
--- a/core/camel-core/src/main/java/org/apache/camel/builder/PredicateClause.java
+++ b/core/camel-core/src/main/java/org/apache/camel/builder/PredicateClause.java
@@ -34,7 +34,7 @@ public class PredicateClause<T> implements org.apache.camel.Predicate {
 
     @Override
     public boolean matches(Exchange exchange) {
-        return (predicate != null) ?  predicate.test(exchange) : false;
+        return (predicate != null) ? predicate.test(exchange) : false;
     }
 
     // *******************************
@@ -49,22 +49,26 @@ public class PredicateClause<T> implements org.apache.camel.Predicate {
         return parent;
     }
 
-
     // *******************************
     // Message
     // *******************************
 
     /**
-     * Define a {@link org.apache.camel.Predicate} which targets the Exchange In Message.
-     *     
-     * <blockquote><pre>{@code
+     * Define a {@link org.apache.camel.Predicate} which targets the Exchange In
+     * Message. <blockquote>
+     * 
+     * <pre>
+     * {@code
      * from("direct:aggregate")
      *     .choice()
      *         .when()
      *            .message(m -> m.getBody() != null)
      *            .log("Received ${body}")
      *     .endChoice()
-     * }</pre></blockquote>
+     * }
+     * </pre>
+     * 
+     * </blockquote>
      */
     public T message(final Predicate<Message> predicate) {
         return exchange(e -> predicate.test(e.getIn()));
@@ -74,74 +78,87 @@ public class PredicateClause<T> implements org.apache.camel.Predicate {
     // Body
     // *******************************
 
-
     /**
-     * Define a {@link org.apache.camel.Predicate} which targets the Exchange In Body.
-     *     
-     * <blockquote><pre>{@code
+     * Define a {@link org.apache.camel.Predicate} which targets the Exchange In
+     * Body. <blockquote>
+     * 
+     * <pre>
+     * {@code
      * from("direct:aggregate")
      *     .choice()
      *         .when()
      *            .body(b -> b != null)
      *            .log("Received ${body}")
      *     .endChoice()
-     * }</pre></blockquote>
+     * }
+     * </pre>
+     * 
+     * </blockquote>
      */
     public T body(final Predicate<Object> predicate) {
         return exchange(e -> predicate.test(e.getIn().getBody()));
     }
 
     /**
-     * Define a {@link org.apache.camel.Predicate} which targets the typed Exchange In Body.
-     *     
-     * <blockquote><pre>{@code
+     * Define a {@link org.apache.camel.Predicate} which targets the typed
+     * Exchange In Body. <blockquote>
+     * 
+     * <pre>
+     * {@code
      * from("direct:aggregate")
      *     .choice()
      *         .when()
      *            .body(Long.class, b -> (b & 1) == 0)
      *            .log("Received even number ${body}")
      *     .endChoice()
-     * }</pre></blockquote>
+     * }
+     * </pre>
+     * 
+     * </blockquote>
      */
     public <B> T body(final Class<B> type, final Predicate<B> predicate) {
         return exchange(e -> predicate.test(e.getIn().getBody(type)));
     }
 
     /**
-     * Define a {@link org.apache.camel.Predicate} which targets the Exchange In Body and its Headers.
-     *     
-     * <blockquote><pre>{@code
+     * Define a {@link org.apache.camel.Predicate} which targets the Exchange In
+     * Body and its Headers. <blockquote>
+     * 
+     * <pre>
+     * {@code
      * from("direct:aggregate")
      *     .choice()
      *         .when()
      *            .body((b, h) -> b != null || h.containsKy("ToProcess"))
      *            .log("Received ${body}")
      *     .endChoice()
-     * }</pre></blockquote>
+     * }
+     * </pre>
+     * 
+     * </blockquote>
      */
     public T body(final BiPredicate<Object, Map<String, Object>> predicate) {
-        return exchange(e -> predicate.test(
-            e.getIn().getBody(),
-            e.getIn().getHeaders())
-        );
+        return exchange(e -> predicate.test(e.getIn().getBody(), e.getIn().getHeaders()));
     }
 
     /**
-     * Define a {@link org.apache.camel.Predicate} which targets the typed Exchange In Body and its Headers.
-     *     
-     * <blockquote><pre>{@code
+     * Define a {@link org.apache.camel.Predicate} which targets the typed
+     * Exchange In Body and its Headers. <blockquote>
+     * 
+     * <pre>
+     * {@code
      * from("direct:aggregate")
      *     .choice()
      *         .when()
      *            .body(String.class, (b, h) -> b != null && !b.isEmpty() || h.containsKy("ToProcess"))
      *            .log("Received ${body}")
      *     .endChoice()
-     * }</pre></blockquote>
+     * }
+     * </pre>
+     * 
+     * </blockquote>
      */
     public <B> T body(final Class<B> type, final BiPredicate<B, Map<String, Object>> predicate) {
-        return exchange(e -> predicate.test(
-            e.getIn().getBody(type),
-            e.getIn().getHeaders())
-        );
+        return exchange(e -> predicate.test(e.getIn().getBody(type), e.getIn().getHeaders()));
     }
 }
diff --git a/core/camel-core/src/main/java/org/apache/camel/builder/ProcessClause.java b/core/camel-core/src/main/java/org/apache/camel/builder/ProcessClause.java
index 8f3fe6e..1b6a0e5 100644
--- a/core/camel-core/src/main/java/org/apache/camel/builder/ProcessClause.java
+++ b/core/camel-core/src/main/java/org/apache/camel/builder/ProcessClause.java
@@ -51,19 +51,23 @@ public class ProcessClause<T> implements Processor {
         return parent;
     }
 
-
     // *******************************
     // Message
     // *******************************
-    
+
     /**
      * Define a {@link Processor} which targets the Exchange In Message.
-     *     
-     * <blockquote><pre>{@code
+     * <blockquote>
+     * 
+     * <pre>
+     * {@code
      * from("direct:aggregate")
      *     .process()
      *         .message(m -> m.setHeader("HasBody", m.getBody() != null));
-     * }</pre></blockquote>
+     * }
+     * </pre>
+     * 
+     * </blockquote>
      */
     public T message(final Consumer<Message> consumer) {
         processor = e -> consumer.accept(e.getIn());
@@ -76,12 +80,17 @@ public class ProcessClause<T> implements Processor {
 
     /**
      * Define a {@link Processor} which targets the Exchange In Body.
-     *     
-     * <blockquote><pre>{@code
+     * <blockquote>
+     * 
+     * <pre>
+     * {@code
      * from("direct:aggregate")
      *     .process()
      *         .body(System.out::println);
-     * }</pre></blockquote>
+     * }
+     * </pre>
+     * 
+     * </blockquote>
      */
     public T body(final Consumer<Object> consumer) {
         processor = e -> consumer.accept(e.getIn().getBody());
@@ -90,39 +99,48 @@ public class ProcessClause<T> implements Processor {
 
     /**
      * Define a {@link Processor} which targets the typed Exchange In Body.
-     *     
-     * <blockquote><pre>{@code
+     * <blockquote>
+     * 
+     * <pre>
+     * {@code
      * from("direct:aggregate")
      *     .process()
      *         .body(MyObject.class, MyObject::dumpToStdOut);
-     * }</pre></blockquote>
+     * }
+     * </pre>
+     * 
+     * </blockquote>
      */
     public <B> T body(Class<B> type, final Consumer<B> consumer) {
         processor = e -> consumer.accept(e.getIn().getBody(type));
         return parent;
     }
-    
+
     /**
-     * Define a {@link Processor} which targets the Exchange In Body and its Headers.
-     *     
-     * <blockquote><pre>{@code
+     * Define a {@link Processor} which targets the Exchange In Body and its
+     * Headers. <blockquote>
+     * 
+     * <pre>
+     * {@code
      * from("direct:aggregate")
      *     .process()
      *         .body((b, h) -> h.put("ClassName", b.getClass().getName()));
-     * }</pre></blockquote>
+     * }
+     * </pre>
+     * 
+     * </blockquote>
      */
     public T body(final BiConsumer<Object, Map<String, Object>> consumer) {
-        processor = e -> consumer.accept(
-            e.getIn().getBody(),
-            e.getIn().getHeaders()
-        );
+        processor = e -> consumer.accept(e.getIn().getBody(), e.getIn().getHeaders());
         return parent;
     }
-    
+
     /**
-     * Define a {@link Processor} which targets the typed Exchange In Body and its Headers.
-     *     
-     * <blockquote><pre>{@code
+     * Define a {@link Processor} which targets the typed Exchange In Body and
+     * its Headers. <blockquote>
+     * 
+     * <pre>
+     * {@code
      * from("direct:aggregate")
      *     .process()
      *         .body(MyObject.class, (b, h) -> { 
@@ -130,13 +148,13 @@ public class ProcessClause<T> implements Processor {
      *                  b.dumpToStdOut();
      *             }
      *         });
-     * }</pre></blockquote>
+     * }
+     * </pre>
+     * 
+     * </blockquote>
      */
     public <B> T body(Class<B> type, final BiConsumer<B, Map<String, Object>> consumer) {
-        processor = e -> consumer.accept(
-            e.getIn().getBody(type),
-            e.getIn().getHeaders()
-        );
+        processor = e -> consumer.accept(e.getIn().getBody(type), e.getIn().getHeaders());
         return parent;
     }
 }
diff --git a/core/camel-core/src/main/java/org/apache/camel/builder/ProxyBuilder.java b/core/camel-core/src/main/java/org/apache/camel/builder/ProxyBuilder.java
index 4c861d8..23178c6 100644
--- a/core/camel-core/src/main/java/org/apache/camel/builder/ProxyBuilder.java
+++ b/core/camel-core/src/main/java/org/apache/camel/builder/ProxyBuilder.java
@@ -38,7 +38,7 @@ public final class ProxyBuilder {
     /**
      * Send the proxied message to this endpoint
      *
-     * @param url  uri of endpoint
+     * @param url uri of endpoint
      * @return the builder
      */
     public ProxyBuilder endpoint(String url) {
@@ -49,7 +49,7 @@ public final class ProxyBuilder {
     /**
      * Send the proxied message to this endpoint
      *
-     * @param endpoint  the endpoint
+     * @param endpoint the endpoint
      * @return the builder
      */
     public ProxyBuilder endpoint(Endpoint endpoint) {
@@ -60,7 +60,7 @@ public final class ProxyBuilder {
     /**
      * Builds the proxy.
      *
-     * @param interfaceClass  the service interface
+     * @param interfaceClass the service interface
      * @return the proxied bean
      * @throws Exception is thrown if error creating the proxy
      */
@@ -69,13 +69,13 @@ public final class ProxyBuilder {
         // this method is introduced to avoid compiler warnings about the
         // generic Class arrays in the case we've got only one single Class
         // to build a Proxy for
-        return build((Class<T>[]) new Class[] {interfaceClass});
+        return build((Class<T>[])new Class[] {interfaceClass});
     }
 
     /**
      * Builds the proxy.
      *
-     * @param interfaceClasses  the service interface(s)
+     * @param interfaceClasses the service interface(s)
      * @return the proxied bean
      * @throws Exception is thrown if error creating the proxy
      */
diff --git a/core/camel-core/src/main/java/org/apache/camel/builder/RouteBuilder.java b/core/camel-core/src/main/java/org/apache/camel/builder/RouteBuilder.java
index 158ffc1..8bf64ff 100644
--- a/core/camel-core/src/main/java/org/apache/camel/builder/RouteBuilder.java
+++ b/core/camel-core/src/main/java/org/apache/camel/builder/RouteBuilder.java
@@ -49,8 +49,8 @@ import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
 /**
- * A <a href="http://camel.apache.org/dsl.html">Java DSL</a> which is
- * used to build {@link Route} instances in a {@link CamelContext} for smart routing.
+ * A <a href="http://camel.apache.org/dsl.html">Java DSL</a> which is used to
+ * build {@link Route} instances in a {@link CamelContext} for smart routing.
  */
 public abstract class RouteBuilder extends BuilderSupport implements RoutesBuilder {
     protected Logger log = LoggerFactory.getLogger(getClass());
@@ -70,15 +70,17 @@ public abstract class RouteBuilder extends BuilderSupport implements RoutesBuild
     }
 
     /**
-     * Add routes to a context using a lambda expression.
-     * It can be used as following:
+     * Add routes to a context using a lambda expression. It can be used as
+     * following:
+     * 
      * <pre>
      * RouteBuilder.addRoutes(context, rb ->
      *     rb.from("direct:inbound").bean(ProduceTemplateBean.class)));
      * </pre>
      *
      * @param context the camel context to add routes
-     * @param rbc a lambda expression receiving the {@code RouteBuilder} to use to create routes
+     * @param rbc a lambda expression receiving the {@code RouteBuilder} to use
+     *            to create routes
      * @throws Exception if an error occurs
      */
     public static void addRoutes(CamelContext context, ThrowingConsumer<RouteBuilder, Exception> rbc) throws Exception {
@@ -96,7 +98,8 @@ public abstract class RouteBuilder extends BuilderSupport implements RoutesBuild
     }
 
     /**
-     * <b>Called on initialization to build the routes using the fluent builder syntax.</b>
+     * <b>Called on initialization to build the routes using the fluent builder
+     * syntax.</b>
      * <p/>
      * This is a central method for RouteBuilder implementations to implement
      * the routes using the Java fluent builder syntax.
@@ -108,7 +111,7 @@ public abstract class RouteBuilder extends BuilderSupport implements RoutesBuild
     /**
      * Binds the bean to the repository (if possible).
      *
-     * @param id   the id of the bean
+     * @param id the id of the bean
      * @param bean the bean
      */
     public void bindToRegistry(String id, Object bean) {
@@ -118,7 +121,7 @@ public abstract class RouteBuilder extends BuilderSupport implements RoutesBuild
     /**
      * Binds the bean to the repository (if possible).
      *
-     * @param id   the id of the bean
+     * @param id the id of the bean
      * @param type the type of the bean to associate the binding
      * @param bean the bean
      */
@@ -154,6 +157,7 @@ public abstract class RouteBuilder extends BuilderSupport implements RoutesBuild
         }
         return restConfiguration;
     }
+
     /**
      * Creates a new REST service
      *
@@ -169,7 +173,7 @@ public abstract class RouteBuilder extends BuilderSupport implements RoutesBuild
     /**
      * Creates a new REST service
      *
-     * @param path  the base path
+     * @param path the base path
      * @return the builder
      */
     public RestDefinition rest(String path) {
@@ -204,7 +208,7 @@ public abstract class RouteBuilder extends BuilderSupport implements RoutesBuild
     /**
      * Creates a new route from the given URI input
      *
-     * @param uri  the from uri
+     * @param uri the from uri
      * @return the builder
      */
     public RouteDefinition from(String uri) {
@@ -217,7 +221,7 @@ public abstract class RouteBuilder extends BuilderSupport implements RoutesBuild
     /**
      * Creates a new route from the given URI input
      *
-     * @param uri  the String formatted from uri
+     * @param uri the String formatted from uri
      * @param args arguments for the string formatting of the uri
      * @return the builder
      */
@@ -231,7 +235,7 @@ public abstract class RouteBuilder extends BuilderSupport implements RoutesBuild
     /**
      * Creates a new route from the given endpoint
      *
-     * @param endpoint  the from endpoint
+     * @param endpoint the from endpoint
      * @return the builder
      */
     public RouteDefinition from(Endpoint endpoint) {
@@ -249,9 +253,12 @@ public abstract class RouteBuilder extends BuilderSupport implements RoutesBuild
     }
 
     /**
-     * Installs the given <a href="http://camel.apache.org/error-handler.html">error handler</a> builder
+     * Installs the given
+     * <a href="http://camel.apache.org/error-handler.html">error handler</a>
+     * builder
      *
-     * @param errorHandlerBuilder  the error handler to be used by default for all child routes
+     * @param errorHandlerBuilder the error handler to be used by default for
+     *            all child routes
      */
     public void errorHandler(ErrorHandlerBuilder errorHandlerBuilder) {
         if (!getRouteCollection().getRoutes().isEmpty()) {
@@ -262,12 +269,14 @@ public abstract class RouteBuilder extends BuilderSupport implements RoutesBuild
     }
 
     /**
-     * Injects a property placeholder value with the given key converted to the given type.
+     * Injects a property placeholder value with the given key converted to the
+     * given type.
      *
-     * @param key  the property key
+     * @param key the property key
      * @param type the type to convert the value as
      * @return the value, or <tt>null</tt> if value is empty
-     * @throws Exception is thrown if property with key not found or error converting to the given type.
+     * @throws Exception is thrown if property with key not found or error
+     *             converting to the given type.
      */
     public <T> T propertyInject(String key, Class<T> type) throws Exception {
         StringHelper.notEmpty(key, "key");
@@ -299,7 +308,8 @@ public abstract class RouteBuilder extends BuilderSupport implements RoutesBuild
     }
 
     /**
-     * Adds a route for an interceptor that intercepts incoming messages on any inputs in this route
+     * Adds a route for an interceptor that intercepts incoming messages on any
+     * inputs in this route
      *
      * @return the builder
      */
@@ -312,9 +322,10 @@ public abstract class RouteBuilder extends BuilderSupport implements RoutesBuild
     }
 
     /**
-     * Adds a route for an interceptor that intercepts incoming messages on the given endpoint.
+     * Adds a route for an interceptor that intercepts incoming messages on the
+     * given endpoint.
      *
-     * @param uri  endpoint uri
+     * @param uri endpoint uri
      * @return the builder
      */
     public InterceptFromDefinition interceptFrom(String uri) {
@@ -326,9 +337,10 @@ public abstract class RouteBuilder extends BuilderSupport implements RoutesBuild
     }
 
     /**
-     * Applies a route for an interceptor if an exchange is send to the given endpoint
+     * Applies a route for an interceptor if an exchange is send to the given
+     * endpoint
      *
-     * @param uri  endpoint uri
+     * @param uri endpoint uri
      * @return the builder
      */
     public InterceptSendToEndpointDefinition interceptSendToEndpoint(String uri) {
@@ -340,8 +352,8 @@ public abstract class RouteBuilder extends BuilderSupport implements RoutesBuild
     }
 
     /**
-     * <a href="http://camel.apache.org/exception-clause.html">Exception clause</a>
-     * for catching certain exceptions and handling them.
+     * <a href="http://camel.apache.org/exception-clause.html">Exception
+     * clause</a> for catching certain exceptions and handling them.
      *
      * @param exception exception to catch
      * @return the builder
@@ -356,8 +368,8 @@ public abstract class RouteBuilder extends BuilderSupport implements RoutesBuild
     }
 
     /**
-     * <a href="http://camel.apache.org/exception-clause.html">Exception clause</a>
-     * for catching certain exceptions and handling them.
+     * <a href="http://camel.apache.org/exception-clause.html">Exception
+     * clause</a> for catching certain exceptions and handling them.
      *
      * @param exceptions list of exceptions to catch
      * @return the builder
@@ -372,7 +384,8 @@ public abstract class RouteBuilder extends BuilderSupport implements RoutesBuild
 
     /**
      * <a href="http://camel.apache.org/oncompletion.html">On completion</a>
-     * callback for doing custom routing when the {@link org.apache.camel.Exchange} is complete.
+     * callback for doing custom routing when the
+     * {@link org.apache.camel.Exchange} is complete.
      *
      * @return the builder
      */
@@ -384,14 +397,15 @@ public abstract class RouteBuilder extends BuilderSupport implements RoutesBuild
         getRouteCollection().setCamelContext(getContext());
         return getRouteCollection().onCompletion();
     }
-    
+
     @Override
     public void addRoutesToCamelContext(CamelContext context) throws Exception {
         // must configure routes before rests
         configureRoutes(context);
         configureRests(context);
 
-        // but populate rests before routes, as we want to turn rests into routes
+        // but populate rests before routes, as we want to turn rests into
+        // routes
         populateRests();
         populateTransformers();
         populateValidators();
@@ -424,7 +438,7 @@ public abstract class RouteBuilder extends BuilderSupport implements RoutesBuild
         restCollection.setCamelContext(context);
         return restCollection;
     }
-    
+
     @Override
     public void setErrorHandlerBuilder(ErrorHandlerBuilder errorHandlerBuilder) {
         super.setErrorHandlerBuilder(errorHandlerBuilder);
@@ -438,7 +452,7 @@ public abstract class RouteBuilder extends BuilderSupport implements RoutesBuild
             // Set the CamelContext ErrorHandler here
             CamelContext camelContext = getContext();
             if (camelContext.adapt(ExtendedCamelContext.class).getErrorHandlerFactory() instanceof ErrorHandlerBuilder) {
-                setErrorHandlerBuilder((ErrorHandlerBuilder) camelContext.adapt(ExtendedCamelContext.class).getErrorHandlerFactory());
+                setErrorHandlerBuilder((ErrorHandlerBuilder)camelContext.adapt(ExtendedCamelContext.class).getErrorHandlerFactory());
             }
             configure();
             // mark all route definitions as custom prepared because
@@ -476,15 +490,18 @@ public abstract class RouteBuilder extends BuilderSupport implements RoutesBuild
                 }
             }
         }
-        // cannot add rests as routes yet as we need to initialize this specially
+        // cannot add rests as routes yet as we need to initialize this
+        // specially
         camelContext.getExtension(Model.class).addRestDefinitions(getRestCollection().getRests(), false);
 
         // convert rests api-doc into routes so they are routes for runtime
         for (RestConfiguration config : camelContext.getRestConfigurations()) {
             if (config.getApiContextPath() != null) {
-                // avoid adding rest-api multiple times, in case multiple RouteBuilder classes is added
+                // avoid adding rest-api multiple times, in case multiple
+                // RouteBuilder classes is added
                 // to the CamelContext, as we only want to setup rest-api once
-                // so we check all existing routes if they have rest-api route already added
+                // so we check all existing routes if they have rest-api route
+                // already added
                 boolean hasRestApi = false;
                 for (RouteDefinition route : camelContext.getExtension(Model.class).getRouteDefinitions()) {
                     FromDefinition from = route.getInput();
@@ -499,10 +516,9 @@ public abstract class RouteBuilder extends BuilderSupport implements RoutesBuild
                 }
             }
         }
-        // add rest as routes and have them prepared as well via routeCollection.route method
-        getRestCollection().getRests()
-            .forEach(rest -> rest.asRouteDefinition(getContext())
-                .forEach(route -> getRouteCollection().route(route)));
+        // add rest as routes and have them prepared as well via
+        // routeCollection.route method
+        getRestCollection().getRests().forEach(rest -> rest.asRouteDefinition(getContext()).forEach(route -> getRouteCollection().route(route)));
     }
 
     protected void populateTransformers() {
diff --git a/core/camel-core/src/main/java/org/apache/camel/builder/SimpleBuilder.java b/core/camel-core/src/main/java/org/apache/camel/builder/SimpleBuilder.java
index 1fbfc9c..9927d3d 100644
--- a/core/camel-core/src/main/java/org/apache/camel/builder/SimpleBuilder.java
+++ b/core/camel-core/src/main/java/org/apache/camel/builder/SimpleBuilder.java
@@ -29,8 +29,9 @@ import org.apache.camel.support.ScriptHelper;
 /**
  * Creates an {@link Simple} language builder.
  * <p/>
- * This builder is available in the Java DSL from the {@link RouteBuilder} which means that using
- * simple language for {@link Expression}s or {@link Predicate}s is very easy with the help of this builder.
+ * This builder is available in the Java DSL from the {@link RouteBuilder} which
+ * means that using simple language for {@link Expression}s or
+ * {@link Predicate}s is very easy with the help of this builder.
  */
 public class SimpleBuilder implements Predicate, Expression, ExpressionResultTypeAware {
 
@@ -54,11 +55,11 @@ public class SimpleBuilder implements Predicate, Expression, ExpressionResultTyp
         return answer;
     }
 
-    public static SimpleBuilder simpleF(String formatText, Object...values) {
+    public static SimpleBuilder simpleF(String formatText, Object... values) {
         return simple(String.format(formatText, values));
     }
 
-    public static SimpleBuilder simpleF(String formatText, Class<?> resultType, Object...values) {
+    public static SimpleBuilder simpleF(String formatText, Class<?> resultType, Object... values) {
         return simple(String.format(formatText, values), resultType);
     }
 
@@ -105,7 +106,8 @@ public class SimpleBuilder implements Predicate, Expression, ExpressionResultTyp
         try {
             // resolve property placeholders
             String resolve = exchange.getContext().resolvePropertyPlaceholders(text);
-            // and optional it be refer to an external script on the file/classpath
+            // and optional it be refer to an external script on the
+            // file/classpath
             resolve = ScriptHelper.resolveOptionalExternalScript(exchange.getContext(), exchange, resolve);
             Language simple = exchange.getContext().resolveLanguage("simple");
             return simple.createPredicate(resolve);
@@ -118,7 +120,8 @@ public class SimpleBuilder implements Predicate, Expression, ExpressionResultTyp
         try {
             // resolve property placeholders
             String resolve = exchange.getContext().resolvePropertyPlaceholders(text);
-            // and optional it be refer to an external script on the file/classpath
+            // and optional it be refer to an external script on the
+            // file/classpath
             resolve = ScriptHelper.resolveOptionalExternalScript(exchange.getContext(), exchange, resolve);
             Language simple = exchange.getContext().resolveLanguage("simple");
             return createSimpleExpression(simple, resolve, resultType);
diff --git a/core/camel-core/src/main/java/org/apache/camel/builder/ThreadPoolBuilder.java b/core/camel-core/src/main/java/org/apache/camel/builder/ThreadPoolBuilder.java
index 40cc934..d7b06ff 100644
--- a/core/camel-core/src/main/java/org/apache/camel/builder/ThreadPoolBuilder.java
+++ b/core/camel-core/src/main/java/org/apache/camel/builder/ThreadPoolBuilder.java
@@ -37,7 +37,7 @@ public final class ThreadPoolBuilder {
         this.context = context;
         this.profile = new ThreadPoolProfile();
     }
-    
+
     public ThreadPoolBuilder poolSize(int poolSize) {
         profile.setPoolSize(poolSize);
         return this;
@@ -47,7 +47,7 @@ public final class ThreadPoolBuilder {
         profile.setMaxPoolSize(maxPoolSize);
         return this;
     }
-    
+
     public ThreadPoolBuilder keepAliveTime(long keepAliveTime, TimeUnit timeUnit) {
         profile.setKeepAliveTime(keepAliveTime);
         profile.setTimeUnit(timeUnit);
@@ -68,7 +68,7 @@ public final class ThreadPoolBuilder {
         profile.setRejectedPolicy(rejectedPolicy);
         return this;
     }
-    
+
     /**
      * Builds the new thread pool
      *
@@ -93,8 +93,9 @@ public final class ThreadPoolBuilder {
     /**
      * Builds the new thread pool
      *
-     * @param source the source object, usually it should be <tt>this</tt> passed in as parameter
-     * @param name   name which is appended to the thread name
+     * @param source the source object, usually it should be <tt>this</tt>
+     *            passed in as parameter
+     * @param name name which is appended to the thread name
      * @return the created thread pool
      * @throws Exception is thrown if error building the thread pool
      */
@@ -126,8 +127,9 @@ public final class ThreadPoolBuilder {
     /**
      * Builds the new scheduled thread pool
      *
-     * @param source the source object, usually it should be <tt>this</tt> passed in as parameter
-     * @param name   name which is appended to the thread name
+     * @param source the source object, usually it should be <tt>this</tt>
+     *            passed in as parameter
+     * @param name name which is appended to the thread name
      * @return the created scheduled thread pool
      * @throws Exception is thrown if error building the scheduled thread pool
      */
diff --git a/core/camel-core/src/main/java/org/apache/camel/builder/ThreadPoolProfileBuilder.java b/core/camel-core/src/main/java/org/apache/camel/builder/ThreadPoolProfileBuilder.java
index 17fbb68..b014ff7 100644
--- a/core/camel-core/src/main/java/org/apache/camel/builder/ThreadPoolProfileBuilder.java
+++ b/core/camel-core/src/main/java/org/apache/camel/builder/ThreadPoolProfileBuilder.java
@@ -37,13 +37,12 @@ public class ThreadPoolProfileBuilder {
         this.profile = origProfile.clone();
         this.profile.setId(id);
     }
-    
+
     public ThreadPoolProfileBuilder defaultProfile(Boolean defaultProfile) {
         this.profile.setDefaultProfile(defaultProfile);
         return this;
     }
 
-
     public ThreadPoolProfileBuilder poolSize(Integer poolSize) {
         profile.setPoolSize(poolSize);
         return this;
@@ -64,7 +63,7 @@ public class ThreadPoolProfileBuilder {
         profile.setKeepAliveTime(keepAliveTime);
         return this;
     }
-    
+
     public ThreadPoolProfileBuilder maxQueueSize(Integer maxQueueSize) {
         if (maxQueueSize != null) {
             profile.setMaxQueueSize(maxQueueSize);
diff --git a/core/camel-core/src/main/java/org/apache/camel/builder/TransformerBuilder.java b/core/camel-core/src/main/java/org/apache/camel/builder/TransformerBuilder.java
index cad5f96..3996943f 100644
--- a/core/camel-core/src/main/java/org/apache/camel/builder/TransformerBuilder.java
+++ b/core/camel-core/src/main/java/org/apache/camel/builder/TransformerBuilder.java
@@ -27,10 +27,12 @@ import org.apache.camel.spi.DataType;
 import org.apache.camel.spi.Transformer;
 
 /**
- * A <a href="http://camel.apache.org/dsl.html">Java DSL</a> which is
- * used to build a {@link org.apache.camel.spi.Transformer} and register into {@link org.apache.camel.CamelContext}.
- * It requires 'scheme' or a pair of 'from' and 'to' to be specified by scheme(), from() and to() method.
- * And then you can choose a type of transformer by withUri(), withDataFormat(), withJava() or withBean() method.
+ * A <a href="http://camel.apache.org/dsl.html">Java DSL</a> which is used to
+ * build a {@link org.apache.camel.spi.Transformer} and register into
+ * {@link org.apache.camel.CamelContext}. It requires 'scheme' or a pair of
+ * 'from' and 'to' to be specified by scheme(), from() and to() method. And then
+ * you can choose a type of transformer by withUri(), withDataFormat(),
+ * withJava() or withBean() method.
  */
 public class TransformerBuilder {
 
@@ -43,10 +45,10 @@ public class TransformerBuilder {
     private String beanRef;
 
     /**
-     * Set the scheme name supported by the transformer.
-     * If you specify 'csv', the transformer will be picked up for all of 'csv' from/to
-     * Java transformation. Note that the scheme matching is performed only when
-     * no exactly matched transformer exists.
+     * Set the scheme name supported by the transformer. If you specify 'csv',
+     * the transformer will be picked up for all of 'csv' from/to Java
+     * transformation. Note that the scheme matching is performed only when no
+     * exactly matched transformer exists.
      *
      * @param scheme scheme name
      */
@@ -56,10 +58,10 @@ public class TransformerBuilder {
     }
 
     /**
-     * Set the 'from' data type name.
-     * If you specify 'xml:XYZ', the transformer will be picked up if source type is
-     * 'xml:XYZ'. If you specify just 'xml', the transformer matches with all of
-     * 'xml' source type like 'xml:ABC' or 'xml:DEF'.
+     * Set the 'from' data type name. If you specify 'xml:XYZ', the transformer
+     * will be picked up if source type is 'xml:XYZ'. If you specify just 'xml',
+     * the transformer matches with all of 'xml' source type like 'xml:ABC' or
+     * 'xml:DEF'.
      *
      * @param from 'from' data type name
      */
@@ -79,10 +81,10 @@ public class TransformerBuilder {
     }
 
     /**
-     * Set the 'to' data type name.
-     * If you specify 'json:XYZ', the transformer will be picked up if destination type is
-     * 'json:XYZ'. If you specify just 'json', the transformer matches with all of
-     * 'json' destination type like 'json:ABC' or 'json:DEF'.
+     * Set the 'to' data type name. If you specify 'json:XYZ', the transformer
+     * will be picked up if destination type is 'json:XYZ'. If you specify just
+     * 'json', the transformer matches with all of 'json' destination type like
+     * 'json:ABC' or 'json:DEF'.
      *
      * @param to 'to' data type
      */
@@ -113,7 +115,8 @@ public class TransformerBuilder {
     }
 
     /**
-     * Set the {@code DataFormatDefinition} to be used for the {@code DataFormat} {@code Transformer}.
+     * Set the {@code DataFormatDefinition} to be used for the
+     * {@code DataFormat} {@code Transformer}.
      */
     public TransformerBuilder withDataFormat(DataFormatDefinition dataFormatDefinition) {
         resetType();
@@ -122,7 +125,8 @@ public class TransformerBuilder {
     }
 
     /**
-     * Set the Java {@code Class} represents a custom {@code Transformer} implementation class.
+     * Set the Java {@code Class} represents a custom {@code Transformer}
+     * implementation class.
      */
     public TransformerBuilder withJava(Class<? extends Transformer> clazz) {
         resetType();
@@ -147,8 +151,8 @@ public class TransformerBuilder {
     }
 
     /**
-     * Configure a Transformer according to the configurations built on this builder
-     * and register it into given {@code CamelContext}.
+     * Configure a Transformer according to the configurations built on this
+     * builder and register it into given {@code CamelContext}.
      * 
      * @param camelContext {@code CamelContext}
      */
@@ -173,14 +177,14 @@ public class TransformerBuilder {
         } else {
             throw new IllegalArgumentException("No Transformer type was specified");
         }
-        
+
         if (scheme != null) {
             transformer.setScheme(scheme);
         } else {
             transformer.setFromType(from);
             transformer.setToType(to);
         }
-        
+
         camelContext.getExtension(Model.class).getTransformers().add(transformer);
     }
 }
diff --git a/core/camel-core/src/main/java/org/apache/camel/builder/ValidatorBuilder.java b/core/camel-core/src/main/java/org/apache/camel/builder/ValidatorBuilder.java
index 491044f..13aa3b8 100644
--- a/core/camel-core/src/main/java/org/apache/camel/builder/ValidatorBuilder.java
+++ b/core/camel-core/src/main/java/org/apache/camel/builder/ValidatorBuilder.java
@@ -30,10 +30,11 @@ import org.apache.camel.spi.DataType;
 import org.apache.camel.spi.Validator;
 
 /**
- * A <a href="http://camel.apache.org/dsl.html">Java DSL</a> which is
- * used to build a {@link org.apache.camel.spi.Validator} and register into {@link org.apache.camel.CamelContext}.
- * It requires a 'type' to be specified by type() method.
- * And then you can choose a type of validator by withUri(), withPredicate(), withJava() or withBean() method.
+ * A <a href="http://camel.apache.org/dsl.html">Java DSL</a> which is used to
+ * build a {@link org.apache.camel.spi.Validator} and register into
+ * {@link org.apache.camel.CamelContext}. It requires a 'type' to be specified
+ * by type() method. And then you can choose a type of validator by withUri(),
+ * withPredicate(), withJava() or withBean() method.
  */
 public class ValidatorBuilder {
 
@@ -44,10 +45,10 @@ public class ValidatorBuilder {
     private String beanRef;
 
     /**
-     * Set the data type name.
-     * If you specify 'xml:XYZ', the validator will be picked up if source type is
-     * 'xml:XYZ'. If you specify just 'xml', the validator matches with all of
-     * 'xml' source type like 'xml:ABC' or 'xml:DEF'.
+     * Set the data type name. If you specify 'xml:XYZ', the validator will be
+     * picked up if source type is 'xml:XYZ'. If you specify just 'xml', the
+     * validator matches with all of 'xml' source type like 'xml:ABC' or
+     * 'xml:DEF'.
      *
      * @param type 'from' data type name
      */
@@ -68,8 +69,8 @@ public class ValidatorBuilder {
 
     /**
      * Set the URI to be used for the endpoint {@link Validator}.
-     * @see EndpointValidatorDefinition, ProcessorValidator
      * 
+     * @see EndpointValidatorDefinition, ProcessorValidator
      * @param uri endpoint URI
      */
     public ValidatorBuilder withUri(String uri) {
@@ -79,9 +80,10 @@ public class ValidatorBuilder {
     }
 
     /**
-     * Set the {@link Expression} to be used for the predicate {@link Validator}.
-     * @see PredicateValidatorDefinition, ProcessorValidator
+     * Set the {@link Expression} to be used for the predicate
+     * {@link Validator}.
      * 
+     * @see PredicateValidatorDefinition, ProcessorValidator
      * @param expression validation expression
      */
     public ValidatorBuilder withExpression(@AsPredicate Expression expression) {
@@ -92,8 +94,8 @@ public class ValidatorBuilder {
 
     /**
      * Set the {@link Predicate} to be used for the predicate {@link Validator}.
-     * @see PredicateValidatorDefinition, ProcessorValidator
      * 
+     * @see PredicateValidatorDefinition, ProcessorValidator
      * @param predicate validation predicate
      */
     public ValidatorBuilder withExpression(@AsPredicate Predicate predicate) {
@@ -103,10 +105,12 @@ public class ValidatorBuilder {
     }
 
     /**
-     * Set the Java {@code Class} represents a custom {@code Validator} implementation class.
-     * @see CustomValidatorDefinition
+     * Set the Java {@code Class} represents a custom {@code Validator}
+     * implementation class.
      * 
-     * @param clazz {@code Class} object represents custom validator implementation
+     * @see CustomValidatorDefinition
+     * @param clazz {@code Class} object represents custom validator
+     *            implementation
      */
     public ValidatorBuilder withJava(Class<? extends Validator> clazz) {
         resetType();
@@ -116,8 +120,8 @@ public class ValidatorBuilder {
 
     /**
      * Set the Java Bean name to be used for custom {@code Validator}.
-     * @see CustomValidatorDefinition
      * 
+     * @see CustomValidatorDefinition
      * @param ref bean name for the custom {@code Validator}
      */
     public ValidatorBuilder withBean(String ref) {
@@ -134,8 +138,8 @@ public class ValidatorBuilder {
     }
 
     /**
-     * Configures a new Validator according to the configurations built on this builder
-     * and register it into the given {@code CamelContext}.
+     * Configures a new Validator according to the configurations built on this
+     * builder and register it into the given {@code CamelContext}.
      * 
      * @param camelContext the given CamelContext
      */
@@ -160,7 +164,7 @@ public class ValidatorBuilder {
         } else {
             throw new IllegalArgumentException("No Validator type was specified");
         }
-        
+
         validator.setType(type);
         camelContext.getExtension(Model.class).getValidators().add(validator);
     }
diff --git a/core/camel-core/src/main/java/org/apache/camel/impl/AbstractModelCamelContext.java b/core/camel-core/src/main/java/org/apache/camel/impl/AbstractModelCamelContext.java
index 14a4b84..decb680 100644
--- a/core/camel-core/src/main/java/org/apache/camel/impl/AbstractModelCamelContext.java
+++ b/core/camel-core/src/main/java/org/apache/camel/impl/AbstractModelCamelContext.java
@@ -272,9 +272,7 @@ public abstract class AbstractModelCamelContext extends AbstractCamelContext imp
     }
 
     private TransformerKey createKey(TransformerDefinition def) {
-        return ObjectHelper.isNotEmpty(def.getScheme())
-                ? new TransformerKey(def.getScheme())
-                : new TransformerKey(new DataType(def.getFromType()), new DataType(def.getToType()));
+        return ObjectHelper.isNotEmpty(def.getScheme()) ? new TransformerKey(def.getScheme()) : new TransformerKey(new DataType(def.getFromType()), new DataType(def.getToType()));
     }
 
     protected abstract HealthCheckRegistry createHealthCheckRegistry();
@@ -310,7 +308,7 @@ public abstract class AbstractModelCamelContext extends AbstractCamelContext imp
     @Override
     protected synchronized void shutdownRouteService(BaseRouteService routeService) throws Exception {
         if (routeService instanceof RouteService) {
-            model.getRouteDefinitions().remove(((RouteService) routeService).getRouteDefinition());
+            model.getRouteDefinitions().remove(((RouteService)routeService).getRouteDefinition());
         }
         super.shutdownRouteService(routeService);
     }
diff --git a/core/camel-core/src/main/java/org/apache/camel/impl/DefaultCamelContext.java b/core/camel-core/src/main/java/org/apache/camel/impl/DefaultCamelContext.java
index bb79975..6e24aae 100644
--- a/core/camel-core/src/main/java/org/apache/camel/impl/DefaultCamelContext.java
+++ b/core/camel-core/src/main/java/org/apache/camel/impl/DefaultCamelContext.java
@@ -100,7 +100,8 @@ import org.apache.camel.support.DefaultRegistry;
 public class DefaultCamelContext extends AbstractModelCamelContext {
 
     /**
-     * Creates the {@link CamelContext} using {@link DefaultRegistry} as registry.
+     * Creates the {@link CamelContext} using {@link DefaultRegistry} as
+     * registry.
      * <p/>
      * Use one of the other constructors to force use an explicit registry.
      */
@@ -110,8 +111,9 @@ public class DefaultCamelContext extends AbstractModelCamelContext {
 
     /**
      * Creates the {@link CamelContext} using the given {@link BeanRepository}
-     * as first-choice repository, and the {@link org.apache.camel.support.SimpleRegistry} as fallback, via
-     * the {@link DefaultRegistry} implementation.
+     * as first-choice repository, and the
+     * {@link org.apache.camel.support.SimpleRegistry} as fallback, via the
+     * {@link DefaultRegistry} implementation.
      *
      * @param repository the bean repository.
      */
@@ -120,10 +122,12 @@ public class DefaultCamelContext extends AbstractModelCamelContext {
     }
 
     /**
-     * Creates the {@link CamelContext} using the given JNDI context as the registry
+     * Creates the {@link CamelContext} using the given JNDI context as the
+     * registry
      *
      * @param jndiContext the JNDI context
-     * @deprecated create a new {@link JndiRegistry} and use the constructor that accepts this registry.
+     * @deprecated create a new {@link JndiRegistry} and use the constructor
+     *             that accepts this registry.
      */
     @Deprecated
     public DefaultCamelContext(Context jndiContext) {
@@ -140,11 +144,12 @@ public class DefaultCamelContext extends AbstractModelCamelContext {
     }
 
     /**
-     * Creates the {@link CamelContext} and allows to control whether the context
-     * should automatic initialize or not.
+     * Creates the {@link CamelContext} and allows to control whether the
+     * context should automatic initialize or not.
      * <p/>
-     * This is used by some Camel components such as camel-cdi and camel-blueprint, however
-     * this constructor is not intended for regular Camel end users.
+     * This is used by some Camel components such as camel-cdi and
+     * camel-blueprint, however this constructor is not intended for regular
+     * Camel end users.
      *
      * @param init whether to automatic initialize.
      */
@@ -154,16 +159,14 @@ public class DefaultCamelContext extends AbstractModelCamelContext {
 
     @Override
     protected TypeConverter createTypeConverter() {
-        return new DefaultTypeConverter(
-                this, getPackageScanClassResolver(),
-                getInjector(), getDefaultFactoryFinder(), isLoadTypeConverters());
+        return new DefaultTypeConverter(this, getPackageScanClassResolver(), getInjector(), getDefaultFactoryFinder(), isLoadTypeConverters());
     }
 
     @Override
     protected TypeConverterRegistry createTypeConverterRegistry() {
         TypeConverter typeConverter = getTypeConverter();
         if (typeConverter instanceof TypeConverterRegistry) {
-            return (TypeConverterRegistry) typeConverter;
+            return (TypeConverterRegistry)typeConverter;
         }
         return null;
     }
diff --git a/core/camel-core/src/main/java/org/apache/camel/impl/DefaultExecutorServiceManager.java b/core/camel-core/src/main/java/org/apache/camel/impl/DefaultExecutorServiceManager.java
index a75bcbc..6f0ceed 100644
--- a/core/camel-core/src/main/java/org/apache/camel/impl/DefaultExecutorServiceManager.java
+++ b/core/camel-core/src/main/java/org/apache/camel/impl/DefaultExecutorServiceManager.java
@@ -53,10 +53,9 @@ public class DefaultExecutorServiceManager extends BaseExecutorServiceManager {
     protected Object forceId(Object source) {
         if (source instanceof OptionalIdentifiedDefinition) {
             NodeIdFactory factory = getCamelContext().adapt(ExtendedCamelContext.class).getNodeIdFactory();
-            ((OptionalIdentifiedDefinition) source).idOrCreate(factory);
+            ((OptionalIdentifiedDefinition)source).idOrCreate(factory);
         }
         return source;
     }
 
 }
-
diff --git a/core/camel-core/src/main/java/org/apache/camel/impl/DefaultModelJAXBContextFactory.java b/core/camel-core/src/main/java/org/apache/camel/impl/DefaultModelJAXBContextFactory.java
index 43babfb..cdd53cb 100644
--- a/core/camel-core/src/main/java/org/apache/camel/impl/DefaultModelJAXBContextFactory.java
+++ b/core/camel-core/src/main/java/org/apache/camel/impl/DefaultModelJAXBContextFactory.java
@@ -23,7 +23,8 @@ import org.apache.camel.model.Constants;
 import org.apache.camel.spi.ModelJAXBContextFactory;
 
 /**
- * Default implementation of {@link org.apache.camel.spi.ModelJAXBContextFactory}.
+ * Default implementation of
+ * {@link org.apache.camel.spi.ModelJAXBContextFactory}.
  */
 public class DefaultModelJAXBContextFactory implements ModelJAXBContextFactory {
 
@@ -48,4 +49,4 @@ public class DefaultModelJAXBContextFactory implements ModelJAXBContextFactory {
     protected ClassLoader getClassLoader() {
         return getClass().getClassLoader();
     }
-}
\ No newline at end of file
+}
diff --git a/core/camel-core/src/main/java/org/apache/camel/impl/RouteIdFactory.java b/core/camel-core/src/main/java/org/apache/camel/impl/RouteIdFactory.java
index 490279d..a0f78db 100644
--- a/core/camel-core/src/main/java/org/apache/camel/impl/RouteIdFactory.java
+++ b/core/camel-core/src/main/java/org/apache/camel/impl/RouteIdFactory.java
@@ -29,11 +29,12 @@ import org.apache.camel.spi.NodeIdFactory;
 /**
  * Factory for generating route ids based on uris.
  * <p>
- * For direct/seda routes it returns route name (direct:start -> start).
- * For rest routes it returns its method and context path formatted as one string.
+ * For direct/seda routes it returns route name (direct:start -> start). For
+ * rest routes it returns its method and context path formatted as one string.
  * <p>
- * When id cannot be generated, falls back to other {@link NodeIdFactory} implementation.
- * If none is passed in the constructor, then {@link DefaultNodeIdFactory} is used.
+ * When id cannot be generated, falls back to other {@link NodeIdFactory}
+ * implementation. If none is passed in the constructor, then
+ * {@link DefaultNodeIdFactory} is used.
  */
 public class RouteIdFactory implements NodeIdFactory {
 
@@ -51,13 +52,13 @@ public class RouteIdFactory implements NodeIdFactory {
     @Override
     public String createId(NamedNode definition) {
         if (definition instanceof RouteDefinition) {
-            Optional<String> id = extractId((RouteDefinition) definition);
+            Optional<String> id = extractId((RouteDefinition)definition);
 
             if (id.isPresent()) {
                 return id.get();
             }
 
-            id = extractIdFromRestDefinition((RouteDefinition) definition);
+            id = extractIdFromRestDefinition((RouteDefinition)definition);
 
             if (id.isPresent()) {
                 return id.get();
@@ -65,7 +66,7 @@ public class RouteIdFactory implements NodeIdFactory {
         }
 
         if (definition instanceof VerbDefinition) {
-            Optional<String> id = extractIdFromVerb((VerbDefinition) definition);
+            Optional<String> id = extractIdFromVerb((VerbDefinition)definition);
 
             if (id.isPresent()) {
                 return id.get();
diff --git a/core/camel-core/src/main/java/org/apache/camel/impl/RouteService.java b/core/camel-core/src/main/java/org/apache/camel/impl/RouteService.java
index 996627a..81eb623 100644
--- a/core/camel-core/src/main/java/org/apache/camel/impl/RouteService.java
+++ b/core/camel-core/src/main/java/org/apache/camel/impl/RouteService.java
@@ -32,8 +32,8 @@ import org.apache.camel.model.RouteDefinitionHelper;
 import org.apache.camel.support.CamelContextHelper;
 
 /**
- * Represents the runtime objects for a given {@link RouteDefinition} so that it can be stopped independently
- * of other routes
+ * Represents the runtime objects for a given {@link RouteDefinition} so that it
+ * can be stopped independently of other routes
  */
 public class RouteService extends BaseRouteService {
 
@@ -41,7 +41,7 @@ public class RouteService extends BaseRouteService {
 
     public RouteService(Route route) {
         super(route);
-        this.routeDefinition = (RouteDefinition) route.getRouteContext().getRoute();
+        this.routeDefinition = (RouteDefinition)route.getRouteContext().getRoute();
     }
 
     public RouteDefinition getRouteDefinition() {
@@ -79,8 +79,10 @@ public class RouteService extends BaseRouteService {
         if (!routeDefinition.isContextScopedErrorHandler()) {
             return false;
         }
-        // if error handler ref is configured it may refer to a context scoped, so we need to check this first
-        // the XML DSL will configure error handlers using refs, so we need this additional test
+        // if error handler ref is configured it may refer to a context scoped,
+        // so we need to check this first
+        // the XML DSL will configure error handlers using refs, so we need this
+        // additional test
         if (routeDefinition.getErrorHandlerRef() != null) {
             ErrorHandlerFactory routeScoped = getRouteContext().getErrorHandlerFactory();
             ErrorHandlerFactory contextScoped = getCamelContext().adapt(ExtendedCamelContext.class).getErrorHandlerFactory();
@@ -91,26 +93,27 @@ public class RouteService extends BaseRouteService {
     }
 
     /**
-     * Gather all other kind of route scoped services from the given route, except error handler
+     * Gather all other kind of route scoped services from the given route,
+     * except error handler
      */
     @Override
     protected void doGetRouteScopedServices(List<Service> services) {
 
         for (ProcessorDefinition<?> output : routeDefinition.getOutputs()) {
             if (output instanceof OnExceptionDefinition) {
-                OnExceptionDefinition onExceptionDefinition = (OnExceptionDefinition) output;
+                OnExceptionDefinition onExceptionDefinition = (OnExceptionDefinition)output;
                 if (onExceptionDefinition.isRouteScoped()) {
                     Processor errorHandler = getRouteContext().getOnException(onExceptionDefinition.getId());
                     if (errorHandler instanceof Service) {
-                        services.add((Service) errorHandler);
+                        services.add((Service)errorHandler);
                     }
                 }
             } else if (output instanceof OnCompletionDefinition) {
-                OnCompletionDefinition onCompletionDefinition = (OnCompletionDefinition) output;
+                OnCompletionDefinition onCompletionDefinition = (OnCompletionDefinition)output;
                 if (onCompletionDefinition.isRouteScoped()) {
                     Processor onCompletionProcessor = getRouteContext().getOnCompletion(onCompletionDefinition.getId());
                     if (onCompletionProcessor instanceof Service) {
-                        services.add((Service) onCompletionProcessor);
+                        services.add((Service)onCompletionProcessor);
                     }
                 }
             }
diff --git a/core/camel-core/src/main/java/org/apache/camel/impl/cluster/ClusteredRouteConfiguration.java b/core/camel-core/src/main/java/org/apache/camel/impl/cluster/ClusteredRouteConfiguration.java
index 79f4140..3eff1b5 100644
--- a/core/camel-core/src/main/java/org/apache/camel/impl/cluster/ClusteredRouteConfiguration.java
+++ b/core/camel-core/src/main/java/org/apache/camel/impl/cluster/ClusteredRouteConfiguration.java
@@ -46,7 +46,7 @@ public class ClusteredRouteConfiguration implements Cloneable {
 
     public ClusteredRouteConfiguration copy() {
         try {
-            return (ClusteredRouteConfiguration) super.clone();
+            return (ClusteredRouteConfiguration)super.clone();
         } catch (CloneNotSupportedException e) {
             throw RuntimeCamelException.wrapRuntimeCamelException(e);
         }
diff --git a/core/camel-core/src/main/java/org/apache/camel/impl/cluster/ClusteredRouteController.java b/core/camel-core/src/main/java/org/apache/camel/impl/cluster/ClusteredRouteController.java
index cfc29df..f20cfd6 100644
--- a/core/camel-core/src/main/java/org/apache/camel/impl/cluster/ClusteredRouteController.java
+++ b/core/camel-core/src/main/java/org/apache/camel/impl/cluster/ClusteredRouteController.java
@@ -169,10 +169,7 @@ public class ClusteredRouteController extends DefaultRouteController {
 
     @Override
     public Collection<Route> getControlledRoutes() {
-        return this.routes.stream()
-            .map(getCamelContext()::getRoute)
-            .filter(Objects::nonNull)
-            .collect(Collectors.toList());
+        return this.routes.stream().map(getCamelContext()::getRoute).filter(Objects::nonNull).collect(Collectors.toList());
     }
 
     @Override
@@ -284,9 +281,7 @@ public class ClusteredRouteController extends DefaultRouteController {
         // Can't perform action on routes managed by this controller as they
         // are clustered and they may be part of the same view.
         if (routes.contains(routeId)) {
-            throw new UnsupportedOperationException(
-                "Operation not supported as route " + routeId + " is clustered"
-            );
+            throw new UnsupportedOperationException("Operation not supported as route " + routeId + " is clustered");
         }
     }
 
@@ -297,7 +292,7 @@ public class ClusteredRouteController extends DefaultRouteController {
     private final class PolicyFactory implements RoutePolicyFactory {
         @Override
         public RoutePolicy createRoutePolicy(CamelContext camelContext, String routeId, NamedNode node) {
-            RouteDefinition route = (RouteDefinition) node;
+            RouteDefinition route = (RouteDefinition)node;
             // All the filter have to be match to include the route in the
             // clustering set-up
             if (filters.stream().allMatch(filter -> filter.test(camelContext, routeId, route))) {
diff --git a/core/camel-core/src/main/java/org/apache/camel/impl/cluster/ClusteredRouteFilter.java b/core/camel-core/src/main/java/org/apache/camel/impl/cluster/ClusteredRouteFilter.java
index 6415cec..67387a2 100644
--- a/core/camel-core/src/main/java/org/apache/camel/impl/cluster/ClusteredRouteFilter.java
+++ b/core/camel-core/src/main/java/org/apache/camel/impl/cluster/ClusteredRouteFilter.java
@@ -24,7 +24,7 @@ public interface ClusteredRouteFilter {
     /**
      * Test if the route should be clustered or not.
      *
-     * @param camelContext  the camel context
+     * @param camelContext the camel context
      * @param routeId the route id
      * @param route the route definition
      * @return true if the route should be included
diff --git a/core/camel-core/src/main/java/org/apache/camel/impl/cluster/ClusteredRoutePolicy.java b/core/camel-core/src/main/java/org/apache/camel/impl/cluster/ClusteredRoutePolicy.java
index a5ae873..9ab8419 100644
--- a/core/camel-core/src/main/java/org/apache/camel/impl/cluster/ClusteredRoutePolicy.java
+++ b/core/camel-core/src/main/java/org/apache/camel/impl/cluster/ClusteredRoutePolicy.java
@@ -125,9 +125,7 @@ public final class ClusteredRoutePolicy extends RoutePolicySupport implements Ca
         }
 
         if (this.camelContext != null && this.camelContext != camelContext) {
-            throw new IllegalStateException(
-                "CamelContext should not be changed: current=" + this.camelContext + ", new=" + camelContext
-            );
+            throw new IllegalStateException("CamelContext should not be changed: current=" + this.camelContext + ", new=" + camelContext);
         }
 
         try {
@@ -179,17 +177,12 @@ public final class ClusteredRoutePolicy extends RoutePolicySupport implements Ca
     @Override
     public void doStart() throws Exception {
         if (clusterService == null) {
-            clusterService = ClusterServiceHelper.lookupService(camelContext, clusterServiceSelector).orElseThrow(
-                () -> new IllegalStateException("CamelCluster service not found")
-            );
+            clusterService = ClusterServiceHelper.lookupService(camelContext, clusterServiceSelector)
+                .orElseThrow(() -> new IllegalStateException("CamelCluster service not found"));
         }
 
-        log.debug("ClusteredRoutePolicy {} is using ClusterService instance {} (id={}, type={})",
-            this,
-            clusterService,
-            clusterService.getId(),
-            clusterService.getClass().getName()
-        );
+        log.debug("ClusteredRoutePolicy {} is using ClusterService instance {} (id={}, type={})", this, clusterService, clusterService.getId(),
+                  clusterService.getClass().getName());
 
         clusterView = clusterService.getView(namespace);
     }
@@ -287,10 +280,8 @@ public final class ClusteredRoutePolicy extends RoutePolicySupport implements Ca
     }
 
     private void onCamelContextStarted() {
-        log.debug("Apply cluster policy (stopped-routes='{}', started-routes='{}')",
-            stoppedRoutes.stream().map(Route::getId).collect(Collectors.joining(",")),
-            startedRoutes.stream().map(Route::getId).collect(Collectors.joining(","))
-        );
+        log.debug("Apply cluster policy (stopped-routes='{}', started-routes='{}')", stoppedRoutes.stream().map(Route::getId).collect(Collectors.joining(",")),
+                  startedRoutes.stream().map(Route::getId).collect(Collectors.joining(",")));
 
         clusterView.addEventListener(leadershipEventListener);
     }
diff --git a/core/camel-core/src/main/java/org/apache/camel/impl/cluster/ClusteredRoutePolicyFactory.java b/core/camel-core/src/main/java/org/apache/camel/impl/cluster/ClusteredRoutePolicyFactory.java
index f3c87a0..2d9e01c 100644
--- a/core/camel-core/src/main/java/org/apache/camel/impl/cluster/ClusteredRoutePolicyFactory.java
+++ b/core/camel-core/src/main/java/org/apache/camel/impl/cluster/ClusteredRoutePolicyFactory.java
@@ -60,8 +60,7 @@ public class ClusteredRoutePolicyFactory implements RoutePolicyFactory {
     public RoutePolicy createRoutePolicy(CamelContext camelContext, String routeId, NamedNode route) {
         try {
             return clusterService != null
-                ? ClusteredRoutePolicy.forNamespace(clusterService, namespace)
-                : ClusteredRoutePolicy.forNamespace(camelContext, clusterServiceSelector, namespace);
+                ? ClusteredRoutePolicy.forNamespace(clusterService, namespace) : ClusteredRoutePolicy.forNamespace(camelContext, clusterServiceSelector, namespace);
         } catch (Exception e) {
             throw new RuntimeCamelException(e);
         }
diff --git a/core/camel-core/src/main/java/org/apache/camel/model/AdviceWithDefinition.java b/core/camel-core/src/main/java/org/apache/camel/model/AdviceWithDefinition.java
index 0609a36..c3535d0 100644
--- a/core/camel-core/src/main/java/org/apache/camel/model/AdviceWithDefinition.java
+++ b/core/camel-core/src/main/java/org/apache/camel/model/AdviceWithDefinition.java
@@ -37,4 +37,4 @@ public class AdviceWithDefinition extends OutputDefinition<AdviceWithDefinition>
         return "adviceWith";
     }
 
-}
\ No newline at end of file
+}
diff --git a/core/camel-core/src/main/java/org/apache/camel/model/AggregateDefinition.java b/core/camel-core/src/main/java/org/apache/camel/model/AggregateDefinition.java
index b7a1146..938002a 100644
--- a/core/camel-core/src/main/java/org/apache/camel/model/AggregateDefinition.java
+++ b/core/camel-core/src/main/java/org/apache/camel/model/AggregateDefinition.java
@@ -53,7 +53,8 @@ import org.apache.camel.spi.Metadata;
 public class AggregateDefinition extends ProcessorDefinition<AggregateDefinition> implements OutputNode, ExecutorServiceAwareDefinition<AggregateDefinition> {
     @XmlElement(name = "correlationExpression", required = true)
     private ExpressionSubElementDefinition correlationExpression;
-    @XmlElement(name = "completionPredicate") @AsPredicate
+    @XmlElement(name = "completionPredicate")
+    @AsPredicate
     private ExpressionSubElementDefinition completionPredicate;
     @XmlElement(name = "completionTimeoutExpression")
     private ExpressionSubElementDefinition completionTimeoutExpression;
@@ -95,7 +96,8 @@ public class AggregateDefinition extends ProcessorDefinition<AggregateDefinition
     private Long completionInterval;
     @XmlAttribute
     private Long completionTimeout;
-    @XmlAttribute @Metadata(defaultValue = "1000")
+    @XmlAttribute
+    @Metadata(defaultValue = "1000")
     private Long completionTimeoutCheckerInterval = 1000L;
     @XmlAttribute
     private Boolean completionFromBatchConsumer;
@@ -128,7 +130,7 @@ public class AggregateDefinition extends ProcessorDefinition<AggregateDefinition
     public AggregateDefinition(@AsPredicate Predicate predicate) {
         this(ExpressionNodeHelper.toExpressionDefinition(predicate));
     }
-    
+
     public AggregateDefinition(Expression expression) {
         this(ExpressionNodeHelper.toExpressionDefinition(expression));
     }
@@ -150,7 +152,7 @@ public class AggregateDefinition extends ProcessorDefinition<AggregateDefinition
     public String toString() {
         return "Aggregate[" + description() + " -> " + getOutputs() + "]";
     }
-    
+
     protected String description() {
         return getExpression() != null ? getExpression().getLabel() : "";
     }
@@ -173,16 +175,20 @@ public class AggregateDefinition extends ProcessorDefinition<AggregateDefinition
         }
 
         if (exp instanceof ExpressionClause) {
-            ExpressionClause<?> clause = (ExpressionClause<?>) exp;
+            ExpressionClause<?> clause = (ExpressionClause<?>)exp;
             if (clause.getExpressionType() != null) {
-                // if using the Java DSL then the expression may have been set using the
-                // ExpressionClause which is a fancy builder to define expressions and predicates
-                // using fluent builders in the DSL. However we need afterwards a callback to
-                // reset the expression to the expression type the ExpressionClause did build for us
+                // if using the Java DSL then the expression may have been set
+                // using the
+                // ExpressionClause which is a fancy builder to define
+                // expressions and predicates
+                // using fluent builders in the DSL. However we need afterwards
+                // a callback to
+                // reset the expression to the expression type the
+                // ExpressionClause did build for us
                 ExpressionFactory model = clause.getExpressionType();
                 if (model instanceof ExpressionDefinition) {
                     correlationExpression = new ExpressionSubElementDefinition();
-                    correlationExpression.setExpressionType((ExpressionDefinition) model);
+                    correlationExpression.setExpressionType((ExpressionDefinition)model);
                 }
             }
         }
@@ -195,9 +201,11 @@ public class AggregateDefinition extends ProcessorDefinition<AggregateDefinition
     /**
      * The AggregationStrategy to use.
      * <p/>
-     * Configuring an AggregationStrategy is required, and is used to merge the incoming Exchange with the existing already merged exchanges.
-     * At first call the oldExchange parameter is null.
-     * On subsequent invocations the oldExchange contains the merged exchanges and newExchange is of course the new incoming Exchange.
+     * Configuring an AggregationStrategy is required, and is used to merge the
+     * incoming Exchange with the existing already merged exchanges. At first
+     * call the oldExchange parameter is null. On subsequent invocations the
+     * oldExchange contains the merged exchanges and newExchange is of course
+     * the new incoming Exchange.
      */
     public void setAggregationStrategy(AggregationStrategy aggregationStrategy) {
         this.aggregationStrategy = aggregationStrategy;
@@ -210,9 +218,11 @@ public class AggregateDefinition extends ProcessorDefinition<AggregateDefinition
     /**
      * A reference to lookup the AggregationStrategy in the Registry.
      * <p/>
-     * Configuring an AggregationStrategy is required, and is used to merge the incoming Exchange with the existing already merged exchanges.
-     * At first call the oldExchange parameter is null.
-     * On subsequent invocations the oldExchange contains the merged exchanges and newExchange is of course the new incoming Exchange.
+     * Configuring an AggregationStrategy is required, and is used to merge the
+     * incoming Exchange with the existing already merged exchanges. At first
+     * call the oldExchange parameter is null. On subsequent invocations the
+     * oldExchange contains the merged exchanges and newExchange is of course
+     * the new incoming Exchange.
      */
     public void setAggregationStrategyRef(String aggregationStrategyRef) {
         this.strategyRef = aggregationStrategyRef;
@@ -225,9 +235,11 @@ public class AggregateDefinition extends ProcessorDefinition<AggregateDefinition
     /**
      * A reference to lookup the AggregationStrategy in the Registry.
      * <p/>
-     * Configuring an AggregationStrategy is required, and is used to merge the incoming Exchange with the existing already merged exchanges.
-     * At first call the oldExchange parameter is null.
-     * On subsequent invocations the oldExchange contains the merged exchanges and newExchange is of course the new incoming Exchange.
+     * Configuring an AggregationStrategy is required, and is used to merge the
+     * incoming Exchange with the existing already merged exchanges. At first
+     * call the oldExchange parameter is null. On subsequent invocations the
+     * oldExchange contains the merged exchanges and newExchange is of course
+     * the new incoming Exchange.
      */
     public void setStrategyRef(String strategyRef) {
         this.strategyRef = strategyRef;
@@ -238,7 +250,8 @@ public class AggregateDefinition extends ProcessorDefinition<AggregateDefinition
     }
 
     /**
-     * This option can be used to explicit declare the method name to use, when using POJOs as the AggregationStrategy.
+     * This option can be used to explicit declare the method name to use, when
+     * using POJOs as the AggregationStrategy.
      */
     public void setAggregationStrategyMethodName(String strategyMethodName) {
         this.strategyMethodName = strategyMethodName;
@@ -253,26 +266,29 @@ public class AggregateDefinition extends ProcessorDefinition<AggregateDefinition
     }
 
     /**
-     * This option can be used to explicit declare the method name to use, when using POJOs as the AggregationStrategy.
+     * This option can be used to explicit declare the method name to use, when
+     * using POJOs as the AggregationStrategy.
      */
     public void setStrategyMethodName(String strategyMethodName) {
         this.strategyMethodName = strategyMethodName;
     }
 
     /**
-     * If this option is false then the aggregate method is not used for the very first aggregation.
-     * If this option is true then null values is used as the oldExchange (at the very first aggregation),
-     * when using POJOs as the AggregationStrategy.
+     * If this option is false then the aggregate method is not used for the
+     * very first aggregation. If this option is true then null values is used
+     * as the oldExchange (at the very first aggregation), when using POJOs as
+     * the AggregationStrategy.
      */
     public void setStrategyMethodAllowNull(Boolean strategyMethodAllowNull) {
         this.strategyMethodAllowNull = strategyMethodAllowNull;
     }
 
     /**
-     * The expression used to calculate the correlation key to use for aggregation.
-     * The Exchange which has the same correlation key is aggregated together.
-     * If the correlation key could not be evaluated an Exception is thrown.
-     * You can disable this by using the ignoreBadCorrelationKeys option.
+     * The expression used to calculate the correlation key to use for
+     * aggregation. The Exchange which has the same correlation key is
+     * aggregated together. If the correlation key could not be evaluated an
+     * Exception is thrown. You can disable this by using the
+     * ignoreBadCorrelationKeys option.
      */
     public void setCorrelationExpression(ExpressionSubElementDefinition correlationExpression) {
         this.correlationExpression = correlationExpression;
@@ -343,18 +359,22 @@ public class AggregateDefinition extends ProcessorDefinition<AggregateDefinition
     }
 
     /**
-     * Time in millis that an aggregated exchange should be inactive before its complete (timeout).
-     * This option can be set as either a fixed value or using an Expression which allows you to evaluate
-     * a timeout dynamically - will use Long as result.
-     * If both are set Camel will fallback to use the fixed value if the Expression result was null or 0.
-     * You cannot use this option together with completionInterval, only one of the two can be used.
+     * Time in millis that an aggregated exchange should be inactive before its
+     * complete (timeout). This option can be set as either a fixed value or
+     * using an Expression which allows you to evaluate a timeout dynamically -
+     * will use Long as result. If both are set Camel will fallback to use the
+     * fixed value if the Expression result was null or 0. You cannot use this
+     * option together with completionInterval, only one of the two can be used.
      * <p/>
-     * By default the timeout checker runs every second, you can use the completionTimeoutCheckerInterval option
-     * to configure how frequently to run the checker.
-     * The timeout is an approximation and there is no guarantee that the a timeout is triggered exactly after the timeout value.
-     * It is not recommended to use very low timeout values or checker intervals.
+     * By default the timeout checker runs every second, you can use the
+     * completionTimeoutCheckerInterval option to configure how frequently to
+     * run the checker. The timeout is an approximation and there is no
+     * guarantee that the a timeout is triggered exactly after the timeout
+     * value. It is not recommended to use very low timeout values or checker
+     * intervals.
      *
-     * @param completionTimeoutExpression  the timeout as an {@link Expression} which is evaluated as a {@link Long} type
+     * @param completionTimeoutExpression the timeout as an {@link Expression}
+     *            which is evaluated as a {@link Long} type
      */
     public void setCompletionTimeoutExpression(ExpressionSubElementDefinition completionTimeoutExpression) {
         this.completionTimeoutExpression = completionTimeoutExpression;
@@ -365,11 +385,15 @@ public class AggregateDefinition extends ProcessorDefinition<AggregateDefinition
     }
 
     /**
-     * Number of messages aggregated before the aggregation is complete. This option can be set as either
-     * a fixed value or using an Expression which allows you to evaluate a size dynamically - will use Integer as result.
-     * If both are set Camel will fallback to use the fixed value if the Expression result was null or 0.
+     * Number of messages aggregated before the aggregation is complete. This
+     * option can be set as either a fixed value or using an Expression which
+     * allows you to evaluate a size dynamically - will use Integer as result.
+     * If both are set Camel will fallback to use the fixed value if the
+     * Expression result was null or 0.
      *
-     * @param completionSizeExpression  the completion size as an {@link org.apache.camel.Expression} which is evaluated as a {@link Integer} type
+     * @param completionSizeExpression the completion size as an
+     *            {@link org.apache.camel.Expression} which is evaluated as a
+     *            {@link Integer} type
      */
     public void setCompletionSizeExpression(ExpressionSubElementDefinition completionSizeExpression) {
         this.completionSizeExpression = completionSizeExpression;
@@ -528,19 +552,20 @@ public class AggregateDefinition extends ProcessorDefinition<AggregateDefinition
     }
 
     /**
-     * To use a {@link org.apache.camel.processor.aggregate.AggregateController} to allow external sources to control
-     * this aggregator.
+     * To use a {@link org.apache.camel.processor.aggregate.AggregateController}
+     * to allow external sources to control this aggregator.
      */
     public void setAggregateControllerRef(String aggregateControllerRef) {
         this.aggregateControllerRef = aggregateControllerRef;
     }
 
     // Fluent API
-    //-------------------------------------------------------------------------
+    // -------------------------------------------------------------------------
 
     /**
-     * Use eager completion checking which means that the completionPredicate will use the incoming Exchange.
-     * As opposed to without eager completion checking the completionPredicate will use the aggregated Exchange.
+     * Use eager completion checking which means that the completionPredicate
+     * will use the incoming Exchange. As opposed to without eager completion
+     * checking the completionPredicate will use the aggregated Exchange.
      *
      * @return builder
      */
@@ -550,8 +575,8 @@ public class AggregateDefinition extends ProcessorDefinition<AggregateDefinition
     }
 
     /**
-     * If a correlation key cannot be successfully evaluated it will be ignored by logging a DEBUG and then just
-     * ignore the incoming Exchange.
+     * If a correlation key cannot be successfully evaluated it will be ignored
+     * by logging a DEBUG and then just ignore the incoming Exchange.
      *
      * @return builder
      */
@@ -561,12 +586,12 @@ public class AggregateDefinition extends ProcessorDefinition<AggregateDefinition
     }
 
     /**
-     * Closes a correlation key when its complete. Any <i>late</i> received exchanges which has a correlation key
-     * that has been closed, it will be defined and a ClosedCorrelationKeyException
-     * is thrown.
+     * Closes a correlation key when its complete. Any <i>late</i> received
+     * exchanges which has a correlation key that has been closed, it will be
+     * defined and a ClosedCorrelationKeyException is thrown.
      *
      * @param capacity the maximum capacity of the closed correlation key cache.
-     *                 Use <tt>0</tt> or negative value for unbounded capacity.
+     *            Use <tt>0</tt> or negative value for unbounded capacity.
      * @return builder
      */
     public AggregateDefinition closeCorrelationKeyOnCompletion(int capacity) {
@@ -577,7 +602,8 @@ public class AggregateDefinition extends ProcessorDefinition<AggregateDefinition
     /**
      * Discards the aggregated message on completion timeout.
      * <p/>
-     * This means on timeout the aggregated message is dropped and not sent out of the aggregator.
+     * This means on timeout the aggregated message is dropped and not sent out
+     * of the aggregator.
      *
      * @return builder
      */
@@ -587,8 +613,9 @@ public class AggregateDefinition extends ProcessorDefinition<AggregateDefinition
     }
 
     /**
-     * Discards the aggregated message when aggregation failed (an exception was thrown from {@link AggregationStrategy}.
-     * This means the partly aggregated message is dropped and not sent out of the aggregator.
+     * Discards the aggregated message when aggregation failed (an exception was
+     * thrown from {@link AggregationStrategy}. This means the partly aggregated
+     * message is dropped and not sent out of the aggregator.
      * <p/>
      * This option cannot be used together with completionFromBatchConsumer.
      *
@@ -600,9 +627,11 @@ public class AggregateDefinition extends ProcessorDefinition<AggregateDefinition
     }
 
     /**
-     * Enables the batch completion mode where we aggregate from a {@link org.apache.camel.BatchConsumer}
-     * and aggregate the total number of exchanges the {@link org.apache.camel.BatchConsumer} has reported
-     * as total by checking the exchange property {@link org.apache.camel.Exchange#BATCH_COMPLETE} when its complete.
+     * Enables the batch completion mode where we aggregate from a
+     * {@link org.apache.camel.BatchConsumer} and aggregate the total number of
+     * exchanges the {@link org.apache.camel.BatchConsumer} has reported as
+     * total by checking the exchange property
+     * {@link org.apache.camel.Exchange#BATCH_COMPLETE} when its complete.
      * <p/>
      * This option cannot be used together with discardOnAggregationFailure.
      *
@@ -614,10 +643,11 @@ public class AggregateDefinition extends ProcessorDefinition<AggregateDefinition
     }
 
     /**
-     * Enables completion on all previous groups when a new incoming correlation group. This can for example be used
-     * to complete groups with same correlation keys when they are in consecutive order.
-     * Notice when this is enabled then only 1 correlation group can be in progress as when a new correlation group
-     * starts, then the previous groups is forced completed.
+     * Enables completion on all previous groups when a new incoming correlation
+     * group. This can for example be used to complete groups with same
+     * correlation keys when they are in consecutive order. Notice when this is
+     * enabled then only 1 correlation group can be in progress as when a new
+     * correlation group starts, then the previous groups is forced completed.
      *
      * @return builder
      */
@@ -627,11 +657,13 @@ public class AggregateDefinition extends ProcessorDefinition<AggregateDefinition
     }
 
     /**
-     * Number of messages aggregated before the aggregation is complete. This option can be set as either
-     * a fixed value or using an Expression which allows you to evaluate a size dynamically - will use Integer as result.
-     * If both are set Camel will fallback to use the fixed value if the Expression result was null or 0.
+     * Number of messages aggregated before the aggregation is complete. This
+     * option can be set as either a fixed value or using an Expression which
+     * allows you to evaluate a size dynamically - will use Integer as result.
+     * If both are set Camel will fallback to use the fixed value if the
+     * Expression result was null or 0.
      *
-     * @param completionSize  the completion size, must be a positive number
+     * @param completionSize the completion size, must be a positive number
      * @return builder
      */
     public AggregateDefinition completionSize(int completionSize) {
@@ -640,11 +672,15 @@ public class AggregateDefinition extends ProcessorDefinition<AggregateDefinition
     }
 
     /**
-     * Number of messages aggregated before the aggregation is complete. This option can be set as either
-     * a fixed value or using an Expression which allows you to evaluate a size dynamically - will use Integer as result.
-     * If both are set Camel will fallback to use the fixed value if the Expression result was null or 0.
+     * Number of messages aggregated before the aggregation is complete. This
+     * option can be set as either a fixed value or using an Expression which
+     * allows you to evaluate a size dynamically - will use Integer as result.
+     * If both are set Camel will fallback to use the fixed value if the
+     * Expression result was null or 0.
      *
-     * @param completionSize  the completion size as an {@link org.apache.camel.Expression} which is evaluated as a {@link Integer} type
+     * @param completionSize the completion size as an
+     *            {@link org.apache.camel.Expression} which is evaluated as a
+     *            {@link Integer} type
      * @return builder
      */
     public AggregateDefinition completionSize(Expression completionSize) {
@@ -653,11 +689,13 @@ public class AggregateDefinition extends ProcessorDefinition<AggregateDefinition
     }
 
     /**
-     * A repeating period in millis by which the aggregator will complete all current aggregated exchanges.
-     * Camel has a background task which is triggered every period. You cannot use this option together
-     * with completionTimeout, only one of them can be used.
+     * A repeating period in millis by which the aggregator will complete all
+     * current aggregated exchanges. Camel has a background task which is
+     * triggered every period. You cannot use this option together with
+     * completionTimeout, only one of them can be used.
      *
-     * @param completionInterval  the interval in millis, must be a positive value
+     * @param completionInterval the interval in millis, must be a positive
+     *            value
      * @return the builder
      */
     public AggregateDefinition completionInterval(long completionInterval) {
@@ -666,18 +704,21 @@ public class AggregateDefinition extends ProcessorDefinition<AggregateDefinition
     }
 
     /**
-     * Time in millis that an aggregated exchange should be inactive before its complete (timeout).
-     * This option can be set as either a fixed value or using an Expression which allows you to evaluate
-     * a timeout dynamically - will use Long as result.
-     * If both are set Camel will fallback to use the fixed value if the Expression result was null or 0.
-     * You cannot use this option together with completionInterval, only one of the two can be used.
+     * Time in millis that an aggregated exchange should be inactive before its
+     * complete (timeout). This option can be set as either a fixed value or
+     * using an Expression which allows you to evaluate a timeout dynamically -
+     * will use Long as result. If both are set Camel will fallback to use the
+     * fixed value if the Expression result was null or 0. You cannot use this
+     * option together with completionInterval, only one of the two can be used.
      * <p/>
-     * By default the timeout checker runs every second, you can use the completionTimeoutCheckerInterval option
-     * to configure how frequently to run the checker.
-     * The timeout is an approximation and there is no guarantee that the a timeout is triggered exactly after the timeout value.
-     * It is not recommended to use very low timeout values or checker intervals.
+     * By default the timeout checker runs every second, you can use the
+     * completionTimeoutCheckerInterval option to configure how frequently to
+     * run the checker. The timeout is an approximation and there is no
+     * guarantee that the a timeout is triggered exactly after the timeout
+     * value. It is not recommended to use very low timeout values or checker
+     * intervals.
      *
-     * @param completionTimeout  the timeout in millis, must be a positive value
+     * @param completionTimeout the timeout in millis, must be a positive value
      * @return the builder
      */
     public AggregateDefinition completionTimeout(long completionTimeout) {
@@ -686,18 +727,22 @@ public class AggregateDefinition extends ProcessorDefinition<AggregateDefinition
     }
 
     /**
-     * Time in millis that an aggregated exchange should be inactive before its complete (timeout).
-     * This option can be set as either a fixed value or using an Expression which allows you to evaluate
-     * a timeout dynamically - will use Long as result.
-     * If both are set Camel will fallback to use the fixed value if the Expression result was null or 0.
-     * You cannot use this option together with completionInterval, only one of the two can be used.
+     * Time in millis that an aggregated exchange should be inactive before its
+     * complete (timeout). This option can be set as either a fixed value or
+     * using an Expression which allows you to evaluate a timeout dynamically -
+     * will use Long as result. If both are set Camel will fallback to use the
+     * fixed value if the Expression result was null or 0. You cannot use this
+     * option together with completionInterval, only one of the two can be used.
      * <p/>
-     * By default the timeout checker runs every second, you can use the completionTimeoutCheckerInterval option
-     * to configure how frequently to run the checker.
-     * The timeout is an approximation and there is no guarantee that the a timeout is triggered exactly after the timeout value.
-     * It is not recommended to use very low timeout values or checker intervals.
+     * By default the timeout checker runs every second, you can use the
+     * completionTimeoutCheckerInterval option to configure how frequently to
+     * run the checker. The timeout is an approximation and there is no
+     * guarantee that the a timeout is triggered exactly after the timeout
+     * value. It is not recommended to use very low timeout values or checker
+     * intervals.
      *
-     * @param completionTimeout  the timeout as an {@link Expression} which is evaluated as a {@link Long} type
+     * @param completionTimeout the timeout as an {@link Expression} which is
+     *            evaluated as a {@link Long} type
      * @return the builder
      */
     public AggregateDefinition completionTimeout(Expression completionTimeout) {
@@ -706,13 +751,16 @@ public class AggregateDefinition extends ProcessorDefinition<AggregateDefinition
     }
 
     /**
-     * Interval in millis that is used by the background task that checks for timeouts ({@link org.apache.camel.TimeoutMap}).
+     * Interval in millis that is used by the background task that checks for
+     * timeouts ({@link org.apache.camel.TimeoutMap}).
      * <p/>
-     * By default the timeout checker runs every second.
-     * The timeout is an approximation and there is no guarantee that the a timeout is triggered exactly after the timeout value.
-     * It is not recommended to use very low timeout values or checker intervals.
+     * By default the timeout checker runs every second. The timeout is an
+     * approximation and there is no guarantee that the a timeout is triggered
+     * exactly after the timeout value. It is not recommended to use very low
+     * timeout values or checker intervals.
      *
-     * @param completionTimeoutCheckerInterval  the interval in millis, must be a positive value
+     * @param completionTimeoutCheckerInterval the interval in millis, must be a
+     *            positive value
      * @return the builder
      */
     public AggregateDefinition completionTimeoutCheckerInterval(long completionTimeoutCheckerInterval) {
@@ -742,7 +790,7 @@ public class AggregateDefinition extends ProcessorDefinition<AggregateDefinition
     /**
      * Sets the aggregate strategy to use
      *
-     * @param aggregationStrategy  the aggregate strategy to use
+     * @param aggregationStrategy the aggregate strategy to use
      * @return the builder
      * @deprecated use {@link #aggregationStrategy(AggregationStrategy)}
      */
@@ -754,7 +802,7 @@ public class AggregateDefinition extends ProcessorDefinition<AggregateDefinition
     /**
      * Sets the aggregate strategy to use
      *
-     * @param aggregationStrategy  the aggregate strategy to use
+     * @param aggregationStrategy the aggregate strategy to use
      * @return the builder
      */
     public AggregateDefinition aggregationStrategy(AggregationStrategy aggregationStrategy) {
@@ -765,7 +813,7 @@ public class AggregateDefinition extends ProcessorDefinition<AggregateDefinition
     /**
      * Sets the aggregate strategy to use
      *
-     * @param aggregationStrategy  the aggregate strategy to use
+     * @param aggregationStrategy the aggregate strategy to use
      * @return the builder
      */
     public AggregateDefinition aggregationStrategy(Supplier<AggregationStrategy> aggregationStrategy) {
@@ -776,7 +824,8 @@ public class AggregateDefinition extends ProcessorDefinition<AggregateDefinition
     /**
      * Sets the aggregate strategy to use
      *
-     * @param aggregationStrategyRef  reference to the strategy to lookup in the registry
+     * @param aggregationStrategyRef reference to the strategy to lookup in the
+     *            registry
      * @return the builder
      */
     public AggregateDefinition aggregationStrategyRef(String aggregationStrategyRef) {
@@ -785,9 +834,10 @@ public class AggregateDefinition extends ProcessorDefinition<AggregateDefinition
     }
 
     /**
-     * Sets the method name to use when using a POJO as {@link AggregationStrategy}.
+     * Sets the method name to use when using a POJO as
+     * {@link AggregationStrategy}.
      *
-     * @param  methodName the method name to call
+     * @param methodName the method name to call
      * @return the builder
      */
     public AggregateDefinition aggregationStrategyMethodName(String methodName) {
@@ -808,9 +858,10 @@ public class AggregateDefinition extends ProcessorDefinition<AggregateDefinition
     /**
      * Sets the custom aggregate repository to use.
      * <p/>
-     * Will by default use {@link org.apache.camel.processor.aggregate.MemoryAggregationRepository}
+     * Will by default use
+     * {@link org.apache.camel.processor.aggregate.MemoryAggregationRepository}
      *
-     * @param aggregationRepository  the aggregate repository to use
+     * @param aggregationRepository the aggregate repository to use
      * @return the builder
      */
     public AggregateDefinition aggregationRepository(AggregationRepository aggregationRepository) {
@@ -821,9 +872,10 @@ public class AggregateDefinition extends ProcessorDefinition<AggregateDefinition
     /**
      * Sets the custom aggregate repository to use.
      * <p/>
-     * Will by default use {@link org.apache.camel.processor.aggregate.MemoryAggregationRepository}
+     * Will by default use
+     * {@link org.apache.camel.processor.aggregate.MemoryAggregationRepository}
      *
-     * @param aggregationRepository  the aggregate repository to use
+     * @param aggregationRepository the aggregate repository to use
      * @return the builder
      */
     public AggregateDefinition aggregationRepository(Supplier<AggregationRepository> aggregationRepository) {
@@ -834,9 +886,11 @@ public class AggregateDefinition extends ProcessorDefinition<AggregateDefinition
     /**
      * Sets the custom aggregate repository to use
      * <p/>
-     * Will by default use {@link org.apache.camel.processor.aggregate.MemoryAggregationRepository}
+     * Will by default use
+     * {@link org.apache.camel.processor.aggregate.MemoryAggregationRepository}
      *
-     * @param aggregationRepositoryRef  reference to the repository to lookup in the registry
+     * @param aggregationRepositoryRef reference to the repository to lookup in
+     *            the registry
      * @return the builder
      */
     public AggregateDefinition aggregationRepositoryRef(String aggregationRepositoryRef) {
@@ -845,8 +899,8 @@ public class AggregateDefinition extends ProcessorDefinition<AggregateDefinition
     }
 
     /**
-     * A Predicate to indicate when an aggregated exchange is complete.
-     * If this is not specified and the AggregationStrategy object implements Predicate,
+     * A Predicate to indicate when an aggregated exchange is complete. If this
+     * is not specified and the AggregationStrategy object implements Predicate,
      * the aggregationStrategy object will be used as the completionPredicate.
      */
     public AggregateDefinition completionPredicate(@AsPredicate Predicate predicate) {
@@ -856,8 +910,8 @@ public class AggregateDefinition extends ProcessorDefinition<AggregateDefinition
     }
 
     /**
-     * A Predicate to indicate when an aggregated exchange is complete.
-     * If this is not specified and the AggregationStrategy object implements Predicate,
+     * A Predicate to indicate when an aggregated exchange is complete. If this
+     * is not specified and the AggregationStrategy object implements Predicate,
      * the aggregationStrategy object will be used as the completionPredicate.
      */
     @AsPredicate
@@ -868,8 +922,8 @@ public class AggregateDefinition extends ProcessorDefinition<AggregateDefinition
     }
 
     /**
-     * A Predicate to indicate when an aggregated exchange is complete.
-     * If this is not specified and the AggregationStrategy object implements Predicate,
+     * A Predicate to indicate when an aggregated exchange is complete. If this
+     * is not specified and the AggregationStrategy object implements Predicate,
      * the aggregationStrategy object will be used as the completionPredicate.
      */
     @AsPredicate
@@ -878,8 +932,8 @@ public class AggregateDefinition extends ProcessorDefinition<AggregateDefinition
     }
 
     /**
-     * A Predicate to indicate when an aggregated exchange is complete.
-     * If this is not specified and the AggregationStrategy object implements Predicate,
+     * A Predicate to indicate when an aggregated exchange is complete. If this
+     * is not specified and the AggregationStrategy object implements Predicate,
      * the aggregationStrategy object will be used as the completionPredicate.
      */
     public AggregateDefinition completion(@AsPredicate Predicate predicate) {
@@ -887,7 +941,8 @@ public class AggregateDefinition extends ProcessorDefinition<AggregateDefinition
     }
 
     /**
-     * Indicates to complete all current aggregated exchanges when the context is stopped
+     * Indicates to complete all current aggregated exchanges when the context
+     * is stopped
      */
     public AggregateDefinition forceCompletionOnStop() {
         setForceCompletionOnStop(true);
@@ -895,14 +950,18 @@ public class AggregateDefinition extends ProcessorDefinition<AggregateDefinition
     }
 
     /**
-     * Indicates to wait to complete all current and partial (pending) aggregated exchanges when the context is stopped.
+     * Indicates to wait to complete all current and partial (pending)
+     * aggregated exchanges when the context is stopped.
      * <p/>
-     * This also means that we will wait for all pending exchanges which are stored in the aggregation repository
-     * to complete so the repository is empty before we can stop.
+     * This also means that we will wait for all pending exchanges which are
+     * stored in the aggregation repository to complete so the repository is
+     * empty before we can stop.
      * <p/>
-     * You may want to enable this when using the memory based aggregation repository that is memory based only,
-     * and do not store data on disk. When this option is enabled, then the aggregator is waiting to complete
-     * all those exchanges before its stopped, when stopping CamelContext or the route using it.
+     * You may want to enable this when using the memory based aggregation
+     * repository that is memory based only, and do not store data on disk. When
+     * this option is enabled, then the aggregator is waiting to complete all
+     * those exchanges before its stopped, when stopping CamelContext or the
+     * route using it.
      */
     public AggregateDefinition completeAllOnStop() {
         setCompleteAllOnStop(true);
@@ -911,8 +970,9 @@ public class AggregateDefinition extends ProcessorDefinition<AggregateDefinition
 
     /**
      * When aggregated are completed they are being send out of the aggregator.
-     * This option indicates whether or not Camel should use a thread pool with multiple threads for concurrency.
-     * If no custom thread pool has been specified then Camel creates a default pool with 10 concurrent threads.
+     * This option indicates whether or not Camel should use a thread pool with
+     * multiple threads for concurrency. If no custom thread pool has been
+     * specified then Camel creates a default pool with 10 concurrent threads.
      */
     public AggregateDefinition parallelProcessing() {
         setParallelProcessing(true);
@@ -921,8 +981,9 @@ public class AggregateDefinition extends ProcessorDefinition<AggregateDefinition
 
     /**
      * When aggregated are completed they are being send out of the aggregator.
-     * This option indicates whether or not Camel should use a thread pool with multiple threads for concurrency.
-     * If no custom thread pool has been specified then Camel creates a default pool with 10 concurrent threads.
+     * This option indicates whether or not Camel should use a thread pool with
+     * multiple threads for concurrency. If no custom thread pool has been
+     * specified then Camel creates a default pool with 10 concurrent threads.
      */
     public AggregateDefinition parallelProcessing(boolean parallelProcessing) {
         setParallelProcessing(parallelProcessing);
@@ -930,8 +991,9 @@ public class AggregateDefinition extends ProcessorDefinition<AggregateDefinition
     }
 
     /**
-     * Turns on using optimistic locking, which requires the aggregationRepository being used,
-     * is supporting this by implementing {@link org.apache.camel.spi.OptimisticLockingAggregationRepository}.
+     * Turns on using optimistic locking, which requires the
+     * aggregationRepository being used, is supporting this by implementing
+     * {@link org.apache.camel.spi.OptimisticLockingAggregationRepository}.
      */
     public AggregateDefinition optimisticLocking() {
         setOptimisticLocking(true);
@@ -947,8 +1009,9 @@ public class AggregateDefinition extends ProcessorDefinition<AggregateDefinition
     }
 
     /**
-     * If using parallelProcessing you can specify a custom thread pool to be used.
-     * In fact also if you are not using parallelProcessing this custom thread pool is used to send out aggregated exchanges as well.
+     * If using parallelProcessing you can specify a custom thread pool to be
+     * used. In fact also if you are not using parallelProcessing this custom
+     * thread pool is used to send out aggregated exchanges as well.
      */
     @Override
     public AggregateDefinition executorService(ExecutorService executorService) {
@@ -957,8 +1020,9 @@ public class AggregateDefinition extends ProcessorDefinition<AggregateDefinition
     }
 
     /**
-     * If using parallelProcessing you can specify a custom thread pool to be used.
-     * In fact also if you are not using parallelProcessing this custom thread pool is used to send out aggregated exchanges as well.
+     * If using parallelProcessing you can specify a custom thread pool to be
+     * used. In fact also if you are not using parallelProcessing this custom
+     * thread pool is used to send out aggregated exchanges as well.
      */
     @Override
     public AggregateDefinition executorServiceRef(String executorServiceRef) {
@@ -967,9 +1031,11 @@ public class AggregateDefinition extends ProcessorDefinition<AggregateDefinition
     }
 
     /**
-     * If using either of the completionTimeout, completionTimeoutExpression, or completionInterval options a
-     * background thread is created to check for the completion for every aggregator.
-     * Set this option to provide a custom thread pool to be used rather than creating a new thread for every aggregator.
+     * If using either of the completionTimeout, completionTimeoutExpression, or
+     * completionInterval options a background thread is created to check for
+     * the completion for every aggregator. Set this option to provide a custom
+     * thread pool to be used rather than creating a new thread for every
+     * aggregator.
      */
     public AggregateDefinition timeoutCheckerExecutorService(ScheduledExecutorService executorService) {
         setTimeoutCheckerExecutorService(executorService);
@@ -977,9 +1043,11 @@ public class AggregateDefinition extends ProcessorDefinition<AggregateDefinition
     }
 
     /**
-     * If using either of the completionTimeout, completionTimeoutExpression, or completionInterval options a
-     * background thread is created to check for the completion for every aggregator.
-     * Set this option to provide a custom thread pool to be used rather than creating a new thread for every aggregator.
+     * If using either of the completionTimeout, completionTimeoutExpression, or
+     * completionInterval options a background thread is created to check for
+     * the completion for every aggregator. Set this option to provide a custom
+     * thread pool to be used rather than creating a new thread for every
+     * aggregator.
      */
     public AggregateDefinition timeoutCheckerExecutorService(Supplier<ScheduledExecutorService> executorService) {
         setTimeoutCheckerExecutorService(executorService.get());
@@ -987,9 +1055,11 @@ public class AggregateDefinition extends ProcessorDefinition<AggregateDefinition
     }
 
     /**
-     * If using either of the completionTimeout, completionTimeoutExpression, or completionInterval options a
-     * background thread is created to check for the completion for every aggregator.
-     * Set this option to provide a custom thread pool to be used rather than creating a new thread for every aggregator.
+     * If using either of the completionTimeout, completionTimeoutExpression, or
+     * completionInterval options a background thread is created to check for
+     * the completion for every aggregator. Set this option to provide a custom
+     * thread pool to be used rather than creating a new thread for every
+     * aggregator.
      */
     public AggregateDefinition timeoutCheckerExecutorServiceRef(String executorServiceRef) {
         setTimeoutCheckerExecutorServiceRef(executorServiceRef);
@@ -997,8 +1067,8 @@ public class AggregateDefinition extends ProcessorDefinition<AggregateDefinition
     }
 
     /**
-     * To use a {@link org.apache.camel.processor.aggregate.AggregateController} to allow external sources to control
-     * this aggregator.
+     * To use a {@link org.apache.camel.processor.aggregate.AggregateController}
+     * to allow external sources to control this aggregator.
      */
     public AggregateDefinition aggregateController(AggregateController aggregateController) {
         setAggregateController(aggregateController);
@@ -1006,8 +1076,8 @@ public class AggregateDefinition extends ProcessorDefinition<AggregateDefinition
     }
 
     /**
-     * To use a {@link org.apache.camel.processor.aggregate.AggregateController} to allow external sources to control
-     * this aggregator.
+     * To use a {@link org.apache.camel.processor.aggregate.AggregateController}
+     * to allow external sources to control this aggregator.
      */
     public AggregateDefinition aggregateController(Supplier<AggregateController> aggregateController) {
         setAggregateController(aggregateController.get());
@@ -1015,12 +1085,13 @@ public class AggregateDefinition extends ProcessorDefinition<AggregateDefinition
     }
 
     // Section - Methods from ExpressionNode
-    // Needed to copy methods from ExpressionNode here so that I could specify the
+    // Needed to copy methods from ExpressionNode here so that I could specify
+    // the
     // correlation expression as optional in JAXB
 
     public ExpressionDefinition getExpression() {
         if (expression == null && correlationExpression != null) {
-            expression = correlationExpression.getExpressionType();            
+            expression = correlationExpression.getExpressionType();
         }
         return expression;
     }
diff --git a/core/camel-core/src/main/java/org/apache/camel/model/BeanDefinition.java b/core/camel-core/src/main/java/org/apache/camel/model/BeanDefinition.java
index 2fbb863..d4f317c 100644
--- a/core/camel-core/src/main/java/org/apache/camel/model/BeanDefinition.java
+++ b/core/camel-core/src/main/java/org/apache/camel/model/BeanDefinition.java
@@ -38,7 +38,8 @@ public class BeanDefinition extends NoOutputDefinition<BeanDefinition> {
     private String method;
     @XmlAttribute
     private String beanType;
-    @XmlAttribute @Metadata(defaultValue = "true")
+    @XmlAttribute
+    @Metadata(defaultValue = "true")
     private Boolean cache;
     @XmlTransient
     private Class<?> beanClass;
@@ -61,7 +62,7 @@ public class BeanDefinition extends NoOutputDefinition<BeanDefinition> {
     public String toString() {
         return "Bean[" + description() + "]";
     }
-    
+
     public String description() {
         if (ref != null) {
             String methodText = "";
@@ -79,7 +80,7 @@ public class BeanDefinition extends NoOutputDefinition<BeanDefinition> {
             return "";
         }
     }
-    
+
     @Override
     public String getShortName() {
         return "bean";
@@ -157,6 +158,6 @@ public class BeanDefinition extends NoOutputDefinition<BeanDefinition> {
     }
 
     // Fluent API
-    //-------------------------------------------------------------------------
+    // -------------------------------------------------------------------------
 
 }
diff --git a/core/camel-core/src/main/java/org/apache/camel/model/CatchDefinition.java b/core/camel-core/src/main/java/org/apache/camel/model/CatchDefinition.java
index e447aaa..baee0d0 100644
--- a/core/camel-core/src/main/java/org/apache/camel/model/CatchDefinition.java
+++ b/core/camel-core/src/main/java/org/apache/camel/model/CatchDefinition.java
@@ -40,7 +40,8 @@ import org.apache.camel.spi.Metadata;
 public class CatchDefinition extends ProcessorDefinition<CatchDefinition> implements OutputNode {
     @XmlElement(name = "exception")
     private List<String> exceptions = new ArrayList<>();
-    @XmlElement(name = "onWhen") @AsPredicate
+    @XmlElement(name = "onWhen")
+    @AsPredicate
     private WhenDefinition onWhen;
     @XmlElementRef
     private List<ProcessorDefinition<?>> outputs = new ArrayList<>();
@@ -90,13 +91,13 @@ public class CatchDefinition extends ProcessorDefinition<CatchDefinition> implem
     public void setExceptionClasses(List<Class<? extends Throwable>> exceptionClasses) {
         this.exceptionClasses = exceptionClasses;
     }
-    
+
     // Fluent API
-    //-------------------------------------------------------------------------
+    // -------------------------------------------------------------------------
     /**
      * The exceptions to catch.
      *
-     * @param exceptionClasses  a list of the exception classes
+     * @param exceptionClasses a list of the exception classes
      * @return the builder
      * @deprecated use {@link #exception(Class[])}
      */
@@ -109,7 +110,7 @@ public class CatchDefinition extends ProcessorDefinition<CatchDefinition> implem
     /**
      * The exception(s) to catch.
      *
-     * @param exceptions  one or more exceptions
+     * @param exceptions one or more exceptions
      * @return the builder
      */
     public CatchDefinition exception(Class<? extends Throwable>... exceptions) {
@@ -121,14 +122,15 @@ public class CatchDefinition extends ProcessorDefinition<CatchDefinition> implem
         }
         return this;
     }
-    
+
     /**
-     * Sets an additional predicate that should be true before the onCatch is triggered.
+     * Sets an additional predicate that should be true before the onCatch is
+     * triggered.
      * <p/>
-     * To be used for fine grained controlling whether a thrown exception should be intercepted
-     * by this exception type or not.
+     * To be used for fine grained controlling whether a thrown exception should
+     * be intercepted by this exception type or not.
      *
-     * @param predicate  predicate that determines true or false
+     * @param predicate predicate that determines true or false
      * @return the builder
      */
     public CatchDefinition onWhen(@AsPredicate Predicate predicate) {
@@ -139,7 +141,7 @@ public class CatchDefinition extends ProcessorDefinition<CatchDefinition> implem
     /**
      * Sets the exception class that the CatchType want to catch
      *
-     * @param exception  the exception of class
+     * @param exception the exception of class
      * @return the builder
      * @deprecated use {@link #exception(Class[])}
      */
diff --git a/core/camel-core/src/main/java/org/apache/camel/model/ChoiceDefinition.java b/core/camel-core/src/main/java/org/apache/camel/model/ChoiceDefinition.java
index e1c4a0b..c3a7333 100644
--- a/core/camel-core/src/main/java/org/apache/camel/model/ChoiceDefinition.java
+++ b/core/camel-core/src/main/java/org/apache/camel/model/ChoiceDefinition.java
@@ -42,7 +42,8 @@ import org.apache.camel.util.ObjectHelper;
 @XmlRootElement(name = "choice")
 @XmlAccessorType(XmlAccessType.FIELD)
 public class ChoiceDefinition extends ProcessorDefinition<ChoiceDefinition> implements OutputNode {
-    @XmlElementRef @AsPredicate
+    @XmlElementRef
+    @AsPredicate
     private List<WhenDefinition> whenClauses = new ArrayList<>();
     @XmlElement
     private OtherwiseDefinition otherwise;
@@ -51,17 +52,18 @@ public class ChoiceDefinition extends ProcessorDefinition<ChoiceDefinition> impl
 
     public ChoiceDefinition() {
     }
-    
+
     @Override
     public List<ProcessorDefinition<?>> getOutputs() {
-        // wrap the outputs into a list where we can on the inside control the when/otherwise
+        // wrap the outputs into a list where we can on the inside control the
+        // when/otherwise
         // but make it appear as a list on the outside
         return new AbstractList<ProcessorDefinition<?>>() {
 
             public ProcessorDefinition<?> get(int index) {
                 if (index < whenClauses.size()) {
                     return whenClauses.get(index);
-                } 
+                }
                 if (index == whenClauses.size()) {
                     return otherwise;
                 }
@@ -75,8 +77,7 @@ public class ChoiceDefinition extends ProcessorDefinition<ChoiceDefinition> impl
                     otherwise = (OtherwiseDefinition)def;
                     return true;
                 }
-                throw new IllegalArgumentException("Expected either a WhenDefinition or OtherwiseDefinition but was "
-                        + ObjectHelper.classCanonicalName(def));
+                throw new IllegalArgumentException("Expected either a WhenDefinition or OtherwiseDefinition but was " + ObjectHelper.classCanonicalName(def));
             }
 
             public int size() {
@@ -93,8 +94,7 @@ public class ChoiceDefinition extends ProcessorDefinition<ChoiceDefinition> impl
                     if (element instanceof WhenDefinition) {
                         return whenClauses.set(index, (WhenDefinition)element);
                     }
-                    throw new IllegalArgumentException("Expected WhenDefinition but was "
-                            + ObjectHelper.classCanonicalName(element));
+                    throw new IllegalArgumentException("Expected WhenDefinition but was " + ObjectHelper.classCanonicalName(element));
                 } else if (index == whenClauses.size()) {
                     ProcessorDefinition<?> old = otherwise;
                     otherwise = (OtherwiseDefinition)element;
@@ -125,11 +125,12 @@ public class ChoiceDefinition extends ProcessorDefinition<ChoiceDefinition> impl
     public void addOutput(ProcessorDefinition<?> output) {
         if (onlyWhenOrOtherwise) {
             if (output instanceof WhenDefinition || output instanceof OtherwiseDefinition) {
-                // okay we are adding a when or otherwise so allow any kind of output after this again
+                // okay we are adding a when or otherwise so allow any kind of
+                // output after this again
                 onlyWhenOrOtherwise = false;
             } else {
                 throw new IllegalArgumentException("A new choice clause should start with a when() or otherwise(). "
-                    + "If you intend to end the entire choice and are using endChoice() then use end() instead.");
+                                                   + "If you intend to end the entire choice and are using endChoice() then use end() instead.");
             }
         }
         super.addOutput(output);
@@ -174,14 +175,14 @@ public class ChoiceDefinition extends ProcessorDefinition<ChoiceDefinition> impl
         addClause(new WhenDefinition(clause));
         return clause;
     }
-    
+
     private void addClause(ProcessorDefinition<?> when) {
         onlyWhenOrOtherwise = true;
         popBlock();
         addOutput(when);
         pushBlock(when);
     }
-    
+
     /**
      * Sets the otherwise node
      *
@@ -195,7 +196,8 @@ public class ChoiceDefinition extends ProcessorDefinition<ChoiceDefinition> impl
 
     @Override
     public void setId(String value) {
-        // when setting id, we should set it on the fine grained element, if possible
+        // when setting id, we should set it on the fine grained element, if
+        // possible
         if (otherwise != null) {
             otherwise.setId(value);
         } else if (!getWhenClauses().isEmpty()) {
@@ -256,15 +258,19 @@ public class ChoiceDefinition extends ProcessorDefinition<ChoiceDefinition> impl
             }
             Predicate pre = exp.getPredicate();
             if (pre instanceof ExpressionClause) {
-                ExpressionClause<?> clause = (ExpressionClause<?>) pre;
+                ExpressionClause<?> clause = (ExpressionClause<?>)pre;
                 if (clause.getExpressionType() != null) {
-                    // if using the Java DSL then the expression may have been set using the
-                    // ExpressionClause which is a fancy builder to define expressions and predicates
-                    // using fluent builders in the DSL. However we need afterwards a callback to
-                    // reset the expression to the expression type the ExpressionClause did build for us
+                    // if using the Java DSL then the expression may have been
+                    // set using the
+                    // ExpressionClause which is a fancy builder to define
+                    // expressions and predicates
+                    // using fluent builders in the DSL. However we need
+                    // afterwards a callback to
+                    // reset the expression to the expression type the
+                    // ExpressionClause did build for us
                     ExpressionFactory model = clause.getExpressionType();
                     if (model instanceof ExpressionDefinition) {
-                        when.setExpression((ExpressionDefinition) model);
+                        when.setExpression((ExpressionDefinition)model);
                     }
                 }
             }
diff --git a/core/camel-core/src/main/java/org/apache/camel/model/ClaimCheckDefinition.java b/core/camel-core/src/main/java/org/apache/camel/model/ClaimCheckDefinition.java
index 09674d4..cb2418e 100644
--- a/core/camel-core/src/main/java/org/apache/camel/model/ClaimCheckDefinition.java
+++ b/core/camel-core/src/main/java/org/apache/camel/model/ClaimCheckDefinition.java
@@ -27,8 +27,9 @@ import org.apache.camel.AggregationStrategy;
 import org.apache.camel.spi.Metadata;
 
 /**
- * The Claim Check EIP allows you to replace message content with a claim check (a unique key),
- * which can be used to retrieve the message content at a later time.
+ * The Claim Check EIP allows you to replace message content with a claim check
+ * (a unique key), which can be used to retrieve the message content at a later
+ * time.
  */
 @Metadata(label = "eip,routing")
 @XmlRootElement(name = "claimCheck")
@@ -41,9 +42,11 @@ public class ClaimCheckDefinition extends NoOutputDefinition<ClaimCheckDefinitio
     private String key;
     @XmlAttribute
     private String filter;
-    @XmlAttribute(name = "strategyRef") @Metadata(label = "advanced")
+    @XmlAttribute(name = "strategyRef")
+    @Metadata(label = "advanced")
     private String aggregationStrategyRef;
-    @XmlAttribute(name = "strategyMethodName") @Metadata(label = "advanced")
+    @XmlAttribute(name = "strategyMethodName")
+    @Metadata(label = "advanced")
     private String aggregationStrategyMethodName;
     @XmlTransient
     private AggregationStrategy aggregationStrategy;
@@ -71,17 +74,18 @@ public class ClaimCheckDefinition extends NoOutputDefinition<ClaimCheckDefinitio
     }
 
     // Fluent API
-    //-------------------------------------------------------------------------
+    // -------------------------------------------------------------------------
 
     /**
-     * The claim check operation to use.
-     * The following operations is supported:
+     * The claim check operation to use. The following operations is supported:
      * <ul>
-     *     <li>Get</li> - Gets (does not remove) the claim check by the given key.
-     *     <li>GetAndRemove</li> - Gets and remove the claim check by the given key.
-     *     <li>Set</li> - Sets a new (will override if key already exists) claim check with the given key.
-     *     <li>Push</li> - Sets a new claim check on the stack (does not use key).
-     *     <li>Pop</li> - Gets the latest claim check from the stack (does not use key).
+     * <li>Get</li> - Gets (does not remove) the claim check by the given key.
+     * <li>GetAndRemove</li> - Gets and remove the claim check by the given key.
+     * <li>Set</li> - Sets a new (will override if key already exists) claim
+     * check with the given key.
+     * <li>Push</li> - Sets a new claim check on the stack (does not use key).
+     * <li>Pop</li> - Gets the latest claim check from the stack (does not use
+     * key).
      * </ul>
      */
     public ClaimCheckDefinition operation(ClaimCheckOperation operation) {
@@ -90,7 +94,8 @@ public class ClaimCheckDefinition extends NoOutputDefinition<ClaimCheckDefinitio
     }
 
     /**
-     * To use a specific key for claim check id (for dynamic keys use simple language syntax as the key).
+     * To use a specific key for claim check id (for dynamic keys use simple
+     * language syntax as the key).
      */
     public ClaimCheckDefinition key(String key) {
         setKey(key);
@@ -98,34 +103,36 @@ public class ClaimCheckDefinition extends NoOutputDefinition<ClaimCheckDefinitio
     }
 
     /**
-     * Specified a filter to control what data gets merging data back from the claim check repository.
-     *
-     * The following syntax is supported:
+     * Specified a filter to control what data gets merging data back from the
+     * claim check repository. The following syntax is supported:
      * <ul>
-     *     <li>body</li> - to aggregate the message body
-     *     <li>attachments</li> - to aggregate all the message attachments
-     *     <li>headers</li> - to aggregate all the message headers
-     *     <li>header:pattern</li> - to aggregate all the message headers that matches the pattern.
+     * <li>body</li> - to aggregate the message body
+     * <li>attachments</li> - to aggregate all the message attachments
+     * <li>headers</li> - to aggregate all the message headers
+     * <li>header:pattern</li> - to aggregate all the message headers that
+     * matches the pattern.
      * </ul>
      * The pattern uses the following rules are applied in this order:
      * <ul>
      * <li>exact match, returns true</li>
-     * <li>wildcard match (pattern ends with a * and the name starts with the pattern), returns true</li>
+     * <li>wildcard match (pattern ends with a * and the name starts with the
+     * pattern), returns true</li>
      * <li>regular expression match, returns true</li>
      * <li>otherwise returns false</li>
      * </ul>
      * <p>
-     * You can specify multiple rules separated by comma. For example to include the message body and all headers starting with foo
-     * <tt>body,header:foo*</tt>.
-     * The syntax supports the following prefixes which can be used to specify include,exclude, or remove
+     * You can specify multiple rules separated by comma. For example to include
+     * the message body and all headers starting with foo
+     * <tt>body,header:foo*</tt>. The syntax supports the following prefixes
+     * which can be used to specify include,exclude, or remove
      * <ul>
-     *     <li>+</li> - to include (which is the default mode)
-     *     <li>-</li> - to exclude (exclude takes precedence over include)
-     *     <li>--</li> - to remove (remove takes precedence)
+     * <li>+</li> - to include (which is the default mode)
+     * <li>-</li> - to exclude (exclude takes precedence over include)
+     * <li>--</li> - to remove (remove takes precedence)
      * </ul>
-     * For example to exclude a header name foo, and remove all headers starting with bar
-     * <tt>-header:foo,--headers:bar*</tt>
-     * Note you cannot have both include and exclude <tt>header:pattern</tt> at the same time.
+     * For example to exclude a header name foo, and remove all headers starting
+     * with bar <tt>-header:foo,--headers:bar*</tt> Note you cannot have both
+     * include and exclude <tt>header:pattern</tt> at the same time.
      */
     public ClaimCheckDefinition filter(String filter) {
         setFilter(filter);
@@ -133,8 +140,9 @@ public class ClaimCheckDefinition extends NoOutputDefinition<ClaimCheckDefinitio
     }
 
     /**
-     * To use a custom {@link AggregationStrategy} instead of the default implementation.
-     * Notice you cannot use both custom aggregation strategy and configure data at the same time.
+     * To use a custom {@link AggregationStrategy} instead of the default
+     * implementation. Notice you cannot use both custom aggregation strategy
+     * and configure data at the same time.
      */
     public ClaimCheckDefinition aggregationStrategy(AggregationStrategy aggregationStrategy) {
         setAggregationStrategy(aggregationStrategy);
@@ -142,8 +150,9 @@ public class ClaimCheckDefinition extends NoOutputDefinition<ClaimCheckDefinitio
     }
 
     /**
-     * To use a custom {@link AggregationStrategy} instead of the default implementation.
-     * Notice you cannot use both custom aggregation strategy and configure data at the same time.
+     * To use a custom {@link AggregationStrategy} instead of the default
+     * implementation. Notice you cannot use both custom aggregation strategy
+     * and configure data at the same time.
      */
     public ClaimCheckDefinition aggregationStrategy(Supplier<AggregationStrategy> aggregationStrategy) {
         setAggregationStrategy(aggregationStrategy.get());
@@ -151,8 +160,9 @@ public class ClaimCheckDefinition extends NoOutputDefinition<ClaimCheckDefinitio
     }
 
     /**
-     * To use a custom {@link AggregationStrategy} instead of the default implementation.
-     * Notice you cannot use both custom aggregation strategy and configure data at the same time.
+     * To use a custom {@link AggregationStrategy} instead of the default
+     * implementation. Notice you cannot use both custom aggregation strategy
+     * and configure data at the same time.
      */
     public ClaimCheckDefinition aggregationStrategyRef(String aggregationStrategyRef) {
         setAggregationStrategyRef(aggregationStrategyRef);
@@ -160,7 +170,8 @@ public class ClaimCheckDefinition extends NoOutputDefinition<ClaimCheckDefinitio
     }
 
     /**
-     * This option can be used to explicit declare the method name to use, when using POJOs as the AggregationStrategy.
+     * This option can be used to explicit declare the method name to use, when
+     * using POJOs as the AggregationStrategy.
      */
     public ClaimCheckDefinition aggregationStrategyMethodName(String aggregationStrategyMethodName) {
         setAggregationStrategyMethodName(aggregationStrategyMethodName);
@@ -168,7 +179,7 @@ public class ClaimCheckDefinition extends NoOutputDefinition<ClaimCheckDefinitio
     }
 
     // Properties
-    //-------------------------------------------------------------------------
+    // -------------------------------------------------------------------------
 
     public String getKey() {
         return key;
diff --git a/core/camel-core/src/main/java/org/apache/camel/model/Constants.java b/core/camel-core/src/main/java/org/apache/camel/model/Constants.java
index 3694390..e2286cf 100644
--- a/core/camel-core/src/main/java/org/apache/camel/model/Constants.java
+++ b/core/camel-core/src/main/java/org/apache/camel/model/Constants.java
@@ -21,17 +21,9 @@ package org.apache.camel.model;
  */
 public final class Constants {
 
-    public static final String JAXB_CONTEXT_PACKAGES = ""
-        + "org.apache.camel:"
-        + "org.apache.camel.model:"
-        + "org.apache.camel.model.cloud:"
-        + "org.apache.camel.model.config:"
-        + "org.apache.camel.model.dataformat:"
-        + "org.apache.camel.model.language:"
-        + "org.apache.camel.model.loadbalancer:"
-        + "org.apache.camel.model.rest:"
-        + "org.apache.camel.model.transformer:"
-        + "org.apache.camel.model.validator";
+    public static final String JAXB_CONTEXT_PACKAGES = "" + "org.apache.camel:" + "org.apache.camel.model:" + "org.apache.camel.model.cloud:" + "org.apache.camel.model.config:"
+                                                       + "org.apache.camel.model.dataformat:" + "org.apache.camel.model.language:" + "org.apache.camel.model.loadbalancer:"
+                                                       + "org.apache.camel.model.rest:" + "org.apache.camel.model.transformer:" + "org.apache.camel.model.validator";
 
     public static final String PLACEHOLDER_QNAME = "http://camel.apache.org/schema/placeholder";
 
diff --git a/core/camel-core/src/main/java/org/apache/camel/model/ContextScanDefinition.java b/core/camel-core/src/main/java/org/apache/camel/model/ContextScanDefinition.java
index 1aae742..0c7357f 100644
--- a/core/camel-core/src/main/java/org/apache/camel/model/ContextScanDefinition.java
+++ b/core/camel-core/src/main/java/org/apache/camel/model/ContextScanDefinition.java
@@ -28,7 +28,8 @@ import javax.xml.bind.annotation.XmlRootElement;
 import org.apache.camel.spi.Metadata;
 
 /**
- * Scans for Java {@link org.apache.camel.builder.RouteBuilder} instances in the context {@link org.apache.camel.spi.Registry}.
+ * Scans for Java {@link org.apache.camel.builder.RouteBuilder} instances in the
+ * context {@link org.apache.camel.spi.Registry}.
  */
 @Metadata(label = "configuration")
 @XmlRootElement(name = "contextScan")
@@ -83,4 +84,4 @@ public class ContextScanDefinition {
         excludes.clear();
         includes.clear();
     }
-}
\ No newline at end of file
+}
diff --git a/core/camel-core/src/main/java/org/apache/camel/model/ConvertBodyDefinition.java b/core/camel-core/src/main/java/org/apache/camel/model/ConvertBodyDefinition.java
index 3dbc876..e0a387f 100644
--- a/core/camel-core/src/main/java/org/apache/camel/model/ConvertBodyDefinition.java
+++ b/core/camel-core/src/main/java/org/apache/camel/model/ConvertBodyDefinition.java
@@ -57,7 +57,7 @@ public class ConvertBodyDefinition extends NoOutputDefinition<ConvertBodyDefinit
     }
 
     @Override
-    public String toString() {        
+    public String toString() {
         return "ConvertBodyTo[" + getType() + "]";
     }
 
@@ -70,7 +70,7 @@ public class ConvertBodyDefinition extends NoOutputDefinition<ConvertBodyDefinit
     public String getLabel() {
         return "convertBodyTo[" + getType() + "]";
     }
-    
+
     public String getType() {
         return type;
     }
diff --git a/core/camel-core/src/main/java/org/apache/camel/model/DataFormatDefinition.java b/core/camel-core/src/main/java/org/apache/camel/model/DataFormatDefinition.java
index 6e14717..4b1d888 100644
--- a/core/camel-core/src/main/java/org/apache/camel/model/DataFormatDefinition.java
+++ b/core/camel-core/src/main/java/org/apache/camel/model/DataFormatDefinition.java
@@ -91,11 +91,11 @@ public class DataFormatDefinition extends IdentifiedType implements OtherAttribu
     }
 
     /**
-     * Whether the data format should set the <tt>Content-Type</tt> header with the type from the data format if the
-     * data format is capable of doing so.
+     * Whether the data format should set the <tt>Content-Type</tt> header with
+     * the type from the data format if the data format is capable of doing so.
      * <p/>
-     * For example <tt>application/xml</tt> for data formats marshalling to XML, or <tt>application/json</tt>
-     * for data formats marshalling to JSon etc.
+     * For example <tt>application/xml</tt> for data formats marshalling to XML,
+     * or <tt>application/json</tt> for data formats marshalling to JSon etc.
      */
     public void setContentTypeHeader(Boolean contentTypeHeader) {
         this.contentTypeHeader = contentTypeHeader;
@@ -110,4 +110,3 @@ public class DataFormatDefinition extends IdentifiedType implements OtherAttribu
     }
 
 }
-
diff --git a/core/camel-core/src/main/java/org/apache/camel/model/DefinitionPropertyPlaceholderConfigurer.java b/core/camel-core/src/main/java/org/apache/camel/model/DefinitionPropertyPlaceholderConfigurer.java
index 65ec401..4b75c58 100644
--- a/core/camel-core/src/main/java/org/apache/camel/model/DefinitionPropertyPlaceholderConfigurer.java
+++ b/core/camel-core/src/main/java/org/apache/camel/model/DefinitionPropertyPlaceholderConfigurer.java
@@ -30,8 +30,9 @@ import org.apache.camel.spi.PropertyPlaceholderConfigurer;
 public interface DefinitionPropertyPlaceholderConfigurer extends PropertyPlaceholderConfigurer {
 
     /**
-     * Gets the options on the model definition which supports property placeholders and can be resolved.
-     * This will be all the string based options.
+     * Gets the options on the model definition which supports property
+     * placeholders and can be resolved. This will be all the string based
+     * options.
      *
      * @return key/values of options
      */
@@ -41,8 +42,8 @@ public interface DefinitionPropertyPlaceholderConfigurer extends PropertyPlaceho
     }
 
     /**
-     * To update an existing property using the function with the key/value and returning the changed value
-     * This will be all the string based options.
+     * To update an existing property using the function with the key/value and
+     * returning the changed value This will be all the string based options.
      */
     default Map<String, Consumer<String>> getWritePropertyPlaceholderOptions(CamelContext camelContext) {
         PropertyPlaceholderConfigurer aware = DefinitionPropertiesPlaceholderProviderHelper.provider(this).orElse(null);
diff --git a/core/camel-core/src/main/java/org/apache/camel/model/DelayDefinition.java b/core/camel-core/src/main/java/org/apache/camel/model/DelayDefinition.java
index a0ea5ca..066f81e 100644
--- a/core/camel-core/src/main/java/org/apache/camel/model/DelayDefinition.java
+++ b/core/camel-core/src/main/java/org/apache/camel/model/DelayDefinition.java
@@ -41,9 +41,11 @@ public class DelayDefinition extends ExpressionNode implements ExecutorServiceAw
     private ExecutorService executorService;
     @XmlAttribute
     private String executorServiceRef;
-    @XmlAttribute @Metadata(defaultValue = "true")
+    @XmlAttribute
+    @Metadata(defaultValue = "true")
     private Boolean asyncDelayed;
-    @XmlAttribute @Metadata(defaultValue = "true")
+    @XmlAttribute
+    @Metadata(defaultValue = "true")
     private Boolean callerRunsWhenRejected;
 
     public DelayDefinition() {
@@ -68,7 +70,7 @@ public class DelayDefinition extends ExpressionNode implements ExecutorServiceAw
         return "Delay[" + getExpression() + " -> " + getOutputs() + "]";
     }
 
-   // Fluent API
+    // Fluent API
     // -------------------------------------------------------------------------
 
     /**
@@ -83,7 +85,8 @@ public class DelayDefinition extends ExpressionNode implements ExecutorServiceAw
     }
 
     /**
-     * Whether or not the caller should run the task when it was rejected by the thread pool.
+     * Whether or not the caller should run the task when it was rejected by the
+     * thread pool.
      * <p/>
      * Is by default <tt>true</tt>
      *
@@ -96,7 +99,8 @@ public class DelayDefinition extends ExpressionNode implements ExecutorServiceAw
     }
 
     /**
-     * Enables asynchronous delay which means the thread will <b>not</b> block while delaying.
+     * Enables asynchronous delay which means the thread will <b>not</b> block
+     * while delaying.
      */
     public DelayDefinition asyncDelayed() {
         setAsyncDelayed(true);
@@ -104,7 +108,8 @@ public class DelayDefinition extends ExpressionNode implements ExecutorServiceAw
     }
 
     /**
-     * Enables asynchronous delay which means the thread will <b>not</b> block while delaying.
+     * Enables asynchronous delay which means the thread will <b>not</b> block
+     * while delaying.
      */
     public DelayDefinition syncDelayed() {
         setAsyncDelayed(false);
diff --git a/core/camel-core/src/main/java/org/apache/camel/model/DynamicRouterDefinition.java b/core/camel-core/src/main/java/org/apache/camel/model/DynamicRouterDefinition.java
index 3e243e1..c15df79 100644
--- a/core/camel-core/src/main/java/org/apache/camel/model/DynamicRouterDefinition.java
+++ b/core/camel-core/src/main/java/org/apache/camel/model/DynamicRouterDefinition.java
@@ -38,12 +38,13 @@ public class DynamicRouterDefinition<Type extends ProcessorDefinition<Type>> ext
 
     public static final String DEFAULT_DELIMITER = ",";
 
-    @XmlAttribute @Metadata(defaultValue = ",")
+    @XmlAttribute
+    @Metadata(defaultValue = ",")
     private String uriDelimiter;
     @XmlAttribute
     private Boolean ignoreInvalidEndpoints;
     @XmlAttribute
-    private Integer cacheSize; 
+    private Integer cacheSize;
 
     public DynamicRouterDefinition() {
     }
@@ -56,7 +57,7 @@ public class DynamicRouterDefinition<Type extends ProcessorDefinition<Type>> ext
     public String toString() {
         return "DynamicRouter[" + getExpression() + "]";
     }
-    
+
     @Override
     public String getShortName() {
         return "dynamicRouter";
@@ -73,10 +74,12 @@ public class DynamicRouterDefinition<Type extends ProcessorDefinition<Type>> ext
     }
 
     /**
-     * Expression to call that returns the endpoint(s) to route to in the dynamic routing.
+     * Expression to call that returns the endpoint(s) to route to in the
+     * dynamic routing.
      * <p/>
-     * <b>Important:</b> The expression will be called in a while loop fashion, until the expression returns <tt>null</tt>
-     * which means the dynamic router is finished.
+     * <b>Important:</b> The expression will be called in a while loop fashion,
+     * until the expression returns <tt>null</tt> which means the dynamic router
+     * is finished.
      */
     @Override
     public void setExpression(ExpressionDefinition expression) {
@@ -115,11 +118,12 @@ public class DynamicRouterDefinition<Type extends ProcessorDefinition<Type>> ext
     @SuppressWarnings("unchecked")
     public Type end() {
         // allow end() to return to previous type so you can continue in the DSL
-        return (Type) super.end();
+        return (Type)super.end();
     }
 
     /**
-     * Ignore the invalidate endpoint exception when try to create a producer with that endpoint
+     * Ignore the invalidate endpoint exception when try to create a producer
+     * with that endpoint
      *
      * @return the builder
      */
@@ -138,12 +142,14 @@ public class DynamicRouterDefinition<Type extends ProcessorDefinition<Type>> ext
         setUriDelimiter(uriDelimiter);
         return this;
     }
-    
+
     /**
-     * Sets the maximum size used by the {@link org.apache.camel.spi.ProducerCache} which is used
-     * to cache and reuse producers when using this dynamic router, when uris are reused.
+     * Sets the maximum size used by the
+     * {@link org.apache.camel.spi.ProducerCache} which is used to cache and
+     * reuse producers when using this dynamic router, when uris are reused.
      *
-     * @param cacheSize  the cache size, use <tt>0</tt> for default cache size, or <tt>-1</tt> to turn cache off.
+     * @param cacheSize the cache size, use <tt>0</tt> for default cache size,
+     *            or <tt>-1</tt> to turn cache off.
      * @return the builder
      */
     public DynamicRouterDefinition<Type> cacheSize(int cacheSize) {
diff --git a/core/camel-core/src/main/java/org/apache/camel/model/EndpointRequiredDefinition.java b/core/camel-core/src/main/java/org/apache/camel/model/EndpointRequiredDefinition.java
index 36d4eb7d51..561f7cc 100644
--- a/core/camel-core/src/main/java/org/apache/camel/model/EndpointRequiredDefinition.java
+++ b/core/camel-core/src/main/java/org/apache/camel/model/EndpointRequiredDefinition.java
@@ -17,8 +17,9 @@
 package org.apache.camel.model;
 
 /**
- * A {@link org.apache.camel.model.ProcessorDefinition} that requires to be configured with an {@link org.apache.camel.Endpoint} such
- * as {@link org.apache.camel.model.SendDefinition}.
+ * A {@link org.apache.camel.model.ProcessorDefinition} that requires to be
+ * configured with an {@link org.apache.camel.Endpoint} such as
+ * {@link org.apache.camel.model.SendDefinition}.
  */
 public interface EndpointRequiredDefinition {
 
diff --git a/core/camel-core/src/main/java/org/apache/camel/model/EnrichDefinition.java b/core/camel-core/src/main/java/org/apache/camel/model/EnrichDefinition.java
index 156ffd1..5798a69 100644
--- a/core/camel-core/src/main/java/org/apache/camel/model/EnrichDefinition.java
+++ b/core/camel-core/src/main/java/org/apache/camel/model/EnrichDefinition.java
@@ -60,12 +60,12 @@ public class EnrichDefinition extends ExpressionNode {
     public EnrichDefinition(AggregationStrategy aggregationStrategy) {
         this.aggregationStrategy = aggregationStrategy;
     }
-    
+
     @Override
     public String toString() {
         return "Enrich[" + getExpression() + "]";
     }
-    
+
     @Override
     public String getShortName() {
         return "enrich";
@@ -80,8 +80,9 @@ public class EnrichDefinition extends ExpressionNode {
     // -------------------------------------------------------------------------
 
     /**
-     * Sets the AggregationStrategy to be used to merge the reply from the external service, into a single outgoing message.
-     * By default Camel will use the reply from the external service as outgoing message.
+     * Sets the AggregationStrategy to be used to merge the reply from the
+     * external service, into a single outgoing message. By default Camel will
+     * use the reply from the external service as outgoing message.
      */
     public EnrichDefinition aggregationStrategy(AggregationStrategy aggregationStrategy) {
         setAggregationStrategy(aggregationStrategy);
@@ -89,8 +90,9 @@ public class EnrichDefinition extends ExpressionNode {
     }
 
     /**
-     * Sets the AggregationStrategy to be used to merge the reply from the external service, into a single outgoing message.
-     * By default Camel will use the reply from the external service as outgoing message.
+     * Sets the AggregationStrategy to be used to merge the reply from the
+     * external service, into a single outgoing message. By default Camel will
+     * use the reply from the external service as outgoing message.
      */
     public EnrichDefinition aggregationStrategy(Supplier<AggregationStrategy> aggregationStrategy) {
         setAggregationStrategy(aggregationStrategy.get());
@@ -98,8 +100,9 @@ public class EnrichDefinition extends ExpressionNode {
     }
 
     /**
-     * Refers to an AggregationStrategy to be used to merge the reply from the external service, into a single outgoing message.
-     * By default Camel will use the reply from the external service as outgoing message.
+     * Refers to an AggregationStrategy to be used to merge the reply from the
+     * external service, into a single outgoing message. By default Camel will
+     * use the reply from the external service as outgoing message.
      */
     public EnrichDefinition aggregationStrategyRef(String aggregationStrategyRef) {
         setAggregationStrategyRef(aggregationStrategyRef);
@@ -107,7 +110,8 @@ public class EnrichDefinition extends ExpressionNode {
     }
 
     /**
-     * This option can be used to explicit declare the method name to use, when using POJOs as the AggregationStrategy.
+     * This option can be used to explicit declare the method name to use, when
+     * using POJOs as the AggregationStrategy.
      */
     public EnrichDefinition aggregationStrategyMethodName(String aggregationStrategyMethodName) {
         setAggregationStrategyMethodName(aggregationStrategyMethodName);
@@ -115,9 +119,10 @@ public class EnrichDefinition extends ExpressionNode {
     }
 
     /**
-     * If this option is false then the aggregate method is not used if there was no data to enrich.
-     * If this option is true then null values is used as the oldExchange (when no data to enrich),
-     * when using POJOs as the AggregationStrategy.
+     * If this option is false then the aggregate method is not used if there
+     * was no data to enrich. If this option is true then null values is used as
+     * the oldExchange (when no data to enrich), when using POJOs as the
+     * AggregationStrategy.
      */
     public EnrichDefinition aggregationStrategyMethodAllowNull(boolean aggregationStrategyMethodAllowNull) {
         setAggregationStrategyMethodAllowNull(aggregationStrategyMethodAllowNull);
@@ -125,10 +130,11 @@ public class EnrichDefinition extends ExpressionNode {
     }
 
     /**
-     * If this option is false then the aggregate method is not used if there was an exception thrown while trying
-     * to retrieve the data to enrich from the resource. Setting this option to true allows end users to control what
-     * to do if there was an exception in the aggregate method. For example to suppress the exception
-     * or set a custom message body etc.
+     * If this option is false then the aggregate method is not used if there
+     * was an exception thrown while trying to retrieve the data to enrich from
+     * the resource. Setting this option to true allows end users to control
+     * what to do if there was an exception in the aggregate method. For example
+     * to suppress the exception or set a custom message body etc.
      */
     public EnrichDefinition aggregateOnException(boolean aggregateOnException) {
         setAggregateOnException(aggregateOnException);
@@ -136,9 +142,10 @@ public class EnrichDefinition extends ExpressionNode {
     }
 
     /**
-     * Shares the {@link org.apache.camel.spi.UnitOfWork} with the parent and the resource exchange.
-     * Enrich will by default not share unit of work between the parent exchange and the resource exchange.
-     * This means the resource exchange has its own individual unit of work.
+     * Shares the {@link org.apache.camel.spi.UnitOfWork} with the parent and
+     * the resource exchange. Enrich will by default not share unit of work
+     * between the parent exchange and the resource exchange. This means the
+     * resource exchange has its own individual unit of work.
      */
     public EnrichDefinition shareUnitOfWork() {
         setShareUnitOfWork(true);
@@ -146,10 +153,12 @@ public class EnrichDefinition extends ExpressionNode {
     }
 
     /**
-     * Sets the maximum size used by the {@link org.apache.camel.spi.ProducerCache} which is used
-     * to cache and reuse producer when uris are reused.
+     * Sets the maximum size used by the
+     * {@link org.apache.camel.spi.ProducerCache} which is used to cache and
+     * reuse producer when uris are reused.
      *
-     * @param cacheSize  the cache size, use <tt>0</tt> for default cache size, or <tt>-1</tt> to turn cache off.
+     * @param cacheSize the cache size, use <tt>0</tt> for default cache size,
+     *            or <tt>-1</tt> to turn cache off.
      * @return the builder
      */
     public EnrichDefinition cacheSize(int cacheSize) {
@@ -158,7 +167,8 @@ public class EnrichDefinition extends ExpressionNode {
     }
 
     /**
-     * Ignore the invalidate endpoint exception when try to create a producer with that endpoint
+     * Ignore the invalidate endpoint exception when try to create a producer
+     * with that endpoint
      *
      * @return the builder
      */
@@ -171,7 +181,8 @@ public class EnrichDefinition extends ExpressionNode {
     // -------------------------------------------------------------------------
 
     /**
-     * Expression that computes the endpoint uri to use as the resource endpoint to enrich from
+     * Expression that computes the endpoint uri to use as the resource endpoint
+     * to enrich from
      */
     @Override
     public void setExpression(ExpressionDefinition expression) {
diff --git a/core/camel-core/src/main/java/org/apache/camel/model/ExecutorServiceAwareDefinition.java b/core/camel-core/src/main/java/org/apache/camel/model/ExecutorServiceAwareDefinition.java
index 843dca6..bf40570 100644
--- a/core/camel-core/src/main/java/org/apache/camel/model/ExecutorServiceAwareDefinition.java
+++ b/core/camel-core/src/main/java/org/apache/camel/model/ExecutorServiceAwareDefinition.java
@@ -22,7 +22,8 @@ import java.util.function.Supplier;
 import org.apache.camel.ExecutorServiceAware;
 
 /**
- * Enables definitions to support concurrency using {@link java.util.concurrent.ExecutorService}
+ * Enables definitions to support concurrency using
+ * {@link java.util.concurrent.ExecutorService}
  */
 public interface ExecutorServiceAwareDefinition<Type extends ProcessorDefinition<?>> extends ExecutorServiceAware {
 
@@ -47,8 +48,9 @@ public interface ExecutorServiceAwareDefinition<Type extends ProcessorDefinition
     /**
      * Setting the executor service for executing
      *
-     * @param executorServiceRef reference for a {@link java.util.concurrent.ExecutorService}
-     *                           to lookup in the {@link org.apache.camel.spi.Registry}
+     * @param executorServiceRef reference for a
+     *            {@link java.util.concurrent.ExecutorService} to lookup in the
+     *            {@link org.apache.camel.spi.Registry}
      * @return the builder
      */
     Type executorServiceRef(String executorServiceRef);
diff --git a/core/camel-core/src/main/java/org/apache/camel/model/ExpressionNode.java b/core/camel-core/src/main/java/org/apache/camel/model/ExpressionNode.java
index 8de221c..92aec4e 100644
--- a/core/camel-core/src/main/java/org/apache/camel/model/ExpressionNode.java
+++ b/core/camel-core/src/main/java/org/apache/camel/model/ExpressionNode.java
@@ -33,8 +33,9 @@ import org.apache.camel.model.language.ExpressionDefinition;
 /**
  * A base {@link ExpressionNode} which does <b>not</b> support any outputs.
  * <p/>
- * This node is to be extended by definitions which need to support an expression but the definition should not
- * contain any outputs, such as {@link org.apache.camel.model.TransformDefinition}.
+ * This node is to be extended by definitions which need to support an
+ * expression but the definition should not contain any outputs, such as
+ * {@link org.apache.camel.model.TransformDefinition}.
  */
 @XmlAccessorType(XmlAccessType.FIELD)
 @XmlTransient
@@ -71,7 +72,8 @@ public abstract class ExpressionNode extends ProcessorDefinition<ExpressionNode>
     }
 
     public void setExpression(ExpressionDefinition expression) {
-        // favour using the helper to set the expression as it can unwrap some unwanted builders when using Java DSL
+        // favour using the helper to set the expression as it can unwrap some
+        // unwanted builders when using Java DSL
         this.expression = expression;
     }
 
@@ -97,21 +99,26 @@ public abstract class ExpressionNode extends ProcessorDefinition<ExpressionNode>
         }
 
         if (exp instanceof ExpressionClause) {
-            ExpressionClause<?> clause = (ExpressionClause<?>) exp;
+            ExpressionClause<?> clause = (ExpressionClause<?>)exp;
             if (clause.getExpressionType() != null) {
-                // if using the Java DSL then the expression may have been set using the
-                // ExpressionClause which is a fancy builder to define expressions and predicates
-                // using fluent builders in the DSL. However we need afterwards a callback to
-                // reset the expression to the expression type the ExpressionClause did build for us
+                // if using the Java DSL then the expression may have been set
+                // using the
+                // ExpressionClause which is a fancy builder to define
+                // expressions and predicates
+                // using fluent builders in the DSL. However we need afterwards
+                // a callback to
+                // reset the expression to the expression type the
+                // ExpressionClause did build for us
                 ExpressionFactory model = clause.getExpressionType();
                 if (model instanceof ExpressionDefinition) {
-                    setExpression((ExpressionDefinition) model);
+                    setExpression((ExpressionDefinition)model);
                 }
             }
         }
 
         if (getExpression() != null && getExpression().getExpression() == null) {
-            // use toString from predicate or expression so we have some information to show in the route model
+            // use toString from predicate or expression so we have some
+            // information to show in the route model
             if (getExpression().getPredicate() != null) {
                 getExpression().setExpression(getExpression().getPredicate().toString());
             } else if (getExpression().getExpressionValue() != null) {
@@ -137,4 +144,3 @@ public abstract class ExpressionNode extends ProcessorDefinition<ExpressionNode>
     }
 
 }
-
diff --git a/core/camel-core/src/main/java/org/apache/camel/model/ExpressionNodeHelper.java b/core/camel-core/src/main/java/org/apache/camel/model/ExpressionNodeHelper.java
index 38d75b1..6a54bd0 100644
--- a/core/camel-core/src/main/java/org/apache/camel/model/ExpressionNodeHelper.java
+++ b/core/camel-core/src/main/java/org/apache/camel/model/ExpressionNodeHelper.java
@@ -34,76 +34,84 @@ public final class ExpressionNodeHelper {
     }
 
     /**
-     * Determines which {@link ExpressionDefinition} describes the given expression best possible.
+     * Determines which {@link ExpressionDefinition} describes the given
+     * expression best possible.
      * <p/>
-     * This implementation will use types such as {@link SimpleExpression}, {@link XPathExpression} etc.
-     * if the given expression is detect as such a type.
+     * This implementation will use types such as {@link SimpleExpression},
+     * {@link XPathExpression} etc. if the given expression is detect as such a
+     * type.
      *
      * @param expression the expression
      * @return a definition which describes the expression
      */
     public static ExpressionDefinition toExpressionDefinition(Expression expression) {
         if (expression instanceof SimpleBuilder) {
-            SimpleBuilder builder = (SimpleBuilder) expression;
-            // we keep the original expression by using the constructor that accepts an expression
+            SimpleBuilder builder = (SimpleBuilder)expression;
+            // we keep the original expression by using the constructor that
+            // accepts an expression
             SimpleExpression answer = new SimpleExpression(builder);
             answer.setExpression(builder.getText());
             answer.setResultType(builder.getResultType());
             return answer;
         } else if (expression instanceof ExpressionResultTypeAware && expression.getClass().getName().equals("org.apache.camel.language.xpath.XPathBuilder")) {
-            ExpressionResultTypeAware aware = (ExpressionResultTypeAware) expression;
-            // we keep the original expression by using the constructor that accepts an expression
+            ExpressionResultTypeAware aware = (ExpressionResultTypeAware)expression;
+            // we keep the original expression by using the constructor that
+            // accepts an expression
             XPathExpression answer = new XPathExpression(expression);
             answer.setExpression(aware.getExpressionText());
             answer.setResultType(answer.getResultType());
             return answer;
         } else if (expression instanceof ValueBuilder) {
             // ValueBuilder wraps the actual expression so unwrap
-            ValueBuilder builder = (ValueBuilder) expression;
+            ValueBuilder builder = (ValueBuilder)expression;
             expression = builder.getExpression();
         }
 
         if (expression instanceof ExpressionDefinition) {
-            return (ExpressionDefinition) expression;
+            return (ExpressionDefinition)expression;
         }
         return new ExpressionDefinition(expression);
     }
 
     /**
-     * Determines which {@link ExpressionDefinition} describes the given predicate best possible.
+     * Determines which {@link ExpressionDefinition} describes the given
+     * predicate best possible.
      * <p/>
-     * This implementation will use types such as {@link SimpleExpression}, {@link XPathExpression} etc.
-     * if the given predicate is detect as such a type.
+     * This implementation will use types such as {@link SimpleExpression},
+     * {@link XPathExpression} etc. if the given predicate is detect as such a
+     * type.
      *
      * @param predicate the predicate
      * @return a definition which describes the predicate
      */
     public static ExpressionDefinition toExpressionDefinition(Predicate predicate) {
         if (predicate instanceof SimpleBuilder) {
-            SimpleBuilder builder = (SimpleBuilder) predicate;
-            // we keep the original expression by using the constructor that accepts an expression
+            SimpleBuilder builder = (SimpleBuilder)predicate;
+            // we keep the original expression by using the constructor that
+            // accepts an expression
             SimpleExpression answer = new SimpleExpression(builder);
             answer.setExpression(builder.getText());
             return answer;
         } else if (predicate instanceof ExpressionResultTypeAware && predicate.getClass().getName().equals("org.apache.camel.language.xpath.XPathBuilder")) {
-            ExpressionResultTypeAware aware = (ExpressionResultTypeAware) predicate;
-            Expression expression = (Expression) predicate;
-            // we keep the original expression by using the constructor that accepts an expression
+            ExpressionResultTypeAware aware = (ExpressionResultTypeAware)predicate;
+            Expression expression = (Expression)predicate;
+            // we keep the original expression by using the constructor that
... 95615 lines suppressed ...