You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@camel.apache.org by or...@apache.org on 2024/04/23 08:25:42 UTC

(camel) branch main updated (d9713c8b4a2 -> aeb57bf9b34)

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

orpiske pushed a change to branch main
in repository https://gitbox.apache.org/repos/asf/camel.git


    from d9713c8b4a2 CAMEL-20505 - Google Calendar Streams CloudEvent Transformer (#13889)
     add aeb57bf9b34 (chores) camel-core: removed redundant throws declaration

No new revisions were added by this update.

Summary of changes:
 .../impl/cloud/CombinedServiceDiscoveryTest.java   |   2 +-
 .../apache/camel/impl/cloud/LoadBalancerTest.java  |   2 +-
 .../impl/cloud/ServiceCallConfigurationTest.java   |  14 +-
 .../camel/impl/cloud/ServiceRegistryTest.java      |   4 +-
 .../camel/impl/console/ContextDevConsoleTest.java  |   4 +-
 .../impl/console/DefaultDevConsolesLoaderTest.java |   4 +-
 .../xml/AbstractCamelContextFactoryBeanTest.java   |   2 +-
 .../java/org/apache/camel/ContextTestSupport.java  |  24 +-
 .../org/apache/camel/InjectorDefaultsTest.java     |   4 +-
 .../java/org/apache/camel/LoggingLevelTest.java    |   4 +-
 .../apache/camel/ThreadPoolRejectedPolicyTest.java |   8 +-
 .../camel/ValidatorExternalResourceTest.java       |   4 +-
 .../camel/builder/AddRoutesAtRuntimeTest.java      |   6 +-
 .../camel/builder/ContextErrorHandlerTest.java     |   4 +-
 .../ErrorHandlerRefPropertyPlaceholderTest.java    |   4 +-
 .../apache/camel/builder/ErrorHandlerRefTest.java  |   4 +-
 .../apache/camel/builder/ExceptionBuilderTest.java |   4 +-
 .../ExceptionBuilderWithHandledExceptionTest.java  |   4 +-
 .../apache/camel/builder/ExchangeBuilderTest.java  |   4 +-
 .../builder/ExpressionBuilderConcurrencyTest.java  |  10 +-
 .../camel/builder/ExpressionBuilderTest.java       |  20 +-
 .../camel/builder/ExpressionFunctionTest.java      |   4 +-
 .../camel/builder/FluentProducerTemplateTest.java  |   4 +-
 .../camel/builder/MyConstructorProcessor.java      |   2 +-
 .../camel/builder/NotifyBuilderFromRouteTest.java  |  12 +-
 .../apache/camel/builder/NotifyBuilderTest.java    |  90 +++----
 .../builder/NotifyBuilderWhenDoneByIndexTest.java  |   8 +-
 .../builder/PredicateBinaryCoerceRouteTest.java    |   4 +-
 .../builder/PredicateBinaryCoerceTypeTest.java     |  20 +-
 .../builder/PredicateBuilderConcurrentTest.java    |   2 +-
 .../apache/camel/builder/PredicateBuilderTest.java |  30 +--
 .../ProxyBuilderSkipJavaLangObjectMethodsTest.java |   4 +-
 .../org/apache/camel/builder/ProxyBuilderTest.java |   4 +-
 .../RouteBuilderAddRoutesOnlyInterceptTest.java    |   4 +-
 .../camel/builder/RouteBuilderAddRoutesTest.java   |   4 +-
 .../org/apache/camel/builder/RouteBuilderTest.java |   6 +-
 .../camel/builder/RouteModelLifecycleTest.java     |   2 +-
 .../builder/RouteTemplateAndExistingRouteTest.java |   6 +-
 .../RouteTemplateBeforeContextStartingTest.java    |   2 +-
 .../RouteTemplateChoiceInPreconditionModeTest.java |   4 +-
 .../builder/RouteTemplateChoicePredicateTest.java  |   4 +-
 .../camel/builder/RouteTemplateConverterTest.java  |   4 +-
 .../builder/RouteTemplateCustomSourceTest.java     |   4 +-
 .../builder/RouteTemplateDefaultValueTest.java     |   6 +-
 .../builder/RouteTemplateDuplicateIdIssueTest.java |   2 +-
 .../camel/builder/RouteTemplateEnvClashTest.java   |   4 +-
 .../builder/RouteTemplateErrorHandlerTest.java     |   2 +-
 ...InterceptSendToEndpointWithPlaceholderTest.java |   2 +-
 .../camel/builder/RouteTemplateLocalBeanTest.java  |  46 ++--
 .../builder/RouteTemplateModelLifecycleTest.java   |   4 +-
 .../builder/RouteTemplateOptionalValueTest.java    |   4 +-
 .../builder/RouteTemplatePreconditionTest.java     |   4 +-
 .../camel/builder/RouteTemplatePrefixIdTest.java   |   8 +-
 .../builder/RouteTemplateStreamCacheTest.java      |   2 +-
 .../apache/camel/builder/RouteTemplateTest.java    |   8 +-
 .../camel/builder/TransformerBuilderTest.java      |   6 +-
 .../org/apache/camel/builder/ValueBuilderTest.java |   6 +-
 .../builder/xml/DefaultNamespaceContextTest.java   |  12 +-
 .../builder/xml/ExtractXPathWithNamespaceTest.java |   4 +-
 .../builder/xml/XPathContentBasedRouterTest.java   |   4 +-
 .../apache/camel/builder/xml/XPathFeatureTest.java |  10 +-
 .../xml/XPathFunctionsONielProblemTest.java        |   4 +-
 .../camel/builder/xml/XPathFunctionsTest.java      |   4 +-
 .../XPathHeaderNameResultTypeAndNamespaceTest.java |   4 +-
 .../camel/builder/xml/XPathHeaderNameTest.java     |   4 +-
 .../apache/camel/builder/xml/XPathHeaderTest.java  |   4 +-
 .../apache/camel/builder/xml/XPathMockTest.java    |   4 +-
 .../builder/xml/XPathNamespaceResultTypeTest.java  |   4 +-
 .../camel/builder/xml/XPathNamespaceTest.java      |   4 +-
 .../builder/xml/XPathNestedNamespaceTest.java      |   4 +-
 .../org/apache/camel/builder/xml/XPathTest.java    |  66 ++---
 .../camel/builder/xml/XPathTransformRouteTest.java |   6 +-
 .../camel/builder/xml/XPathTransformTest.java      |   2 +-
 .../xml/XPathWithNamespacesFromDomTest.java        |   2 +-
 .../camel/builder/xml/XsltOutputFileTest.java      |   2 +-
 .../catalog/CustomEndpointUriFactoryTest.java      |   2 +-
 .../camel/cluster/ClusterServiceSelectorTest.java  |  12 +-
 .../camel/cluster/ClusterServiceViewTest.java      |   6 +-
 .../cluster/ClusteredRoutePolicyFactoryTest.java   |  14 +-
 .../ClusteredRoutePolicyLeaderChangeTest.java      |  12 +-
 .../camel/cluster/ClusteredRoutePolicyTest.java    |  16 +-
 ...eredRoutePolicyUnmanagedClusterServiceTest.java |  10 +-
 .../apache/camel/component/bar/BarEndpoint.java    |   4 +-
 .../apache/camel/component/bar/BarProducer.java    |   2 +-
 .../camel/component/bar/BarSendDynamicAware.java   |   6 +-
 ...AmbiguousMethodCallExceptionSimplifiedTest.java |   2 +-
 .../component/bean/BeanByteArrayBodyTest.java      |   4 +-
 ...seMethodWithMatchingTypeAndSkipSettersTest.java |   4 +-
 .../bean/BeanClassTypeUseBeanFromRegistryTest.java |   6 +-
 .../bean/BeanComponentMissingParenthesisTest.java  |   6 +-
 ...entWithPropertiesLookupSetFromEndpointTest.java |   4 +-
 .../camel/component/bean/BeanConcurrentTest.java   |   4 +-
 .../bean/BeanCreateBodyExceptionTest.java          |  10 +-
 .../camel/component/bean/BeanEndpointTest.java     |   8 +-
 .../BeanExchangeAsReturnTypeNotAllowedTest.java    |   4 +-
 .../component/bean/BeanExcludedMethodTest.java     |   4 +-
 .../bean/BeanExplicitMethodAmbiguousTest.java      |  12 +-
 .../component/bean/BeanExplicitMethodTest.java     |   4 +-
 .../bean/BeanExpressionConcurrentTest.java         |   4 +-
 .../bean/BeanHandlerMethodPredicateTest.java       |   4 +-
 .../component/bean/BeanHandlerMethodTest.java      |   8 +-
 .../component/bean/BeanImplicitMethodTest.java     |   2 +-
 .../camel/component/bean/BeanInPipelineTest.java   |   6 +-
 .../bean/BeanInfoAMoreComplexOverloadedTest.java   |   4 +-
 .../component/bean/BeanInfoOverloadedTest.java     |   2 +-
 .../component/bean/BeanInfoSelectMethodTest.java   |   6 +-
 .../apache/camel/component/bean/BeanInfoTest.java  |   4 +-
 .../camel/component/bean/BeanInvokeAsyncTest.java  |   4 +-
 .../BeanInvokeSimpleOgnlToStringMethodTest.java    |   4 +-
 .../bean/BeanInvokeSingleMethodNoBodyTest.java     |   4 +-
 .../camel/component/bean/BeanInvokeStaticTest.java |   4 +-
 .../camel/component/bean/BeanInvokeTest.java       |   4 +-
 .../bean/BeanInvokeToStringMethodTest.java         |   4 +-
 .../component/bean/BeanInvokeWithNullBodyTest.java |   4 +-
 .../camel/component/bean/BeanLifecycleTest.java    |   4 +-
 .../bean/BeanLookupUsingJndiRegistryIssueTest.java |   2 +-
 .../camel/component/bean/BeanMapPutTest.java       |   6 +-
 .../bean/BeanMethodNameHeaderIssueTest.java        |   4 +-
 .../bean/BeanMethodValueWithCommaTest.java         |   4 +-
 .../bean/BeanMethodValueWithExchangeTest.java      |   4 +-
 ...rameterAndNoMethodWithNoParameterIssueTest.java |   4 +-
 .../bean/BeanMethodWithStringParameterTest.java    |   4 +-
 .../camel/component/bean/BeanNoCacheTest.java      |   4 +-
 .../bean/BeanNoTypeConvertionPossibleTest.java     |   4 +-
 ...BeanNoTypeConvertionPossibleWhenHeaderTest.java |   4 +-
 .../BeanOgnlBodyMethodReturnNullValueTest.java     |   4 +-
 .../component/bean/BeanOgnlPerformanceTest.java    |   4 +-
 .../component/bean/BeanOnglStaticMethodTest.java   |   4 +-
 .../bean/BeanOverloadedCovariantMethodTest.java    |   8 +-
 .../bean/BeanOverloadedMethodFQNTest.java          |  12 +-
 .../BeanOverloadedMethodParameterValueTest.java    |  16 +-
 .../component/bean/BeanOverloadedMethodTest.java   |  22 +-
 .../bean/BeanOverloadsWithAssignableParamTest.java |   4 +-
 .../bean/BeanPackageScopeOutsideTest.java          |   4 +-
 .../camel/component/bean/BeanPackageScopeTest.java |   4 +-
 .../BeanParameterBindingStreamCachingTest.java     |   4 +-
 .../component/bean/BeanParameterInfoTest.java      |   2 +-
 .../bean/BeanParameterInvalidSyntaxTest.java       |   4 +-
 .../bean/BeanParameterInvalidValueTest.java        |   4 +-
 .../BeanParameterMethodCallThreeBodyOgnlTest.java  |   4 +-
 .../bean/BeanParameterNoBeanBindingTest.java       |   4 +-
 .../bean/BeanParameterThreeBodyOgnlTest.java       |   4 +-
 .../component/bean/BeanParameterValueOgnlTest.java |   4 +-
 .../bean/BeanParameterValueOverloadedTest.java     |   4 +-
 .../component/bean/BeanParameterValueTest.java     |   4 +-
 .../camel/component/bean/BeanPerformanceTest.java  |   6 +-
 .../camel/component/bean/BeanPipelineTest.java     |   4 +-
 .../component/bean/BeanPipelineVariablesTest.java  |   4 +-
 .../BeanPrivateClassWithInterfaceMethodTest.java   |   4 +-
 .../component/bean/BeanPropagateHeaderTest.java    |   4 +-
 .../component/bean/BeanPropertiesFunctionTest.java |   2 +-
 .../component/bean/BeanProxyNoBindingTest.java     |   4 +-
 .../apache/camel/component/bean/BeanProxyTest.java |   4 +-
 .../component/bean/BeanRefMethodNotFoundTest.java  |   2 +-
 .../camel/component/bean/BeanRefNoCacheTest.java   |   4 +-
 .../camel/component/bean/BeanRefNotFoundTest.java  |   2 +-
 .../bean/BeanReturnCallableReturnNullTest.java     |   4 +-
 .../component/bean/BeanReturnCallableTest.java     |   4 +-
 .../camel/component/bean/BeanReturnNullTest.java   |  10 +-
 .../BeanSimpleLanguageStaticMethodIssueTest.java   |   4 +-
 .../camel/component/bean/BeanStaticMethodTest.java |   4 +-
 .../bean/BeanThrowAssertionErrorTest.java          |   6 +-
 .../bean/BeanWithAnnotationAndExchangeTest.java    |   4 +-
 .../bean/BeanWithAnnotationInheritedTest.java      |   6 +-
 .../BeanWithExchangeExceptionAnnotationTest.java   |   4 +-
 .../BeanWithExpressionInjectionPredicateTest.java  |   4 +-
 .../bean/BeanWithExpressionInjectionTest.java      |   2 +-
 .../camel/component/bean/BeanWithHeaderTest.java   |   4 +-
 .../bean/BeanWithHeadersAndBodyInject2Test.java    |  12 +-
 .../bean/BeanWithHeadersAndBodyInjectionTest.java  |   4 +-
 .../bean/BeanWithInputStreamBodyTest.java          |  10 +-
 .../component/bean/BeanWithMethodHeaderTest.java   |  14 +-
 ...thPropertiesAndHeadersAndBodyInjectionTest.java |   4 +-
 .../BeanWithPropertiesAndHeadersInjectionTest.java |   4 +-
 ...eanWithPropertiesAndVariablesInjectionTest.java |   4 +-
 .../BeanWithVariablesAndBodyInjectionTest.java     |   4 +-
 ...BeanWithXPathInjectionUsingHeaderValueTest.java |   2 +-
 .../BeanWithXPathInjectionUsingResultTypeTest.java |   2 +-
 .../BodyAnnotationToDisambiguateMethodsTest.java   |   2 +-
 .../ClassComponentInvalidConfigurationTest.java    |   4 +-
 .../camel/component/bean/ClassComponentTest.java   |   4 +-
 ...entWithPropertiesLookupSetFromEndpointTest.java |   4 +-
 ...ComponentWithPropertiesSetFromEndpointTest.java |   4 +-
 .../bean/CustomParameterMappingStrategyTest.java   |   4 +-
 .../bean/DefaultParameterMappingStrategyTest.java  |   6 +-
 ...ressionAnnotationToDisambiguateMethodsTest.java |   4 +-
 .../bean/FileBeanParameterBindingTest.java         |   6 +-
 .../bean/MethodCallBeanFunctionScopeTest.java      |   4 +-
 .../bean/MethodCallBeanRefMethodNotFoundTest.java  |   2 +-
 .../bean/MethodCallBeanRefNotFoundTest.java        |   2 +-
 .../bean/MethodCallBeanTypeFunctionScopeTest.java  |   4 +-
 .../bean/MethodCallByTypeRefExistingBeanTest.java  |   4 +-
 .../bean/MethodCallMissingParenthesisTest.java     |   4 +-
 .../MethodCallRefOrBeanPrefixPredicateTest.java    |   4 +-
 .../bean/MethodCallRefOrBeanPrefixTest.java        |   4 +-
 .../component/bean/MethodCallStaticMethodTest.java |   4 +-
 .../MethodNotFoundExceptionSimplifiedTest.java     |   2 +-
 .../component/bean/MockitoMockForClassTest.java    |   6 +-
 .../bean/MockitoMockForInterfaceTest.java          |   6 +-
 .../component/bean/MockitoSpyForClassTest.java     |   6 +-
 .../component/bean/MyAuditServiceProxyTest.java    |   4 +-
 .../camel/component/bean/MyCurrencyBeanTest.java   |   4 +-
 .../camel/component/bean/MyServiceProxyTest.java   |   6 +-
 .../camel/component/bean/PredicateAsBeanTest.java  |   2 +-
 .../bean/ProxyReturnFutureExceptionTest.java       |   4 +-
 .../component/bean/ProxyReturnFutureTest.java      |   4 +-
 .../bean/RequestScopedBeanComponentTest.java       |   4 +-
 .../component/bean/RequestScopedBeanEIPTest.java   |   4 +-
 .../component/bean/RouteMethodCallStaticTest.java  |   4 +-
 .../SimpleLanguageBeanBodyParenthesisTest.java     |   4 +-
 ...nguageBeanFunctionMethodValueWithCommaTest.java |   4 +-
 ...BeanFunctionMethodValueWithParenthesisTest.java |   4 +-
 .../bean/SimpleLanguageBeanFunctionScopeTest.java  |   6 +-
 .../SimpleLanguageBeanTypeFunctionScopeTest.java   |   4 +-
 .../bean/issues/BeanAbstractMethodIssueTest.java   |   4 +-
 .../issues/BeanInfoSingleMethodServiceTest.java    |   6 +-
 .../BeanParameterBestTypeMatchIssueTest.java       |   4 +-
 .../BeanParameterMatchPerformanceIssueTest.java    |   6 +-
 .../bean/issues/BeanParameterTypeAndValueTest.java |   4 +-
 .../bean/issues/BeanRouteToDerivedClassTest.java   |   6 +-
 .../bean/issues/BeanThisAdviceWithIssueTest.java   |   4 +-
 .../issues/BeanVsProcessorPerformanceTest.java     |   8 +-
 ...efaultMethodCalledFromSimpleExpressionTest.java |   4 +-
 .../issues/FilterBeanLanguageNonRegistryTest.java  |   4 +-
 .../bean/issues/FilterBeanNonRegistryTest.java     |   4 +-
 .../bean/issues/FilterBeanRegistryTest.java        |   4 +-
 .../component/bean/issues/FilterPojoIssueTest.java |   4 +-
 .../component/bean/issues/MyLittleProcessor.java   |   2 +-
 .../bean/issues/MyMessageToProcessorConverter.java |   2 +-
 .../bean/issues/TransformerIssueTest.java          |   4 +-
 .../camel/component/browse/BrowseEndpointTest.java |   4 +-
 .../component/browse/BrowseRouteConsumeTest.java   |   4 +-
 .../camel/component/browse/BrowseRouteTest.java    |   4 +-
 .../apache/camel/component/browse/BrowseTest.java  |   4 +-
 .../controlbus/ControlBusFailRouteTest.java        |   6 +-
 .../ControlBusLanguageSimpleStartRouteTest.java    |   4 +-
 .../controlbus/ControlBusRestartRouteTest.java     |   6 +-
 .../controlbus/ControlBusStartRouteAsyncTest.java  |   4 +-
 .../controlbus/ControlBusStartRouteTest.java       |   4 +-
 .../component/dataset/BigDataSetManualTest.java    |   4 +-
 .../camel/component/dataset/CustomDataSetTest.java |   7 +-
 .../component/dataset/DataSetConsumerTest.java     |  12 +-
 .../component/dataset/DataSetEndpointTest.java     |  14 +-
 .../component/dataset/DataSetPreloadTest.java      |   4 +-
 .../component/dataset/DataSetProducerTest.java     |  16 +-
 .../camel/component/dataset/DataSetSedaTest.java   |   4 +-
 .../camel/component/dataset/DataSetTest.java       |   4 +-
 .../component/dataset/DataSetTestAnyOrderTest.java |   2 +-
 .../component/dataset/DataSetTestEndpointTest.java |   6 +-
 .../dataset/DataSetTestFileSplitTest.java          |   2 +-
 .../component/dataset/DataSetTestFileTest.java     |   2 +-
 .../component/dataset/DataSetTestSedaTest.java     |   2 +-
 .../component/dataset/FileDataSetConsumerTest.java |   4 +-
 .../dataset/FileDataSetConsumerWithSplitTest.java  |   2 +-
 .../component/dataset/FileDataSetProducerTest.java |   4 +-
 .../dataset/FileDataSetProducerWithSplitTest.java  |   4 +-
 .../component/dataset/ListDataSetConsumerTest.java |   2 +-
 .../component/dataset/ListDataSetProducerTest.java |   4 +-
 .../component/dataset/RoutePerformanceTest.java    |   4 +-
 .../direct/DirectEndpointRouteInlinedTest.java     |   6 +-
 .../component/direct/DirectNoConsumerTest.java     |  16 +-
 .../direct/DirectNoMultipleConsumersTest.java      |   2 +-
 .../camel/component/direct/DirectNoToTypeTest.java |   8 +-
 .../direct/DirectProducerBlockingTest.java         |   4 +-
 .../camel/component/direct/DirectQueueTest.java    |   6 +-
 .../direct/DirectShouldUseSameThreadTest.java      |   8 +-
 ...SendingToAlotOfDifferentDirectEndpointTest.java |   4 +-
 .../direct/TwoCamelContextDirectEndpointTest.java  |   6 +-
 .../file/AntPathMatcherGenericFileFilterTest.java  |  16 +-
 .../camel/component/file/BeanToFileTest.java       |   4 +-
 .../file/ConsumerTemplateFileShutdownTest.java     |   2 +-
 .../component/file/DirectoryCreateIssueTest.java   |   4 +-
 .../file/FileAbsoluteAndRelativeConsumerTest.java  |   4 +-
 .../component/file/FileAbsolutePathIssueTest.java  |   4 +-
 .../FileBatchConsumerMemoryLeakManualTest.java     |   4 +-
 .../file/FileBeginFailureOneTimeTest.java          |  19 +-
 .../component/file/FileBridgeErrorHandlerTest.java |   4 +-
 .../component/file/FileBrowsableEndpointTest.java  |   8 +-
 .../FileConcurrentWriteAppendSameFileTest.java     |   4 +-
 .../camel/component/file/FileConfigureTest.java    |   4 +-
 .../FileConsumeAlterFileNameHeaderIssueTest.java   |   8 +-
 .../file/FileConsumeBackoffMultiplierTest.java     |   4 +-
 .../component/file/FileConsumeCharsetTest.java     |   4 +-
 .../file/FileConsumeDoneFileIssueTest.java         |   4 +-
 ...eConsumeDynamicDoneFileNameWithTwoDotsTest.java |   4 +-
 .../file/FileConsumeFilesAndDeleteTest.java        |   4 +-
 .../component/file/FileConsumeHiddenDirsTest.java  |   4 +-
 .../component/file/FileConsumeHiddenFilesTest.java |   4 +-
 .../file/FileConsumeMaxMessagesPerPollTest.java    |   4 +-
 .../file/FileConsumeMoveRelativeNameTest.java      |   4 +-
 .../file/FileConsumeMultipleDirectoriesTest.java   |   4 +-
 .../file/FileConsumeNoopIdempotentAutoTest.java    |   4 +-
 .../FileConsumeNoopIdempotentDisabledTest.java     |   4 +-
 .../file/FileConsumeNoopIdempotentEnabledTest.java |   6 +-
 .../FileConsumeNotEagerMaxMessagesPerPollTest.java |   4 +-
 .../FileConsumePollEnrichFileIdleEventTest.java    |   6 +-
 .../file/FileConsumePollEnrichFileTest.java        |   6 +-
 ...ileConsumePollEnrichFileUsingProcessorTest.java |   4 +-
 .../file/FileConsumeRootDirManualTest.java         |   4 +-
 .../file/FileConsumeRunLoggingLevelTest.java       |   4 +-
 ...ileConsumeSimpleAbsoluteMoveToAbsoluteTest.java |   4 +-
 ...ileConsumeSimpleAbsoluteMoveToRelativeTest.java |   4 +-
 ...meSimpleDynamicDoneFileNameWithTwoDotsTest.java |   4 +-
 ...ileConsumeSimpleRelativeMoveToAbsoluteTest.java |   4 +-
 ...ileConsumeSimpleRelativeMoveToRelativeTest.java |   4 +-
 .../file/FileConsumeSingleDirectoryOnlyTest.java   |   4 +-
 .../component/file/FileConsumeTemplateTest.java    |   2 +-
 .../file/FileConsumeWithDollarInPathTest.java      |   4 +-
 .../FileConsumerAbsolutePathDefaultMoveTest.java   |   4 +-
 .../file/FileConsumerAbsolutePathTest.java         |   4 +-
 ...leConsumerAbsolutePathWithAbsoluteMoveTest.java |   4 +-
 ...leConsumerAbsolutePathWithRelativeMoveTest.java |   4 +-
 ...ileConsumerAbsoluteRootPathDefaultMoveTest.java |   4 +-
 .../file/FileConsumerAutoCreateDirectoryTest.java  |  10 +-
 .../component/file/FileConsumerBatchTest.java      |   4 +-
 ...BeginAndCommitExpressionRenameStrategyTest.java |   6 +-
 ...leConsumerBeginAndCommitRenameStrategyTest.java |   6 +-
 ...eConsumerBeginExpressionRenameStrategyTest.java |   6 +-
 .../file/FileConsumerBeginRenameStrategyTest.java  |   6 +-
 ...ileConsumerBridgeRouteExceptionHandlerTest.java |  16 +-
 ...nsumerCommitRenameAbsolutePathStrategyTest.java |   4 +-
 .../file/FileConsumerCommitRenameStrategyTest.java |   4 +-
 .../file/FileConsumerConsumedFileNameTest.java     |   4 +-
 .../FileConsumerCustomExceptionHandlerTest.java    |  18 +-
 .../file/FileConsumerCustomSchedulerTest.java      |   4 +-
 .../file/FileConsumerDeleteAndFailureTest.java     |   6 +-
 .../file/FileConsumerDeleteAndMoveFailedTest.java  |   6 +-
 .../file/FileConsumerDeleteExchangePooledTest.java |   4 +-
 .../file/FileConsumerDirectoryFilterTest.java      |   4 +-
 ...erDirectoryMustExistBridgeErrorHandlerTest.java |   4 +-
 .../file/FileConsumerDirectoryNotMatchedTest.java  |   4 +-
 .../component/file/FileConsumerExcludeExtTest.java |   4 +-
 .../file/FileConsumerExcludeNameTest.java          |   6 +-
 .../file/FileConsumerExtendedAttributesTest.java   |   4 +-
 .../file/FileConsumerFailureHandledTest.java       |   6 +-
 .../file/FileConsumerFileExpressionTest.java       |   4 +-
 ...leConsumerFileExpressionThrowExceptionTest.java |   4 +-
 .../component/file/FileConsumerFileFilterTest.java |   4 +-
 .../file/FileConsumerFileNameFilterTest.java       |   2 +-
 .../file/FileConsumerFilterDirectoryTest.java      |   4 +-
 .../component/file/FileConsumerFilterFileTest.java |   4 +-
 ...FileConsumerIdempotentKeyChangedIssue2Test.java |   4 +-
 .../FileConsumerIdempotentKeyChangedIssueTest.java |   4 +-
 .../FileConsumerIdempotentKeyNameAndSizeTest.java  |   4 +-
 .../file/FileConsumerIdempotentKeyTest.java        |   4 +-
 ...leConsumerIdempotentOnExceptionHandledTest.java |   4 +-
 .../file/FileConsumerIdempotentRefTest.java        |   4 +-
 .../component/file/FileConsumerIdempotentTest.java |   4 +-
 .../file/FileConsumerIdleMessageTest.java          |   4 +-
 .../FileConsumerIncludeAndExcludeNameTest.java     |   6 +-
 .../component/file/FileConsumerIncludeExtTest.java |   4 +-
 .../file/FileConsumerIncludeNameTest.java          |   6 +-
 .../file/FileConsumerInterceptEmptyFileTest.java   |   6 +-
 .../file/FileConsumerMessageTimestampTest.java     |   4 +-
 .../file/FileConsumerMoveAndMoveFailureTest.java   |   6 +-
 .../file/FileConsumerMoveExpressionTest.java       |  10 +-
 .../FileConsumerMoveFailureOnCompletionTest.java   |   6 +-
 .../file/FileConsumerMoveFailureTest.java          |   6 +-
 .../camel/component/file/FileConsumerNoopTest.java |   4 +-
 .../file/FileConsumerPathWithAmpersandTest.java    |   4 +-
 .../file/FileConsumerPollStrategyNotBeginTest.java |   6 +-
 ...FileConsumerPollStrategyPolledMessagesTest.java |   6 +-
 ...umerPollStrategyRollbackThrowExceptionTest.java |   6 +-
 ...FileConsumerPollStrategyStopOnRollbackTest.java |   6 +-
 .../file/FileConsumerPollStrategyTest.java         |   6 +-
 ...rPreMoveCopyAndDeleteOnRenameFailFalseTest.java |   4 +-
 .../file/FileConsumerPreMoveDeleteTest.java        |   6 +-
 .../file/FileConsumerPreMoveIssueTest.java         |   6 +-
 .../file/FileConsumerPreMoveLastModifiedTest.java  |   6 +-
 .../file/FileConsumerPreMoveNoopTest.java          |   6 +-
 .../component/file/FileConsumerPreMoveTest.java    |   6 +-
 ...ileConsumerPreMoveWithProbeContentTypeTest.java |   4 +-
 .../file/FileConsumerRelativeFileNameTest.java     |   4 +-
 .../file/FileConsumerRestartNotLeakThreadTest.java |   4 +-
 .../FileConsumerResumeFromOffsetStrategyTest.java  |   2 +-
 .../file/FileConsumerResumeStrategyTest.java       |   2 +-
 .../file/FileConsumerSharedThreadPollTest.java     |   4 +-
 .../file/FileConsumerSkipDotFilesTest.java         |   4 +-
 .../file/FileConsumerSpringSchedulerTest.java      |   2 +-
 .../file/FileConsumerSuspendAndResumeTest.java     |   4 +-
 .../component/file/FileConsumerSuspendTest.java    |   4 +-
 .../component/file/FileConsumerTemplateTest.java   |   2 +-
 .../FileConsumerThreadsInProgressIssueTest.java    |   4 +-
 .../component/file/FileContentBasedRouterTest.java |   4 +-
 .../component/file/FileConvertBodyToUTF8Test.java  |   2 +-
 .../file/FileExclusiveReadLockCopyTest.java        |   4 +-
 .../file/FileExclusiveReadManualTest.java          |   4 +-
 .../file/FileExclusiveReadNoneStrategyTest.java    |   4 +-
 .../file/FileHeaderFileNameProducedTest.java       |   4 +-
 .../file/FileIdempotentReadSameFileAgainTest.java  |   4 +-
 .../component/file/FileKeepLastModifiedTest.java   |   6 +-
 .../camel/component/file/FileLanguageCBRTest.java  |   4 +-
 .../camel/component/file/FileMEPInOutTest.java     |   4 +-
 .../file/FileMarkerFileDeleteOldLockFilesTest.java |   4 +-
 ...eMarkerFileRecursiveDeleteOldLockFilesTest.java |   4 +-
 ...erFileRecursiveDoNotDeleteOldLockFilesTest.java |   4 +-
 ...cursiveFilterDeleteOldLockFilesIncludeTest.java |   4 +-
 ...rFileRecursiveFilterDeleteOldLockFilesTest.java |   4 +-
 .../file/FileMoveAndMoveFailedIssueTest.java       |   4 +-
 .../FileMoveErrorOnExceptionNotHandledTest.java    |   4 +-
 .../component/file/FileMoveWithInMessageTest.java  |   8 +-
 .../component/file/FileMoveWithOutMessageTest.java |   8 +-
 .../component/file/FileMulticastDeleteTest.java    |   4 +-
 .../camel/component/file/FileNoOpLockFileTest.java |   6 +-
 .../component/file/FilePollEnrichNoWaitTest.java   |   4 +-
 .../camel/component/file/FilePollEnrichTest.java   |   4 +-
 .../file/FileProduceGeneratedFileNameTest.java     |   6 +-
 .../file/FileProduceTempFileNameTest.java          |  10 +-
 .../component/file/FileProduceTempPrefixTest.java  |   8 +-
 .../file/FileProducerAllowNullBodyTest.java        |   2 +-
 .../file/FileProducerCharsetUTFOptimizedTest.java  |   4 +-
 .../FileProducerCharsetUTFtoISOConfiguredTest.java |   2 +-
 ...leProducerCharsetUTFtoISOConvertBodyToTest.java |   2 +-
 .../file/FileProducerCharsetUTFtoISOTest.java      |   2 +-
 .../file/FileProducerCharsetUTFtoUTFTest.java      |   4 +-
 .../component/file/FileProducerExpressionTest.java |  12 +-
 .../file/FileProducerFileBodyGetsMovedTest.java    |   4 +-
 ...ileProducerFileExistAppendNoFileBeforeTest.java |   4 +-
 .../file/FileProducerFileExistAppendTest.java      |   4 +-
 .../file/FileProducerFileExistFailTest.java        |   4 +-
 .../file/FileProducerFileExistIgnoreTest.java      |   4 +-
 ...eProducerFileExistOverrideNoFileBeforeTest.java |   4 +-
 .../file/FileProducerFileExistOverrideTest.java    |   4 +-
 .../file/FileProducerFileExistTryRenameTest.java   |   4 +-
 .../file/FileProducerFilenameConstantTest.java     |   2 +-
 .../FileProducerJailStartingDirectoryTest.java     |   4 +-
 .../file/FileProducerMoveExistingTest.java         |   2 +-
 .../file/FileProducerNoForcedWritesTest.java       |   4 +-
 .../file/FileProducerRenameUsingCopyTest.java      |   4 +-
 .../component/file/FileProducerStreamTest.java     |   4 +-
 .../file/FileProducerTempFileExistsIssueTest.java  |   4 +-
 .../file/FileProducerToDMoveExistingTest.java      |   4 +-
 .../component/file/FileRecursiveDepthTest.java     |   4 +-
 .../component/file/FileRecursiveNoopTest.java      |   4 +-
 .../file/FileRenameFileOnCommitIssueTest.java      |   6 +-
 .../FileRenameReadLockMustUseMarkerFileTest.java   |   6 +-
 .../file/FileRouteOnDosWithNoVolTest.java          |   4 +-
 .../component/file/FileSortByExpressionTest.java   |   4 +-
 .../file/FileSortByIgnoreCaseExpressionTest.java   |   6 +-
 .../file/FileSortByNestedExpressionTest.java       |   4 +-
 .../camel/component/file/FileSorterRefTest.java    |   2 +-
 .../camel/component/file/FileSplitInSplitTest.java |   4 +-
 .../component/file/FileToFileNioLowBufferTest.java |   4 +-
 .../component/file/FileToFileWithFlattenTest.java  |   4 +-
 .../camel/component/file/FileURLDecodingTest.java  |   2 +-
 .../file/FilerConsumerDoneFileNameDeleteTest.java  |   4 +-
 .../file/FilerConsumerDoneFileNamePrefixTest.java  |   4 +-
 .../FilerConsumerDoneFileNameSimplePrefixTest.java |   4 +-
 .../file/FilerConsumerDoneFileNameSuffixTest.java  |   4 +-
 .../file/FilerConsumerDoneFileNameTest.java        |   4 +-
 .../file/FilerConsumerDoneFileNoopTest.java        |   4 +-
 .../file/FilerConsumerDualDoneFileNameTest.java    |   6 +-
 .../FilerConsumerMoveFailedDoneFileNameTest.java   |   4 +-
 .../file/FilerConsumerPreMoveDoneFileNameTest.java |   4 +-
 .../file/FilerConsumerRetryDoneFileNameTest.java   |   6 +-
 .../FilerConsumerShouldSkipDoneFilePrefixTest.java |   4 +-
 .../FilerConsumerShouldSkipDoneFileSuffixTest.java |   4 +-
 .../file/FilerConsumerShouldSkipDoneFileTest.java  |   4 +-
 .../component/file/FilerProducerAbsoluteTest.java  |   4 +-
 .../file/FilerProducerDoneFileNameRouteTest.java   |   4 +-
 .../file/FilerProducerDoneFileNameTest.java        |  14 +-
 .../component/file/FilerProducerFileNamesTest.java |   8 +-
 .../FromFileDoNotDeleteFileIfProcessFailsTest.java |   6 +-
 .../FromFileDoNotMoveFileIfProcessFailsTest.java   |   6 +-
 .../file/FromFileMoveDoneCustomHeaderTest.java     |   4 +-
 .../file/FromFileMoveFileIfProcessFailsTest.java   |   6 +-
 .../file/FromFileMulticastToFilesTest.java         |   4 +-
 .../file/FromFilePollThirdTimeOkTest.java          |   6 +-
 .../component/file/GenericFileConverterTest.java   |  18 +-
 .../component/file/GenericFileMessageTest.java     |   4 +-
 ...lusiveReadLockStrategyRecursiveCleanupTest.java |  10 +-
 ...kerFileExclusiveReadLockStrategyUnlockTest.java |   4 +-
 .../camel/component/file/MyFileTypeDetector.java   |   3 +-
 .../camel/component/file/NewFileConsumerTest.java  |   4 +-
 .../camel/component/file/ToFileRouteTest.java      |   6 +-
 .../camel/component/file/XPathToFileTest.java      |   4 +-
 .../FileLockClusteredRoutePolicyFactoryTest.java   |   2 +-
 .../FileChangedReadLockLoggingLevelTest.java       |   4 +-
 .../FileChangedReadLockMarkerFileFalseTest.java    |   4 +-
 .../FileChangedReadLockMinAgeShortCircuitTest.java |   4 +-
 .../strategy/FileChangedReadLockMinAgeTest.java    |   4 +-
 .../file/strategy/FileChangedReadLockTest.java     |   4 +-
 .../strategy/FileChangedReadLockTimeoutTest.java   |   4 +-
 .../FileChangedReadLockZeroTimeoutTest.java        |   4 +-
 .../FileChangedZeroLengthReadLockTest.java         |   4 +-
 .../FileIdempotentChangedReadLockTest.java         |   6 +-
 .../FileIdempotentReadLockDelayedAsyncTest.java    |   6 +-
 .../FileIdempotentReadLockDelayedTest.java         |   6 +-
 .../file/strategy/FileIdempotentReadLockTest.java  |   6 +-
 .../strategy/FileIdempotentRenameReadLockTest.java |   6 +-
 .../GenericFileDeleteProcessStrategyTest.java      |   2 +-
 .../MarkerFileExclusiveReadLockStrategyTest.java   |   6 +-
 .../FileAsyncStressFileDropperManualTest.java      |   4 +-
 .../file/stress/FileAsyncStressManualTest.java     |   4 +-
 .../stress/FileAsyncStressManuallyManualTest.java  |   4 +-
 ...StressReadLockLockFileTestManualManualTest.java |   4 +-
 ...ileAsyncStressReadLockNoneManualManualTest.java |   4 +-
 ...eAsyncStressReadLockRenameManualManualTest.java |   4 +-
 .../FileConsumerPollManyFilesManualTest.java       |   2 +-
 ...leProducerAppendManyMessagesFastManualTest.java |   4 +-
 .../FileProducerAppendManyMessagesManualTest.java  |   4 +-
 .../language/LanguageCacheScriptTest.java          |   4 +-
 .../language/LanguageEndpointScriptRouteTest.java  |   4 +-
 .../language/LanguageHeaderRouteTest.java          |   4 +-
 .../LanguageLoadScriptFromClasspathHeaderTest.java |   4 +-
 .../LanguageLoadScriptFromClasspathTest.java       |   4 +-
 .../LanguageLoadScriptFromFileUpdateTest.java      |   4 +-
 .../language/LanguageNoCacheScriptTest.java        |   4 +-
 ...guageResourceLoadConstantFromClasspathTest.java |   4 +-
 ...anguageResourceLoadScriptFromClasspathTest.java |   4 +-
 .../language/LanguageRouteConvertBodyTest.java     |   4 +-
 .../language/LanguageRouteNoTransformTest.java     |   4 +-
 .../component/language/LanguageRouteTest.java      |   4 +-
 ...guageScriptInHeaderRouteTakePrecedenceTest.java |   4 +-
 .../language/LanguageScriptInHeaderRouteTest.java  |   4 +-
 .../language/LanguageScriptRouteTest.java          |   4 +-
 .../component/language/LanguageXPathRouteTest.java |   4 +-
 .../log/DefaultExchangeFormatterTest.java          |   3 +-
 .../component/log/LogBodyWithNewLineTest.java      |   8 +-
 .../component/log/LogComponentOptionsTest.java     |  10 +-
 .../component/log/LogCustomFormatterTest.java      |  10 +-
 .../camel/component/log/LogCustomLoggerTest.java   |  10 +-
 .../component/log/LogEndpointOptionsTest.java      |   6 +-
 .../camel/component/log/LogEndpointTest.java       |   4 +-
 .../camel/component/log/LogInputStreamTest.java    |   4 +-
 .../camel/component/log/LogListenerTest.java       |   4 +-
 .../apache/camel/component/log/LogMaskTest.java    |   2 +-
 .../camel/component/mock/MockAsBeanTest.java       |   6 +-
 .../component/mock/MockAssertionClauseTest.java    |   4 +-
 .../camel/component/mock/MockComponentLogTest.java |   4 +-
 .../camel/component/mock/MockEndpointTest.java     |  28 +-
 .../mock/MockEndpointWithParametersTest.java       |   4 +-
 .../mock/MockExpectedBodiesAsListTest.java         |   4 +-
 .../apache/camel/component/mock/MockLogTest.java   |   4 +-
 .../camel/component/mock/MockPredicateTest.java    |   4 +-
 .../component/mock/MockStreamCachingTest.java      |   4 +-
 .../camel/component/mock/MockThroughtputTest.java  |   4 +-
 .../apache/camel/component/mock/MockXpathTest.java |   4 +-
 .../OptionalPropertiesDslInvalidSyntaxTest.java    |   2 +-
 .../properties/OptionalPropertiesDslTest.java      |   4 +-
 .../OptionalPropertyPlaceholderBeanTest.java       |   6 +-
 .../OptionalPropertyPlaceholderEipTest.java        |   4 +-
 .../OptionalPropertyPlaceholderTest.java           |  18 +-
 ...onentAdviceWithInterceptSendToEndpointTest.java |   6 +-
 ...opertiesComponentConcatenatePropertiesTest.java |   4 +-
 .../PropertiesComponentDefaultFunctionsTest.java   |   4 +-
 .../PropertiesComponentDisableDefaultsTest.java    |   2 +-
 ...pertiesComponentEIPChoiceConvertBodyToTest.java |   4 +-
 .../PropertiesComponentEIPChoiceSimpleTest.java    |   4 +-
 .../PropertiesComponentEIPConvertBodyToTest.java   |   4 +-
 .../PropertiesComponentEIPRoutingSlipTest.java     |   4 +-
 .../PropertiesComponentEncodingTest.java           |   4 +-
 .../PropertiesComponentEndpointTest.java           |   4 +-
 .../properties/PropertiesComponentEscapedTest.java |   4 +-
 .../PropertiesComponentFunctionTest.java           |   2 +-
 ...opertiesComponentIgnoreMissingPropertyTest.java |   2 +-
 .../PropertiesComponentInitialPropertiesTest.java  |   2 +-
 .../PropertiesComponentInterceptFromTest.java      |   4 +-
 ...ertiesComponentInterceptSendToEndpointTest.java |   4 +-
 .../PropertiesComponentKeepOnlyChangedTest.java    |   2 +-
 ...ponentLoadPropertiesFromFileTrimValuesTest.java |   2 +-
 .../PropertiesComponentLookupListenerTest.java     |   6 +-
 .../properties/PropertiesComponentNegateTest.java  |   6 +-
 .../PropertiesComponentNestedFalseTest.java        |   4 +-
 .../properties/PropertiesComponentNestedTest.java  |   4 +-
 ...ertiesComponentOnExceptionDelayPatternTest.java |   4 +-
 .../PropertiesComponentOnExceptionTest.java        |   4 +-
 ...ropertiesComponentOnlyUseDefaultValuesTest.java |   6 +-
 ...esComponentOverridePropertiesNonStringTest.java |   2 +-
 .../PropertiesComponentOverridePropertiesTest.java |   2 +-
 .../PropertiesComponentRegistryTest.java           |   4 +-
 .../PropertiesComponentReloadPropertiesTest.java   |   2 +-
 .../PropertiesComponentServiceHostPortTest.java    |   4 +-
 .../PropertiesComponentServiceHostTest.java        |   4 +-
 .../PropertiesComponentServicePortTest.java        |   4 +-
 .../properties/PropertiesComponentServiceTest.java |   4 +-
 .../PropertiesComponentSetHeaderSimpleTest.java    |   4 +-
 ...rtiesComponentSomethingElseBoundToJndiTest.java |   2 +-
 .../properties/PropertiesPropertyTest.java         |   4 +-
 .../properties/PropertiesRouteFromTest.java        |   4 +-
 .../properties/PropertiesRouteIdTest.java          |   6 +-
 ...rtyFunctionOptionalPropertyPlaceholderTest.java |  14 +-
 .../PropertyPlaceholderDefaultValueTest.java       |   4 +-
 .../properties/XPathPropertyPlaceholderTest.java   |   4 +-
 .../camel/component/ref/RefComponentTest.java      |   2 +-
 .../camel/component/ref/RefFileEndpointTest.java   |   6 +-
 .../apache/camel/component/ref/RefInvalidTest.java |   8 +-
 .../component/rest/DummyRestProcessorFactory.java  |   5 +-
 .../component/rest/FromRestAdviceWithTest.java     |   4 +-
 .../camel/component/rest/FromRestApiTest.java      |   6 +-
 .../component/rest/FromRestConfigurationTest.java  |   6 +-
 .../component/rest/FromRestDefaultValueTest.java   |   4 +-
 .../component/rest/FromRestDisabledAllTest.java    |   4 +-
 .../camel/component/rest/FromRestDisabledTest.java |   4 +-
 .../rest/FromRestExplicitComponentTest.java        |   4 +-
 .../component/rest/FromRestGetContentTypeTest.java |   8 +-
 .../rest/FromRestGetCorsAllowCredentialsTest.java  |   8 +-
 .../component/rest/FromRestGetCorsCustomTest.java  |   6 +-
 .../camel/component/rest/FromRestGetCorsTest.java  |   6 +-
 .../component/rest/FromRestGetEndPathTest.java     |   4 +-
 .../rest/FromRestGetHttpErrorCodeTest.java         |   8 +-
 .../component/rest/FromRestGetInterceptTest.java   |   4 +-
 .../component/rest/FromRestGetOnExceptionTest.java |   4 +-
 .../rest/FromRestGetPlaceholderParamTest.java      |   2 +-
 .../component/rest/FromRestGetPolicyTest.java      |   4 +-
 .../rest/FromRestGetRouteOnExceptionTest.java      |   4 +-
 .../camel/component/rest/FromRestGetTest.java      |   4 +-
 .../rest/FromRestIdAndDescriptionTest.java         |   4 +-
 .../component/rest/FromRestInlineRoutesTest.java   |   6 +-
 .../rest/FromRestPathPlaceholderTest.java          |   6 +-
 .../camel/component/rest/FromRestRouteIdTest.java  |   4 +-
 .../component/rest/FromRestUriPrefixTest.java      |   4 +-
 .../rest/RestComponentVerifierExtensionTest.java   |  12 +-
 .../component/rest/RestComponentVerifierTest.java  |  12 +-
 .../camel/component/rest/RestEndpointTest.java     |   6 +-
 .../rest/RestProducerBindingProcessorTest.java     |   2 +-
 .../camel/component/saga/SagaComponentTest.java    |   2 +-
 .../scheduler/SchedulerBlockingManualTest.java     |   4 +-
 .../SchedulerMulticastParallelGreedyTest.java      |   4 +-
 .../scheduler/SchedulerNoPolledMessagesTest.java   |   4 +-
 .../scheduler/SchedulerRepeatCountTest.java        |   2 +-
 .../component/scheduler/SchedulerRouteTest.java    |   2 +-
 .../TwoSchedulerConcurrentTasksOneRouteTest.java   |   2 +-
 .../scheduler/TwoSchedulerConcurrentTasksTest.java |   2 +-
 .../component/scheduler/TwoSchedulerTest.java      |   2 +-
 .../seda/DirectRequestReplyAndSedaInOnlyTest.java  |   4 +-
 .../seda/FileSedaShutdownCompleteAllTasksTest.java |   2 +-
 ...meSedaQueueMultipleConsumersDifferenceTest.java |   4 +-
 .../seda/SameSedaQueueSizeAndNoSizeTest.java       |   4 +-
 .../component/seda/SedaAsyncProducerTest.java      |   6 +-
 .../camel/component/seda/SedaAsyncRouteTest.java   |   4 +-
 .../SedaBlockWhenFullInvalidConfigurationTest.java |   2 +-
 .../component/seda/SedaBlockWhenFullTest.java      |   2 +-
 .../camel/component/seda/SedaComplexInOutTest.java |   4 +-
 .../seda/SedaComponentReferenceEndpointTest.java   |   6 +-
 .../seda/SedaConcurrentConsumersNPEIssueTest.java  |   4 +-
 .../seda/SedaConcurrentConsumersTest.java          |   4 +-
 .../camel/component/seda/SedaConcurrentTest.java   |   6 +-
 .../camel/component/seda/SedaConfigureTest.java    |   2 +-
 .../seda/SedaConsumerSuspendResumeTest.java        |   4 +-
 .../seda/SedaDefaultBlockWhenFullTest.java         |   2 +-
 .../seda/SedaDefaultDiscardWhenFullTest.java       |   4 +-
 .../seda/SedaDefaultUnboundedQueueSizeTest.java    |   4 +-
 .../seda/SedaDiscardIfNoConsumerTest.java          |   6 +-
 .../component/seda/SedaDiscardWhenFullTest.java    |   4 +-
 .../camel/component/seda/SedaEndpointTest.java     |  12 +-
 .../apache/camel/component/seda/SedaErrorTest.java |   4 +-
 .../camel/component/seda/SedaFromRouteIdTest.java  |   4 +-
 .../component/seda/SedaInOnlyChainedTest.java      |   4 +-
 .../camel/component/seda/SedaInOnlyMEPTest.java    |   4 +-
 .../camel/component/seda/SedaInOnlyTest.java       |   4 +-
 .../component/seda/SedaInOutBigChainedTest.java    |   4 +-
 .../camel/component/seda/SedaInOutChainedTest.java |   4 +-
 .../seda/SedaInOutChainedTimeoutTest.java          |   4 +-
 .../seda/SedaInOutChainedWithOnCompletionTest.java |   6 +-
 .../camel/component/seda/SedaInOutMEPTest.java     |   4 +-
 .../apache/camel/component/seda/SedaInOutTest.java |   4 +-
 .../SedaInOutWithErrorDeadLetterChannelTest.java   |   4 +-
 .../component/seda/SedaInOutWithErrorTest.java     |   4 +-
 .../component/seda/SedaMultipleConsumersTest.java  |   6 +-
 .../camel/component/seda/SedaNoConsumerTest.java   |   8 +-
 .../component/seda/SedaPurgeWhenStoppingTest.java  |   4 +-
 .../camel/component/seda/SedaQueueFactoryTest.java |   6 +-
 .../apache/camel/component/seda/SedaQueueTest.java |   8 +-
 .../seda/SedaRemoveRouteThenAddAgainTest.java      |   4 +-
 .../seda/SedaShouldNotUseSameThreadTest.java       |   8 +-
 .../camel/component/seda/SedaSimpleSizeTest.java   |   4 +-
 .../apache/camel/component/seda/SedaSizeTest.java  |   4 +-
 .../seda/SedaSuspendConsumerStopRouteTest.java     |   4 +-
 .../component/seda/SedaTimeoutDisabledTest.java    |   4 +-
 .../camel/component/seda/SedaTimeoutTest.java      |   4 +-
 .../camel/component/seda/SedaUnitOfWorkTest.java   |  14 +-
 .../seda/SedaWaitForTaskAsPropertyTest.java        |   8 +-
 .../SedaWaitForTaskCompleteOnCompletionTest.java   |  10 +-
 .../seda/SedaWaitForTaskCompleteTest.java          |   6 +-
 .../seda/SedaWaitForTaskIfReplyExpectedTest.java   |   6 +-
 .../seda/SedaWaitForTaskNewerOnCompletionTest.java |  10 +-
 .../component/seda/SedaWaitForTaskNewerTest.java   |   6 +-
 .../component/seda/SedaWireTapOnCompleteTest.java  |   4 +-
 .../camel/component/seda/TracingWithDelayTest.java |   6 +-
 .../apache/camel/component/stub/StubAwsTest.java   |   2 +-
 .../camel/component/stub/StubConsumerTest.java     |   4 +-
 .../camel/component/stub/StubInOnlyTest.java       |   4 +-
 .../apache/camel/component/stub/StubInOutTest.java |   4 +-
 .../camel/component/stub/StubShadowTest.java       |   4 +-
 .../org/apache/camel/component/stub/StubTest.java  |   4 +-
 .../component/timer/TimerDelaySecondsTest.java     |   4 +-
 .../camel/component/timer/TimerDelayTest.java      |   4 +-
 .../camel/component/timer/TimerEndpointTest.java   |   4 +-
 .../camel/component/timer/TimerFiredTimeTest.java  |   4 +-
 .../component/timer/TimerGracefulShutdownTest.java |   4 +-
 .../timer/TimerMultipleConsumerStopRouteTest.java  |   4 +-
 .../component/timer/TimerMultipleConsumerTest.java |   4 +-
 .../camel/component/timer/TimerNameTest.java       |   4 +-
 .../component/timer/TimerNegativeDelayTest.java    |   4 +-
 .../timer/TimerNegativeNoRepeatCountDelayTest.java |   4 +-
 .../timer/TimerReferenceConfigurationTest.java     |   4 +-
 .../component/timer/TimerRepeatCountTest.java      |   4 +-
 .../camel/component/timer/TimerRestartTest.java    |   2 +-
 .../camel/component/timer/TimerRouteTest.java      |   2 +-
 .../component/timer/TimerRouteWithTracerTest.java  |   2 +-
 .../timer/TimerSuspendCamelContextTest.java        |   2 +-
 .../component/timer/TimerWithTimeOptionTest.java   |  16 +-
 .../validator/FileValidatorRouteTest.java          |   4 +-
 .../component/validator/ValidatorBeanCallTest.java |   4 +-
 .../validator/ValidatorDtdAccessAbstractTest.java  |   4 +-
 .../ValidatorEndpointClearCachedSchemaTest.java    |   6 +-
 .../validator/ValidatorIllegalImportTest.java      |   4 +-
 .../ValidatorIncludeEncodingRouteTest.java         |   6 +-
 .../ValidatorIncludeRelativeRouteTest.java         |   4 +-
 .../validator/ValidatorIncludeRouteTest.java       |   4 +-
 .../validator/ValidatorLazyStartProducerTest.java  |   4 +-
 .../ValidatorResourceResolverFactoryTest.java      |   6 +-
 .../component/validator/ValidatorRootPathTest.java |   4 +-
 .../component/validator/ValidatorRouteTest.java    |   4 +-
 .../validator/ValidatorWithDirectTest.java         |   4 +-
 .../ValidatorWithResourceResolverRouteTest.java    |   2 +-
 .../camel/component/xslt/InvalidXsltFileTest.java  |   4 +-
 .../xslt/XsltCustomErrorListenerTest.java          |   4 +-
 .../xslt/XsltCustomizeEntityResolverTest.java      |   7 +-
 .../xslt/XsltCustomizeURIResolverTest.java         |   4 +-
 .../apache/camel/component/xslt/XsltDTDTest.java   |   4 +-
 .../camel/component/xslt/XsltFeatureRouteTest.java |   6 +-
 .../camel/component/xslt/XsltFileNotFoundTest.java |   4 +-
 .../component/xslt/XsltFromFileExceptionTest.java  |   4 +-
 .../XsltFromHeaderOverrideEndpointUriTest.java     |   4 +-
 .../XsltIncludeClasspathDotInDirectoryTest.java    |   2 +-
 .../component/xslt/XsltIncludeClasspathTest.java   |   4 +-
 .../xslt/XsltIncludeRelativeFileSchemeTest.java    |   4 +-
 .../xslt/XsltIncludeRelativeNestedTest.java        |   4 +-
 .../xslt/XsltIncludeRelativeOtherTest.java         |   4 +-
 .../component/xslt/XsltIncludeRelativeTest.java    |   4 +-
 .../camel/component/xslt/XsltIncludeTest.java      |   4 +-
 .../component/xslt/XsltMessageTerminateTest.java   |   4 +-
 .../camel/component/xslt/XsltOutputBytesTest.java  |   4 +-
 .../camel/component/xslt/XsltOutputDOMTest.java    |   4 +-
 .../component/xslt/XsltOutputFileDeleteTest.java   |   4 +-
 .../camel/component/xslt/XsltOutputFileTest.java   |   6 +-
 .../camel/component/xslt/XsltOutputStringTest.java |   4 +-
 .../component/xslt/XsltResultHandlerTest.java      |   4 +-
 .../camel/component/xslt/XsltRouteFileTest.java    |   4 +-
 .../apache/camel/component/xslt/XsltRouteTest.java |   4 +-
 .../component/xslt/XsltRouteXsltWithErrorTest.java |   2 +-
 ...tTemplateFromHeaderOverrideEndpointUriTest.java |   4 +-
 .../xslt/XsltTransformingExceptionTest.java        |   4 +-
 .../component/xslt/XsltUriResolverFactoryTest.java |   6 +-
 .../camel/converter/CollectionConverterTest.java   |   4 +-
 .../org/apache/camel/converter/ConverterTest.java  |   4 +-
 .../camel/converter/DateTimeConverterTest.java     |   2 +-
 .../camel/converter/DurationConverterTest.java     |   6 +-
 .../apache/camel/converter/EnumConverterTest.java  |   2 +-
 .../camel/converter/FallbackPromoteTest.java       |   2 +-
 .../camel/converter/FutureConverterTest.java       |   6 +-
 .../apache/camel/converter/IOConverterTest.java    |   2 +-
 .../converter/InstanceFallbackConverterTest.java   |   4 +-
 .../java/org/apache/camel/converter/JaxpTest.java  |   8 +-
 .../camel/converter/ObjectConverterNaNTest.java    |  20 +-
 .../camel/converter/ObjectConverterTest.java       |  14 +-
 .../converter/PrimitiveTypeConverterIssueTest.java |   2 +-
 .../PropertyEditorTypeConverterIssueTest.java      |   2 +-
 .../converter/StaticFallbackConverterTest.java     |   6 +-
 .../apache/camel/converter/StringSourceTest.java   |   2 +-
 .../converter/TimePatternTypeConversionTest.java   |  14 +-
 .../TimerDrivenTimePatternConverterTest.java       |   2 +-
 .../camel/converter/jaxp/DomConverterTest.java     |   4 +-
 .../converter/jaxp/StreamSourceConverterTest.java  |   2 +-
 .../camel/converter/jaxp/XmlConverterTest.java     |   8 +-
 .../converter/stream/StreamCacheConverterTest.java |   2 +-
 .../camel/impl/BeanInjectProducerTemplateTest.java |   4 +-
 .../camel/impl/BeanInjectRouteBuilderTest.java     |   6 +-
 .../CamelContextAddRestDefinitionsFromXmlTest.java |   4 +-
 ...CamelContextAddRouteDefinitionsFromXmlTest.java |   2 +-
 .../camel/impl/CamelContextDeadlockTest.java       |   2 +-
 ...ontextReloadStrategyPropertiesFunctionTest.java |   4 +-
 .../camel/impl/CamelContextReloadStrategyTest.java |   6 +-
 .../apache/camel/impl/CamelContextTrackerTest.java |   2 +-
 .../CamelCustomDefaultThreadPoolProfileTest.java   |   6 +-
 .../CamelProduceInterfaceEventNotifierTest.java    |   2 +-
 .../camel/impl/CamelProduceInterfaceTest.java      |   4 +-
 .../camel/impl/ClassicUuidGeneratorTest.java       |   2 +-
 .../apache/camel/impl/ConfigurerResolverTest.java  |   2 +-
 .../camel/impl/ConsumerCacheOneCapacityTest.java   |   2 +-
 .../camel/impl/CustomBulkTypeConvertersTest.java   |   2 +-
 .../impl/CustomHeadersMapFactoryRouteTest.java     |   4 +-
 .../org/apache/camel/impl/CustomIdFactoryTest.java |   7 +-
 .../camel/impl/CustomUnitOfWorkFactoryTest.java    |   4 +-
 .../camel/impl/DataFormatContextAwareTest.java     |  10 +-
 .../camel/impl/DataFormatFluentSyntaxTest.java     |   2 +-
 .../impl/DataFormatPropertyPlaceholderTest.java    |   4 +-
 ...amelBeanPostProcessorComplexFieldFirstTest.java |  20 +-
 ...melContextAllowUseOriginalMessageFalseTest.java |   4 +-
 ...amelContextAllowUseOriginalMessageTrueTest.java |   4 +-
 .../impl/DefaultCamelContextAutoStartupTest.java   |   8 +-
 .../impl/DefaultCamelContextResolverTest.java      |  28 +-
 .../camel/impl/DefaultCamelContextRestartTest.java |   4 +-
 .../impl/DefaultCamelContextStopFailureTest.java   |   2 +-
 ...lContextSuspendResumeRouteStartupOrderTest.java |   4 +-
 .../DefaultCamelContextSuspendResumeRouteTest.java |   4 +-
 ...melContextWithLifecycleStrategyRestartTest.java |   7 +-
 .../impl/DefaultComponentAutowiredFalseTest.java   |  12 +-
 .../camel/impl/DefaultComponentAutowiredTest.java  |   4 +-
 .../DefaultComponentReferencePropertiesTest.java   |   6 +-
 .../apache/camel/impl/DefaultComponentTest.java    |   2 +-
 .../impl/DefaultComponentValidateURITest.java      |   4 +-
 .../camel/impl/DefaultConsumerCacheTest.java       |   2 +-
 .../camel/impl/DefaultConsumerTemplateTest.java    |  50 ++--
 ...ConsumerTemplateWithCustomCacheMaxSizeTest.java |   2 +-
 .../camel/impl/DefaultEndpointRegistryTest.java    |  10 +-
 .../camel/impl/DefaultExchangeHolderTest.java      |  14 +-
 .../org/apache/camel/impl/DefaultExchangeTest.java |  28 +-
 .../impl/DefaultExecutorServiceManagerTest.java    |  52 ++--
 .../camel/impl/DefaultInflightRepositoryTest.java  |   2 +-
 .../org/apache/camel/impl/DefaultInjectorTest.java |   4 +-
 .../camel/impl/DefaultMessageHeaderTest.java       |   2 +-
 .../camel/impl/DefaultProducerCacheTest.java       |  20 +-
 .../impl/DefaultProducerTemplateAsyncTest.java     |  14 +-
 ...efaultProducerTemplateNonBlockingAsyncTest.java |   5 +-
 .../camel/impl/DefaultProducerTemplateTest.java    |  22 +-
 ...ProducerTemplateWithCustomCacheMaxSizeTest.java |   2 +-
 .../apache/camel/impl/DummyLifecycleStrategy.java  |   3 +-
 .../camel/impl/DurationRoutePolicyFactoryTest.java |   4 +-
 .../impl/DurationRoutePolicyMaxMessagesTest.java   |   4 +-
 .../impl/DurationRoutePolicyMaxSecondsTest.java    |   6 +-
 .../apache/camel/impl/EndpointPrototypeTest.java   |   4 +-
 ...outeEndpointsRemoteRouteSharedEndpointTest.java |   4 +-
 ...tRegistryKeepRouteEndpointsRemoteRouteTest.java |   4 +-
 .../EndpointRegistryKeepRouteEndpointsTest.java    |   6 +-
 .../camel/impl/EndpointShutdownOnceTest.java       |   8 +-
 .../impl/EventDrivenPollingConsumerCopyTest.java   |   4 +-
 .../EventDrivenPollingConsumerQueueSizeTest.java   |   8 +-
 .../apache/camel/impl/ExpressionAdapterTest.java   |   4 +-
 .../apache/camel/impl/ExpressionSupportTest.java   |   4 +-
 .../impl/ExtendedStartupListenerComponentTest.java |   8 +-
 .../org/apache/camel/impl/FromEndpointTest.java    |   4 +-
 .../camel/impl/FromHasNoOutputRouteTest.java       |   2 +-
 .../camel/impl/FromMultipleEndpointTest.java       |   4 +-
 .../apache/camel/impl/GetRegistryAsTypeTest.java   |   4 +-
 .../GracefulShutdownNoAutoStartOrderClashTest.java |   2 +-
 .../impl/HashMapHeadersMapFactoryRouteTest.java    |   4 +-
 .../impl/HeaderFilterStrategyComponentTest.java    |   6 +-
 .../InflightRepositoryBrowseFromRouteTest.java     |   8 +-
 .../camel/impl/InflightRepositoryBrowseTest.java   |   8 +-
 .../camel/impl/InflightRepositoryRouteTest.java    |   6 +-
 ...erceptSendToMockEndpointStrategyCustomTest.java |   2 +-
 .../InterceptSendToMockEndpointStrategyTest.java   |   4 +-
 .../camel/impl/LanguageCamelContextAwareTest.java  |   2 +-
 .../camel/impl/LanguageFluentSyntaxTest.java       |   2 +-
 .../apache/camel/impl/LazyStartProducerTest.java   |   4 +-
 .../camel/impl/LifecycleStrategyDiscoveryTest.java |   2 +-
 .../impl/LifecycleStrategyFailOnStartupTest.java   |   5 +-
 .../camel/impl/LifecycleStrategyServiceTest.java   |   2 +-
 .../LimitedPollingConsumerPollStrategyTest.java    |  12 +-
 .../camel/impl/LogDebugBodyMaxCharsOffTest.java    |   4 +-
 .../camel/impl/LogDebugBodyMaxCharsTest.java       |   4 +-
 .../apache/camel/impl/LogDebugBodyStreamsTest.java |   4 +-
 .../org/apache/camel/impl/MessageSupportTest.java  |   8 +-
 .../camel/impl/Mock321ScheduledPollConsumer.java   |   2 +-
 .../apache/camel/impl/ModelCamelContextTest.java   |   6 +-
 .../camel/impl/MultipleComponentInstancesTest.java |   4 +-
 .../camel/impl/MultipleConsumersSupportTest.java   |  12 +-
 .../camel/impl/OriginalMessageProcessor.java       |   2 +-
 ...ingExchangesAsyncDelayShutdownGracefulTest.java |   4 +-
 .../impl/PendingExchangesShutdownGracefulTest.java |   6 +-
 ...ndingExchangesTwoRouteShutdownGracefulTest.java |   8 +-
 .../impl/PojoProduceInterceptEndpointTest.java     |   4 +-
 .../PojoProduceProxyInterceptEndpointTest.java     |   6 +-
 .../camel/impl/ProducerCacheNonSingletonTest.java  |   8 +-
 .../org/apache/camel/impl/RefDataFormatTest.java   |   8 +-
 .../RegistryLookupTypeClassCastExceptionTest.java  |   6 +-
 .../camel/impl/RemoveRouteStopEndpointTest.java    |   4 +-
 .../camel/impl/RouteDirectSuspendResumeTest.java   |   4 +-
 .../camel/impl/RouteIdRestDefinitionTest.java      |   4 +-
 .../impl/RouteMustHaveOutputOnExceptionTest.java   |   4 +-
 .../org/apache/camel/impl/RouteNoOutputTest.java   |   6 +-
 .../apache/camel/impl/RoutePolicyCallbackTest.java |   8 +-
 .../apache/camel/impl/RoutePolicyFactoryTest.java  |   4 +-
 .../camel/impl/RoutePolicyRefCallbackTest.java     |   4 +-
 .../apache/camel/impl/RoutePolicySupportTest.java  |   4 +-
 .../org/apache/camel/impl/RoutePolicyTest.java     |   8 +-
 .../org/apache/camel/impl/RouteRemoveTest.java     |   4 +-
 .../apache/camel/impl/RouteSedaStopStartTest.java  |   4 +-
 .../camel/impl/RouteSedaSuspendResumeTest.java     |   4 +-
 .../camel/impl/RouteSetRouteIdTwoTimesTest.java    |   2 +-
 .../camel/impl/RouteSuspendResumeWarmUpTest.java   |  10 +-
 .../impl/RouteWithMistypedComponentNameTest.java   |   4 +-
 .../camel/impl/RuntimeEndpointRegistryTest.java    |   4 +-
 .../impl/ScheduledPollConsumerBackoffTest.java     |   8 +-
 .../impl/ScheduledPollConsumerGreedyTest.java      |   8 +-
 .../camel/impl/ScheduledPollConsumerTest.java      |  10 +-
 .../ShutdownGracefulNoAutoStartedRoutesTest.java   |   4 +-
 .../impl/ShutdownGracefulTimeoutTriggerTest.java   |   6 +-
 ...ategyNotSuppressLoggingOnTimeoutManualTest.java |   4 +-
 ...StrategySuppressLoggingOnTimeoutManualTest.java |   4 +-
 .../org/apache/camel/impl/SimpleRegistryTest.java  |   2 +-
 .../apache/camel/impl/SimpleRegistryWrapTest.java  |   2 +-
 .../SimpleShutdownGracefulNoAtuoStartedTest.java   |   6 +-
 .../camel/impl/SimpleShutdownGracefulTest.java     |   6 +-
 .../apache/camel/impl/StartAndStopRoutesTest.java  |   4 +-
 .../camel/impl/StartStopAndShutdownRouteTest.java  |   4 +-
 .../StartupListenerComponentFromRegistryTest.java  |   6 +-
 .../camel/impl/StartupListenerComponentTest.java   |   6 +-
 .../org/apache/camel/impl/StartupListenerTest.java |   6 +-
 .../apache/camel/impl/StartupStepLoggingTest.java  |   6 +-
 .../camel/impl/StopRouteAbortAfterTimeoutTest.java |   4 +-
 .../apache/camel/impl/StopTimeoutRouteTest.java    |   4 +-
 .../camel/impl/TwoRouteSuspendResumeTest.java      |   4 +-
 .../impl/TypeConverterRegistryPerformanceTest.java |   2 +-
 ...gistryStatisticsEnabledNoStreamCachingTest.java |   4 +-
 ...TypeConverterRegistryStatisticsEnabledTest.java |   4 +-
 .../camel/impl/VetoCamelContextStartTest.java      |   6 +-
 .../camel/impl/converter/TypeConvertersTest.java   |   2 +-
 .../impl/engine/CamelPostProcessorHelperTest.java  |  14 +-
 .../camel/impl/engine/DefaultCamelContextTest.java |  24 +-
 .../engine/DefaultComponentNameResolverTest.java   |   2 +-
 .../impl/engine/DefaultFactoryFinderTest.java      |  15 +-
 .../DefaultSupervisingRouteControllerTest.java     |   8 +-
 .../engine/DefaultTransformerRegistryTest.java     |   2 +-
 .../engine/DefaultTransformerResolverTest.java     |   4 +-
 .../camel/impl/engine/EmptyProducerCacheTest.java  |   4 +-
 .../impl/engine/IntrospectionSupportTest.java      |  10 +-
 .../java/org/apache/camel/impl/engine/MyBean.java  |   2 +-
 .../camel/impl/engine/PeriodTaskSchedulerTest.java |   8 +-
 .../apache/camel/impl/engine/RouteRemove2Test.java |   4 +-
 .../event/CamelEventsTimestampEnabledTest.java     |   8 +-
 .../camel/impl/event/EventNotifierEventsTest.java  |  14 +-
 .../event/EventNotifierExchangeCompletedTest.java  |   6 +-
 .../EventNotifierExchangeSentParallelTest.java     |   4 +-
 .../impl/event/EventNotifierExchangeSentTest.java  |  10 +-
 .../EventNotifierFailureHandledEventsTest.java     |  10 +-
 ...ntNotifierIgnoreCamelContextInitEventsTest.java |  14 +-
 .../event/EventNotifierRedeliveryEventsTest.java   |   8 +-
 ...ventNotifierServiceStoppingFailedEventTest.java |   4 +-
 .../event/MultipleEventNotifierEventsTest.java     |  12 +-
 .../impl/event/SimpleEventNotifierEventsTest.java  |  14 +-
 .../health/DefaultHealthCheckRegistryTest.java     |  10 +-
 .../impl/health/HealthCheckResultStrategyTest.java |   4 +-
 .../apache/camel/impl/health/HealthCheckTest.java  |   2 +-
 .../camel/impl/health/MyFooHealthCheckTest.java    |   4 +-
 .../impl/health/ReadinessAndLivenessTest.java      |   4 +-
 .../camel/impl/health/RouteHealthCheckTest.java    |   4 +-
 .../health/SchedulerConsumerHealthCheckTest.java   |   2 +-
 .../verifier/DefaultComponentVerifierTest.java     |   6 +-
 .../camel/issues/AdviceWithCBRRouteIdTest.java     |   8 +-
 .../org/apache/camel/issues/AdviceWithCBRTest.java |   8 +-
 ...viceWithContextScopedErrorHandlerIssueTest.java |   6 +-
 .../issues/AdviceWithErrorHandlerRemoveTest.java   |   8 +-
 .../issues/AdviceWithInterceptFromRemoveTest.java  |   8 +-
 .../issues/AdviceWithInterceptRemoveTest.java      |   8 +-
 ...dviceWithInterceptSendToEndpointRemoveTest.java |   8 +-
 ...nterceptSendToEndpointWithLoadbalancerTest.java |   4 +-
 .../camel/issues/AdviceWithInterceptTest.java      |   6 +-
 .../issues/AdviceWithInvalidConfiguredTest.java    |   6 +-
 .../apache/camel/issues/AdviceWithIssueTest.java   |  14 +-
 .../issues/AdviceWithOnCompletionRemoveTest.java   |   8 +-
 .../camel/issues/AdviceWithOnCompletionTest.java   |   6 +-
 .../AdviceWithOnExceptionAndInterceptTest.java     |   2 +-
 .../AdviceWithOnExceptionMultipleIssueTest.java    |  16 +-
 .../issues/AdviceWithOnExceptionRemoveTest.java    |   8 +-
 .../camel/issues/AdviceWithOnExceptionTest.java    |   6 +-
 .../apache/camel/issues/AdviceWithPolicyTest.java  |   6 +-
 .../issues/AdviceWithPropertyPlaceholderTest.java  |   4 +-
 .../camel/issues/AdviceWithRoutePolicyTest.java    |   6 +-
 ...AdviceWithRouteScopedErrorHandlerIssueTest.java |   6 +-
 .../issues/AdviceWithStartTargetIssueTest.java     |   9 +-
 .../camel/issues/AdviceWithTransactedTest.java     |   6 +-
 .../AdviceWithTwoRoutesOnExceptionIssueTest.java   |  10 +-
 .../camel/issues/AdviceWithUrlIssueTest.java       |   6 +-
 .../issues/AdviceWithWeaveByToUriCBRTest.java      |   4 +-
 .../issues/AdviceWithWeaveByToUriToDTest.java      |   8 +-
 .../camel/issues/AdviceWithWeaveByTypeCBRTest.java |   6 +-
 .../AggregatorWithBatchConsumingIssueTest.java     |   6 +-
 .../apache/camel/issues/AmahDeadLetterTest.java    |   4 +-
 .../apache/camel/issues/CBRContainsIssueTest.java  |   4 +-
 .../issues/CBRCustomPredicateAsFilterTest.java     |   4 +-
 .../CacheInputStreamInDeadLetterIssue520Test.java  |   6 +-
 .../apache/camel/issues/Camel4857UriIssueTest.java |   7 +-
 .../camel/issues/ChangeHeaderCaseIssueTest.java    |   6 +-
 .../CharlesSplitAndTryCatchRollbackIssueTest.java  |   4 +-
 ...CharlesSplitUseBeanAsErrorHandlerIssueTest.java |   4 +-
 .../issues/ChoiceEndOrEndChoiceIssueTest.java      |   4 +-
 .../issues/ChoicePredicateSimpleHeaderTest.java    |   4 +-
 .../camel/issues/ComponentUseRawUriTest.java       |   4 +-
 .../issues/ConsumerTemplateSedaQueueIssueTest.java |   6 +-
 ...tScopedOnExceptionErrorHandlerRefIssueTest.java |   4 +-
 ...ExceptionErrorHandlerRefIssueTwoRoutesTest.java |   4 +-
 ...nExceptionMultipleRouteBuildersReverseTest.java |   6 +-
 ...ScopedOnExceptionMultipleRouteBuildersTest.java |   6 +-
 ...xceptionNotHandledErrorHandlerRefIssueTest.java |   4 +-
 ...otHandledErrorHandlerRefIssueTwoRoutesTest.java |   4 +-
 ...HandledRouteScopedErrorHandlerRefIssueTest.java |   4 +-
 ...uteScopedErrorHandlerRefIssueTwoRoutesTest.java |   4 +-
 ...ceptionRouteScopedErrorHandlerRefIssueTest.java |   4 +-
 ...uteScopedErrorHandlerRefIssueTwoRoutesTest.java |   4 +-
 .../camel/issues/CustomFailveOverProcessor.java    |   6 +-
 .../org/apache/camel/issues/DavidSiefertTest.java  |   6 +-
 .../issues/DoCatchCaughExceptionIssueTest.java     |   6 +-
 .../issues/DynamicRouterWithInterceptorTest.java   |   3 +-
 .../DynamicallyConcurrentlyAddRoutesTest.java      |   6 +-
 .../issues/EndpointWithRawUriParameterTest.java    |  10 +-
 .../camel/issues/ErrorHandlerAdviceIssueTest.java  |   8 +-
 .../issues/ErrorHandlerOnRedeliveryStopTest.java   |   6 +-
 .../camel/issues/ExceptionCamel4022Test.java       |   4 +-
 .../camel/issues/ExceptionPolicyIssueTest.java     |   4 +-
 .../org/apache/camel/issues/ExceptionTest.java     |   2 +-
 ...tionThrownFromOnExceptionNoEndlessLoopTest.java |   4 +-
 .../issues/ExceptionThrownFromOnExceptionTest.java |  16 +-
 .../issues/FileSplitStreamingWithChoiceTest.java   |   4 +-
 .../issues/FilterCustomPredicateAsFilterTest.java  |   4 +-
 .../org/apache/camel/issues/GertJBIIssueTest.java  |   6 +-
 .../InterceptCustomPredicateAsFilterTest.java      |   4 +-
 .../apache/camel/issues/InterceptFromLogTest.java  |   4 +-
 .../InterceptFromPredicateProceedAndStopTest.java  |  12 +-
 .../java/org/apache/camel/issues/Issue3Test.java   |   8 +-
 .../MDCUnitLoggingOutOfMemoryManualTest.java       |   6 +-
 .../camel/issues/MethodClassByTypeIssueTest.java   |   4 +-
 .../camel/issues/MockValueBuilderIssueTest.java    |   4 +-
 ...ticastAggregationStrategyInputExchangeTest.java |   4 +-
 ...icastAggregationStrategyThrowExceptionTest.java |   4 +-
 ...essageBodyAndEnrichedHeadersClaimCheckTest.java |   2 +-
 ...xOriginalMessageBodyAndEnrichedHeadersTest.java |   2 +-
 ...eBodyAndEnrichedHeadersUseOriginalBodyTest.java |   2 +-
 ...lelStopOnExceptionWithOnExceptionIssueTest.java |   8 +-
 ...thAggregationStrategyThrowingExceptionTest.java |   4 +-
 .../MulticastParallelWithOnExceptionIssueTest.java |   4 +-
 .../MulticastPipelineAggregateIssueTest.java       |   4 +-
 ...UnitOfWorkOnExceptionHandledFalseIssueTest.java |   4 +-
 .../issues/MulticastSingleAggregateIssueTest.java  |   4 +-
 ...astStopOnExceptionWithOnExceptionIssueTest.java |  10 +-
 .../issues/MulticastWithOnExceptionIssueTest.java  |  10 +-
 .../MultipleErrorHandlerOnExceptionIssueTest.java  |   4 +-
 .../org/apache/camel/issues/MultipleFromTest.java  |   4 +-
 ...derExactlyDoneSplitterWhereSentToIssueTest.java |   4 +-
 ...tifyBuilderOnFailureShutdownCamelIssueTest.java |   6 +-
 .../OnCompletionAfterConsumerModeIssueTest.java    |   6 +-
 .../OnCompletionBeforeConsumerModeIssueTest.java   |  12 +-
 .../apache/camel/issues/OnCompletionIssueTest.java |   4 +-
 .../OnExceptionBeforeErrorHandlerIssueTest.java    |   6 +-
 .../issues/OnExceptionContinuedIssueTest.java      |   8 +-
 ...OnExceptionContinuedNoFailureProcessorTest.java |   6 +-
 ...tionErrorHandlerNoRouteOnExchangeIssueTest.java |  10 +-
 .../OnExceptionErrorHandlerRefIssueTest.java       |   4 +-
 ...ExceptionErrorHandlerRefIssueTwoRoutesTest.java |   4 +-
 .../OnExceptionHandledNoFailureProcessorTest.java  |   6 +-
 ...xceptionNotHandledErrorHandlerRefIssueTest.java |   4 +-
 ...otHandledErrorHandlerRefIssueTwoRoutesTest.java |   4 +-
 ...nExceptionNotHandledNoFailureProcessorTest.java |   6 +-
 ...HandledRouteScopedErrorHandlerRefIssueTest.java |   4 +-
 ...uteScopedErrorHandlerRefIssueTwoRoutesTest.java |   4 +-
 .../camel/issues/OnExceptionProcessIssueTest.java  |  10 +-
 ...ceptionRouteScopedErrorHandlerRefIssueTest.java |   4 +-
 ...uteScopedErrorHandlerRefIssueTwoRoutesTest.java |   4 +-
 .../camel/issues/OnExceptionWithTwoBeansTest.java  |   6 +-
 .../PopulateInitialHeadersFailedIssueTest.java     |   4 +-
 .../issues/PropertiesAvailableEverywhereTest.java  |   4 +-
 .../camel/issues/ProxyReturnNullIssueTest.java     |   4 +-
 ...ntListAggregationStrategyInputExchangeTest.java |   4 +-
 .../RecipientListDirectNoConsumerIssueTest.java    |   4 +-
 .../RecipientListErrorHandlingIssueTest.java       |   6 +-
 ...thAggregationStrategyThrowingExceptionTest.java |   4 +-
 ...UnitOfWorkOnExceptionHandledFalseIssueTest.java |   4 +-
 ...eOriginalMessageEndpointExceptionIssueTest.java |   4 +-
 .../RecipientListUseOriginalMessageIssueTest.java  |   8 +-
 .../issues/RecipientListWithInterceptorTest.java   |   3 +-
 ...andlerAsyncDelayedTwoCamelContextIssueTest.java |   2 +-
 ...olicyOnExceptionWhileRedeliveringIssueTest.java |   4 +-
 .../camel/issues/RegExPredicateIssueTest.java      |   4 +-
 ...ryContextScopedUntilRecipientListIssueTest.java |   4 +-
 ...tScopedUntilRecipientListParallelIssueTest.java |   4 +-
 ...etryRouteScopedUntilRecipientListIssueTest.java |  16 +-
 ...eScopedUntilRecipientListParallelIssueTest.java |   4 +-
 .../RetryWhilePredicateExpressionIssueTest.java    |   6 +-
 .../RetryWhileSimpleExpressionIssueTest.java       |   4 +-
 .../issues/RetryWhileStackOverflowIssueTest.java   |   4 +-
 .../apache/camel/issues/RomeksExceptionTest.java   |   4 +-
 .../issues/RouteIdAnonymousAndFixedClashTest.java  |   8 +-
 .../camel/issues/RouteIdAutoAssignClashIssue.java  |   4 +-
 .../RouteScopedErrorHandlerAndOnExceptionTest.java |   8 +-
 ...ScopedOnExceptionMultipleRouteBuildersTest.java |   6 +-
 ...eptionWithInterceptSendToEndpointIssueTest.java |   6 +-
 ...erceptSendToEndpointIssueWithPredicateTest.java |   6 +-
 .../RouteStartupFailShouldStopAlsoIssueTest.java   |   8 +-
 .../apache/camel/issues/RouteWithCustomIdTest.java |   4 +-
 .../camel/issues/RoutingSlipMemoryLeakTest.java    |   6 +-
 .../issues/RoutingSlipWithInterceptorTest.java     |   3 +-
 ...RouteAndContextScopedErrorHandlerIssueTest.java |   8 +-
 .../camel/issues/SedaFileIdempotentIssueTest.java  |   6 +-
 .../SedaFileIdempotentNoTimeoutIssueTest.java      |   4 +-
 .../issues/SedaFileIdempotentTimeoutIssueTest.java |   4 +-
 .../issues/SentExchangeEventNotifierIssueTest.java |  16 +-
 .../SentExchangeEventNotifierTwoIssueTest.java     |  16 +-
 .../camel/issues/SetBodyTryCatchIssueTest.java     |   6 +-
 .../camel/issues/SetHeaderInDoCatchIssueTest.java  |  16 +-
 .../camel/issues/SplitContinuedLogIssueTest.java   |   2 +-
 .../camel/issues/SplitListListIssueTest.java       |   4 +-
 .../camel/issues/SplitPropertiesFileIssueTest.java |   4 +-
 ...UnitOfWorkOnExceptionHandledFalseIssueTest.java |   4 +-
 .../issues/SplitStopOnExceptionIssueTest.java      |   6 +-
 .../SplitWithCustomAggregationStrategyTest.java    |   4 +-
 .../camel/issues/SplitWithInterceptorTest.java     |   3 +-
 ...litterAggregationStrategyInputExchangeTest.java |   4 +-
 .../issues/SplitterCorrelationIdIssueTest.java     |   6 +-
 .../camel/issues/SplitterParallelIssueTest.java    |   4 +-
 ...arallelRuntimeExceptionInHasNextOrNextTest.java |   4 +-
 ...thAggregationStrategyThrowingExceptionTest.java |   4 +-
 ...rParallelWithIteratorThrowingExceptionTest.java |   4 +-
 .../SplitterThrowExceptionInExpressionTest.java    |   4 +-
 .../SplitterThrowExceptionInExpressionTwoTest.java |   4 +-
 ...terUsingBeanReturningCloseableIteratorTest.java |   9 +-
 .../SplitterUsingBeanReturningMessageTest.java     |   4 +-
 .../apache/camel/issues/StopAndFailRouteTest.java  |   4 +-
 .../camel/issues/StopCamelFromRouteTest.java       |   6 +-
 .../camel/issues/StopRouteFromRouteTest.java       |   6 +-
 .../issues/StopRouteImpactsErrorHandlerTest.java   |   8 +-
 ...dNotStopContextScopedErrorHandlerIssueTest.java |   4 +-
 ...uldNotStopRouteScopedErrorHandlerIssueTest.java |   4 +-
 ...ryCatchInterceptSendToAllEndpointIssueTest.java |   4 +-
 ...ThreadsRejectedExecutionWithDeadLetterTest.java |   4 +-
 .../issues/TimerAndErrorHandlerIssueTest.java      |   4 +-
 .../issues/ToDWindowsFilePathIssueManualTest.java  |   6 +-
 .../camel/issues/TracingStandbyNoRouteTest.java    |   2 +-
 .../apache/camel/issues/TracingStandbyTest.java    |   6 +-
 .../TransactedPropertyPlaceholderIssueTest.java    |   4 +-
 .../camel/issues/TransactedSetHeaderIssueTest.java |   4 +-
 .../TryCatchFinallyOnExceptionIssueTest.java       |   4 +-
 .../camel/issues/TryCatchSetHeaderIssueTest.java   |   8 +-
 .../camel/issues/TryCatchWireTapOnPrepareTest.java |   4 +-
 .../camel/issues/TryCatchWithSplitIssueTest.java   |   2 +-
 .../TwoDoTryAndThrowInInnerCatchIssueTest.java     |   4 +-
 ...erceptSendToEndpointIssueWithPredicateTest.java |   6 +-
 .../camel/issues/TwoTimerWithJMXIssueTest.java     |   7 +-
 .../apache/camel/issues/XPathSplitStreamTest.java  |   4 +-
 .../language/BeanAnnotationParameterTest.java      |   4 +-
 .../language/BeanAnnotationParameterTwoTest.java   |   4 +-
 .../language/BeanLanguageInvalidOGNLTest.java      |   2 +-
 .../BeanLanguageMethodMissingParenthesisTest.java  |   6 +-
 .../camel/language/BeanLanguageOGNLTest.java       |   6 +-
 ...LWithDotInParameterPropertyPlaceholderTest.java |   4 +-
 .../BeanLanguageOGNLWithDotInParameterTest.java    |   4 +-
 .../java/org/apache/camel/language/BeanTest.java   |  16 +-
 .../ConstantLanguageBinaryResourceTest.java        |   8 +-
 .../camel/language/ConstantResultTypeTest.java     |   4 +-
 .../org/apache/camel/language/ConstantTest.java    |   4 +-
 .../apache/camel/language/ConstantTrimTest.java    |   4 +-
 .../camel/language/FileLanguageExtSingleTest.java  |   2 +-
 .../apache/camel/language/FileLanguageTest.java    |  28 +-
 .../java/org/apache/camel/language/HeaderTest.java |   4 +-
 .../apache/camel/language/LanguageServiceTest.java |   6 +-
 .../apache/camel/language/NoSuchLanguageTest.java  |   2 +-
 .../PropertyInjectAnnotationParameterTest.java     |   4 +-
 .../org/apache/camel/language/PropertyTest.java    |   4 +-
 .../apache/camel/language/RefPredicateTest.java    |   4 +-
 .../java/org/apache/camel/language/RefTest.java    |  10 +-
 .../camel/language/SimpleLanguageRouteTest.java    |   4 +-
 .../SimpleLanguageTransformRandomTest.java         |   6 +-
 .../camel/language/SimpleOgnlMapIssueTest.java     |   4 +-
 ...irIteratorSplitChoicePerformanceManualTest.java |  16 +-
 .../camel/language/TokenPairPredicateTest.java     |   4 +-
 .../TokenXMLPairMultiNamespaceSplitTest.java       |   2 +-
 .../TokenXMLPairNamespaceMultilineSplitTest.java   |   2 +-
 ...kenXMLPairNamespaceSplitChildNamespaceTest.java |   4 +-
 .../language/TokenXMLPairNamespaceSplitTest.java   |   4 +-
 .../org/apache/camel/language/TokenizerTest.java   |  54 ++--
 .../org/apache/camel/language/VariableTest.java    |   6 +-
 .../language/XPathAnotherRouteConcurrentTest.java  |   6 +-
 .../camel/language/XPathFromFileExceptionTest.java |   4 +-
 .../apache/camel/language/XPathFunctionTest.java   |   2 +-
 .../camel/language/XPathIntegerResultTest.java     |   6 +-
 .../camel/language/XPathLanguageEndpointTest.java  |   4 +-
 .../language/XPathLanguageSingleNodeListTest.java  |   4 +-
 .../apache/camel/language/XPathResourceTest.java   |   4 +-
 .../language/XPathRouteConcurrentBigTest.java      |   4 +-
 .../camel/language/XPathRouteConcurrentTest.java   |   4 +-
 .../XPathSplitChoicePerformanceManualTest.java     |  16 +-
 .../java/org/apache/camel/language/XPathTest.java  |   6 +-
 .../csimple/CSimpleExpressionParserTest.java       |  26 +-
 .../csimple/CSimplePredicateParserTest.java        |   8 +-
 .../apache/camel/language/csimple/CSimpleTest.java |   4 +-
 .../camel/language/csimple/HighPredicate.java      |   3 +-
 .../camel/language/csimple/MedPredicate.java       |   3 +-
 .../language/simple/BodyOriginalMessageTest.java   |   4 +-
 .../camel/language/simple/InvokeCloneTest.java     |   2 +-
 .../simple/SimpleBackwardsCompatibleTest.java      |   8 +-
 .../language/simple/SimpleCacheExpressionTest.java |  10 +-
 .../camel/language/simple/SimpleDecHeaderTest.java |   4 +-
 .../simple/SimpleExpressionParserNodesTest.java    |   4 +-
 .../camel/language/simple/SimpleIncHeaderTest.java |   4 +-
 .../simple/SimpleInheritanceIssueTest.java         |   6 +-
 .../SimpleMessageHistoryNotDetailedTest.java       |   4 +-
 .../language/simple/SimpleMessageHistoryTest.java  |   4 +-
 .../camel/language/simple/SimpleOperatorTest.java  |  92 +++----
 .../language/simple/SimpleOverrideMethodTest.java  |   2 +-
 .../simple/SimpleParserExpressionInvalidTest.java  |  10 +-
 .../simple/SimpleParserExpressionTest.java         |  42 +--
 .../simple/SimpleParserPredicateInvalidTest.java   |  14 +-
 .../language/simple/SimpleParserPredicateTest.java |  38 +--
 .../simple/SimpleParserRegexpPredicateTest.java    |   2 +-
 .../simple/SimplePredicateParserNodesTest.java     |   4 +-
 .../language/simple/SimpleResourceDynamicTest.java |   4 +-
 .../camel/language/simple/SimpleResourceTest.java  |   4 +-
 .../SimpleRouteExpressionAsPredicateTest.java      |   4 +-
 .../simple/SimpleSetHeaderPredicateTest.java       |   4 +-
 .../apache/camel/language/simple/SimpleTest.java   | 300 ++++++++++-----------
 .../tokenizer/TokenizePairTokenSimpleTest.java     |   4 +-
 .../apache/camel/model/ChoiceDefinitionTest.java   |  20 +-
 .../model/GatherAllStaticEndpointUrisTest.java     |   6 +-
 .../model/GenerateXmFromCamelContextTest.java      |   4 +-
 .../model/ModelRouteFilterPatternExcludeTest.java  |   4 +-
 .../ModelRouteFilterPatternIncludeExcludeTest.java |   4 +-
 .../model/ModelRouteFilterPatternIncludeTest.java  |   4 +-
 .../apache/camel/model/ModelSanityCheckerTest.java |   2 +-
 .../camel/model/ProcessDefinitionSetBodyTest.java  |   4 +-
 .../camel/model/ProcessorDefinitionHelperTest.java |   6 +-
 .../model/ProcessorTypeConfigurationTest.java      |   4 +-
 .../model/RouteConfigurationOnCompletionTest.java  |   4 +-
 .../org/apache/camel/model/RouteGroupTest.java     |   4 +-
 .../apache/camel/model/RoutePropertiesTest.java    |   2 +-
 .../RoutesConfigurationBuilderIdOrPatternTest.java |  22 +-
 .../model/RoutesConfigurationBuilderTest.java      |  30 +--
 .../model/RoutesConfigurationErrorHandlerTest.java |  16 +-
 ...outesConfigurationMultipleRouteBuilderTest.java |   6 +-
 .../model/RoutesConfigurationOnCompletionTest.java |  12 +-
 .../camel/model/RoutesConfigurationTest.java       |   6 +-
 .../camel/model/RoutesConfigurationUpdateTest.java |  16 +-
 .../model/StartingRoutesErrorReportedTest.java     |  20 +-
 .../camel/model/dataformat/DummyDataformat.java    |   4 +-
 .../camel/processor/AnimalDeepClonePrepare.java    |   2 +-
 .../apache/camel/processor/AsyncLoopCopyTest.java  |   8 +-
 .../processor/BatchConsumerPooledExchangeTest.java |   6 +-
 .../BatchResequencerAllowDuplicatesTest.java       |   4 +-
 .../processor/BatchResequencerJMSPriorityTest.java |   4 +-
 .../BatchResequencerWithDuplicateTest.java         |   4 +-
 .../BeanInvocationThrowsExceptionTest.java         |   6 +-
 .../BeanOgnMethodWithXPathInjectionTest.java       |   4 +-
 .../BeanProcessorSpecializedMessageTest.java       |   6 +-
 .../BeanRecipientListInterfaceAnnotationTest.java  |   2 +-
 .../camel/processor/BeanRecipientListTest.java     |   2 +-
 .../org/apache/camel/processor/BeanRouteTest.java  |   4 +-
 .../apache/camel/processor/BeanSingletonTest.java  |   2 +-
 .../camel/processor/BeanWithExceptionTest.java     |   4 +-
 .../BeanWithXPathInjectionPreCompileTest.java      |   4 +-
 .../processor/BeanWithXPathInjectionTest.java      |   4 +-
 .../camel/processor/BreadcrumbDisabledTest.java    |   8 +-
 .../org/apache/camel/processor/BreadcrumbTest.java |   8 +-
 .../camel/processor/CBRHeaderPredicateTest.java    |   4 +-
 .../CBRPredicateBeanThrowExceptionTest.java        |   4 +-
 .../processor/CBRSimplePredicateEmptyBodyTest.java |   4 +-
 .../apache/camel/processor/CBRSimpleTypeTest.java  |   4 +-
 .../camel/processor/CBRWithLoadBalancerTest.java   |   4 +-
 .../camel/processor/CBRWithMulticastTest.java      |   4 +-
 .../camel/processor/CBRWithRecipientListTest.java  |   4 +-
 .../apache/camel/processor/CBRWithWireTapTest.java |   4 +-
 .../processor/Camel715ThreadProcessorTest.java     |   6 +-
 .../CamelCaseInsentiveHeadersFalseTest.java        |   4 +-
 .../CamelCaseInsentiveHeadersTrueTest.java         |   4 +-
 .../CamelContextLogExhaustedMessageBodyTest.java   |   6 +-
 .../org/apache/camel/processor/ChannelTest.java    |   6 +-
 .../apache/camel/processor/ChoiceAsyncTest.java    |   2 +-
 .../processor/ChoiceInPreconditionModeTest.java    |   2 +-
 .../camel/processor/ChoiceNoErrorHandlerTest.java  |   4 +-
 .../camel/processor/ChoiceNoOtherwiseTest.java     |  10 +-
 .../ChoicePredicateThrowExceptionTest.java         |   4 +-
 .../org/apache/camel/processor/ChoiceTest.java     |   2 +-
 .../apache/camel/processor/ChoiceWithEndTest.java  |   8 +-
 .../ClaimCheckEipDynamicKeyGetSetTest.java         |   4 +-
 .../ClaimCheckEipGetAndRemoveSetTest.java          |   4 +-
 .../camel/processor/ClaimCheckEipGetSetTest.java   |   4 +-
 .../processor/ClaimCheckEipPushPopBodyTest.java    |   4 +-
 .../ClaimCheckEipPushPopExcludeBodyTest.java       |   4 +-
 .../ClaimCheckEipPushPopHeadersPatternTest.java    |   4 +-
 .../processor/ClaimCheckEipPushPopHeadersTest.java |   4 +-
 .../ClaimCheckEipPushPopRemoveHeaderTest.java      |   4 +-
 .../camel/processor/ClaimCheckEipPushPopTest.java  |   4 +-
 .../camel/processor/ConsumerRouteIdAwareTest.java  |  10 +-
 .../apache/camel/processor/CorrectRouteIdTest.java |   4 +-
 .../CreateRouteWithNonExistingEndpointTest.java    |   4 +-
 .../CustomConsumerExceptionHandlerTest.java        |   4 +-
 .../processor/CustomProcessorFactoryTest.java      |   4 +-
 .../camel/processor/CustomRoutePolicyTest.java     |   4 +-
 .../processor/CustomScheduledRoutePolicyTest.java  |   4 +-
 .../processor/DataFormatServiceCustomRefTest.java  |   4 +-
 .../camel/processor/DataFormatServiceTest.java     |  10 +-
 .../DeadLetterChannelAlwaysHandledTest.java        |   4 +-
 ...ChannelBuilderWithInvalidDeadLetterUriTest.java |   8 +-
 .../DeadLetterChannelCatchThrowableTest.java       |   6 +-
 .../DeadLetterChannelFailureRouteIdTest.java       |   4 +-
 .../DeadLetterChannelHandleNewExceptionTest.java   |   4 +-
 .../DeadLetterChannelHandledExampleTest.java       |   4 +-
 ...lHandledExampleWithDefaultErrorHandlerTest.java |   4 +-
 ...etterChannelLogExhaustedMessageHistoryTest.java |   4 +-
 ...nnelLogExhaustedMessageHistoryWithBodyTest.java |   4 +-
 .../DeadLetterChannelNewExceptionTest.java         |   8 +-
 .../DeadLetterChannelNoRedeliveryTest.java         |   6 +-
 ...DeadLetterChannelNotHandleNewExceptionTest.java |   8 +-
 ...adLetterChannelOnExceptionOnRedeliveryTest.java |  10 +-
 .../processor/DeadLetterChannelOnPrepareTest.java  |   6 +-
 .../DeadLetterChannelOnRedeliveryTest.java         |   8 +-
 ...dLetterChannelPropagateCausedExceptionTest.java |  12 +-
 ...etterChannelRedeliverWithDelayBlockingTest.java |   6 +-
 ...LetterChannelRedeliveringWhileShutdownTest.java |   6 +-
 ...eadLetterChannelRedeliveryDelayPatternTest.java |   6 +-
 .../processor/DeadLetterChannelRedeliveryTest.java |   4 +-
 .../DeadLetterChannelRestartFromBeginningTest.java |   6 +-
 .../processor/DeadLetterChannelSetHeaderTest.java  |   4 +-
 .../DeadLetterChannelUnmarshalSetHeaderTest.java   |  12 +-
 .../DeadLetterChannelUseOriginalInBodyTest.java    |   6 +-
 ...LetterChannelUseOriginalInBodyWithFileTest.java |   6 +-
 ...tConsumerBridgeErrorHandlerOnExceptionTest.java |  10 +-
 ...ltConsumerBridgeErrorHandlerRedeliveryTest.java |   6 +-
 .../DefaultConsumerBridgeErrorHandlerTest.java     |  10 +-
 .../DefaultErrorHandlerCatchThrowableTest.java     |   8 +-
 .../DefaultErrorHandlerExplicitConfiguredTest.java |   6 +-
 .../DefaultErrorHandlerFailureRouteIdTest.java     |   6 +-
 ...ErrorHandlerLogExhaustedMessageHistoryTest.java |   6 +-
 .../DefaultErrorHandlerLogStackTraceTest.java      |   6 +-
 .../DefaultErrorHandlerOnExceptionTest.java        |   6 +-
 .../DefaultErrorHandlerOnPrepareTest.java          |  10 +-
 .../DefaultErrorHandlerRedeliveryRefTest.java      |   6 +-
 .../DefaultErrorHandlerRedeliveryTest.java         |  10 +-
 .../camel/processor/DefaultErrorHandlerTest.java   |   6 +-
 ...cheduledPollConsumerBridgeErrorHandlerTest.java |  10 +-
 .../DefinitionPolicyPerProcessorTest.java          |   4 +-
 .../camel/processor/DelayInterceptorTest.java      |   8 +-
 .../camel/processor/DelayerPerRouteTest.java       |   4 +-
 .../camel/processor/DisabledProcessorTest.java     |   4 +-
 .../processor/DoTryCatchWithSplitterTest.java      |   4 +-
 .../DoubleLoadBalancerMisconfigurationTest.java    |   6 +-
 .../apache/camel/processor/DualPipelineTest.java   |   4 +-
 .../apache/camel/processor/DynamicRouter2Test.java |   4 +-
 .../apache/camel/processor/DynamicRouter3Test.java |   4 +-
 .../apache/camel/processor/DynamicRouter4Test.java |   4 +-
 .../processor/DynamicRouterAnnotationTest.java     |   4 +-
 .../DynamicRouterExchangeHeaders2Test.java         |   4 +-
 .../DynamicRouterExchangeHeadersTest.java          |   4 +-
 .../DynamicRouterExchangePropertiesTest.java       |   4 +-
 .../processor/DynamicRouterOnExceptionTest.java    |  16 +-
 .../apache/camel/processor/DynamicRouterTest.java  |   4 +-
 ...amicRouterThrowExceptionFromExpressionTest.java |   4 +-
 .../org/apache/camel/processor/EchoProcessor.java  |   2 +-
 ...point2MustBeStartedBeforeSendProcessorTest.java |  26 +-
 ...dpointMustBeStartedBeforeSendProcessorTest.java |  26 +-
 .../camel/processor/EnrichSubUnitOfWorkTest.java   |   8 +-
 .../camel/processor/EnrichVariableErrorTest.java   |  20 +-
 .../camel/processor/EnrichVariableHeadersTest.java |   4 +-
 .../apache/camel/processor/EnrichVariableTest.java |   4 +-
 .../camel/processor/EnrichWithUnitOfWorkTest.java  |   8 +-
 ...HandlerOnExceptionRedeliveryAndHandledTest.java |   4 +-
 .../apache/camel/processor/ErrorHandlerTest.java   |   6 +-
 .../processor/ErrorHandlerWrappedEachNodeTest.java |   8 +-
 .../processor/EvaluateExpressionProcessorTest.java |   4 +-
 .../EventNotifierExchangeSentExampleTest.java      |   4 +-
 .../processor/EventNotifierExchangeSentTest.java   |   6 +-
 .../processor/ExceptionHandlerStreamCacheTest.java |   2 +-
 .../processor/ExchangeCreatedTimestampTest.java    |   4 +-
 .../processor/ExchangeIdempotentConsumerTest.java  |   2 +-
 .../processor/ExpressionPlaceholderNestedTest.java |   6 +-
 .../processor/FailOverAllFailedExceptionTest.java  |   2 +-
 .../camel/processor/FailOverLoadBalanceTest.java   |   2 +-
 .../FailOverLoadBalanceWithRedeliveryTest.java     |   6 +-
 .../FailOverLoadBalancerSetFaultTest.java          |   8 +-
 .../processor/FailOverNotCatchedExceptionTest.java |   2 +-
 ...overLoadBalancerBreakoutDuringShutdownTest.java |   8 +-
 .../FailoverMaximumFailoverAttemptsTest.java       |   4 +-
 .../processor/FailoverRoundRobinGoodBadTest.java   |   4 +-
 .../processor/FailoverRoundRobinStickyTest.java    |   4 +-
 .../camel/processor/FailoverRoundRobinTest.java    |   4 +-
 .../apache/camel/processor/FailoverStickyTest.java |   4 +-
 .../FileIdempotentConsumerCreateRepoTest.java      |   2 +-
 .../processor/FileRollbackOnCompletionTest.java    |   6 +-
 .../camel/processor/FilterBeforeSplitTest.java     |   4 +-
 .../camel/processor/FlipRoutePolicyTest.java       |   4 +-
 .../apache/camel/processor/FromToInOutTest.java    |   6 +-
 .../camel/processor/FromToInOutUsingToTest.java    |   6 +-
 .../apache/camel/processor/FromVariableTest.java   |   4 +-
 .../processor/IdempotentConsumerAsyncTest.java     |  10 +-
 .../IdempotentConsumerCompletionEagerTest.java     |   4 +-
 .../IdempotentConsumerConcurrentTest.java          |  12 +-
 .../camel/processor/IdempotentConsumerDslTest.java |   2 +-
 .../processor/IdempotentConsumerEagerTest.java     |  18 +-
 .../IdempotentConsumerNoMessageIdTest.java         |   2 +-
 .../IdempotentConsumerRemoveOnFailureTest.java     |   6 +-
 .../IdempotentConsumerRepoExceptionTest.java       |   4 +-
 .../camel/processor/IdempotentConsumerTest.java    |  18 +-
 ...dempotentConsumerUsingCustomRepositoryTest.java |   4 +-
 .../processor/InheritErrorHandlerDefaultTest.java  |   6 +-
 .../processor/InheritErrorHandlerFalseTest.java    |   6 +-
 .../processor/InheritErrorHandlerTrueTest.java     |   6 +-
 .../camel/processor/InlinedProcessorIdTest.java    |   6 +-
 .../org/apache/camel/processor/JoinRoutesTest.java |   2 +-
 .../camel/processor/LanguageBuilderTest.java       |   4 +-
 .../LineNumberProcessorDebuggingTest.java          |   4 +-
 .../camel/processor/LineNumberProcessorTest.java   |   6 +-
 .../processor/LineNumberProcessorTracingTest.java  |   4 +-
 .../camel/processor/LogEipBodyWithSimpleTest.java  |   6 +-
 .../apache/camel/processor/LogEipListenerTest.java |   4 +-
 .../org/apache/camel/processor/LogEipMaskTest.java |   4 +-
 .../processor/LogEipPropagateExceptionTest.java    |   8 +-
 .../apache/camel/processor/LogProcessorTest.java   |   4 +-
 .../LogProcessorWithProvidedLoggerTest.java        |   4 +-
 .../apache/camel/processor/LoopAsyncCopyTest.java  |   4 +-
 .../camel/processor/LoopAsyncNoCopyTest.java       |   4 +-
 .../apache/camel/processor/LoopCopyErrorTest.java  |   6 +-
 .../org/apache/camel/processor/LoopCopyTest.java   |   4 +-
 .../camel/processor/LoopDoWhileDelayTest.java      |   4 +-
 .../camel/processor/LoopDoWhileTaskCountTest.java  |   4 +-
 .../apache/camel/processor/LoopDoWhileTest.java    |   4 +-
 .../apache/camel/processor/LoopExceptionTest.java  |   4 +-
 .../org/apache/camel/processor/LoopNoCopyTest.java |   4 +-
 .../camel/processor/LoopWithAggregatorTest.java    |   6 +-
 .../org/apache/camel/processor/MDCAsyncTest.java   |   8 +-
 .../apache/camel/processor/MDCClearingTest.java    |   4 +-
 .../apache/camel/processor/MDCCustomKeysTest.java  |   6 +-
 .../camel/processor/MDCErrorHandlerTest.java       |  10 +-
 .../processor/MDCOnCompletionOnCompletionTest.java |   8 +-
 .../camel/processor/MDCOnCompletionTest.java       |   8 +-
 .../MDCResetMidRouteProducerTemplateTest.java      |  12 +-
 .../org/apache/camel/processor/MDCResetTest.java   |  10 +-
 .../processor/MDCSplitParallelProcessingTest.java  |   6 +-
 .../org/apache/camel/processor/MDCSplitTest.java   |   6 +-
 .../java/org/apache/camel/processor/MDCTest.java   |  10 +-
 .../org/apache/camel/processor/MDCWireTapTest.java |  10 +-
 .../camel/processor/MDCWithBreadcrumbTest.java     |   8 +-
 .../camel/processor/MarkRollbackOnlyTest.java      |   4 +-
 .../camel/processor/MarshalVariableTest.java       |   6 +-
 .../processor/MessageHistoryCopyExchangeTest.java  |   4 +-
 .../processor/MessageHistoryCopyMessageTest.java   |   4 +-
 .../processor/MessageHistoryDumpRoutingTest.java   |   6 +-
 .../processor/MessageHistoryStepOnlyTest.java      |   4 +-
 .../MultiCastParallelAndStreamCachingTest.java     |   4 +-
 ...ParallelAndStreamCachingWithEncryptionTest.java |   4 +-
 .../MultiCastStreamCachingInSubRouteTest.java      |   4 +-
 .../MultiErrorHandlerInRouteNotHandledTest.java    |   6 +-
 .../processor/MultiErrorHandlerInRouteTest.java    |   6 +-
 .../processor/MulticastCompletedPropertyTest.java  |   4 +-
 .../MulticastCopyOfSplitSubUnitOfWorkTest.java     |   6 +-
 .../processor/MulticastCorrelationIdTest.java      |   2 +-
 .../apache/camel/processor/MulticastDslTest.java   |   4 +-
 .../MulticastFineGrainedErrorHandlingTest.java     |   4 +-
 .../MulticastGroupedExchangeExceptionTest.java     |   8 +-
 .../camel/processor/MulticastNoOnPrepareTest.java  |   8 +-
 .../processor/MulticastNoStopOnExceptionTest.java  |   6 +-
 .../camel/processor/MulticastOnPrepareTest.java    |   8 +-
 .../MulticastParallelAllTimeoutAwareTest.java      |   4 +-
 .../MulticastParallelFailureEndpointTest.java      |   4 +-
 ...ticastParallelFineGrainedErrorHandlingTest.java |   4 +-
 .../MulticastParallelLastTimeoutTest.java          |   4 +-
 .../MulticastParallelMiddleTimeoutTest.java        |   4 +-
 .../MulticastParallelNoStopOnExceptionTest.java    |   6 +-
 .../MulticastParallelStopOnExceptionTest.java      |   6 +-
 .../processor/MulticastParallelStreamingTest.java  |   6 +-
 .../MulticastParallelStreamingTimeoutTest.java     |   4 +-
 .../MulticastParallelStreamingTwoTimeoutTest.java  |   4 +-
 .../processor/MulticastParallelStressTest.java     |   6 +-
 .../MulticastParallelSynchronousTest.java          |   4 +-
 .../camel/processor/MulticastParallelTest.java     |   6 +-
 .../processor/MulticastParallelTimeout2Test.java   |   4 +-
 .../processor/MulticastParallelTimeout3Test.java   |   4 +-
 .../MulticastParallelTimeoutAwareTest.java         |   4 +-
 .../MulticastParallelTimeoutStreamCachingTest.java |   2 +-
 .../processor/MulticastParallelTimeoutTest.java    |   4 +-
 .../MulticastParallelTwoTimeoutMiddleTest.java     |   4 +-
 .../processor/MulticastParallelTwoTimeoutTest.java |   4 +-
 .../camel/processor/MulticastPipelineTest.java     |   8 +-
 .../camel/processor/MulticastRedeliverTest.java    |   8 +-
 ...castStopOnExceptionLastWithOnExceptionTest.java |   4 +-
 .../processor/MulticastStopOnExceptionTest.java    |   6 +-
 ...ulticastStopOnExceptionWithOnExceptionTest.java |   6 +-
 .../processor/MulticastSubUnitOfWorkTest.java      |   8 +-
 .../processor/MulticastThreadPoolProfileTest.java  |   4 +-
 .../camel/processor/MulticastUnitOfWorkTest.java   |  10 +-
 .../MulticastWithOnExceptionFirstTest.java         |   4 +-
 .../MulticastWithOnExceptionLastTest.java          |   4 +-
 .../processor/MulticastWithOnExceptionTest.java    |   6 +-
 .../camel/processor/MyLoggingSentEventNotifer.java |   2 +-
 .../camel/processor/MySentEventNotifier.java       |   2 +-
 .../apache/camel/processor/NavigateRouteTest.java  |   4 +-
 .../camel/processor/NestedChoiceIssueTest.java     |   4 +-
 .../processor/NewProcessorAndServiceTest.java      |   8 +-
 ...deliveryWhileStoppingDeadLetterChannelTest.java |   4 +-
 .../NotAllowRedeliveryWhileStoppingTest.java       |   4 +-
 .../OnCompletionAfterChainedSedaRoutesTest.java    |   4 +-
 ...letionAndInterceptAndOnExceptionGlobalTest.java |   6 +-
 .../OnCompletionAndInterceptGlobalTest.java        |   6 +-
 .../processor/OnCompletionAndInterceptTest.java    |   6 +-
 .../camel/processor/OnCompletionAsyncTest.java     |  12 +-
 .../OnCompletionBeforeChainedSedaRoutesTest.java   |   4 +-
 .../OnCompletionBridgeErrorHandlerTest.java        |  10 +-
 .../camel/processor/OnCompletionContainsTest.java  |   6 +-
 .../camel/processor/OnCompletionFailAndOkTest.java |   4 +-
 .../OnCompletionGlobalCustomPoolTest.java          |   4 +-
 .../camel/processor/OnCompletionGlobalTest.java    |   6 +-
 .../OnCompletionInvalidConfiguredTest.java         |   2 +-
 ...nModeBeforeConsumerExceptionSuppressedTest.java |   4 +-
 .../camel/processor/OnCompletionModeTest.java      |   4 +-
 .../OnCompletionMoreGlobalRouteCompletionTest.java |   6 +-
 .../processor/OnCompletionMoreGlobalTest.java      |   6 +-
 .../processor/OnCompletionOnCompleteOnlyTest.java  |   4 +-
 .../processor/OnCompletionOnFailureOnlyTest.java   |   4 +-
 .../OnCompletionParallelProcessingTest.java        |   4 +-
 ...ompletionRouteScopeOverrideGlobalScopeTest.java |   6 +-
 .../processor/OnCompletionShouldBeLastTest.java    |   6 +-
 .../OnCompletionShutdownProcessorTest.java         |  10 +-
 .../apache/camel/processor/OnCompletionTest.java   |   6 +-
 .../processor/OnCompletionUseOriginalBodyTest.java |   6 +-
 .../camel/processor/OnCompletionWhenTest.java      |   4 +-
 .../processor/OnExceptionContinueToRouteTest.java  |   4 +-
 .../processor/OnExceptionFailureRouteIdTest.java   |   4 +-
 .../camel/processor/PipelineConcurrentTest.java    |   6 +-
 .../camel/processor/PipelineStepWithEventTest.java |  11 +-
 .../org/apache/camel/processor/PipelineTest.java   |   4 +-
 .../camel/processor/PolicyPerProcessorTest.java    |   4 +-
 .../apache/camel/processor/PolicyPerRouteTest.java |   4 +-
 .../processor/PollEnrichVariableErrorTest.java     |   6 +-
 .../processor/PollEnrichVariableHeadersTest.java   |   4 +-
 .../camel/processor/PollEnrichVariableTest.java    |   4 +-
 .../apache/camel/processor/PooledExchangeTest.java |   6 +-
 .../camel/processor/ProcessRefBeanIdTest.java      |   4 +-
 .../camel/processor/ProcessRefBeanTypeTest.java    |   4 +-
 .../camel/processor/ProcessRefClassTest.java       |   4 +-
 .../apache/camel/processor/ProcessRefHashTest.java |   4 +-
 .../ProcessorMutateExchangeRedeliverTest.java      |   8 +-
 .../ProducerTemplateDisableEventNotifierTest.java  |   4 +-
 .../RecipientListAggregationStrategyTest.java      |   4 +-
 .../processor/RecipientListBeanOnPrepareTest.java  |   8 +-
 .../RecipientListBeanSubUnitOfWorkTest.java        |   8 +-
 ...pientListContextScopedOnExceptionIssueTest.java |  10 +-
 .../RecipientListDoNotStopOnExceptionTest.java     |   4 +-
 .../RecipientListExchangePatternOptionTest.java    |   4 +-
 .../RecipientListFineGrainedErrorHandlingTest.java |  10 +-
 .../camel/processor/RecipientListMEPTest.java      |   4 +-
 .../processor/RecipientListMEPWithRawTest.java     |   4 +-
 .../processor/RecipientListNoErrorHandlerTest.java |   6 +-
 .../processor/RecipientListOnPrepareTest.java      |   8 +-
 ...ntListParallelAggregateThreadPoolIssueTest.java |   4 +-
 ...ntListParallelFineGrainedErrorHandlingTest.java |   8 +-
 ...ParallelStopOnExceptionWithOnExceptionTest.java |   4 +-
 .../RecipientListParallelStreamingTest.java        |   4 +-
 .../RecipientListParallelSynchronousTest.java      |   4 +-
 .../camel/processor/RecipientListParallelTest.java |   4 +-
 .../RecipientListParallelTimeoutTest.java          |   4 +-
 .../processor/RecipientListRedeliverTest.java      |   8 +-
 .../RecipientListStopOnExceptionTest.java          |   4 +-
 ...ientListStopOnExceptionWithOnExceptionTest.java |   4 +-
 .../processor/RecipientListSubUnitOfWorkTest.java  |   8 +-
 ...ipientListThrowExceptionFromExpressionTest.java |   4 +-
 .../RecipientListThrowExceptionSubRouteTest.java   |   4 +-
 .../processor/RecipientListWithDelimiterTest.java  |   6 +-
 .../RecipientListWithSimpleExpressionTest.java     |   2 +-
 .../camel/processor/RedeliverToSubRouteTest.java   |   4 +-
 ...tterErrorHandlerNoRedeliveryOnShutdownTest.java |   6 +-
 .../RedeliveryErrorHandlerBlockedDelayTest.java    |   6 +-
 ...veryErrorHandlerBreakoutDuringShutdownTest.java |   6 +-
 .../RedeliveryErrorHandlerLogHandledTest.java      |  14 +-
 ...veryErrorHandlerNoRedeliveryOnShutdownTest.java |   4 +-
 .../RedeliveryErrorHandlerNonBlockedDelayTest.java |   6 +-
 ...ErrorHandlerNonBlockedRedeliveryHeaderTest.java |   6 +-
 .../RedeliveryOnExceptionBlockedDelayTest.java     |   6 +-
 .../RedeliveryPolicyDelayPatternTest.java          |   2 +-
 .../ResequenceBatchIgnoreInvalidExchangesTest.java |   4 +-
 ...sequenceBatchNotIgnoreInvalidExchangesTest.java |   4 +-
 ...ResequenceStreamIgnoreInvalidExchangesTest.java |   4 +-
 ...equenceStreamNotIgnoreInvalidExchangesTest.java |   2 +-
 .../ResequenceStreamRejectOldExchangesTest.java    |   4 +-
 .../camel/processor/RollbackCustomMessageTest.java |   6 +-
 .../processor/RollbackDefaultErrorHandlerTest.java |  12 +-
 .../processor/RollbackDefaultMessageTest.java      |   6 +-
 .../camel/processor/RollbackDoTryCatchTest.java    |   6 +-
 .../org/apache/camel/processor/RollbackTest.java   |   6 +-
 .../camel/processor/RoundRobinLoadBalanceTest.java |   2 +-
 .../camel/processor/RouteAutoStartupTest.java      |  12 +-
 .../camel/processor/RouteAwareProcessorTest.java   |  10 +-
 .../camel/processor/RouteAwareRouteTest.java       |  10 +-
 .../processor/RouteAwareSynchronizationTest.java   |   6 +-
 .../RouteConfigurationPreconditionTest.java        |   2 +-
 .../processor/RouteContextProcessorManualTest.java |   6 +-
 .../camel/processor/RouteFormattedUriTest.java     |   4 +-
 .../org/apache/camel/processor/RouteIdTest.java    |   4 +-
 .../camel/processor/RouteNoAutoStartupTest.java    |   4 +-
 .../processor/RouteNodePrefixIdDuplicateTest.java  |   6 +-
 .../camel/processor/RouteNodePrefixIdTest.java     |   6 +-
 .../camel/processor/RouteOneInputAllowedTest.java  |   2 +-
 .../camel/processor/RoutePerformanceCountTest.java |   8 +-
 .../camel/processor/RoutePoliciesRefTest.java      |   4 +-
 .../apache/camel/processor/RoutePoliciesTest.java  |   4 +-
 .../processor/RouteServicesStartupOrderTest.java   |  10 +-
 .../RouteShutdownNotReverseOrderTest.java          |   4 +-
 .../processor/RouteShutdownReverseOrderTest.java   |   4 +-
 .../processor/RouteStartupOrderClashTest.java      |   2 +-
 .../RouteStartupOrderDirectReverseTest.java        |   4 +-
 .../processor/RouteStartupOrderDirectTest.java     |   4 +-
 .../camel/processor/RouteStartupOrderLastTest.java |   4 +-
 .../processor/RouteStartupOrderSimpleTest.java     |   4 +-
 ...StartupOrderSuspendResumeNoAutoStartupTest.java |   4 +-
 .../RouteStartupOrderSuspendResumeTest.java        |   4 +-
 .../camel/processor/RouteStartupOrderTest.java     |   4 +-
 .../RouteStartupOrderWithDefaultTest.java          |   4 +-
 .../org/apache/camel/processor/RouteStopTest.java  |   4 +-
 .../processor/RouteTopLevelMisconfiguredTest.java  |   6 +-
 ...RouteWithConstantFieldFromExchangeFailTest.java |   8 +-
 .../RouteWithConstantFieldFromExchangeTest.java    |   4 +-
 ...utingSlipContextScopedOnExceptionIssueTest.java |  10 +-
 .../processor/RoutingSlipInOutAndInOnlyTest.java   |   4 +-
 .../processor/RoutingSlipNoErrorHandlerTest.java   |   6 +-
 .../RoutingSlipNoSuchEndpointExceptionTest.java    |   4 +-
 .../processor/RoutingSlipOnExceptionTest.java      |   4 +-
 .../camel/processor/RoutingSlipRedeliverTest.java  |   8 +-
 ...outingSlipThrowExceptionFromExpressionTest.java |   4 +-
 .../apache/camel/processor/SagaFailuresTest.java   |   2 +-
 .../apache/camel/processor/SagaOptionsTest.java    |   2 +-
 .../camel/processor/SagaPropagationTest.java       |  14 +-
 .../java/org/apache/camel/processor/SagaTest.java  |   6 +-
 .../apache/camel/processor/SagaTimeoutTest.java    |   2 +-
 .../processor/SendExchangePatternOptionTest.java   |   4 +-
 .../camel/processor/SendToNoErrorHandlerTest.java  |   6 +-
 .../processor/SendToNonExistingEndpointTest.java   |   2 +-
 .../camel/processor/SetBodyProcessorTest.java      |   6 +-
 .../camel/processor/SetExchangePatternTest.java    |   4 +-
 .../SetHeaderUsingDslExpressionsTest.java          |  14 +-
 .../camel/processor/SetHeadersProcessorTest.java   |   6 +-
 .../processor/ShutdownCompleteAllTasksTest.java    |   6 +-
 .../ShutdownCompleteCurrentTaskOnlyTest.java       |   4 +-
 .../apache/camel/processor/ShutdownDeferTest.java  |   4 +-
 .../camel/processor/ShutdownNotDeferTest.java      |   4 +-
 .../ShutdownSedaAndDirectEndpointTest.java         |   4 +-
 .../apache/camel/processor/SimpleDirectTest.java   |   4 +-
 .../camel/processor/SimpleMockPlaceholderTest.java |   4 +-
 .../camel/processor/SimpleMockSampleTest.java      |   4 +-
 .../org/apache/camel/processor/SimpleMockTest.java |   4 +-
 .../camel/processor/SimpleMockTwoRoutesTest.java   |  10 +-
 .../processor/SimpleProcessorIdAwareTest.java      |   4 +-
 .../camel/processor/SimpleProcessorTest.java       |   8 +-
 .../processor/SimpleProcessorTraceableTest.java    |   8 +-
 .../camel/processor/SimpleResultTypeRouteTest.java |   4 +-
 .../processor/SimpleSingleOutputMockTest.java      |   4 +-
 .../camel/processor/SimpleTryCatchFinallyTest.java |   4 +-
 .../camel/processor/SimpleTryFinallyTest.java      |   4 +-
 .../SimpleTryThrowExceptionFinallyTest.java        |   4 +-
 .../org/apache/camel/processor/SimulatorTest.java  |   2 +-
 .../camel/processor/Split123ParallelTest.java      |   4 +-
 .../camel/processor/SplitAggregateInOutTest.java   |   4 +-
 .../camel/processor/SplitCustomExpressionTest.java |   4 +-
 .../camel/processor/SplitGroupMultiLinesTest.java  |   4 +-
 .../camel/processor/SplitGroupMultiXmlTest.java    |   4 +-
 .../camel/processor/SplitGroupSkipFirstTest.java   |   4 +-
 .../camel/processor/SplitIteratorNullTest.java     |   4 +-
 .../processor/SplitParallelSynchronousTest.java    |   4 +-
 ...itParallelTimeoutNoAggregationStrategyTest.java |   4 +-
 .../camel/processor/SplitParallelTimeoutTest.java  |   4 +-
 .../processor/SplitRefCustomExpressionTest.java    |   4 +-
 ...ubUnitOfWorkStopOnExceptionAndParallelTest.java |   6 +-
 ...SplitSubUnitOfWorkStopOnExceptionIssueTest.java |   4 +-
 .../SplitSubUnitOfWorkStopOnExceptionTest.java     |   6 +-
 .../camel/processor/SplitSubUnitOfWorkTest.java    |   6 +-
 .../processor/SplitTimeoutCancelTaskTest.java      |   4 +-
 .../processor/SplitTokenizerGroupDynamicTest.java  |   4 +-
 .../camel/processor/SplitTokenizerGroupTest.java   |   4 +-
 .../processor/SplitTokenizerNamespaceTest.java     |   4 +-
 .../processor/SplitTokenizerRegexpGroupTest.java   |   4 +-
 .../apache/camel/processor/SplitTokenizerTest.java |   4 +-
 .../processor/SplitTokenizerXmlMultilineTest.java  |   4 +-
 .../camel/processor/SplitTwoSubUnitOfWorkTest.java |   6 +-
 .../apache/camel/processor/SplitWithEndTest.java   |   6 +-
 .../camel/processor/SplitterCollateTest.java       |   4 +-
 .../processor/SplitterCompletedPropertyTest.java   |   4 +-
 .../apache/camel/processor/SplitterMapTest.java    |   4 +-
 .../SplitterNoAggregationStrategyTest.java         |   6 +-
 .../processor/SplitterNoStopOnExceptionTest.java   |   6 +-
 .../processor/SplitterNullBodyParallelTest.java    |   4 +-
 .../camel/processor/SplitterNullBodyTest.java      |   4 +-
 .../camel/processor/SplitterOnCompletionTest.java  |   6 +-
 .../SplitterOnPrepareExceptionStreamingTest.java   |   4 +-
 .../processor/SplitterOnPrepareExceptionTest.java  |   6 +-
 .../camel/processor/SplitterOnPrepareTest.java     |   8 +-
 .../SplitterParallelAggregateManualTest.java       |   4 +-
 .../SplitterParallelBigFileManualTest.java         |   4 +-
 .../SplitterParallelNoStopOnExceptionTest.java     |   6 +-
 .../SplitterParallelStopOnExceptionTest.java       |   6 +-
 ...ParallelStopOnExceptionWithOnExceptionTest.java |   6 +-
 .../apache/camel/processor/SplitterPojoTest.java   |   2 +-
 .../processor/SplitterPropertyContinuedTest.java   |   4 +-
 .../camel/processor/SplitterSingleMapTest.java     |   4 +-
 .../apache/camel/processor/SplitterSkipTest.java   |   4 +-
 .../SplitterStopOnExceptionAndContinueTest.java    |   6 +-
 .../processor/SplitterStopOnExceptionTest.java     |   6 +-
 ...SplitterStopOnExceptionWithOnExceptionTest.java |   6 +-
 .../SplitterStreamCachingInSubRouteTest.java       |   4 +-
 .../SplitterStreamingErrorHandlingTest.java        |   6 +-
 ...rStreamingStopOnExceptionErrorHandlingTest.java |   6 +-
 .../processor/SplitterStreamingUoWIssueTest.java   |   4 +-
 .../SplitterStreamingWithErrorHandlerTest.java     |   4 +-
 .../org/apache/camel/processor/SplitterTest.java   |   2 +-
 .../SplitterThrowExceptionFromExpressionTest.java  |   4 +-
 .../camel/processor/SplitterUoWIssueTest.java      |   4 +-
 .../processor/SplitterUseOriginalLoopTest.java     |   4 +-
 ...litterUseOriginalNotPropagateExceptionTest.java |   6 +-
 .../processor/SplitterWireTapStreamCacheTest.java  |   4 +-
 .../SplitterWithCustomThreadPoolExecutorTest.java  |   2 +-
 .../processor/SplitterWithDualMulticastTest.java   |   4 +-
 .../camel/processor/SplitterWithMulticastTest.java |   4 +-
 .../SplitterWithScannerIoExceptionTest.java        |   4 +-
 .../camel/processor/StepEventNotifierTest.java     |   6 +-
 .../java/org/apache/camel/processor/StepTest.java  |   4 +-
 .../processor/StreamCachingAllowDenyTest.java      |   8 +-
 .../StreamCachingCustomShouldSpoolRuleTest.java    |   6 +-
 .../camel/processor/StreamCachingInOutTest.java    |   4 +-
 .../processor/StreamCachingOnlyRouteTest.java      |   4 +-
 .../camel/processor/StreamCachingPerRouteTest.java |   4 +-
 .../processor/StreamCachingRecipientListTest.java  |   4 +-
 .../processor/StreamCachingRoutingSlipTest.java    |   4 +-
 .../StreamCachingSpoolDirectoryQuarkusTest.java    |   6 +-
 .../camel/processor/StreamCachingVariableTest.java |   4 +-
 .../processor/StreamCachingXPathRouteTest.java     |   4 +-
 .../ThreadsCoreAndMaxPoolInvalidTest.java          |   4 +-
 .../ThreadsCoreAndMaxPoolKeepAliveTimeTest.java    |   4 +-
 .../camel/processor/ThreadsCoreAndMaxPoolTest.java |   4 +-
 .../camel/processor/ThreadsCorePoolTest.java       |  12 +-
 .../apache/camel/processor/ThreadsDefaultTest.java |   4 +-
 .../camel/processor/ThreadsInvalidConfigTest.java  |  28 +-
 .../camel/processor/ThreadsMaxQueueSizeTest.java   |   4 +-
 .../processor/ThreadsRejectedExecutionTest.java    |  10 +-
 .../camel/processor/ThreadsRejectedPolicyTest.java |   4 +-
 .../camel/processor/ThreadsRequestReplyTest.java   |   8 +-
 .../processor/ThreadsZeroInCoreAndMaxPoolTest.java |   8 +-
 .../processor/ThreadsZeroMaxQueueSizeTest.java     |   4 +-
 .../camel/processor/ThrowExceptionMessageTest.java |   4 +-
 .../processor/ThrowExceptionNullMessageTest.java   |   4 +-
 .../apache/camel/processor/ThrowExceptionTest.java |   4 +-
 .../ThrowExceptionUninstantiatableClassTest.java   |   2 +-
 .../ToDynamicAutoStartupComponentsTest.java        |   4 +-
 .../apache/camel/processor/ToDynamicEmptyTest.java |   6 +-
 .../camel/processor/ToDynamicFluentTest.java       |   4 +-
 .../camel/processor/ToDynamicIgnoreTest.java       |   4 +-
 .../processor/ToDynamicLanguageXPathTest.java      |   4 +-
 .../ToDynamicPropertyPlaceholderTest.java          |   6 +-
 .../apache/camel/processor/ToDynamicRawTest.java   |   4 +-
 .../processor/ToDynamicSendDynamicAwareTest.java   |   7 +-
 .../camel/processor/ToDynamicStopProducerTest.java |  16 +-
 .../org/apache/camel/processor/ToDynamicTest.java  |   6 +-
 .../processor/ToDynamicVariableErrorTest.java      |  20 +-
 .../processor/ToDynamicVariableHeadersTest.java    |   4 +-
 .../camel/processor/ToDynamicVariableTest.java     |   4 +-
 .../camel/processor/ToEndpointPropertyTest.java    |  20 +-
 .../camel/processor/ToVariableErrorTest.java       |  20 +-
 .../camel/processor/ToVariableHeadersTest.java     |   4 +-
 .../org/apache/camel/processor/ToVariableTest.java |   4 +-
 .../camel/processor/TraceInterceptorTest.java      |   8 +-
 .../camel/processor/TracePerRouteManualTest.java   |   4 +-
 .../camel/processor/TracerConfigurationTest.java   |   4 +-
 .../processor/TransformBeanExceptionTest.java      |   4 +-
 .../processor/TransformDataTypeProcessorTest.java  |   2 +-
 .../processor/TripleNestedChoiceIssueTest.java     |   4 +-
 .../TryCatchCaughtExceptionFinallyTest.java        |  10 +-
 .../processor/TryCatchCaughtExceptionTest.java     |   8 +-
 .../TryCatchCaughtExceptionTwoTimesTest.java       |  12 +-
 .../processor/TryCatchContinueToRouteTest.java     |   4 +-
 .../TryCatchMustHaveExceptionConfiguredTest.java   |   2 +-
 .../camel/processor/TryCatchNestedChoiceTest.java  |   6 +-
 .../camel/processor/TryCatchRecipientListTest.java |  32 +--
 .../processor/TryFinallyCaughtExceptionTest.java   |   6 +-
 .../TryProcessorHandleWrappedExceptionTest.java    |   4 +-
 .../apache/camel/processor/TryProcessorTest.java   |   4 +-
 .../camel/processor/UnitOfWorkHelperTest.java      |   2 +-
 .../camel/processor/UnitOfWorkProducerTest.java    |   6 +-
 .../org/apache/camel/processor/UnitOfWorkTest.java |   4 +-
 .../camel/processor/UnmarshalProcessorTest.java    |   6 +-
 .../camel/processor/UnmarshalVariableTest.java     |   8 +-
 .../camel/processor/UriAsJava17TextBlockTest.java  |   4 +-
 .../org/apache/camel/processor/ValidateIdTest.java |   4 +-
 .../camel/processor/VerySimpleDirectTest.java      |   4 +-
 .../processor/WeightedRandomLoadBalanceTest.java   |   2 +-
 .../WeightedRoundRobinLoadBalanceTest.java         |   2 +-
 .../processor/WireTapBeanAsProcessorTest.java      |   2 +-
 .../org/apache/camel/processor/WireTapMDCTest.java |   6 +-
 .../camel/processor/WireTapOnExceptionTest.java    |   8 +-
 .../camel/processor/WireTapOnPrepareRefTest.java   |   4 +-
 .../camel/processor/WireTapOnPrepareTest.java      |   8 +-
 .../camel/processor/WireTapShutdownBeanTest.java   |   2 +-
 .../camel/processor/WireTapShutdownRouteTest.java  |   2 +-
 .../camel/processor/WireTapVariableTest.java       |   4 +-
 .../apache/camel/processor/XPathChoiceTest.java    |   2 +-
 ...ggregateAggregationStrategyIsPredicateTest.java |   4 +-
 .../aggregator/AggregateBiFunctionTest.java        |   4 +-
 .../AggregateClosedCorrelationKeyTest.java         |   4 +-
 .../aggregator/AggregateCompleteAllOnStopTest.java |   4 +-
 ...yBatchConsumerSendEmptyMessageWhenIdleTest.java |   4 +-
 ...gateCompletionAwareAggregationStrategyTest.java |   4 +-
 .../AggregateCompletionByBatchConsumerTest.java    |   4 +-
 .../AggregateCompletionIntervalTest.java           |   4 +-
 ...gregateCompletionOnNewCorrelationGroupTest.java |   4 +-
 ...nNewCorrelationGroupWithCanPreCompleteTest.java |   4 +-
 .../aggregator/AggregateCompletionOnlyOneTest.java |   4 +-
 .../aggregator/AggregateCompletionOnlyTwoTest.java |   2 +-
 .../AggregateCompletionPredicateTest.java          |   4 +-
 ...ggregateCompletionSizeAndBatchConsumerTest.java |   4 +-
 ...gateCompletionSizeExpressionAndTimeoutTest.java |   4 +-
 .../AggregateConcurrentPerCorrelationKeyTest.java  |   6 +-
 .../aggregator/AggregateControllerTest.java        |   4 +-
 .../aggregator/AggregateDiscardOnFailureTest.java  |   4 +-
 .../aggregator/AggregateDiscardOnTimeoutTest.java  |   4 +-
 .../processor/aggregator/AggregateDslTest.java     |   4 +-
 .../AggregateEagerCheckCompletionTest.java         |   4 +-
 .../AggregateExpressionSizeFallbackTest.java       |   4 +-
 .../AggregateExpressionSizeOverrideFixedTest.java  |   4 +-
 ...gateExpressionSizeOverrideFixedTimeoutTest.java |   4 +-
 .../aggregator/AggregateExpressionSizeTest.java    |   4 +-
 .../aggregator/AggregateExpressionTest.java        |   4 +-
 .../AggregateExpressionTimeoutFallbackTest.java    |   4 +-
 .../AggregateExpressionTimeoutPerGroupTest.java    |   4 +-
 .../aggregator/AggregateExpressionTimeoutTest.java |   4 +-
 ...eCompletionHeaderInAggregationStrategyTest.java |   4 +-
 .../AggregateForceCompletionHeaderTest.java        |   4 +-
 ...AggregateForceCompletionOnStopParallelTest.java |   4 +-
 .../AggregateForceCompletionOnStopTest.java        |   8 +-
 .../aggregator/AggregateFromWireTapTest.java       |   4 +-
 .../aggregator/AggregateGroupMessageTest.java      |   4 +-
 .../AggregateGroupedExchangeBatchSizeTest.java     |   4 +-
 ...roupedExchangeCompletionExpressionSizeTest.java |   4 +-
 ...AggregateGroupedExchangeCompletionSizeTest.java |   4 +-
 ...gateGroupedExchangeMultipleCorrelationTest.java |   4 +-
 .../AggregateGroupedExchangeSizePredicateTest.java |   4 +-
 .../AggregateGroupedExchangeSizeTest.java          |   4 +-
 .../aggregator/AggregateGroupedExchangeTest.java   |   4 +-
 .../AggregateIgnoreInvalidCorrelationKeysTest.java |   4 +-
 .../aggregator/AggregateLostGroupIssueTest.java    |   6 +-
 .../aggregator/AggregateMultipleSourceTest.java    |   4 +-
 .../AggregateNewExchangeAndConfirmTest.java        |   4 +-
 .../AggregateParallelProcessingTest.java           |   4 +-
 .../AggregatePreCompleteAwareStrategyTest.java     |   4 +-
 ...gregatePreCompleteAwareStrategyTimeoutTest.java |   4 +-
 .../aggregator/AggregatePreCompleteSizeTest.java   |   4 +-
 .../AggregateRepositoryReturnNullTest.java         |   6 +-
 .../AggregateShouldSkipFilteredExchangesTest.java  |   4 +-
 .../AggregateShutdownThreadPoolTest.java           |   4 +-
 .../AggregateSimpleExpressionIssueManualTest.java  |   4 +-
 .../AggregateSimplePredicateEagerTest.java         |   4 +-
 .../aggregator/AggregateSimplePredicateTest.java   |   4 +-
 .../aggregator/AggregateSimpleSizeTest.java        |   4 +-
 .../aggregator/AggregateSimpleTimeoutTest.java     |   4 +-
 .../aggregator/AggregateStrategyRefTest.java       |   4 +-
 .../aggregator/AggregateStrategyServiceTest.java   |   4 +-
 .../aggregator/AggregateThreadPoolProfileTest.java |   4 +-
 .../aggregator/AggregateTimeoutManualTest.java     |   6 +-
 .../aggregator/AggregateTimeoutOnlyTest.java       |   4 +-
 .../processor/aggregator/AggregateTimeoutTest.java |   4 +-
 .../AggregateTimeoutWithExecutorServiceTest.java   |   4 +-
 .../AggregateTimeoutWithNoExecutorServiceTest.java |   4 +-
 .../AggregateUnknownExecutorServiceRefTest.java    |   4 +-
 .../AggregationStrategyAsPredicateTest.java        |   4 +-
 ...trategyBeanAdapterAllowNullOldExchangeTest.java |   4 +-
 ...ggregationStrategyBeanAdapterAllowNullTest.java |   4 +-
 ...tionStrategyBeanAdapterNonStaticMethodTest.java |   4 +-
 ...ggregationStrategyBeanAdapterOneMethodTest.java |   4 +-
 ...nAdapterPollEnrichAllowNullNewExchangeTest.java |   4 +-
 ...gregationStrategyBeanAdapterPollEnrichTest.java |   4 +-
 ...gationStrategyBeanAdapterRefMethodNameTest.java |   4 +-
 .../AggregationStrategyBeanAdapterRefTest.java     |   4 +-
 ...egationStrategyBeanAdapterStaticMethodTest.java |   4 +-
 .../AggregationStrategyBeanAdapterTest.java        |   4 +-
 ...egyBeanAdapterWithHeadersAndPropertiesTest.java |   4 +-
 ...regationStrategyBeanAdapterWithHeadersTest.java |   4 +-
 .../AggregationStrategyCompleteByPropertyTest.java |   4 +-
 .../AggregationStrategyGroupedBodyTest.java        |   4 +-
 .../AggregationStrategyLifecycleTest.java          |   8 +-
 .../aggregator/AggregatorAndOnExceptionTest.java   |   4 +-
 .../aggregator/AggregatorConcurrencyTest.java      |   6 +-
 .../aggregator/AggregatorExceptionHandleTest.java  |   6 +-
 .../AggregatorExceptionInPredicateTest.java        |   4 +-
 .../aggregator/AggregatorExceptionTest.java        |   6 +-
 .../aggregator/AggregatorLockingTest.java          |   4 +-
 .../aggregator/AlbertoAggregatorTest.java          |   6 +-
 .../aggregator/BeanBeforeAggregateIssueTest.java   |   4 +-
 .../BodyOnlyAggregationStrategyTest.java           |   4 +-
 .../CustomAggregationStrategyServiceTest.java      |   8 +-
 .../aggregator/CustomAggregationStrategyTest.java  |   4 +-
 ...ionStrategyCompletionFromBatchConsumerTest.java |   4 +-
 ...ustomListAggregationStrategyEmptySplitTest.java |   4 +-
 .../CustomListAggregationStrategySplitTest.java    |   4 +-
 .../CustomListAggregationStrategyTest.java         |   4 +-
 .../DefaultAggregatorCollectionTest.java           |   4 +-
 .../DistributedCompletionIntervalTest.java         |   8 +-
 ...DistributedConcurrentPerCorrelationKeyTest.java |   4 +-
 .../DistributedOptimisticLockFailingTest.java      |   4 +-
 .../aggregator/DistributedTimeoutTest.java         |   4 +-
 .../EnricherRouteNumberOfProcessorTest.java        |   8 +-
 .../aggregator/MyAggregationStrategyService.java   |   4 +-
 .../aggregator/MyCompletionProcessor.java          |   2 +-
 .../aggregator/OptimisticLockRetryPolicyTest.java  |   2 +-
 .../PredicateAggregatorCollectionTest.java         |   4 +-
 ...teParallelProcessingStackOverflowIssueTest.java |   4 +-
 .../SplitAggregateStackOverflowIssueTest.java      |   4 +-
 ...itParallelProcessingStackOverflowIssueTest.java |   4 +-
 .../SplitRouteNumberOfProcessorTest.java           |   8 +-
 .../aggregator/SplitStackOverflowIssueTest.java    |   4 +-
 .../aggregator/StringAggregationStrategyTest.java  |   4 +-
 ...yncDeadLetterChannelExecutorServiceRefTest.java |   2 +-
 .../async/AsyncDeadLetterChannelTest.java          |   2 +-
 .../async/AsyncDefaultErrorHandlerTest.java        |   2 +-
 .../async/AsyncDirectForceSynchronousTest.java     |   8 +-
 .../processor/async/AsyncEndpointCBRTest.java      |   8 +-
 .../AsyncEndpointCustomAsyncInterceptorTest.java   |  11 +-
 .../async/AsyncEndpointCustomInterceptorTest.java  |  11 +-
 .../async/AsyncEndpointCustomRoutePolicyTest.java  |   8 +-
 .../processor/async/AsyncEndpointDelayUoWTest.java |   8 +-
 .../async/AsyncEndpointDoWhileLoopTest.java        |   4 +-
 .../async/AsyncEndpointDualMulticastTest.java      |   4 +-
 .../AsyncEndpointDualTopicLoadBalanceTest.java     |   4 +-
 .../async/AsyncEndpointDynamicRouterTest.java      |   4 +-
 .../processor/async/AsyncEndpointEnricherTest.java |   8 +-
 .../AsyncEndpointEventNotifierSendingTest.java     |   8 +-
 .../async/AsyncEndpointEventNotifierTest.java      |   6 +-
 ...AsyncEndpointFailOverLoadBalanceMixed2Test.java |   8 +-
 ...AsyncEndpointFailOverLoadBalanceMixed3Test.java |   8 +-
 .../AsyncEndpointFailOverLoadBalanceMixedTest.java |   8 +-
 ...ncEndpointFailOverLoadBalanceOnlyAsyncTest.java |   8 +-
 ...ncEndpointFailedAfterDeadLetterChannelTest.java |   8 +-
 ...EndpointFailedAfterOnExceptionContinueTest.java |   8 +-
 ...cEndpointFailedAfterOnExceptionHandledTest.java |   8 +-
 .../async/AsyncEndpointFailedAfterTest.java        |   8 +-
 .../AsyncEndpointFailureProcessorContinueTest.java |   8 +-
 .../async/AsyncEndpointFailureProcessorTest.java   |   8 +-
 .../processor/async/AsyncEndpointFilterTest.java   |   8 +-
 .../async/AsyncEndpointIdempotentConsumerTest.java |   8 +-
 .../processor/async/AsyncEndpointLoopTest.java     |   8 +-
 ...pointMulticastFineGrainedErrorHandlingTest.java |   4 +-
 .../async/AsyncEndpointMulticastTest.java          |  10 +-
 .../processor/async/AsyncEndpointPipelineTest.java |   4 +-
 .../processor/async/AsyncEndpointPolicyTest.java   |  10 +-
 .../async/AsyncEndpointRecipientList2Test.java     |   8 +-
 .../async/AsyncEndpointRecipientList3Test.java     |   8 +-
 .../async/AsyncEndpointRecipientList4Test.java     |   8 +-
 .../async/AsyncEndpointRecipientListBean3Test.java |  10 +-
 .../async/AsyncEndpointRecipientListBean4Test.java |  10 +-
 .../async/AsyncEndpointRecipientListBeanTest.java  |  10 +-
 ...tRecipientListFineGrainedErrorHandlingTest.java |   6 +-
 .../AsyncEndpointRecipientListParallel2Test.java   |   8 +-
 .../AsyncEndpointRecipientListParallel3Test.java   |   8 +-
 .../AsyncEndpointRecipientListParallel4Test.java   |   8 +-
 .../AsyncEndpointRecipientListParallel5Test.java   |   8 +-
 .../AsyncEndpointRecipientListParallelTest.java    |  10 +-
 .../async/AsyncEndpointRecipientListTest.java      |  10 +-
 ...RedeliveryErrorHandlerNonBlockedDelay2Test.java |  10 +-
 ...RedeliveryErrorHandlerNonBlockedDelay3Test.java |   8 +-
 ...tRedeliveryErrorHandlerNonBlockedDelayTest.java |  10 +-
 .../AsyncEndpointRoundRobinLoadBalanceTest.java    |   8 +-
 .../async/AsyncEndpointRoutingSlip2Test.java       |   6 +-
 .../async/AsyncEndpointRoutingSlip3Test.java       |   8 +-
 .../async/AsyncEndpointRoutingSlipBean2Test.java   |   6 +-
 .../async/AsyncEndpointRoutingSlipBean3Test.java   |   8 +-
 ...syncEndpointRoutingSlipBeanNonBlockingTest.java |   6 +-
 .../async/AsyncEndpointRoutingSlipBeanTest.java    |   4 +-
 .../async/AsyncEndpointRoutingSlipTest.java        |   4 +-
 .../processor/async/AsyncEndpointSamplingTest.java |   8 +-
 .../async/AsyncEndpointSedaInOnlyTest.java         |  10 +-
 .../processor/async/AsyncEndpointSedaTest.java     |   8 +-
 .../AsyncEndpointSingleTopicLoadBalanceTest.java   |   4 +-
 ...cEndpointSplitFineGrainedErrorHandlingTest.java |   6 +-
 .../processor/async/AsyncEndpointSplitTest.java    |  10 +-
 ...pointSplitUseLatestAggregationStrategyTest.java |  10 +-
 .../processor/async/AsyncEndpointStopTest.java     |   8 +-
 .../async/AsyncEndpointSynchronousFalseTest.java   |   8 +-
 .../async/AsyncEndpointSynchronousTest.java        |   8 +-
 .../camel/processor/async/AsyncEndpointTest.java   |   8 +-
 .../async/AsyncEndpointTransformTest.java          |   8 +-
 .../async/AsyncEndpointTryCatchFinally2Test.java   |  10 +-
 .../async/AsyncEndpointTryCatchFinally3Test.java   |  12 +-
 .../async/AsyncEndpointTryCatchFinally4Test.java   |   4 +-
 .../async/AsyncEndpointTryCatchFinally5Test.java   |   4 +-
 .../async/AsyncEndpointTryCatchFinallyTest.java    |   8 +-
 .../async/AsyncEndpointUoWFailedTest.java          |   8 +-
 .../processor/async/AsyncEndpointUoWTest.java      |   8 +-
 .../async/AsyncEndpointWithDelayerTest.java        |   8 +-
 .../async/AsyncEndpointWithStreamCachingTest.java  |   8 +-
 .../async/AsyncEndpointWithTracingTest.java        |   8 +-
 ...FailureProcessorWithRedeliveryAndDelayTest.java |   8 +-
 .../AsyncFailureProcessorWithRedeliveryTest.java   |   8 +-
 .../processor/async/AsyncInOnlyEndpointTest.java   |   8 +-
 .../apache/camel/processor/async/AsyncMDCTest.java |   8 +-
 .../async/AsyncNestedTripleChoiceIssueTest.java    |   4 +-
 ...xceptionFailureProcessorWithRedeliveryTest.java |   8 +-
 .../AsyncProcessorAwaitManagerInterruptTest.java   |   6 +-
 ...sorAwaitManagerInterruptWithRedeliveryTest.java |   2 +-
 .../async/AsyncProcessorAwaitManagerTest.java      |   6 +-
 .../camel/processor/async/AsyncProducerTest.java   |   6 +-
 .../processor/async/AsyncRouteWithErrorTest.java   |   6 +-
 .../async/AsyncSedaInOnlyEndpointTest.java         |   8 +-
 .../processor/async/AsyncTwoEndpointTest.java      |  10 +-
 .../camel/processor/async/MyAsyncEndpoint.java     |   4 +-
 .../EnrichExpressionIgnoreInvalidEndpointTest.java |   4 +-
 .../enricher/EnrichExpressionNoCacheTest.java      |   4 +-
 .../processor/enricher/EnrichExpressionTest.java   |   4 +-
 .../enricher/EnricherAggregateOnExceptionTest.java |   6 +-
 .../enricher/EnricherAggregateStreamingTest.java   |   6 +-
 .../EnricherAsyncUnhandledExceptionTest.java       |   4 +-
 .../processor/enricher/EnricherBiFunctionTest.java |   6 +-
 .../enricher/EnricherCorrelationIdTest.java        |   2 +-
 .../EnricherDefaultAggregationStrategyTest.java    |   4 +-
 .../camel/processor/enricher/EnricherDslTest.java  |   4 +-
 .../enricher/EnricherLambdaAggregateTest.java      |   4 +-
 .../enricher/EnricherLambdaPojoAggregateTest.java  |   4 +-
 .../enricher/EnricherRefBeanClassTest.java         |   6 +-
 .../enricher/EnricherRefBeanTypeTest.java          |   6 +-
 .../camel/processor/enricher/EnricherRefTest.java  |   6 +-
 .../processor/enricher/EnricherSendEventTest.java  |  10 +-
 .../camel/processor/enricher/EnricherTest.java     |   6 +-
 .../camel/processor/enricher/FailureProcessor.java |   2 +-
 .../enricher/PollEnrichBridgeErrorHandlerTest.java |   6 +-
 ...lEnrichExpressionIgnoreInvalidEndpointTest.java |   4 +-
 .../enricher/PollEnrichExpressionNoCacheTest.java  |   4 +-
 .../enricher/PollEnrichExpressionTest.java         |   4 +-
 ...ollEnrichFileCustomAggregationStrategyTest.java |   4 +-
 ...llEnrichFileDefaultAggregationStrategyTest.java |   4 +-
 .../processor/enricher/PollEnrichNullBodyTest.java |   4 +-
 .../PollEnricherAggregateOnExceptionTest.java      |   8 +-
 .../processor/enricher/PollEnricherFileTest.java   |   4 +-
 .../processor/enricher/PollEnricherRefTest.java    |   6 +-
 .../camel/processor/enricher/PollEnricherTest.java |   4 +-
 .../ErrorHandlerDynamicContinueTest.java           |   2 +-
 .../errorhandler/ErrorHandlerSupportTest.java      |  10 +-
 .../errorhandler/NewDeadLetterChannelTest.java     |   4 +-
 .../CustomExceptionPolicyStrategyTest.java         |   6 +-
 ...ltExceptionPolicyStrategyUsingOnlyWhenTest.java |   4 +-
 ...efaultExceptionPolicyStrategyUsingWhenTest.java |   4 +-
 .../InterceptFromEndpointInstanceTest.java         |   4 +-
 .../InterceptFromEndpointRefFixedTest.java         |   4 +-
 .../intercept/InterceptFromEndpointRefTest.java    |   4 +-
 .../InterceptFromEndpointRefUriFixedTest.java      |   4 +-
 .../intercept/InterceptFromEndpointRefUriTest.java |   4 +-
 .../InterceptFromPropertyPlaceholderTest.java      |   4 +-
 .../intercept/InterceptFromSimpleLogTest.java      |   4 +-
 .../InterceptFromSimplePredicateTest.java          |   6 +-
 .../InterceptFromSimplePredicateWithStopTest.java  |   4 +-
 .../intercept/InterceptFromSimpleRouteTest.java    |   4 +-
 .../intercept/InterceptFromUriRegexTest.java       |   4 +-
 .../intercept/InterceptFromUriSimpleLogTest.java   |   4 +-
 .../InterceptFromUriWildcardHeaderUriTest.java     |   4 +-
 .../intercept/InterceptFromUriWildcardTest.java    |   4 +-
 .../intercept/InterceptFromWhenNoStopTest.java     |   4 +-
 .../processor/intercept/InterceptFromWhenTest.java |   4 +-
 .../intercept/InterceptFromWhenWithChoiceTest.java |   4 +-
 .../InterceptSendToEndpointAfterTest.java          |   8 +-
 ...nterceptSendToEndpointConditionalSkip2Test.java |   4 +-
 ...nterceptSendToEndpointConditionalSkip3Test.java |   4 +-
 ...InterceptSendToEndpointConditionalSkipTest.java |   4 +-
 .../InterceptSendToEndpointDynamicTest.java        |  10 +-
 .../InterceptSendToEndpointInOnException.java      |   6 +-
 ...nterceptSendToEndpointNormalizePatternTest.java |   4 +-
 .../intercept/InterceptSendToEndpointTest.java     |  12 +-
 .../InterceptSendToEndpointWithParametersTest.java |   6 +-
 .../InterceptSendToEndpointWithStopTest.java       |   4 +-
 .../intercept/InterceptSendToExceptionTest.java    |   4 +-
 .../intercept/InterceptSendToIssueTest.java        |   4 +-
 .../InterceptSendToRecipientListTest.java          |   4 +-
 .../intercept/InterceptSimpleRouteStopTest.java    |   4 +-
 .../intercept/InterceptSimpleRouteTest.java        |   4 +-
 .../InterceptSimpleRouteWhenStopTest.java          |   4 +-
 .../intercept/InterceptSimpleRouteWhenTest.java    |   4 +-
 .../ParentChildInterceptStrategyTest.java          |   7 +-
 ...ipientListInterceptSendToEndpointException.java |   4 +-
 .../interceptor/AdviceWithAutoStartupTest.java     |   6 +-
 .../interceptor/AdviceWithLambdaTest.java          |   4 +-
 .../AuditInterceptorAsyncDelegateIssueTest.java    |   7 +-
 .../AuditInterceptorDelegateIssueTest.java         |   7 +-
 .../CustomInterceptorRouteWithChildOutputTest.java |   7 +-
 .../interceptor/DebugExceptionBreakpointTest.java  |   4 +-
 .../DebugExceptionEventBreakpointTest.java         |   4 +-
 .../interceptor/DebugSingleStepConditionTest.java  |   4 +-
 .../processor/interceptor/DebugSingleStepTest.java |   4 +-
 .../camel/processor/interceptor/DebugTest.java     |   4 +-
 .../InterceptorStrategyNotOrderedTest.java         |  10 +-
 .../InterceptorStrategyOrderedTest.java            |  10 +-
 .../processor/interceptor/NoStreamCachingTest.java |   6 +-
 ...xtScopedOnExceptionCorrectRouteContextTest.java |   8 +-
 ...ScopedOnExceptionLoadBalancerStopRouteTest.java |   4 +-
 .../ContextScopedOnExceptionLogRouteTest.java      |   4 +-
 ...efaultErrorHandlerExchangeFormatterRefTest.java |   6 +-
 ...rorHandlerOnExceptionOccurredProcessorTest.java |   8 +-
 .../DefaultErrorHandlerRetryWhileTest.java         |   6 +-
 .../onexception/DoCatchDirectDynamicRouteTest.java |   4 +-
 .../DoCatchDirectRecipientListStreamingTest.java   |   4 +-
 .../DoCatchDirectRecipientListTest.java            |   4 +-
 .../onexception/DoCatchDirectRouteTest.java        |   4 +-
 .../ErrorHandlerSuppressExceptionTest.java         |  10 +-
 .../processor/onexception/OnCatchHandledTest.java  |   4 +-
 .../onexception/OnExceptionAfterRouteTest.java     |   2 +-
 ...xceptionAndDLCErrorHandlerIssueReverseTest.java |   4 +-
 .../OnExceptionAndDLCErrorHandlerIssueTest.java    |   4 +-
 .../OnExceptionCallSubRouteNoErrorHandlerTest.java |   4 +-
 .../onexception/OnExceptionComplexRouteTest.java   |   4 +-
 ...tionComplexWithNestedErrorHandlerRouteTest.java |   4 +-
 ...rorHandlerRouteWithDefaultErrorHandlerTest.java |   4 +-
 .../OnExceptionContinuePredicateTest.java          |   6 +-
 .../OnExceptionContinueSubRouteTest.java           |   4 +-
 .../OnExceptionContinueSubSubRouteTest.java        |   4 +-
 .../onexception/OnExceptionContinueTest.java       |   4 +-
 .../OnExceptionContinueTwoPredicateTest.java       |   6 +-
 .../onexception/OnExceptionContinueTwoTest.java    |   4 +-
 .../onexception/OnExceptionFromChoiceTest.java     |   4 +-
 .../OnExceptionFromChoiceUseOriginalBodyTest.java  |   4 +-
 ...ptionFromChoiceWithDefaultErrorHandlerTest.java |   4 +-
 ...onGlobalAndDLCErrorHandlerIssueReverseTest.java |   4 +-
 ...ExceptionGlobalAndDLCErrorHandlerIssueTest.java |   4 +-
 .../OnExceptionGlobalScopedRecursionTest.java      |  12 +-
 .../OnExceptionHandleAndThrowNewExceptionTest.java |   6 +-
 .../OnExceptionHandleAndTransformTest.java         |   6 +-
 ...dleAndTransformWithDefaultErrorHandlerTest.java |   6 +-
 .../OnExceptionHandledAndContinueTest.java         |   2 +-
 .../onexception/OnExceptionHandledTest.java        |   4 +-
 .../OnExceptionHandledThrowsExceptionTest.java     |   4 +-
 .../OnExceptionLoadBalancerDoubleIssueTest.java    |   4 +-
 .../onexception/OnExceptionMisconfiguredTest.java  |  20 +-
 ...nExceptionOccurredProcessorOnExceptionTest.java |   6 +-
 .../OnExceptionOccurredProcessorTest.java          |   6 +-
 ...ceptionProcessorInspectCausedExceptionTest.java |   6 +-
 ...CausedExceptionWithDefaultErrorHandlerTest.java |   6 +-
 .../onexception/OnExceptionRecursionTest.java      |   4 +-
 .../onexception/OnExceptionRetryUntilTest.java     |   2 +-
 ...ptionRetryUntilWithDefaultErrorHandlerTest.java |   2 +-
 .../onexception/OnExceptionRouteIdTest.java        |   4 +-
 .../OnExceptionRouteScopedRecursionTest.java       |  12 +-
 .../onexception/OnExceptionRouteTest.java          |   4 +-
 ...nExceptionRouteWithDefaultErrorHandlerTest.java |   4 +-
 .../onexception/OnExceptionSubRouteTest.java       |   4 +-
 ...ceptionSubRouteWithDefaultErrorHandlerTest.java |   4 +-
 .../OnExceptionUseOriginalBodyTest.java            |   4 +-
 .../OnExceptionUseOriginalMessageStreamTest.java   |   6 +-
 ...OnExceptionUseOriginalMessageStreamTwoTest.java |  10 +-
 .../OnExceptionUseOriginalMessageTest.java         |   6 +-
 .../onexception/OnExceptionWhenSimpleOgnlTest.java |   4 +-
 .../OnExceptionWithRouteAndContinueTest.java       |   4 +-
 .../OnExceptionWrappedExceptionTest.java           |   4 +-
 .../onexception/OnExceptionsPerRouteTest.java      |   4 +-
 .../onexception/RedeliverEntireRouteTest.java      |   4 +-
 ...ScopedOnExceptionLoadBalancerStopRouteTest.java |   4 +-
 .../RouteScopedOnExceptionSameTypeTest.java        |  22 +-
 .../resequencer/ResequencerEngineTest.java         |   2 +-
 .../camel/processor/resequencer/SequenceTest.java  |   4 +-
 .../processor/resequencer/TestComparatorTest.java  |   2 +-
 .../DynamicRouterEventNotifierTest.java            |   2 +-
 .../RecipientListEventNotifierTest.java            |   2 +-
 .../RoutingSlipCreateProducerFailedTest.java       |   6 +-
 .../routingslip/RoutingSlipEventNotifierTest.java  |   2 +-
 .../processor/routingslip/RoutingSlipPOJOTest.java |   2 +-
 .../routingslip/RoutingSlipWithExceptionTest.java  |   2 +-
 .../throttle/ThrottlerInvalidConfiguredTest.java   |   2 +-
 .../processor/throttle/ThrottlerNullEvalTest.java  |   4 +-
 ...xceptionRoutePolicyHalfOpenHandlerSedaTest.java |   6 +-
 ...ingExceptionRoutePolicyHalfOpenHandlerTest.java |   6 +-
 ...ThrottlingExceptionRoutePolicyHalfOpenTest.java |   6 +-
 ...lingExceptionRoutePolicyKeepOpenOnInitTest.java |   4 +-
 ...tlingExceptionRoutePolicyOpenViaConfigTest.java |   4 +-
 .../ThrottlingExceptionRoutePolicyTest.java        |   6 +-
 .../ThrottlingInflightRoutePolicyTest.java         |   4 +-
 .../ThrottlerAsyncDelayedCallerRunsTest.java       |   4 +-
 .../concurrent/ThrottlingGroupingTest.java         |   4 +-
 .../ThrottlerAsyncDelayedCallerRunsTest.java       |   4 +-
 .../throttle/requests/ThrottlingGroupingTest.java  |   4 +-
 .../ByteArrayDataTypeTransformerTest.java          |   2 +-
 .../transformer/StringDataTypeTransformerTest.java |   2 +-
 .../transformer/TransformerContractTest.java       |   8 +-
 .../transformer/TransformerRouteTest.java          |  32 +--
 .../custom/CustomDataTypeTransformer.java          |   2 +-
 .../validator/BeanValidatorInputValidateTest.java  |   4 +-
 .../validator/BeanValidatorOutputValidateTest.java |   4 +-
 ...InflightRepositoryWithFailedValidationTest.java |   6 +-
 .../processor/validator/ValidatorContractTest.java |   4 +-
 .../processor/validator/ValidatorRouteTest.java    |  15 +-
 .../validator/ValidatorXmlSchemaTest.java          |   2 +-
 .../org/apache/camel/support/CustomizersTest.java  |   4 +-
 .../DefaultCamelContextEndpointCacheLimitTest.java |   4 +-
 .../DefaultCamelContextEndpointCacheTest.java      |   4 +-
 .../apache/camel/support/DefaultComponentTest.java |   6 +-
 .../apache/camel/support/DefaultEndpointTest.java  |   4 +-
 .../apache/camel/support/DefaultRegistryTest.java  |  28 +-
 .../camel/support/DefaultTimeoutMapTest.java       |  12 +-
 .../camel/support/GroupTokenIteratorTest.java      |   6 +-
 .../support/PropertyBindingSupportArrayTest.java   |  12 +-
 .../PropertyBindingSupportAutowireNestedTest.java  |   2 +-
 .../PropertyBindingSupportConfigurerTest.java      |  14 +-
 .../support/PropertyBindingSupportFlattenTest.java |  16 +-
 .../support/PropertyBindingSupportListTest.java    |  12 +-
 .../PropertyBindingSupportMapDotKeyTest.java       |   2 +-
 .../PropertyBindingSupportMapKeyWithDotTest.java   |   4 +-
 .../support/PropertyBindingSupportMapTest.java     |   8 +-
 .../camel/support/PropertyBindingSupportTest.java  |  54 ++--
 .../apache/camel/support/ServiceSupportTest.java   |  24 +-
 .../support/component/ApiMethodHelperTest.java     |  10 +-
 .../component/ApiMethodPropertiesHelperTest.java   |   8 +-
 .../component/ArgumentSubstitutionParserTest.java  |   2 +-
 ...ndiCamelSingletonInitialContextFactoryTest.java |   2 +-
 .../processor/DefaultMaskingFormatterTest.java     |  14 +-
 .../processor/state/FileStateRepositoryTest.java   |   4 +-
 .../processor/state/MemoryStateRepositoryTest.java |   4 +-
 .../apache/camel/urlhandler/custom/Handler.java    |   3 +-
 .../org/apache/camel/urlhandler/pd/Handler.java    |   3 +-
 .../apache/camel/util/CamelContextHelperTest.java  |   2 +-
 .../util/DumpModelAsXmlAggregateRouteTest.java     |   4 +-
 ...mlChoiceFilterRoutePropertyPlaceholderTest.java |   4 +-
 .../util/DumpModelAsXmlChoiceFilterRouteTest.java  |   4 +-
 .../util/DumpModelAsXmlDanishCharactersTest.java   |   4 +-
 .../util/DumpModelAsXmlFromRouteTemplateTest.java  |   4 +-
 .../camel/util/DumpModelAsXmlNamespaceTest.java    |   4 +-
 .../camel/util/DumpModelAsXmlPlaceholdersTest.java |   4 +-
 .../util/DumpModelAsXmlRouteExpressionTest.java    |   4 +-
 .../util/DumpModelAsXmlRoutePredicateTest.java     |   4 +-
 .../util/DumpModelAsXmlRouteTemplateTest.java      |   4 +-
 .../DumpModelAsXmlSourceLocationStandbyTest.java   |   4 +-
 .../util/DumpModelAsXmlSourceLocationTest.java     |   4 +-
 .../util/DumpModelAsXmlSplitBodyRouteTest.java     |   4 +-
 ...elAsXmlSplitNestedChoiceEndChoiceRouteTest.java |   4 +-
 ...umpModelAsXmlSplitNestedChoiceEndRouteTest.java |   4 +-
 .../DumpModelAsXmlTransformRouteConstantTest.java  |   4 +-
 .../DumpModelAsXmlTransformRouteLanguageTest.java  |   4 +-
 .../util/DumpModelAsXmlTransformRouteTest.java     |   4 +-
 .../util/DumpModelAsYamlSourceLocationTest.java    |   4 +-
 ...mpModelAsYamlSplitNestedChoiceEndRouteTest.java |   4 +-
 .../util/DumpModelAsYamlTransformRouteTest.java    |   4 +-
 .../util/DumpModelAsYamlUriAsParametersTest.java   |   4 +-
 .../org/apache/camel/util/EndpointHelperTest.java  |  24 +-
 .../org/apache/camel/util/EventHelperTest.java     |  12 +-
 .../org/apache/camel/util/ExchangeHelperTest.java  |  26 +-
 .../apache/camel/util/FilePathResolverTest.java    |   2 +-
 .../java/org/apache/camel/util/IOHelperTest.java   |   8 +-
 .../org/apache/camel/util/InetAddressUtilTest.java |   2 +-
 .../org/apache/camel/util/MessageHelperTest.java   |  35 ++-
 .../java/org/apache/camel/util/MyCoolRoute.java    |   2 +-
 .../NoClassDefFoundErrorWrapExceptionTest.java     |   6 +-
 .../java/org/apache/camel/util/OgnlHelperTest.java |  10 +-
 .../apache/camel/util/OrderedComparatorTest.java   |  16 +-
 .../camel/util/PredicateAssertHelperTest.java      |   4 +-
 .../java/org/apache/camel/util/ProcessorA.java     |   2 +-
 .../java/org/apache/camel/util/ProcessorB.java     |   2 +-
 .../java/org/apache/camel/util/ProcessorFail.java  |   2 +-
 .../org/apache/camel/util/ResourceHelperTest.java  |   6 +-
 .../org/apache/camel/util/ResourceLoaderTest.java  |   4 +-
 .../apache/camel/util/StingQuoteHelperTest.java    |  14 +-
 .../toolbox/FlexibleAggregationStrategiesTest.java |   8 +-
 .../FileIdempotentRepositoryConfigurerTest.java    |   2 +-
 .../apache/camel/main/MainAddDynamicRouteTest.java |   4 +-
 .../main/MainBeansClassFactoryMethodTest.java      |   4 +-
 .../MainBeansClassStaticFactoryMethodTest.java     |   4 +-
 .../camel/main/MainBeansConstructorTest.java       |   2 +-
 .../java/org/apache/camel/main/MainBeansTest.java  |  14 +-
 .../main/MainComponentAutowiredFalseTest.java      |   6 +-
 .../java/org/apache/camel/main/MainExample.java    |   4 +-
 .../apache/camel/main/MainGlobalOptionsTest.java   |   2 +-
 .../main/MainHealthCheckExcludedPatternTest.java   |   2 +-
 .../MainIoCBeanConfigInjectConfigurerTest.java     |   2 +-
 .../camel/main/MainIoCBeanConfigInjectMapTest.java |   2 +-
 .../MainIoCBeanConfigInjectPropertiesTest.java     |   2 +-
 .../camel/main/MainIoCBeanConfigInjectTest.java    |   2 +-
 .../main/MainIoCBeanPostProcessorDisabledTest.java |   4 +-
 .../main/MainIoCNewRouteBuilderComplexTest.java    |   2 +-
 .../camel/main/MainIoCNewRouteBuilderTest.java     |   2 +-
 .../java/org/apache/camel/main/MainIoCTest.java    |   2 +-
 .../apache/camel/main/MainLogPlaceholderTest.java  |   2 +-
 .../java/org/apache/camel/main/MainRestTest.java   |   2 +-
 .../apache/camel/main/MainRouteOrderedTest.java    |   6 +-
 .../apache/camel/main/MainRouteTemplateTest.java   |   2 +-
 .../apache/camel/main/MainRoutesCollectorTest.java |   2 +-
 .../java/org/apache/camel/main/MainSSLTest.java    |   4 +-
 .../java/org/apache/camel/main/MainScan2Test.java  |   2 +-
 .../java/org/apache/camel/main/MainSedaTest.java   |   4 +-
 .../apache/camel/main/MainSedaWildcardTest.java    |   4 +-
 ...gRouteControllerFilterFailToStartRouteTest.java |  10 +-
 .../main/MainSupervisingRouteControllerTest.java   |   8 +-
 .../camel/main/MainSupportCommandLineTest.java     |   4 +-
 .../main/MainTemplatedRoutePlaceholderTest.java    |   2 +-
 .../camel/main/MainTemplatedRoutePrefixIdTest.java |   4 +-
 .../apache/camel/main/MainTemplatedRouteTest.java  |   2 +-
 .../test/java/org/apache/camel/main/MainTest.java  |  10 +-
 .../org/apache/camel/main/MainThreadPoolTest.java  |   8 +-
 .../org/apache/camel/main/MainVariableTest.java    |   4 +-
 .../java/org/apache/camel/main/MainVaultTest.java  |  18 +-
 .../java/org/apache/camel/main/MainVetoTest.java   |   2 +-
 .../apache/camel/main/MainWithRestConfigTest.java  |   4 +-
 .../PropertyBindingSupportBuildMethodTest.java     |   2 +-
 ...opertyBindingSupportClassFactoryMethodTest.java |   4 +-
 ...BindingSupportHelperClassFactoryMethodTest.java |   6 +-
 .../PropertyBindingSupportOptionalValueTest.java   |   2 +-
 ...pertyBindingSupportRootArrayReflectionTest.java |   6 +-
 .../main/PropertyBindingSupportRootArrayTest.java  |   2 +-
 ...yBindingSupportRootArrayWithConfigurerTest.java |   6 +-
 .../java/org/apache/camel/main/SimpleMainTest.java |   2 +-
 .../camel/main/scan/MyConcreteRouteBuilder.java    |   2 +-
 .../camel/main/scan/MyDummyRouteBuilder.java       |   2 +-
 .../camel/main/scan/MyScanConfiguration.java       |   2 +-
 .../apache/camel/main/scan/MyScanRouteBuilder.java |   2 +-
 .../org/apache/camel/main/scan2/MyProcessor.java   |   2 +-
 .../apache/camel/main/scan2/MyRouteBuilder.java    |   2 +-
 .../camel/main/support/MyDummyComponent.java       |   2 +-
 .../component/controlbus/ControlBusStatsTest.java  |   4 +-
 .../LanguageLoadScriptFromFileCachedTest.java      |   4 +-
 .../component/xslt/ManagedXsltOutputBytesTest.java |   4 +-
 .../camel/component/xslt/XsltContentCacheTest.java |   2 +-
 .../DynamicRouterConvertBodyToIssueManualTest.java |   4 +-
 .../camel/management/AddEventNotifierTest.java     |   6 +-
 .../management/BacklogDebuggerStandbyTest.java     |   2 +-
 .../camel/management/BacklogDebuggerTest.java      |   4 +-
 .../camel/management/BacklogTracerFilterTest.java  |   4 +-
 .../management/BacklogTracerIdOnAllNodesTest.java  |   4 +-
 .../management/BacklogTracerPatternRouteTest.java  |   4 +-
 .../camel/management/BacklogTracerPatternTest.java |   4 +-
 .../management/BacklogTracerStreamCachingTest.java |   4 +-
 .../apache/camel/management/BacklogTracerTest.java |   4 +-
 .../org/apache/camel/management/BigRouteTest.java  |   4 +-
 .../management/CamelChoiceWithManagementTest.java  |   2 +-
 .../management/CamelContextDisableJmxTest.java     |   2 +-
 .../management/DefaultManagementAgentMockTest.java |   4 +-
 .../DualManagedThreadPoolProfileTest.java          |   4 +-
 .../DualManagedThreadPoolWithIdTest.java           |   4 +-
 .../management/ExceptionWithManagementTest.java    |   4 +-
 .../JmxInstrumentationCustomMBeanTest.java         |   3 +-
 ...mxInstrumentationDisableOnCamelContextTest.java |   2 +-
 .../management/JmxInstrumentationDisableTest.java  |   2 +-
 ...ationOnlyRegisterProcessorWithCustomIdTest.java |   4 +-
 .../JmxInstrumentationUsingDefaultsTest.java       |   2 +-
 .../JmxInstrumentationUsingPlatformMBSTest.java    |   2 +-
 .../JmxNotificationEventNotifierTest.java          |   4 +-
 .../org/apache/camel/management/LoadTimerTest.java |   2 +-
 .../camel/management/LoggingEventNotifierTest.java |   6 +-
 .../management/ManagedAggregateControllerTest.java |   4 +-
 .../management/ManagedBeanIntrospectionTest.java   |   4 +-
 .../ManagedBrowsableEndpointAsXmlFileTest.java     |   4 +-
 .../ManagedBrowsableEndpointAsXmlTest.java         |   4 +-
 .../ManagedBrowsableEndpointEmptyTest.java         |   4 +-
 .../management/ManagedBrowsableEndpointTest.java   |   4 +-
 .../apache/camel/management/ManagedCBRTest.java    |   4 +-
 .../ManagedCamelContextAutoStartupTest.java        |   4 +-
 ...gedCamelContextDumpRouteTemplatesAsXmlTest.java |   4 +-
 .../ManagedCamelContextDumpRoutesAsXmlTest.java    |   4 +-
 .../ManagedCamelContextDumpRoutesAsYamlTest.java   |   4 +-
 ...gedCamelContextDumpRoutesCoverageAsXmlTest.java |   4 +-
 .../ManagedCamelContextDumpStatsAsXmlTest.java     |   4 +-
 .../ManagedCamelContextPropertiesTest.java         |   4 +-
 .../management/ManagedCamelContextRestartTest.java |  10 +-
 .../ManagedCamelContextSuspendResumeTest.java      |   4 +-
 .../ManagedCamelContextSuspendStartTest.java       |   4 +-
 .../camel/management/ManagedCamelContextTest.java  |   6 +-
 .../ManagedCamelContextTotalCounterTest.java       |   4 +-
 .../ManagedCanekContextExchangeStatisticsTest.java |   4 +-
 .../apache/camel/management/ManagedChoiceTest.java |   4 +-
 .../camel/management/ManagedComponentTest.java     |   2 +-
 .../management/ManagedConcurrentThrottlerTest.java |   4 +-
 .../camel/management/ManagedConsumerCacheTest.java |   4 +-
 .../camel/management/ManagedConvertBodyTest.java   |   4 +-
 .../camel/management/ManagedCustomBeanTest.java    |   6 +-
 .../management/ManagedCustomComponentNameTest.java |   4 +-
 .../management/ManagedCustomLoadBalancerTest.java  |   4 +-
 .../camel/management/ManagedCustomPolicyTest.java  |   4 +-
 .../management/ManagedCustomProcessorTest.java     |  10 +-
 .../camel/management/ManagedDataFormatTest.java    |   4 +-
 .../ManagedDefaultReactiveExecutorTest.java        |   4 +-
 .../camel/management/ManagedDelayerTest.java       |   4 +-
 .../camel/management/ManagedDisabledTest.java      |   4 +-
 .../management/ManagedDoTryCatchFinallyTest.java   |   4 +-
 .../management/ManagedDualCamelContextTest.java    |   4 +-
 .../camel/management/ManagedDuplicateIdTest.java   |   2 +-
 .../camel/management/ManagedDynamicRouterTest.java |   4 +-
 .../management/ManagedEndpointBaseUriTest.java     |   4 +-
 .../management/ManagedEndpointExplainTest.java     |   4 +-
 .../management/ManagedEndpointRegistryTest.java    |   4 +-
 .../camel/management/ManagedEndpointTest.java      |   4 +-
 .../ManagedEndpointUtilizationStatisticsTest.java  |   4 +-
 .../camel/management/ManagedEnricherTest.java      |   4 +-
 .../ManagedFailoverLoadBalancerTest.java           |   4 +-
 .../apache/camel/management/ManagedFilterTest.java |   4 +-
 .../camel/management/ManagedFromRestGetTest.java   |   4 +-
 .../management/ManagedFromRestPlaceholderTest.java |   4 +-
 .../camel/management/ManagedHealthCheckTest.java   |   4 +-
 .../ManagedInflightRepositoryBrowseTest.java       |   4 +-
 .../management/ManagedInflightRepositoryTest.java  |   4 +-
 .../management/ManagedInflightStatisticsTest.java  |   4 +-
 .../management/ManagedInlinedProcessorTest.java    |   4 +-
 .../camel/management/ManagedInterceptFromTest.java |   4 +-
 .../camel/management/ManagedInterceptTest.java     |   4 +-
 .../camel/management/ManagedLoadBalancerTest.java  |   4 +-
 .../camel/management/ManagedLogEndpointTest.java   |   4 +-
 .../apache/camel/management/ManagedLoopTest.java   |   4 +-
 ...edMBeansLevelContextOnlyWithAddedRouteTest.java |   2 +-
 ...anagedMBeansLevelDefaultWithAddedRouteTest.java |   2 +-
 .../management/ManagedMBeansLevelTestSupport.java  |   4 +-
 .../camel/management/ManagedMarshalTest.java       |   4 +-
 .../management/ManagedMessageHistoryTest.java      |   4 +-
 .../camel/management/ManagedMulticastTest.java     |   4 +-
 .../management/ManagedNamePatternFixedTest.java    |   4 +-
 .../ManagedNamePatternIncludeHostNameTest.java     |   4 +-
 .../ManagedNamePatternJvmSystemPropertyTest.java   |   4 +-
 .../camel/management/ManagedNamePatternTest.java   |   4 +-
 .../management/ManagedNonManagedServiceTest.java   |  12 +-
 .../camel/management/ManagedPollEnricherTest.java  |   4 +-
 .../management/ManagedPooledExchangeTest.java      |   6 +-
 .../camel/management/ManagedProcessTest.java       |   4 +-
 ...gedProducerRecipientListRegisterAlwaysTest.java |   4 +-
 .../ManagedProducerRecipientListTest.java          |   4 +-
 ...edProducerRouteAddRemoveRegisterAlwaysTest.java |   6 +-
 .../camel/management/ManagedProducerTest.java      |   4 +-
 .../management/ManagedRandomLoadBalancerTest.java  |   4 +-
 .../camel/management/ManagedRecipientListTest.java |   4 +-
 .../management/ManagedRedeliverRouteOnlyTest.java  |   4 +-
 .../camel/management/ManagedRedeliverTest.java     |   4 +-
 .../camel/management/ManagedRefProducerTest.java   |   4 +-
 .../ManagedRegisterCamelContextTest.java           |   4 +-
 .../management/ManagedRegisterEndpointTest.java    |   4 +-
 .../ManagedRegisterExchangeStatisticsTest.java     |   4 +-
 .../camel/management/ManagedRegisterRouteTest.java |   4 +-
 .../management/ManagedRegisterTwoRoutesTest.java   |   4 +-
 .../ManagedRemoveRouteAggregateThreadPoolTest.java |   4 +-
 .../camel/management/ManagedResequencerTest.java   |   4 +-
 .../ManagedResetIncludeProcessorsTest.java         |   4 +-
 .../management/ManagedResetIncludeRoutesTest.java  |   4 +-
 .../camel/management/ManagedResourceTest.java      |   4 +-
 .../camel/management/ManagedRestRegistryTest.java  |   4 +-
 .../ManagedRoundRobinLoadBalancerTest.java         |   4 +-
 .../management/ManagedRouteAddFromRouteTest.java   |   4 +-
 .../management/ManagedRouteAddRemoveTest.java      |  18 +-
 ...outeAddSecondRouteNotRegisterNewRoutesTest.java |   6 +-
 .../management/ManagedRouteAddSecondRouteTest.java |   6 +-
 .../management/ManagedRouteAutoStartupTest.java    |   4 +-
 .../ManagedRouteDirectWhileIssueLeakTest.java      |   4 +-
 .../ManagedRouteDumpRouteAsXmlPlaceholderTest.java |   4 +-
 .../management/ManagedRouteDumpRouteAsXmlTest.java |   4 +-
 ...DumpStatsAsXmlAndResetWithCustomDomainTest.java |   4 +-
 ...ManagedRouteDumpStatsAsXmlCustomDomainTest.java |   4 +-
 .../management/ManagedRouteDumpStatsAsXmlTest.java |   4 +-
 .../management/ManagedRouteDumpStrategyTest.java   |   4 +-
 .../management/ManagedRouteGetPropertiesTest.java  |   4 +-
 .../management/ManagedRouteLoadstatisticsTest.java |   4 +-
 .../management/ManagedRouteNoAutoStartupTest.java  |   4 +-
 .../management/ManagedRouteNodePrefixIdTest.java   |   4 +-
 .../ManagedRoutePerformanceCounterTest.java        |   4 +-
 ...edRouteRemoveContextScopedErrorHandlerTest.java |   4 +-
 ...emoveRouteAndContextScopedErrorHandlerTest.java |   4 +-
 ...agedRouteRemoveRouteScopedErrorHandlerTest.java |   4 +-
 .../camel/management/ManagedRouteRemoveTest.java   |   4 +-
 ...edRouteRemoveWireTapExplicitThreadPoolTest.java |   4 +-
 .../management/ManagedRouteRemoveWireTapTest.java  |   4 +-
 .../camel/management/ManagedRouteRestartTest.java  |   4 +-
 .../ManagedRouteShutdownAndStartTest.java          |   4 +-
 .../management/ManagedRouteStopAndFailTest.java    |   4 +-
 .../management/ManagedRouteStopAndStartTest.java   |   4 +-
 .../camel/management/ManagedRouteStopTest.java     |   4 +-
 .../ManagedRouteStopUsingMBeanAPITest.java         |   4 +-
 .../ManagedRouteStopWithAbortAfterTimeoutTest.java |   4 +-
 .../ManagedRouteSuspendAndResumeTest.java          |   4 +-
 .../ManagedRouteUpdateRouteFromXmlTest.java        |   4 +-
 .../ManagedRouteWithOnExceptionTest.java           |   4 +-
 .../camel/management/ManagedRoutingSlipTest.java   |   4 +-
 .../camel/management/ManagedSanitizeTest.java      |   4 +-
 .../ManagedScheduledPollConsumerTest.java          |   4 +-
 .../camel/management/ManagedSedaEndpointTest.java  |   4 +-
 .../management/ManagedSedaRouteRemoveTest.java     |   4 +-
 .../ManagedSendDynamicProcessorTest.java           |   4 +-
 .../camel/management/ManagedSendProcessorTest.java |   4 +-
 ...ManagedSetAndRemoveHeaderAndPropertiesTest.java |   4 +-
 .../management/ManagedShutdownStrategyTest.java    |   4 +-
 .../camel/management/ManagedSplitterTest.java      |   4 +-
 .../camel/management/ManagedStartupFailedTest.java |   4 +-
 .../management/ManagedStatisticsDisabledTest.java  |   4 +-
 .../management/ManagedStatisticsLevelOffTest.java  |   4 +-
 .../ManagedStatisticsLevelRoutesOnlyTest.java      |   4 +-
 .../camel/management/ManagedStatisticsTest.java    |   4 +-
 .../ManagedStatisticsWithSplitterTest.java         |   4 +-
 .../apache/camel/management/ManagedStepTest.java   |   4 +-
 .../management/ManagedStickyLoadBalancerTest.java  |   4 +-
 .../ManagedStreamCachingStrategyTest.java          |   4 +-
 .../ManagedSupervisingRouteControllerTest.java     |  10 +-
 .../management/ManagedSuspendedServiceTest.java    |   4 +-
 .../management/ManagedThreadPoolProfileTest.java   |   4 +-
 .../camel/management/ManagedThreadPoolTest.java    |   4 +-
 .../management/ManagedThreadPoolWithIdTest.java    |   4 +-
 .../camel/management/ManagedThreadsTest.java       |   4 +-
 .../camel/management/ManagedThrottlerTest.java     |   4 +-
 .../ManagedThrottlingExceptionRoutePolicyTest.java |   4 +-
 .../ManagedThrottlingInflightRoutePolicyTest.java  |   4 +-
 .../apache/camel/management/ManagedTimerTest.java  |   4 +-
 .../management/ManagedTopicLoadBalancerTest.java   |   4 +-
 .../apache/camel/management/ManagedTracerTest.java |   4 +-
 .../management/ManagedTransformerRegistryTest.java |   6 +-
 .../ManagedTypeConverterRegistryTest.java          |   4 +-
 .../camel/management/ManagedUnmarshalTest.java     |   4 +-
 .../management/ManagedUnregisterComponentTest.java |   4 +-
 .../management/ManagedUnregisterConsumerTest.java  |   4 +-
 .../management/ManagedUnregisterEndpointTest.java  |   4 +-
 .../management/ManagedUnregisterProcessorTest.java |   4 +-
 .../management/ManagedUnregisterProducerTest.java  |   4 +-
 .../management/ManagedUnregisterRouteTest.java     |   4 +-
 .../management/ManagedValidatorRegistryTest.java   |   7 +-
 .../ManagedWeightedLoadBalancerTest.java           |   4 +-
 .../camel/management/ManagedWireTapTest.java       |   4 +-
 .../apache/camel/management/MyDummyProcessor.java  |   2 +-
 .../camel/management/PublishEventNotifierTest.java |   4 +-
 .../PublishEventNotifierToRouteTest.java           |   4 +-
 .../camel/management/RemoveEventNotifierTest.java  |   6 +-
 .../management/RemoveRouteDefinitionTest.java      |   4 +-
 ...nagedCamelContextAutoAssignedNameClashTest.java |   2 +-
 .../TwoManagedCamelContextClashTest.java           |   2 +-
 .../management/TwoManagedCamelContextTest.java     |   2 +-
 .../management/TwoManagedNamePatternTest.java      |   2 +-
 .../apache/camel/processor/NoErrorHandlerTest.java |   4 +-
 ...StacksNeededDuringRoutingSendProcessorTest.java |   8 +-
 .../ReduceStacksNeededDuringRoutingTest.java       |   4 +-
 .../processor/async/AsyncEndpointWithJMXTest.java  |   4 +-
 .../apache/camel/support/MessageHelperTest.java    |   5 +-
 .../camel/util/CamelCaseOrderedPropertiesTest.java |   2 +-
 .../org/apache/camel/util/CamelURIParserTest.java  |  16 +-
 .../apache/camel/util/CollectionHelperTest.java    |   4 +-
 .../java/org/apache/camel/util/IOHelperTest.java   |   4 +-
 .../camel/util/ObjectHelperLoadClassTest.java      |   2 +-
 .../apache/camel/util/OrderedPropertiesTest.java   |   2 +-
 .../java/org/apache/camel/util/ScannerTest.java    |   4 +-
 .../java/org/apache/camel/util/TimeUtilsTest.java  |   6 +-
 .../java/org/apache/camel/util/URISupportTest.java |  12 +-
 .../java/org/apache/camel/util/UnitUtilsTest.java  |   4 +-
 .../concurrent/AsyncCompletionServiceTest.java     |   4 +-
 .../concurrent/SynchronousExecutorServiceTest.java |   4 +-
 .../org/apache/camel/yaml/out/ModelWriterTest.java |   2 +-
 .../yaml/out/ModelWriterUriAsParametersTest.java   |   2 +-
 2516 files changed, 7006 insertions(+), 7067 deletions(-)