You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@camel.apache.org by ac...@apache.org on 2020/02/24 11:37:40 UTC

[camel] branch master updated (95169e7 -> 2e2fdb3)

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

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


    from 95169e7  CAMEL-14609: camel-core - optimize
     add 28e0ba5  Upgrade GraphQL to version 14.0
     add 5a9651d  CAMEL-14020 - change from getOut(0 to getMessage() -> camel-jacksonxml
     add 4dbc5cf  CAMEL-14020 - replace getOut in tests camel-jacksonxml component.
     add 82f442f  CAMEL-14020 - Replace getOut() with getMessage() in HTTP component.
     add 75ff60e  CAMEL-14020 - Migrate from getOut() to getMessage() in camel-docker tests.
     add e2244b8  CAMEL-14020 - Migrate getOut to getMessage in tests camel-beanstalk. Code Cleanup.
     add cacc397  CAMEL-14020 - Migrate getOut to getMessage where it's possible camel-disruptor.
     add d291af9  CAMEL-14020 - migrate getOut to getMessage in camel-cassandraql.
     add a5952db  CAMEL-14020 - migrate getOut to getMessage in camel-cmis.
     add 29e8bac  CAMEL-14020 - migrate getOut to getMessage in camel-coap.
     add 8328ce6  CAMEL-14020 - migrate getOut to getMessage in camel-crypto.
     add 020b030  CAMEL-14020 - migrate getOut to getMessage in camel-crypto-cms
     add 230abf1  CAMEL-14020 - Migrate getOut to getMessage in camel-hazelcast
     add 94f59a3  CAMEL-14020 - Migrate getOut to getMessage in camel-hbase
     add 30fc860  CAMEL-14020 - Migrate getOut to getMessage in camel-hl7
     add af2527f  CAMEL-14020 - Migrate getOut to getMessage in camel-jackson
     add d2b0459  CAMEL-14020 - Migrate getOut to getMessage in camel-jcr
     add deb602f  CAMEL-14020 - Migrate getOut to getMessage in camel-jms. Use lambda where it's possible.
     add c78be11  CAMEL-14020 - Migrate getOut to getMessage in camel-jolt.
     add 886b647  CAMEL-14020 - Migrate getOut to getMessage in camel-kafka.
     add 44a13c4  CAMEL-14020 - Migrate getOut to getMessage() in camel-kubernetes
     add b358a21  CAMEL-14020 - Migrate getOut to getMessage in camel-ldap
     add c739645  CAMEL-14020 - Migrate getOut to getMessage() in camel-ldif.
     add 0746eb5  CAMEL-14020 - Migrate getOut to getMessage in camel-lucene.
     add e1cb695  CAMEL-14020 - Migrate getOut to getMessage in camel-mina
     add d82afee  CAMEL-14020 - migrate getOut to getmessage in camel-quickfix
     add 2fdfaeb  CAMEL-14020 - migrate getOut to getMessage() in camel-netty-http.
     add 8c9a2c7  CAMEL-14020 - migrate getOut to getMessage in camel-reactor.
     add 8a81aec  CAMEL-14020 - migrate getOut to getMessage in camel-rxjava
     add 6da8582  CAMEL-14020 - migrate getOut to getMessage in camel-salesforce
     add baaae67  CAMEL-14020 - Migrate from getOut to getMessage in camel-schematron.
     add 7c9a935  CAMEL-14020 - Migrate getOut to getMessage in camel-servlet.
     add 167e1b5  CAMEL-14020 - migrate getOut to getMessage in camel-sjms.
     add f05e10f  CAMEL-14020 - Migrate getOut to getMessage in camel-smpp
     add 4f256bf  CAMEL-14020 - migrate getOut to getMessage in camel-spark-rest
     add d3586cc  CAMEL-14020 - Migrate getOut to getMessage in camel-spring-integration
     add c7e7f32  CAMEL-14020 - Migrate getOut to getMessage in camel-sql.
     add 391f823  CAMEL-14020 - Migrate getOut to getMessage in camel-stringtemplate.
     add 133bda5  CAMEL-14020 - Migrate getOut to getMessage in tests camel-test.
     add f7efaea  CAMEL-14020 - Migrate getOut to getMessage in tests camel-thrift.
     add c143080  CAMEL-14020 - Migrate getOut to getMessage in tests camel-undertow.
     add e3318fe  CAMEL-14020 - Remove final from connectionSettings in camel-beanstalk.
     add ed39d68  CAMEL-14020 - Fix compiling errors.
     add 2e2fdb3  CAMEL-14020 - Fix compilation error in camel-beanstalk

No new revisions were added by this update.

Summary of changes:
 .../component/beanstalk/BeanstalkProducer.java     |   6 +-
 .../beanstalk/ConsumerCompletionTest.java          |   4 +-
 .../beanstalk/ConsumerToProducerHeadersTest.java   |   3 +-
 .../apache/camel/component/beanstalk/Helper.java   |   2 +-
 .../component/beanstalk/ImmediateConsumerTest.java |   4 +-
 .../camel/component/beanstalk/ProducerTest.java    |  87 +++------
 .../integration/PutProducerIntegrationTest.java    |  10 +-
 .../component/cassandra/CassandraProducer.java     |   4 +-
 .../camel/component/cmis/CMISProducerTest.java     |  26 +--
 .../component/cmis/CMISQueryProducerTest.java      |  10 +-
 .../camel/coap/CoAPRestComponentTestBase.java      |  20 +--
 .../component/crypto/cms/EnvelopedDataTest.java    |   4 +-
 .../camel/component/crypto/cms/SignedDataTest.java |   6 +-
 .../camel/component/crypto/SignatureTest.java      |   6 +-
 .../converter/crypto/CryptoDataFormatTest.java     |   2 +-
 .../DisruptorWaitForTaskAsPropertyTest.java        |   2 +-
 .../it/DockerCustomCmdExecFactoryTestIT.java       |   9 +-
 .../HazelcastReplicatedmapProducer.java            |   6 +-
 .../component/hbase/CamelHBaseFilterTest.java      |   2 +-
 .../camel/component/hbase/HBaseProducerTest.java   | 142 +++++++--------
 .../camel/component/hl7/HL7MLLPCodecLongTest.java  |  16 +-
 .../hl7/HL7MLLPCodecMessageFloodingTest.java       |  51 +++---
 .../component/hl7/HL7MLLPCodecPlainStringTest.java |  14 +-
 .../hl7/HL7MLLPCodecStandAndEndBytesTest.java      |  16 +-
 .../camel/component/hl7/HL7MLLPCodecTest.java      |  16 +-
 .../component/hl7/HL7MLLPNettyCodecLongTest.java   |   2 +-
 .../hl7/HL7MLLPNettyCodecStandAndEndBytesTest.java |   2 +-
 .../camel/component/hl7/HL7MLLPNettyCodecTest.java |   2 +-
 .../apache/camel/component/http/BaseHttpTest.java  |   2 +-
 .../apache/camel/component/http/BaseHttpsTest.java |   2 +-
 .../component/http/HttpAuthenticationTest.java     |   2 +-
 .../camel/component/http/HttpCompressionTest.java  |   2 +-
 .../component/http/HttpDisableStreamCacheTest.java |   2 +-
 .../camel/component/http/HttpMethodsTest.java      |   6 +-
 .../component/http/HttpNoCamelHeaderTest.java      |   4 +-
 .../http/HttpProducerConnectionCloseTest.java      |   2 +-
 .../http/HttpProducerContentTypeTest.java          |   4 +-
 .../HttpProducerContentTypeWithSemiColonTest.java  |   4 +-
 .../HttpProducerExplicitConnectionCloseTest.java   |   2 +-
 .../HttpProducerTwoHeadersWithSameKeyTest.java     |   6 +-
 .../HttpProducerTwoParametersWithSameKeyTest.java  |   6 +-
 .../camel/component/http/HttpRedirectTest.java     |   6 +-
 .../http/HttpThrowExceptionOnFailureTest.java      |   4 +-
 .../http/ManagedHttpProducerPoolStatsTest.java     |   2 +-
 .../JacksonMarshalContentTypeHeaderTest.java       |  27 +--
 .../component/jacksonxml/JacksonXMLDataFormat.java |   6 +-
 .../JacksonMarshalContentTypeHeaderTest.java       |   6 +-
 .../camel/component/jcr/JcrAuthLoginTest.java      |   2 +-
 .../component/jcr/JcrNodePathCreationTest.java     |   4 +-
 .../jcr/JcrProducerDifferentWorkspaceTest.java     |   2 +-
 .../component/jcr/JcrProducerSubNodeTest.java      |   4 +-
 .../camel/component/jcr/JcrProducerTest.java       |   4 +-
 .../component/jms/DefaultQueueBrowseStrategy.java  |  63 +++----
 .../component/jms/EndpointMessageListener.java     |  37 ++--
 .../camel/component/jms/JmsConfiguration.java      |  35 +---
 .../camel/component/jms/JmsProviderMetadata.java   |  21 +--
 .../component/jms/AggregratedJmsRouteTest.java     |  17 +-
 .../component/jms/ConsumeJmsBytesMessageTest.java  |  18 +-
 .../component/jms/ConsumeJmsMapMessageTest.java    |  16 +-
 .../component/jms/ConsumeJmsObjectMessageTest.java |  18 +-
 .../jms/JmsAsyncStartStopListenerTest.java         |   8 +-
 .../camel/component/jms/JmsClientAckTest.java      |  19 +-
 ...sumerRestartPickupConfigurationChangesTest.java |   8 +-
 .../jms/JmsDeadLetterChannelInOutTest.java         |  11 +-
 .../component/jms/JmsDeadLetterQueueTest.java      |  11 +-
 ...msDeadLetterQueueUsingTransferExchangeTest.java |  12 +-
 .../jms/JmsDefaultTaskExecutorTypeTest.java        |  15 +-
 .../jms/JmsEagerLoadingPropertiesTest.java         |  10 +-
 .../jms/JmsEndpointConfigurationTest.java          |  42 +----
 .../component/jms/JmsHeaderFilteringTest.java      |  15 +-
 .../jms/JmsInOnlyWithReplyToHeaderTest.java        |  10 +-
 .../jms/JmsInOnlyWithReplyToHeaderTopicTest.java   |  10 +-
 .../component/jms/JmsInOutBeanReturnNullTest.java  |  10 +-
 .../jms/JmsInOutFixedReplyQueueTimeoutTest.java    |  15 +-
 ...ueueTimeoutUseMessageIDAsCorrelationIDTest.java |  15 +-
 .../jms/JmsInOutIndividualRequestTimeoutTest.java  |  15 +-
 .../jms/JmsInOutSynchronousFalseTest.java          |  20 +--
 .../component/jms/JmsInOutSynchronousTest.java     |  20 +--
 .../jms/JmsInOutTransferExchangeTest.java          |  30 ++--
 .../component/jms/JmsMessageBodySetNullTest.java   |  16 +-
 .../component/jms/JmsPollingConsumerTest.java      |  36 ++--
 .../component/jms/JmsProduerConcurrentTest.java    |   9 +-
 .../jms/JmsProduerConcurrentWithReplyTest.java     |   7 +-
 .../jms/JmsRequestReplyCorrelationTest.java        | 127 ++++++-------
 ...RequestReplyExclusiveReplyToConcurrentTest.java |  15 +-
 .../JmsRequestReplyFixedReplyToInEndpointTest.java |  49 ++---
 .../jms/JmsRequestReplyManualReplyTest.java        |  14 +-
 .../JmsRequestReplyManualWithJMSReplyToTest.java   |  10 +-
 .../jms/JmsRequestReplyReplyToOverrideTest.java    |  21 +--
 ...RequestReplyTempQueueMultipleConsumersTest.java |  30 ++--
 .../jms/JmsRequestReplyTemporaryCacheNoneTest.java |  10 +-
 .../component/jms/JmsRouteRequestReplyTest.java    | 148 +++++++--------
 .../component/jms/JmsRouteUsingJMSXGroupTest.java  |  11 +-
 .../apache/camel/component/jms/JmsSessionTest.java |  15 +-
 ...BodyNullErrorHandlerUseOriginalMessageTest.java |  11 +-
 .../component/jms/JmsSimpleInOnlyNoMutateTest.java |  10 +-
 .../jms/JmsSimpleRequestCustomReplyToTest.java     |  41 ++---
 .../jms/JmsSimpleRequestLateReplyTest.java         |  38 ++--
 .../component/jms/JmsSimpleRequestReplyTest.java   |  25 ++-
 .../component/jms/JmsTransferExceptionTest.java    |  18 +-
 .../jms/JmsTransferExchangeFromSplitterTest.java   |  12 +-
 .../component/jms/JmsTransferExchangeTest.java     |  12 +-
 .../camel/component/jms/JmsXMLRouteTest.java       |  22 +--
 .../component/jms/ManagedJmsEndpointTest.java      |   2 +-
 .../component/jms/ManagedJmsEndpointTopicTest.java |   2 +-
 .../component/jms/async/AsyncJmsProducerTest.java  |  14 +-
 .../camel/component/jms/async/MyAsyncProducer.java |  37 ++--
 .../jms/issues/ActiveMQPropagateHeadersTest.java   |  19 +-
 .../ActiveMQPropagateSerializableHeadersTest.java  |  15 +-
 .../jms/issues/JmsAnotherCustomJMSReplyToTest.java |  10 +-
 .../jms/issues/JmsConcurrentConsumersTest.java     |  26 ++-
 .../jms/issues/JmsCustomJMSReplyToIssueTest.java   |  12 +-
 .../jms/issues/JmsGetHeaderKeyFormatIssueTest.java |  22 +--
 ...derKeyFormatIssueWithContentTypeHeaderTest.java |  14 +-
 .../component/jms/issues/JmsInOnlyIssueTest.java   |  21 +--
 .../JmsInOutExclusiveTopicRecipientListTest.java   |  25 ++-
 .../jms/issues/JmsInOutExclusiveTopicTest.java     |  25 ++-
 .../component/jms/issues/JmsInOutIssueTest.java    |  25 +--
 .../jms/issues/JmsInOutPipelineWithBeanTest.java   |  19 +-
 ...ransferExchangeInflightRepositoryFlushTest.java |  19 +-
 .../JmsInOutUseMessageIDasCorrelationIDTest.java   |  12 +-
 .../JmsJMSReplyToEndpointUsingInOutTest.java       |  63 +++----
 .../component/jms/issues/JmsMutateMessageTest.java |  30 ++--
 .../issues/JmsMutateRemoveHeaderMessageTest.java   |  30 ++--
 ...roughtJmsKeyFormatStrategyEndUserIssueTest.java |  22 +--
 ...ssThroughtJmsKeyFormatStrategyEndpointTest.java |  12 +-
 .../JmsPassThroughtJmsKeyFormatStrategyTest.java   |  12 +-
 ...KeyFormatStrategyUsingJmsConfigurationTest.java |  22 +--
 .../component/jms/issues/JmsResequencerTest.java   |   4 +-
 .../jms/issues/JmsToFileMessageIdTest.java         |  28 ++-
 .../camel/component/jms/issues/LarsIssueTest.java  |   7 +-
 .../issues/RequestReplyWithProducerIssueTest.java  |   9 +-
 .../component/jms/issues/TempReplyToIssueTest.java |  15 +-
 .../component/jms/tx/AsyncEndpointJmsTX2Test.java  |  18 +-
 .../jms/tx/AsyncEndpointJmsTXMulticastTest.java    |  18 +-
 .../tx/AsyncEndpointJmsTXRecipientListTest.java    |  18 +-
 .../jms/tx/AsyncEndpointJmsTXRollback2Test.java    |  30 ++--
 .../jms/tx/AsyncEndpointJmsTXRollbackTest.java     |  30 ++--
 .../jms/tx/AsyncEndpointJmsTXRoutingSlipTest.java  |  18 +-
 .../component/jms/tx/AsyncEndpointJmsTXTest.java   |  18 +-
 .../tx/AsyncEndpointJmsTXTryCatchFinallyTest.java  |  18 +-
 .../jms/tx/AsyncEndpointJmsTXWireTapTest.java      |  22 +--
 .../jms/tx/JMSTXInOutPersistentQueueTest.java      |  10 +-
 .../QueueToQueueRequestReplyTransactionTest.java   |  18 +-
 .../jms/tx/TransactedAsyncUsingThreadsTest.java    |  24 +--
 .../camel/component/jolt/JoltDefaultrTest.java     |  19 +-
 .../camel/component/jolt/JoltRemovrTest.java       |  21 +--
 .../camel/component/kafka/KafkaProducerTest.java   |  28 +--
 .../consumer/KubernetesConfigMapsConsumerTest.java |  66 +++----
 .../consumer/KubernetesNamespacesConsumerTest.java |  44 ++---
 .../consumer/KubernetesNodesConsumerTest.java      |  76 ++++----
 .../consumer/KubernetesPodsConsumerTest.java       |  76 ++++----
 ...bernetesReplicationControllersConsumerTest.java |  54 +++---
 .../consumer/KubernetesServicesConsumerTest.java   |  58 +++---
 .../producer/KubernetesConfigMapsProducerTest.java |  51 ++----
 .../KubernetesDeploymentsProducerTest.java         |  43 ++---
 .../producer/KubernetesHPAProducerTest.java        |   6 +-
 .../producer/KubernetesJobProducerTest.java        |  29 ++-
 .../producer/KubernetesNamespacesProducerTest.java |  21 +--
 .../producer/KubernetesNodesProducerTest.java      |  49 ++---
 ...ernetesPersistentVolumesClaimsProducerTest.java |  30 ++--
 .../KubernetesPersistentVolumesProducerTest.java   |  17 +-
 .../producer/KubernetesPodsProducerTest.java       |  51 ++----
 ...bernetesReplicationControllersProducerTest.java |  55 ++----
 .../KubernetesResourcesQuotaProducerTest.java      |  13 +-
 .../producer/KubernetesSecretsProducerTest.java    |  41 ++---
 .../KubernetesServiceAccountsProducerTest.java     |  29 ++-
 .../producer/KubernetesServicesProducerTest.java   |  41 ++---
 .../apache/camel/component/ldap/LdapRouteTest.java |  17 +-
 .../camel/component/ldap/LdapRouteTwoTest.java     |   6 +-
 .../apache/camel/component/ldif/LdifRouteTest.java |   6 +-
 .../lucene/LuceneIndexAndQueryProducerTest.java    |  17 +-
 .../camel/component/mina/MinaClientServerTest.java |   2 +-
 .../camel/component/mina/MinaConsumerTest.java     |   2 +-
 .../mina/MinaDisconnectRaceConditionTest.java      |  12 +-
 .../camel/component/mina/MinaDisconnectTest.java   |   2 +-
 .../camel/component/mina/MinaEncodingTest.java     |  14 +-
 .../mina/MinaExchangeDefaultTimeOutTest.java       |  17 +-
 .../component/mina/MinaExchangeTimeOutTest.java    |  15 +-
 .../camel/component/mina/MinaInOnlyRouteTest.java  |  11 +-
 .../MinaInOutCloseSessionWhenCompleteTest.java     |  13 +-
 .../camel/component/mina/MinaInOutRouteTest.java   |  11 +-
 .../mina/MinaInOutRouteTextLineDelimiterTest.java  |  11 +-
 .../component/mina/MinaMaxLineLengthTest.java      |   2 +-
 .../mina/MinaProducerAnotherConcurrentTest.java    |  11 +-
 .../component/mina/MinaProducerConcurrentTest.java |  11 +-
 .../MinaTcpLineDelimiterUsingPlainSocketTest.java  |  26 ++-
 .../mina/MinaTcpWithInOutUsingPlainSocketTest.java |  31 ++--
 .../mina/MinaTransferExchangeOptionTest.java       |   4 +-
 .../mina/MinaUdpWithInOutUsingPlainSocketTest.java |  11 +-
 .../mina/MinaVMTransferExchangeOptionTest.java     |  44 +++--
 .../netty/http/NettyHttp500ErrorTest.java          |  11 +-
 ...pBindingPreservePostFormUrlEncodedBodyTest.java |  48 +++--
 .../http/NettyHttpBindingUseAbsolutePathTest.java  |  64 +++----
 .../NettyHttpBindingUseRelativePathInPostTest.java |  48 +++--
 .../http/NettyHttpBindingUseRelativePathTest.java  |  64 +++----
 .../netty/http/NettyHttpBridgeEncodedPathTest.java |  16 +-
 .../NettyHttpBridgeRouteUsingHttpClientTest.java   |  24 +--
 .../netty/http/NettyHttpCharacterEncodingTest.java |  16 +-
 ...pEndpointUriCustomHeaderFilterStrategyTest.java |   2 +-
 .../NettyHttpEndpointUriEncodingIssueTest.java     |   8 +-
 ...pointUriEncodingIssueUrlDecodeDisabledTest.java |  10 +-
 .../http/NettyHttpFilterCamelHeadersTest.java      |  12 +-
 .../http/NettyHttpGetWithInvalidMessageTest.java   |   2 +-
 .../netty/http/NettyHttpGetWithParamTest.java      |   6 +-
 .../netty/http/NettyHttpHandle404Test.java         |  34 ++--
 .../netty/http/NettyHttpHeaderCaseTest.java        |  24 ++-
 .../netty/http/NettyHttpMapHeadersFalseTest.java   |  26 ++-
 .../netty/http/NettyHttpMethodRestrictTest.java    |  12 +-
 .../http/NettyHttpOnExceptionHandledTest.java      |   4 +-
 .../netty/http/NettyHttpProducerKeepAliveTest.java |  10 +-
 .../http/NettyHttpProducerQueryParamTest.java      |  51 ++----
 .../netty/http/NettyHttpProducerSimpleTest.java    |  11 +-
 ...tyHttpProducerTwoParametersWithSameKeyTest.java |  62 +++----
 .../http/NettyHttpRedirectNoLocationTest.java      |   7 +-
 .../netty/http/NettyHttpRedirectTest.java          |   8 +-
 .../netty/http/NettyHttpRestOptionsAllowTest.java  |  15 +-
 ...ttpReturnDataNotInputStreamConvertableTest.java |   6 +-
 .../component/netty/http/NettyHttpSSLTest.java     |  14 +-
 .../netty/http/NettyUseRawHttpResponseTest.java    |  17 +-
 .../RestNettyHttpContextPathConfigurationTest.java |  16 +-
 .../rest/RestNettyHttpContextPathMatchGetTest.java |  16 +-
 .../netty/http/rest/RestNettyHttpGetCorsTest.java  |  23 +--
 .../netty/http/rest/RestNettyHttpGetTest.java      |   8 +-
 .../http/rest/RestNettyHttpGetWildcardsTest.java   |  16 +-
 .../netty/http/rest/RestNettyHttpOptionsTest.java  |  32 ++--
 .../http/rest/RestNettyMethodNotAllowedTest.java   |   2 +-
 .../netty/http/rest/RestNettyProducerGetTest.java  |   8 +-
 .../rest/RestNettyProducerGetUriParameterTest.java |   8 +-
 .../RestNettyProducerThrowExceptionErrorTest.java  |  14 +-
 .../rest/RestNettyProducerVerbUpperCaseTest.java   |  14 +-
 .../component/quickfixj/QuickfixjConsumerTest.java |   4 +-
 .../component/quickfixj/QuickfixjProducerTest.java |  55 +++---
 .../reactor/engine/ReactorStreamsServiceTest.java  |   4 +-
 .../rxjava/engine/RxJavaStreamsServiceTest.java    |   4 +-
 .../SalesforceHeadersIntegrationTest.java          |   4 +-
 .../schematron/SchematronEndpointTest.java         |   4 +-
 .../schematron/SchematronProducerTest.java         |   8 +-
 .../component/servlet/HttpClientRouteTest.java     |  72 ++++----
 .../RestServletBindingModeOffWithContractTest.java |   4 +-
 .../component/servlet/rest/RestServletGetTest.java |  10 +-
 .../servlet/rest/RestServletGetWildcardsTest.java  |  18 +-
 .../rest/RestServletMethodNotAllowedTest.java      |  10 +-
 .../sjms/SjmsDestinationCreationStrategyTest.java  |   9 +-
 .../sjms/consumer/InOutConcurrentConsumerTest.java |  26 +--
 .../consumer/InOutSynchronousConsumerTest.java     |  20 +--
 .../sjms/producer/InOutQueueProducerTest.java      |  11 +-
 .../sjms/producer/InOutTempQueueProducerTest.java  |  15 +-
 .../component/sjms/support/MyAsyncProducer.java    |  37 ++--
 .../component/smpp/SmppCancelSmCommandTest.java    |   4 +-
 .../component/smpp/SmppDataSmCommandTest.java      |  72 ++++----
 .../component/smpp/SmppQuerySmCommandTest.java     |  16 +-
 .../component/smpp/SmppReplaceSmCommandTest.java   |   6 +-
 .../component/smpp/SmppSubmitMultiCommandTest.java |  69 +++----
 .../component/smpp/SmppSubmitSmCommandTest.java    |  71 ++++----
 .../integration/SmppComponentIntegrationTest.java  |  22 +--
 .../SmppComponentSpringIntegrationTest.java        |  22 +--
 .../sparkrest/RestCamelSparkCorsTest.java          |  24 +--
 .../sparkrest/RestCamelSparkJsonTest.java          |  12 +-
 .../component/spring/integration/MyProcessor.java  |   4 +-
 .../camel/component/sql/SqlGeneratedKeysTest.java  |  74 ++++----
 .../StringTemplateCustomDelimiterTest.java         |  19 +-
 .../stringtemplate/StringTemplateTest.java         |  46 +++--
 .../RouteProcessorDumpRouteCoverageTest.java       |   2 +-
 .../component/thrift/ThriftProducerAsyncTest.java  |  12 +-
 .../component/undertow/MultiPartFormTest.java      |  40 ++---
 .../PreservePostFormUrlEncodedBodyTest.java        |  45 ++---
 .../UndertowComponentVerifierExtensionTest.java    |   2 +-
 .../undertow/UndertowComponentVerifierTest.java    |   2 +-
 .../undertow/UndertowMethodRestricTest.java        |  12 +-
 .../camel/component/undertow/rest/RestGetTest.java |  10 +-
 .../rest/RestUndertowComponentVerifierTest.java    |   2 +-
 ...stUndertowHttpContextPathConfigurationTest.java |  16 +-
 .../RestUndertowHttpContextPathMatchGetTest.java   |  16 +-
 .../undertow/rest/RestUndertowHttpGetCorsTest.java |  47 ++---
 .../undertow/rest/RestUndertowHttpGetTest.java     |  10 +-
 .../rest/RestUndertowHttpGetWildcardsTest.java     |  16 +-
 .../undertow/rest/RestUndertowHttpOptionsTest.java |  27 +--
 .../rest/RestUndertowHttpPojoTypeTest.java         | 199 +++++++++------------
 .../rest/RestUndertowMethodNotAllowedTest.java     |   2 +-
 .../undertow/rest/RestUndertowProducerGetTest.java |  10 +-
 .../RestUndertowProducerGetUriParameterTest.java   |  10 +-
 ...estUndertowProducerThrowExceptionErrorTest.java |  13 +-
 .../RestUndertowProducerVerbUpperCaseTest.java     |  15 +-
 parent/pom.xml                                     |   2 +-
 285 files changed, 2257 insertions(+), 3660 deletions(-)