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

[camel] branch master updated: cleanups for camel-netty4 to camel-netty component renaming

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

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


The following commit(s) were added to refs/heads/master by this push:
     new 9af2523  cleanups for camel-netty4 to camel-netty component renaming
9af2523 is described below

commit 9af252327acb925bd0d5bca4acfc6864bfbe1caf
Author: Babak Vahdat <bv...@apache.org>
AuthorDate: Thu Aug 15 22:14:50 2019 +0200

    cleanups for camel-netty4 to camel-netty component renaming
---
 .../org/apache/camel/catalog/CamelCatalogTest.java | 10 ++--
 .../camel-hl7/src/main/docs/hl7-dataformat.adoc    |  2 +-
 .../HL7MLLPConfigAwareChannelHandlerFactory.java   |  2 +-
 .../camel/component/hl7/HL7MLLPNettyDecoder.java   |  2 +-
 .../camel/component/hl7/HL7MLLPNettyEncoder.java   |  2 +-
 .../src/main/docs/netty-http-component.adoc        | 44 +++++++-------
 .../{netty4 => netty}/http/ChunkedHttpRequest.java |  2 +-
 .../http/ChunkedHttpResponse.java                  |  2 +-
 .../{netty4 => netty}/http/ContextPathMatcher.java |  6 +-
 .../http/CustomChunkedWriteHandler.java            |  2 +-
 .../http/DefaultContextPathMatcher.java            |  2 +-
 .../http/DefaultNettyHttpBinding.java              | 10 ++--
 .../http/DefaultNettySharedHttpServer.java         |  6 +-
 .../http/HttpClientInitializerFactory.java         | 21 +++----
 .../{netty4 => netty}/http/HttpPrincipal.java      |  2 +-
 .../http/HttpServerBootstrapFactory.java           |  8 +--
 .../http/HttpServerConsumerChannelFactory.java     |  2 +-
 .../http/HttpServerInitializerFactory.java         | 18 +++---
 .../http/HttpServerSharedInitializerFactory.java   |  8 +--
 .../http/JAASSecurityAuthenticator.java            |  2 +-
 .../http/NettyChannelBufferStreamCache.java        |  2 +-
 .../NettyChannelBufferStreamCacheOnCompletion.java |  2 +-
 .../{netty4 => netty}/http/NettyHttpBinding.java   |  2 +-
 .../{netty4 => netty}/http/NettyHttpComponent.java | 24 ++++----
 .../http/NettyHttpConfiguration.java               |  8 +--
 .../{netty4 => netty}/http/NettyHttpConstants.java |  2 +-
 .../{netty4 => netty}/http/NettyHttpConsumer.java  |  6 +-
 .../{netty4 => netty}/http/NettyHttpConverter.java |  4 +-
 .../{netty4 => netty}/http/NettyHttpEndpoint.java  | 18 +++---
 .../http/NettyHttpHeaderFilterStrategy.java        |  2 +-
 .../{netty4 => netty}/http/NettyHttpHelper.java    |  2 +-
 .../{netty4 => netty}/http/NettyHttpMessage.java   |  2 +-
 .../http/NettyHttpOperationFailedException.java    |  6 +-
 .../{netty4 => netty}/http/NettyHttpProducer.java  |  8 +--
 .../http/NettyHttpRestHeaderFilterStrategy.java    |  2 +-
 .../http/NettyHttpSecurityConfiguration.java       |  2 +-
 .../http/NettyHttpSendDynamicAware.java            |  2 +-
 .../http/NettySharedHttpServer.java                |  6 +-
 ...ettySharedHttpServerBootstrapConfiguration.java |  4 +-
 .../http/RestContextPathMatcher.java               |  6 +-
 .../http/RestNettyHttpBinding.java                 |  4 +-
 .../http/SecurityAuthenticator.java                |  2 +-
 .../http/SecurityAuthenticatorSupport.java         |  4 +-
 .../{netty4 => netty}/http/SecurityConstraint.java |  2 +-
 .../http/SecurityConstraintMapping.java            |  2 +-
 .../http/cloud/NettyHttpServiceExpression.java}    |  8 +--
 .../cloud/NettyHttpServiceExpressionFactory.java}  |  6 +-
 .../http/handlers/HttpClientChannelHandler.java    | 11 ++--
 .../http/handlers/HttpRestConsumerPath.java        |  2 +-
 .../http/handlers/HttpServerChannelHandler.java    | 20 +++----
 .../HttpServerMultiplexChannelHandler.java         | 15 ++---
 .../{netty4 => netty}/http/BaseNettyTest.java      |  2 +-
 .../{netty4 => netty}/http/LogCaptureAppender.java |  2 +-
 .../{netty4 => netty}/http/LogCaptureTest.java     |  2 +-
 .../http/ManagedNettyEndpointTest.java             |  4 +-
 .../{netty4 => netty}/http/MyLoginModule.java      |  2 +-
 .../{netty4 => netty}/http/MyRolePrincipal.java    |  2 +-
 .../http/NettyCamelWebsiteTest.java                |  2 +-
 .../http/NettyDefaultProtocolTest.java             |  4 +-
 .../http/NettyHttp500ErrorTest.java                |  2 +-
 ...ettyHttp500ErrorThrowExceptionOnServerTest.java |  2 +-
 ...tyHttpAccessHttpRequestAndResponseBeanTest.java |  6 +-
 .../http/NettyHttpAccessHttpRequestBeanTest.java   |  2 +-
 .../http/NettyHttpAccessHttpRequestTest.java       |  2 +-
 .../NettyHttpBasicAuthConstraintMapperTest.java    |  2 +-
 ...tpBasicAuthCustomSecurityAuthenticatorTest.java |  2 +-
 .../http/NettyHttpBasicAuthTest.java               |  6 +-
 ...pBindingPreservePostFormUrlEncodedBodyTest.java |  2 +-
 .../http/NettyHttpBindingUseAbsolutePathTest.java  |  2 +-
 .../NettyHttpBindingUseRelativePathInPostTest.java |  2 +-
 .../http/NettyHttpBindingUseRelativePathTest.java  |  2 +-
 .../http/NettyHttpBridgeEncodedPathTest.java       |  2 +-
 .../NettyHttpBridgeRouteUsingHttpClientTest.java   |  8 +--
 .../http/NettyHttpCharacterEncodingTest.java       |  2 +-
 .../http/NettyHttpClientChunkedTest.java           |  2 +-
 .../http/NettyHttpClientExpectContinueTest.java    |  4 +-
 .../http/NettyHttpCompressTest.java                | 12 ++--
 .../http/NettyHttpContentTypeTest.java             |  2 +-
 .../NettyHttpConvertPayloadToInputStreamTest.java  |  2 +-
 .../http/NettyHttpCustomOptionsTest.java           |  2 +-
 .../http/NettyHttpEmptyQueryParameterTest.java     |  2 +-
 ...pEndpointUriCustomHeaderFilterStrategyTest.java |  2 +-
 .../NettyHttpEndpointUriEncodingIssueTest.java     |  2 +-
 ...pointUriEncodingIssueUrlDecodeDisabledTest.java |  2 +-
 .../http/NettyHttpFilterCamelHeadersTest.java      |  2 +-
 .../http/NettyHttpGetWithInvalidMessageTest.java   | 32 +++++-----
 .../NettyHttpGetWithParamAsExchangeHeaderTest.java |  2 +-
 .../http/NettyHttpGetWithParamTest.java            |  3 +-
 .../http/NettyHttpHandle404Test.java               |  2 +-
 .../http/NettyHttpHeaderCaseTest.java              |  2 +-
 .../NettyHttpHeaderFilterStrategyRemovalTest.java  |  2 +-
 .../http/NettyHttpHeaderFilterStrategyTest.java    |  6 +-
 .../http/NettyHttpHeaderMaxSizeTest.java           |  2 +-
 .../http/NettyHttpHeadersTest.java                 |  2 +-
 .../http/NettyHttpMapHeadersFalseTest.java         |  2 +-
 .../http/NettyHttpMethodRestrictTest.java          |  2 +-
 .../http/NettyHttpOkStatusCodeTest.java            |  2 +-
 .../http/NettyHttpOnExceptionHandledTest.java      |  2 +-
 .../NettyHttpOperationFailedExceptionTest.java     |  2 +-
 .../http/NettyHttpProducerBridgeTest.java          |  2 +-
 .../http/NettyHttpProducerConcurrentTest.java      |  2 +-
 .../http/NettyHttpProducerHeadersTest.java         |  2 +-
 .../http/NettyHttpProducerKeepAliveTest.java       | 14 ++---
 .../http/NettyHttpProducerQueryParamTest.java      |  4 +-
 .../http/NettyHttpProducerSendEmptyHeaderTest.java |  2 +-
 .../http/NettyHttpProducerSessionTest.java         |  2 +-
 .../http/NettyHttpProducerSimpleGetTest.java       |  4 +-
 .../http/NettyHttpProducerSimpleTest.java          |  2 +-
 ...ttyHttpProducerThrowExceptionOnFailureTest.java |  2 +-
 ...tyHttpProducerTwoParametersWithSameKeyTest.java |  2 +-
 .../http/NettyHttpProducerWithHeaderTest.java      |  2 +-
 .../http/NettyHttpProtocolNoSlashTest.java         |  2 +-
 .../http/NettyHttpRawQueryTest.java                |  2 +-
 .../http/NettyHttpRedeliveryTest.java              |  2 +-
 .../http/NettyHttpRedirectNoLocationTest.java      |  2 +-
 .../http/NettyHttpRedirectTest.java                |  2 +-
 .../http/NettyHttpRequestTimeoutTest.java          |  2 +-
 .../http/NettyHttpRestContextPathMatcherTest.java  |  2 +-
 .../http/NettyHttpRestOptionsAllowTest.java        |  4 +-
 ...ttpReturnDataNotInputStreamConvertableTest.java |  2 +-
 .../http/NettyHttpSSLHandshakeErrorTest.java       |  4 +-
 .../{netty4 => netty}/http/NettyHttpSSLTest.java   |  4 +-
 .../NettyHttpSameHostDifferentParametersTest.java  |  2 +-
 .../http/NettyHttpSendDynamicAwareTest.java        |  2 +-
 ...ttyHttpSimpleBasicAuthConstraintMapperTest.java |  2 +-
 .../http/NettyHttpSimpleBasicAuthTest.java         | 12 ++--
 .../http/NettyHttpSimpleTest.java                  |  2 +-
 .../http/NettyHttpSimpleUriParametersTest.java     |  2 +-
 .../http/NettyHttpStreamCacheFileResponseTest.java |  2 +-
 .../http/NettyHttpSuspendResume503Test.java        |  2 +-
 .../http/NettyHttpSuspendResumeTest.java           |  2 +-
 .../http/NettyHttpTraceDisabledTest.java           |  2 +-
 .../http/NettyHttpTransferExceptionTest.java       |  2 +-
 ...ttyHttpTwoRoutesBootstrapConfigurationTest.java |  4 +-
 .../NettyHttpTwoRoutesMatchOnUriPrefixTest.java    |  2 +-
 .../http/NettyHttpTwoRoutesStopOneRouteTest.java   |  2 +-
 .../http/NettyHttpTwoRoutesTest.java               |  2 +-
 ...woRoutesValidateBootstrapConfigurationTest.java |  2 +-
 .../http/NettyHttpXMLXPathResponseTest.java        |  2 +-
 .../http/NettyHttpXMLXPathTest.java                |  2 +-
 .../http/NettyMDCLoggingTest.java                  |  2 +-
 .../http/NettyMixedCaseHttpPathTest.java           |  4 +-
 .../http/NettyProxyMixedCasePathTest.java          |  4 +-
 .../http/NettyRecipientListHttpBaseTest.java       |  2 +-
 .../http/NettyRequestManagementTest.java           |  2 +-
 .../http/NettyRouteSimpleDynamicURITest.java       |  4 +-
 .../http/NettyRouteSimpleTest.java                 |  4 +-
 .../http/NettySharedHttpServerTest.java            |  2 +-
 .../http/NettyUseRawHttpResponseTest.java          |  4 +-
 .../{netty4 => netty}/http/ProxyProtocolTest.java  |  2 +-
 .../http/SecurityConstraintMappingTest.java        |  2 +-
 .../http/SpringNettyHttpBasicAuthTest.java         | 12 ++--
 .../http/SpringNettyHttpSSLTest.java               |  4 +-
 .../http/cloud/NettyHttpServiceCallRouteTest.java} |  4 +-
 .../{netty4 => netty}/http/rest/CountryPojo.java   |  2 +-
 .../http/rest/RestApiNettyTest.java                |  4 +-
 .../RestNettyHttpBindingModeAutoWithJsonTest.java  |  4 +-
 .../RestNettyHttpBindingModeAutoWithXmlTest.java   |  4 +-
 .../rest/RestNettyHttpBindingModeJsonTest.java     |  4 +-
 ...stNettyHttpBindingModeJsonWithContractTest.java |  4 +-
 ...estNettyHttpBindingModeOffWithContractTest.java |  4 +-
 .../http/rest/RestNettyHttpBindingModeXmlTest.java |  4 +-
 .../RestNettyHttpContextPathConfigurationTest.java |  4 +-
 .../rest/RestNettyHttpContextPathMatchGetTest.java |  4 +-
 .../http/rest/RestNettyHttpGetCorsTest.java        |  4 +-
 .../http/rest/RestNettyHttpGetTest.java            | 11 ++--
 .../http/rest/RestNettyHttpGetWildcardsTest.java   |  9 +--
 .../http/rest/RestNettyHttpOptionsTest.java        |  4 +-
 .../http/rest/RestNettyHttpPojoInOutTest.java      | 12 ++--
 .../rest/RestNettyHttpPostJsonJaxbPojoTest.java    |  4 +-
 .../rest/RestNettyHttpPostJsonPojoListTest.java    |  4 +-
 .../http/rest/RestNettyHttpPostJsonPojoTest.java   |  4 +-
 .../rest/RestNettyHttpPostXmlJaxbPojoTest.java     |  4 +-
 .../http/rest/RestNettyHttpVerbTest.java           |  4 +-
 .../http/rest/RestNettyMethodNotAllowedTest.java   |  6 +-
 .../http/rest/RestNettyProducerGetTest.java        |  4 +-
 .../rest/RestNettyProducerGetUriParameterTest.java |  4 +-
 .../http/rest/RestNettyProducerPutTest.java        |  4 +-
 .../RestNettyProducerThrowExceptionErrorTest.java  |  8 +--
 .../rest/RestNettyProducerVerbUpperCaseTest.java   |  4 +-
 .../http/rest/RestPathMatchingTest.java            |  4 +-
 .../{netty4 => netty}/http/rest/UserJaxbPojo.java  |  2 +-
 .../{netty4 => netty}/http/rest/UserPojo.java      |  2 +-
 .../{netty4 => netty}/http/rest/UserPojoEx.java    |  2 +-
 .../{netty4 => netty}/http/rest/UserService.java   |  2 +-
 .../src/test/resources/log4j2.properties           |  2 +-
 .../src/test/resources/myjaas.config               |  2 +-
 .../http/SpringNettyHttpBasicAuthTest.xml          |  2 +-
 .../http/SpringNettyHttpSSLTest.xml                |  0
 .../camel-netty/src/main/docs/netty-component.adoc | 20 +++----
 .../{netty4 => netty}/ChannelHandlerFactories.java | 42 ++++++-------
 .../{netty4 => netty}/ChannelHandlerFactory.java   |  2 +-
 .../ClientInitializerFactory.java                  |  2 +-
 .../ClientModeTCPNettyServerBootstrapFactory.java  | 16 ++---
 .../DefaultChannelHandlerFactory.java              |  2 +-
 .../DefaultClientInitializerFactory.java           |  6 +-
 .../DefaultNettyCamelStateCorrelationManager.java  |  2 +-
 .../DefaultServerInitializerFactory.java           | 10 ++--
 .../{netty4 => netty}/NettyCamelState.java         |  4 +-
 .../NettyCamelStateCorrelationManager.java         |  2 +-
 .../{netty4 => netty}/NettyComponent.java          |  6 +-
 .../{netty4 => netty}/NettyConfiguration.java      |  8 +--
 .../{netty4 => netty}/NettyConstants.java          |  2 +-
 .../component/{netty4 => netty}/NettyConsumer.java |  2 +-
 .../NettyConsumerExceptionHandler.java             |  2 +-
 .../{netty4 => netty}/NettyConverter.java          |  2 +-
 .../component/{netty4 => netty}/NettyEndpoint.java | 12 ++--
 .../component/{netty4 => netty}/NettyHelper.java   |  4 +-
 .../{netty4 => netty}/NettyPayloadHelper.java      | 18 +++---
 .../component/{netty4 => netty}/NettyProducer.java | 10 ++--
 .../NettyServerBootstrapConfiguration.java         |  6 +-
 .../NettyServerBootstrapFactory.java               |  2 +-
 .../NettyServerBossPoolBuilder.java                |  4 +-
 .../{netty4 => netty}/NettyWorkerPoolBuilder.java  |  2 +-
 .../ServerInitializerFactory.java                  |  2 +-
 .../ShareableChannelHandlerFactory.java            |  4 +-
 .../SharedSingletonObjectPool.java                 |  2 +-
 .../SingleTCPNettyServerBootstrapFactory.java      |  6 +-
 .../SingleUDPNettyServerBootstrapFactory.java      | 14 ++---
 .../{netty4 => netty}/TextLineDelimiter.java       |  2 +-
 .../TimeoutCorrelationManagerSupport.java          |  2 +-
 .../codec/DatagramPacketByteArrayDecoder.java      |  2 +-
 .../codec/DatagramPacketByteArrayEncoder.java      |  2 +-
 .../codec/DatagramPacketDecoder.java               |  6 +-
 .../codec/DatagramPacketDelimiterDecoder.java      | 14 ++---
 .../codec/DatagramPacketEncoder.java               |  2 +-
 .../codec/DatagramPacketObjectDecoder.java         |  8 +--
 .../codec/DatagramPacketObjectEncoder.java         |  4 +-
 .../codec/DatagramPacketStringDecoder.java         |  4 +-
 .../codec/DatagramPacketStringEncoder.java         |  4 +-
 .../codec/DelegateByteArrayDecoder.java            |  2 +-
 .../codec/DelegateByteArrayEncoder.java            |  2 +-
 .../codec/DelimiterBasedFrameDecoder.java          |  4 +-
 .../codec/LineBasedFrameDecoder.java               |  2 +-
 .../{netty4 => netty}/codec/ObjectDecoder.java     |  6 +-
 .../{netty4 => netty}/codec/ObjectEncoder.java     |  2 +-
 .../handlers/ClientChannelHandler.java             | 18 +++---
 .../handlers/ServerChannelHandler.java             | 14 ++---
 .../handlers/ServerResponseFutureListener.java     | 10 ++--
 .../{netty4 => netty}/ssl/SSLEngineFactory.java    |  4 +-
 .../{netty4 => netty}/util/SubnetUtils.java        | 26 ++++-----
 .../component/{netty4 => netty}/BaseNettyTest.java |  2 +-
 .../DatagramPacketByteArrayCodecTest.java          |  2 +-
 .../{netty4 => netty}/LogCaptureAppender.java      |  2 +-
 .../{netty4 => netty}/LogCaptureTest.java          |  2 +-
 .../MultipleCodecsSpringTest.java                  |  4 +-
 .../{netty4 => netty}/MultipleCodecsTest.java      |  2 +-
 .../component/{netty4 => netty}/MyCustomCodec.java |  6 +-
 .../{netty4 => netty}/Netty2978IssueTest.java      |  2 +-
 .../{netty4 => netty}/NettyBacklogTest.java        |  8 +--
 .../NettyComponentWithConfigurationTest.java       |  4 +-
 .../{netty4 => netty}/NettyConcurrentTest.java     |  2 +-
 .../NettyConsumerClientModeReconnectTest.java      |  2 +-
 .../NettyConsumerClientModeReuseChannelTest.java   |  2 +-
 .../NettyConsumerClientModeTest.java               | 30 +++++-----
 .../{netty4 => netty}/NettyConverterTest.java      |  2 +-
 .../{netty4 => netty}/NettyCustomCodecTest.java    |  2 +-
 .../NettyCustomCorrelationManagerTest.java         |  2 +-
 .../NettyCustomPipelineFactoryAsynchTest.java      |  6 +-
 .../NettyCustomPipelineFactorySynchTest.java       |  6 +-
 .../{netty4 => netty}/NettyDisconnectTest.java     |  2 +-
 .../{netty4 => netty}/NettyFileTcpTest.java        |  2 +-
 .../NettyGlobalSSLContextParametersTest.java       |  6 +-
 .../NettyInOutCloseChannelWhenCompleteTest.java    |  2 +-
 .../{netty4 => netty}/NettyInOutFromSedaTest.java  |  2 +-
 .../NettyInOutWithForcedNoResponseTest.java        |  2 +-
 .../{netty4 => netty}/NettyManualEndpointTest.java |  2 +-
 .../NettyMultipleSimultaneousClientsTest.java      |  2 +-
 .../{netty4 => netty}/NettyOptionTest.java         |  8 +--
 .../NettyProducerAsyncEndpointTest.java            |  2 +-
 .../{netty4 => netty}/NettyProducerHangTest.java   |  8 +--
 .../NettyProducerPoolDisabledTest.java             |  4 +-
 .../{netty4 => netty}/NettyProxyTest.java          |  2 +-
 .../{netty4 => netty}/NettyRedeliveryTest.java     |  2 +-
 .../NettyRequestTimeoutIssueTest.java              |  2 +-
 .../{netty4 => netty}/NettyRequestTimeoutTest.java |  4 +-
 .../{netty4 => netty}/NettyReuseChannelTest.java   |  2 +-
 .../NettyReuseConnectionTest.java                  |  2 +-
 .../{netty4 => netty}/NettySSLClasspathTest.java   |  4 +-
 .../NettySSLClientCertHeadersTest.java             |  2 +-
 .../NettySSLConsumerClientModeTest.java            |  2 +-
 .../NettySSLContextParametersTest.java             |  2 +-
 .../NettySSLPassphaseBeanTest.java                 |  2 +-
 .../component/{netty4 => netty}/NettySSLTest.java  |  2 +-
 .../{netty4 => netty}/NettySingleCodecTest.java    |  2 +-
 .../{netty4 => netty}/NettySuspendResumeTest.java  |  4 +-
 .../{netty4 => netty}/NettyTCPAsyncTest.java       |  8 +--
 .../{netty4 => netty}/NettyTCPChainedTest.java     |  6 +-
 .../NettyTCPSyncNotLazyChannelTest.java            |  2 +-
 .../{netty4 => netty}/NettyTCPSyncTest.java        | 12 ++--
 .../NettyTcpWithInOutUsingPlainSocketTest.java     |  2 +-
 .../NettyTextlineInOnlyNullDelimiterTest.java      |  4 +-
 .../{netty4 => netty}/NettyTextlineInOnlyTest.java |  2 +-
 .../NettyTextlineInOutNonBlockingTest.java         |  4 +-
 .../NettyTextlineInOutSynchronousFalseTest.java    |  4 +-
 .../NettyTextlineInOutSynchronousTest.java         |  4 +-
 .../{netty4 => netty}/NettyTextlineInOutTest.java  |  4 +-
 .../NettyTransferExchangeOptionTest.java           |  2 +-
 .../{netty4 => netty}/NettyUDPAsyncTest.java       |  4 +-
 .../NettyUDPByteArrayConsumerTest.java             |  2 +-
 .../NettyUDPByteArrayProviderTest.java             |  2 +-
 .../NettyUDPLargeMessageInOnlyTest.java            |  2 +-
 ...yUDPMessageLargerThanDefaultBufferSizeTest.java |  2 +-
 .../NettyUDPMulticastAsyncTest.java                |  8 +--
 .../{netty4 => netty}/NettyUDPObjectSyncTest.java  | 10 ++--
 .../{netty4 => netty}/NettyUDPSyncTest.java        | 14 ++---
 .../NettyUdpConnectedSendTest.java                 |  2 +-
 .../NettyUdpConnectionlessSendTest.java            |  2 +-
 .../NettyUdpWithInOutUsingPlainSocketTest.java     |  2 +-
 ...ttyUseSharedWorkerThreadPoolManyRoutesTest.java |  2 +-
 .../NettyUseSharedWorkerThreadPoolTest.java        |  2 +-
 .../camel/component/{netty4 => netty}/Poetry.java  | 40 ++++++-------
 .../SpringNettyUseSharedWorkerThreadPoolTest.java  |  6 +-
 .../UnsharableCodecsConflicts2Test.java            |  2 +-
 .../UnsharableCodecsConflictsTest.java             |  2 +-
 .../src/test/resources/log4j2.properties           |  2 +-
 .../SpringNettyUseSharedWorkerThreadPoolTest.xml   |  2 +-
 .../{netty4 => netty}/multiple-codecs.xml          |  4 +-
 .../syslog/netty/Rfc5425FrameDecoder.java          |  2 +-
 .../impl/cloud/DefaultServiceCallExpression.java   |  2 +-
 .../endpoint/dsl/NettyEndpointBuilderFactory.java  | 36 +++++-------
 .../dsl/NettyHttpEndpointBuilderFactory.java       | 68 +++++++++++-----------
 .../modules/ROOT/pages/hl7-dataformat.adoc         |  2 +-
 .../modules/ROOT/pages/netty-component.adoc        | 20 +++----
 .../modules/ROOT/pages/netty-http-component.adoc   | 44 +++++++-------
 .../META-INF/spring-configuration-metadata.json    |  2 +-
 .../META-INF/spring-configuration-metadata.json    |  2 +-
 .../META-INF/spring-configuration-metadata.json    |  2 +-
 .../camel/example/netty/MyCodecDecoderFactory.java |  2 +-
 .../camel/example/netty/MyCodecEncoderFactory.java |  2 +-
 .../camel/example/netty/MyCorrelationManager.java  |  4 +-
 .../camel-example-netty-http/myapp-cdi/pom.xml     |  4 +-
 .../camel/example/netty/cdi/NettyHttpRoute.java    |  2 +-
 .../camel-example-netty-http/myapp-one/pom.xml     |  4 +-
 .../resources/OSGI-INF/blueprint/camel-one.xml     |  2 +-
 .../camel-example-netty-http/myapp-two/pom.xml     |  4 +-
 .../resources/OSGI-INF/blueprint/camel-two.xml     |  2 +-
 .../shared-netty-http-server/pom.xml               |  4 +-
 .../resources/OSGI-INF/blueprint/http-server.xml   |  6 +-
 .../NettyHttpComponentAutoConfiguration.java       |  4 +-
 .../NettyHttpComponentConfiguration.java           | 20 +++----
 .../src/main/resources/META-INF/spring.factories   |  2 +-
 .../NettyComponentAutoConfiguration.java           |  4 +-
 .../springboot/NettyComponentConfiguration.java    | 14 ++---
 .../src/main/resources/META-INF/spring.factories   |  2 +-
 .../camel/tools/apt/DocumentationHelper.java       |  2 +-
 346 files changed, 882 insertions(+), 882 deletions(-)

diff --git a/catalog/camel-catalog/src/test/java/org/apache/camel/catalog/CamelCatalogTest.java b/catalog/camel-catalog/src/test/java/org/apache/camel/catalog/CamelCatalogTest.java
index 7029e6e..8b3761a 100644
--- a/catalog/camel-catalog/src/test/java/org/apache/camel/catalog/CamelCatalogTest.java
+++ b/catalog/camel-catalog/src/test/java/org/apache/camel/catalog/CamelCatalogTest.java
@@ -214,7 +214,7 @@ public class CamelCatalogTest {
     }
 
     @Test
-    public void testAsEndpointUriNetty4http() throws Exception {
+    public void testAsEndpointUriNettyhttp() throws Exception {
         Map<String, String> map = new HashMap<>();
         // use http protocol
         map.put("protocol", "http");
@@ -399,7 +399,7 @@ public class CamelCatalogTest {
     }
 
     @Test
-    public void testEndpointPropertiesNetty4Http() throws Exception {
+    public void testEndpointPropertiesNettyHttp() throws Exception {
         Map<String, String> map = catalog.endpointProperties("netty-http:http:localhost:8080/foo/bar?disconnect=true&keepAlive=false");
         assertNotNull(map);
         assertEquals(6, map.size());
@@ -413,7 +413,7 @@ public class CamelCatalogTest {
     }
 
     @Test
-    public void testEndpointPropertiesNetty4HttpDefaultPort() throws Exception {
+    public void testEndpointPropertiesNettyHttpDefaultPort() throws Exception {
         Map<String, String> map = catalog.endpointProperties("netty-http:http:localhost/foo/bar?disconnect=true&keepAlive=false");
         assertNotNull(map);
         assertEquals(5, map.size());
@@ -426,7 +426,7 @@ public class CamelCatalogTest {
     }
 
     @Test
-    public void testEndpointPropertiesNetty4HttpPlaceholder() throws Exception {
+    public void testEndpointPropertiesNettyHttpPlaceholder() throws Exception {
         Map<String, String> map = catalog.endpointProperties("netty-http:http:{{myhost}}:{{myport}}/foo/bar?disconnect=true&keepAlive=false");
         assertNotNull(map);
         assertEquals(6, map.size());
@@ -440,7 +440,7 @@ public class CamelCatalogTest {
     }
 
     @Test
-    public void testEndpointPropertiesNetty4HttpWithDoubleSlash() throws Exception {
+    public void testEndpointPropertiesNettyHttpWithDoubleSlash() throws Exception {
         Map<String, String> map = catalog.endpointProperties("netty-http:http://localhost:8080/foo/bar?disconnect=true&keepAlive=false");
         assertNotNull(map);
         assertEquals(6, map.size());
diff --git a/components/camel-hl7/src/main/docs/hl7-dataformat.adoc b/components/camel-hl7/src/main/docs/hl7-dataformat.adoc
index 6b55962..ed91242 100644
--- a/components/camel-hl7/src/main/docs/hl7-dataformat.adoc
+++ b/components/camel-hl7/src/main/docs/hl7-dataformat.adoc
@@ -32,7 +32,7 @@ for this component:
 == HL7 MLLP protocol
 
 HL7 is often used with the HL7 MLLP protocol, which is a text based TCP
-socket based protocol. This component ships with a Mina and Netty4 Codec
+socket based protocol. This component ships with a Mina and Netty Codec
 that conforms to the MLLP protocol so you can easily expose an HL7
 listener accepting HL7 requests over the TCP transport layer. To expose
 a HL7 listener service, the xref:mina-component.adoc[camel-mina] or
diff --git a/components/camel-hl7/src/main/java/org/apache/camel/component/hl7/HL7MLLPConfigAwareChannelHandlerFactory.java b/components/camel-hl7/src/main/java/org/apache/camel/component/hl7/HL7MLLPConfigAwareChannelHandlerFactory.java
index dfe55d5..eb404ef 100644
--- a/components/camel-hl7/src/main/java/org/apache/camel/component/hl7/HL7MLLPConfigAwareChannelHandlerFactory.java
+++ b/components/camel-hl7/src/main/java/org/apache/camel/component/hl7/HL7MLLPConfigAwareChannelHandlerFactory.java
@@ -18,7 +18,7 @@ package org.apache.camel.component.hl7;
 
 import java.nio.charset.Charset;
 
-import org.apache.camel.component.netty4.DefaultChannelHandlerFactory;
+import org.apache.camel.component.netty.DefaultChannelHandlerFactory;
 
 /**
  * Abstract helper for Netty decoder and encoder factory
diff --git a/components/camel-hl7/src/main/java/org/apache/camel/component/hl7/HL7MLLPNettyDecoder.java b/components/camel-hl7/src/main/java/org/apache/camel/component/hl7/HL7MLLPNettyDecoder.java
index 6aa3deb..d21c335 100644
--- a/components/camel-hl7/src/main/java/org/apache/camel/component/hl7/HL7MLLPNettyDecoder.java
+++ b/components/camel-hl7/src/main/java/org/apache/camel/component/hl7/HL7MLLPNettyDecoder.java
@@ -27,7 +27,7 @@ import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
 /**
- * HL7 MLLP Decoder for Netty4
+ * HL7 MLLP Decoder for Netty
  */
 class HL7MLLPNettyDecoder extends DelimiterBasedFrameDecoder {
 
diff --git a/components/camel-hl7/src/main/java/org/apache/camel/component/hl7/HL7MLLPNettyEncoder.java b/components/camel-hl7/src/main/java/org/apache/camel/component/hl7/HL7MLLPNettyEncoder.java
index b4c5a14..da0f451 100644
--- a/components/camel-hl7/src/main/java/org/apache/camel/component/hl7/HL7MLLPNettyEncoder.java
+++ b/components/camel-hl7/src/main/java/org/apache/camel/component/hl7/HL7MLLPNettyEncoder.java
@@ -22,7 +22,7 @@ import io.netty.channel.ChannelHandlerContext;
 import io.netty.handler.codec.MessageToByteEncoder;
 
 /**
- * HL7 MLLP Encoder for Netty4
+ * HL7 MLLP Encoder for Netty
  */
 class HL7MLLPNettyEncoder extends MessageToByteEncoder<Object> {
 
diff --git a/components/camel-netty-http/src/main/docs/netty-http-component.adoc b/components/camel-netty-http/src/main/docs/netty-http-component.adoc
index d9d199b..358ce10 100644
--- a/components/camel-netty-http/src/main/docs/netty-http-component.adoc
+++ b/components/camel-netty-http/src/main/docs/netty-http-component.adoc
@@ -19,7 +19,7 @@ of the stream *once*. If you find a situation where the message body appears to
 you need to access the data multiple times (eg: doing multicasting, or
 redelivery error handling) you should use Stream caching or convert the
 message body to a `String` which is safe to be re-read multiple times. 
-Notice Netty4 HTTP reads the entire stream into memory using
+Notice Netty HTTP reads the entire stream into memory using
 `io.netty.handler.codec.http.HttpObjectAggregator` to build the entire
 full http message. But the resulting message is still a stream based
 message which is readable once.
@@ -80,7 +80,7 @@ This component inherits all the options from
 xref:netty-component.adoc[Netty], so make sure to look at
 the xref:netty-component.adoc[Netty] documentation as well.
 Notice that some options from xref:netty-component.adoc[Netty] is not
-applicable when using this Netty4 HTTP component, such as options
+applicable when using this Netty HTTP component, such as options
 related to UDP transport.
 ====
 
@@ -95,10 +95,10 @@ The Netty HTTP component supports 9 options, which are listed below.
 [width="100%",cols="2,5,^1,2",options="header"]
 |===
 | Name | Description | Default | Type
-| *nettyHttpBinding* (advanced) | To use a custom org.apache.camel.component.netty4.http.NettyHttpBinding for binding to/from Netty and Camel Message API. |  | NettyHttpBinding
+| *nettyHttpBinding* (advanced) | To use a custom org.apache.camel.component.netty.http.NettyHttpBinding for binding to/from Netty and Camel Message API. |  | NettyHttpBinding
 | *configuration* (common) | To use the NettyConfiguration as configuration when creating endpoints. |  | NettyHttpConfiguration
 | *headerFilterStrategy* (advanced) | To use a custom org.apache.camel.spi.HeaderFilterStrategy to filter headers. |  | HeaderFilterStrategy
-| *securityConfiguration* (security) | Refers to a org.apache.camel.component.netty4.http.NettyHttpSecurityConfiguration for configuring secure web resources. |  | NettyHttpSecurity Configuration
+| *securityConfiguration* (security) | Refers to a org.apache.camel.component.netty.http.NettyHttpSecurityConfiguration for configuring secure web resources. |  | NettyHttpSecurity Configuration
 | *useGlobalSslContext Parameters* (security) | Enable usage of global SSL context parameters. | false | boolean
 | *maximumPoolSize* (advanced) | The thread pool size for the EventExecutorGroup if its in use. The default value is 16. | 16 | int
 | *executorService* (advanced) | To use the given EventExecutorGroup. |  | EventExecutorGroup
@@ -169,7 +169,7 @@ with the following path and query parameters:
 | *serverExceptionCaughtLog Level* (consumer) | If the server (NettyConsumer) catches an exception then its logged using this logging level. | WARN | LoggingLevel
 | *serverInitializerFactory* (consumer) | To use a custom ServerInitializerFactory |  | ServerInitializer Factory
 | *traceEnabled* (consumer) | Specifies whether to enable HTTP TRACE for this Netty HTTP consumer. By default TRACE is turned off. | false | boolean
-| *urlDecodeHeaders* (consumer) | If this option is enabled, then during binding from Netty to Camel Message then the header values will be URL decoded (eg %20 will be a space character. Notice this option is used by the default org.apache.camel.component.netty.http.NettyHttpBinding and therefore if you implement a custom org.apache.camel.component.netty4.http.NettyHttpBinding then you would need to decode the headers accordingly to this option. | false | boolean
+| *urlDecodeHeaders* (consumer) | If this option is enabled, then during binding from Netty to Camel Message then the header values will be URL decoded (eg %20 will be a space character. Notice this option is used by the default org.apache.camel.component.netty.http.NettyHttpBinding and therefore if you implement a custom org.apache.camel.component.netty.http.NettyHttpBinding then you would need to decode the headers accordingly to this option. | false | boolean
 | *usingExecutorService* (consumer) | Whether to use ordered thread pool, to ensure events are processed orderly on the same channel. | true | boolean
 | *connectTimeout* (producer) | Time to wait for a socket connection to be available. Value is in milliseconds. | 10000 | int
 | *cookieHandler* (producer) | Configure a cookie handler to maintain a HTTP session |  | CookieHandler
@@ -190,7 +190,7 @@ with the following path and query parameters:
 | *disableStreamCache* (advanced) | Determines whether or not the raw input stream from Netty HttpRequest#getContent() or HttpResponset#getContent() is cached or not (Camel will read the stream into a in light-weight memory based Stream caching) cache. By default Camel will cache the Netty input stream to support reading it multiple times to ensure it Camel can retrieve all data from the stream. However you can set this option to true when you for example need to access the raw stream, s [...]
 | *headerFilterStrategy* (advanced) | To use a custom org.apache.camel.spi.HeaderFilterStrategy to filter headers. |  | HeaderFilterStrategy
 | *nativeTransport* (advanced) | Whether to use native transport instead of NIO. Native transport takes advantage of the host operating system and is only supported on some platforms. You need to add the netty JAR for the host operating system you are using. See more details at: \http://netty.io/wiki/native-transports.html | false | boolean
-| *nettyHttpBinding* (advanced) | To use a custom org.apache.camel.component.netty4.http.NettyHttpBinding for binding to/from Netty and Camel Message API. |  | NettyHttpBinding
+| *nettyHttpBinding* (advanced) | To use a custom org.apache.camel.component.netty.http.NettyHttpBinding for binding to/from Netty and Camel Message API. |  | NettyHttpBinding
 | *options* (advanced) | Allows to configure additional netty options using option. as prefix. For example option.child.keepAlive=false to set the netty option child.keepAlive=false. See the Netty documentation for possible options that can be used. |  | Map
 | *receiveBufferSize* (advanced) | The TCP/UDP buffer sizes to be used during inbound communication. Size is bytes. | 65536 | int
 | *receiveBufferSizePredictor* (advanced) | Configures the buffer size predictor. See details at Jetty documentation and this mail thread. |  | int
@@ -209,7 +209,7 @@ with the following path and query parameters:
 | *keyStoreResource* (security) | Client side certificate keystore to be used for encryption. Is loaded by default from classpath, but you can prefix with classpath:, file:, or http: to load the resource from different systems. |  | String
 | *needClientAuth* (security) | Configures whether the server needs client authentication when using SSL. | false | boolean
 | *passphrase* (security) | Password setting to use in order to encrypt/decrypt payloads sent using SSH |  | String
-| *securityConfiguration* (security) | Refers to a org.apache.camel.component.netty4.http.NettyHttpSecurityConfiguration for configuring secure web resources. |  | NettyHttpSecurity Configuration
+| *securityConfiguration* (security) | Refers to a org.apache.camel.component.netty.http.NettyHttpSecurityConfiguration for configuring secure web resources. |  | NettyHttpSecurity Configuration
 | *securityOptions* (security) | To configure NettyHttpSecurityConfiguration using key/value pairs from the map |  | Map
 | *securityProvider* (security) | Security provider to be used for payload encryption. Defaults to SunX509 if not set. |  | String
 | *ssl* (security) | Setting to specify whether SSL encryption is applied to this endpoint | false | boolean
@@ -266,13 +266,13 @@ The component supports 32 options, which are listed below.
 | *camel.component.netty-http.configuration.send503when-suspended* | Whether to send back HTTP status code 503 when the consumer has been suspended. If the option is false then the Netty Acceptor is unbound when the consumer is suspended, so clients cannot connect anymore. | true | Boolean
 | *camel.component.netty-http.configuration.throw-exception-on-failure* | Option to disable throwing the HttpOperationFailedException in case of failed responses from the remote server. This allows you to get all responses regardless of the HTTP status code. | true | Boolean
 | *camel.component.netty-http.configuration.transfer-exception* | If enabled and an Exchange failed processing on the consumer side, and if the caused Exception was send back serialized in the response as a application/x-java-serialized-object content type. On the producer side the exception will be deserialized and thrown as is, instead of the HttpOperationFailedException. The caused exception is required to be serialized. <p/> This is by default turned off. If you enable this then be a [...]
-| *camel.component.netty-http.configuration.url-decode-headers* | If this option is enabled, then during binding from Netty to Camel Message then the header values will be URL decoded (eg %20 will be a space character. Notice this option is used by the default org.apache.camel.component.netty.http.NettyHttpBinding and therefore if you implement a custom org.apache.camel.component.netty4.http.NettyHttpBinding then you would need to decode the headers accordingly to this option. | false | Boolean
+| *camel.component.netty-http.configuration.url-decode-headers* | If this option is enabled, then during binding from Netty to Camel Message then the header values will be URL decoded (eg %20 will be a space character. Notice this option is used by the default org.apache.camel.component.netty.http.NettyHttpBinding and therefore if you implement a custom org.apache.camel.component.netty.http.NettyHttpBinding then you would need to decode the headers accordingly to this option. | false | Boolean
 | *camel.component.netty-http.configuration.use-relative-path* | Sets whether to use a relative path in HTTP requests. | true | Boolean
 | *camel.component.netty-http.enabled* | Whether to enable auto configuration of the netty-http component. This is enabled by default. |  | Boolean
 | *camel.component.netty-http.executor-service* | To use the given EventExecutorGroup. The option is a io.netty.util.concurrent.EventExecutorGroup type. |  | String
 | *camel.component.netty-http.header-filter-strategy* | To use a custom org.apache.camel.spi.HeaderFilterStrategy to filter headers. The option is a org.apache.camel.spi.HeaderFilterStrategy type. |  | String
 | *camel.component.netty-http.maximum-pool-size* | The thread pool size for the EventExecutorGroup if its in use. The default value is 16. | 16 | Integer
-| *camel.component.netty-http.netty-http-binding* | To use a custom org.apache.camel.component.netty4.http.NettyHttpBinding for binding to/from Netty and Camel Message API. The option is a org.apache.camel.component.netty4.http.NettyHttpBinding type. |  | String
+| *camel.component.netty-http.netty-http-binding* | To use a custom org.apache.camel.component.netty.http.NettyHttpBinding for binding to/from Netty and Camel Message API. The option is a org.apache.camel.component.netty.http.NettyHttpBinding type. |  | String
 | *camel.component.netty-http.security-configuration.authenticate* | Whether to enable authentication <p/> This is by default enabled. |  | Boolean
 | *camel.component.netty-http.security-configuration.constraint* | The supported restricted. <p/> Currently only Basic is supported. |  | String
 | *camel.component.netty-http.security-configuration.login-denied-logging-level* | Sets a logging level to use for logging denied login attempts (incl stacktraces) <p/> This level is by default DEBUG. |  | LoggingLevel
@@ -321,7 +321,7 @@ success, and 500 for failure.
 |=======================================================================
 
 The following headers is provided as meta-data when a route starts from
-an Netty4 HTTP endpoint:
+an Netty HTTP endpoint:
 
 The description in the table takes offset in a route having:
 `from("netty-http:http:0.0.0.0:8080/myapp")...`
@@ -360,7 +360,7 @@ with the value `Basic`.
 == Access to Netty types
 
 This component uses the
-`org.apache.camel.component.netty4.http.NettyHttpMessage` as the message
+`org.apache.camel.component.netty.http.NettyHttpMessage` as the message
 implementation on the Exchange. This allows end
 users to get access to the original Netty request/response instances if
 needed, as shown below. Mind that the original response may not be
@@ -373,7 +373,7 @@ io.netty.handler.codec.http.HttpRequest request = exchange.getIn(NettyHttpMessag
 
 == Examples
 
-In the route below we use Netty4 HTTP as a HTTP server, which returns
+In the route below we use Netty HTTP as a HTTP server, which returns
 back a hardcoded "Bye World" message.
 
 [source,java]
@@ -395,7 +395,7 @@ And we get back "Bye World" as the output.
 
 === How do I let Netty match wildcards
 
-By default Netty4 HTTP will only match on exact uri's. But you can
+By default Netty HTTP will only match on exact uri's. But you can
 instruct Netty to match prefixes. For example
 
 [source,java]
@@ -403,7 +403,7 @@ instruct Netty to match prefixes. For example
 from("netty-http:http://0.0.0.0:8123/foo").to("mock:foo");
 -----------------------------------------------------------
 
-In the route above Netty4 HTTP will only match if the uri is an exact
+In the route above Netty HTTP will only match if the uri is an exact
 match, so it will match if you enter +
  `\http://0.0.0.0:8123/foo` but not match if you do
 `\http://0.0.0.0:8123/foo/bar`.
@@ -427,7 +427,7 @@ from("netty-http:http://0.0.0.0:8123?matchOnUriPrefix=true").to("mock:foo");
 === Using multiple routes with same port
 
 In the same CamelContext you can have multiple
-routes from Netty4 HTTP that shares the same port (eg a
+routes from Netty HTTP that shares the same port (eg a
 `io.netty.bootstrap.ServerBootstrap` instance). Doing this requires a
 number of bootstrap options to be identical in the routes, as the routes
 will share the same `io.netty.bootstrap.ServerBootstrap` instance. The
@@ -436,7 +436,7 @@ created.
 
 The options the routes must be identical configured is all the options
 defined in the
-`org.apache.camel.component.netty4.NettyServerBootstrapConfiguration`
+`org.apache.camel.component.netty.NettyServerBootstrapConfiguration`
 configuration class. If you have configured another route with different
 options, Camel will throw an exception on startup, indicating the
 options is not identical. To mitigate this ensure all options is
@@ -459,7 +459,7 @@ from("netty-http:http://0.0.0.0:{{port}}/bar")
 
 And here is an example of a mis configured 2nd route that do not have
 identical
-`org.apache.camel.component.netty4.NettyServerBootstrapConfiguration`
+`org.apache.camel.component.netty.NettyServerBootstrapConfiguration`
 option as the 1st route. This will cause Camel to fail on startup.
 
 *Two routes sharing the same port, but the 2nd route is misconfigured
@@ -481,13 +481,13 @@ from("netty-http:http://0.0.0.0:{{port}}/bar?ssl=true")
 
 By configuring the common server bootstrap option in an single instance
 of a
-`org.apache.camel.component.netty4.NettyServerBootstrapConfiguration`
-type, we can use the `bootstrapConfiguration` option on the Netty4 HTTP
+`org.apache.camel.component.netty.NettyServerBootstrapConfiguration`
+type, we can use the `bootstrapConfiguration` option on the Netty HTTP
 consumers to refer and reuse the same options across all consumers.
 
 [source,xml]
 -----------------------------------------------------------------------------------------------------------------
-<bean id="nettyHttpBootstrapOptions" class="org.apache.camel.component.netty4.NettyServerBootstrapConfiguration">
+<bean id="nettyHttpBootstrapOptions" class="org.apache.camel.component.netty.NettyServerBootstrapConfiguration">
   <property name="backlog" value="200"/>
   <property name="connectionTimeout" value="20000"/>
   <property name="workerCount" value="16"/>
@@ -574,7 +574,7 @@ containers.
 
 === Specifying ACL on web resources
 
-The `org.apache.camel.component.netty4.http.SecurityConstraint` allows
+The `org.apache.camel.component.netty.http.SecurityConstraint` allows
 to define constrains on web resources. And the
 `org.apache.camel.component.netty.http.SecurityConstraintMapping` is
 provided out of the box, allowing to easily define inclusions and
@@ -585,7 +585,7 @@ bean:
 
 [source,xml]
 -------------------------------------------------------------------------------------------------
-  <bean id="constraint" class="org.apache.camel.component.netty4.http.SecurityConstraintMapping">
+  <bean id="constraint" class="org.apache.camel.component.netty.http.SecurityConstraintMapping">
     <!-- inclusions defines url -> roles restrictions -->
     <!-- a * should be used for any role accepted (or even no roles) -->
     <property name="inclusions">
diff --git a/components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/ChunkedHttpRequest.java b/components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/ChunkedHttpRequest.java
similarity index 98%
rename from components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/ChunkedHttpRequest.java
rename to components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/ChunkedHttpRequest.java
index 1e41530..b34ca18 100644
--- a/components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/ChunkedHttpRequest.java
+++ b/components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/ChunkedHttpRequest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import java.io.InputStream;
 
diff --git a/components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/ChunkedHttpResponse.java b/components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/ChunkedHttpResponse.java
similarity index 98%
rename from components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/ChunkedHttpResponse.java
rename to components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/ChunkedHttpResponse.java
index 2261a3b..29bfa1c 100644
--- a/components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/ChunkedHttpResponse.java
+++ b/components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/ChunkedHttpResponse.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import java.io.InputStream;
 
diff --git a/components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/ContextPathMatcher.java b/components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/ContextPathMatcher.java
similarity index 91%
rename from components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/ContextPathMatcher.java
rename to components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/ContextPathMatcher.java
index 7d3b664..486271c 100644
--- a/components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/ContextPathMatcher.java
+++ b/components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/ContextPathMatcher.java
@@ -14,10 +14,12 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
+
+import org.apache.camel.component.netty.http.handlers.HttpServerChannelHandler;
 
 /**
- * A matcher used for selecting the correct {@link org.apache.camel.component.netty4.http.handlers.HttpServerChannelHandler}
+ * A matcher used for selecting the correct {@link HttpServerChannelHandler}
  * to handle an incoming {@link io.netty.handler.codec.http.HttpRequest} when you use multiple routes on the same
  * port.
  * <p/>
diff --git a/components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/CustomChunkedWriteHandler.java b/components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/CustomChunkedWriteHandler.java
similarity index 96%
rename from components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/CustomChunkedWriteHandler.java
rename to components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/CustomChunkedWriteHandler.java
index c3eba4e..e07fa2a 100644
--- a/components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/CustomChunkedWriteHandler.java
+++ b/components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/CustomChunkedWriteHandler.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import io.netty.channel.ChannelHandlerContext;
 import io.netty.channel.ChannelPromise;
diff --git a/components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/DefaultContextPathMatcher.java b/components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/DefaultContextPathMatcher.java
similarity index 98%
rename from components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/DefaultContextPathMatcher.java
rename to components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/DefaultContextPathMatcher.java
index 032cd65..8e50fa5 100644
--- a/components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/DefaultContextPathMatcher.java
+++ b/components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/DefaultContextPathMatcher.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import java.util.Locale;
 
diff --git a/components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/DefaultNettyHttpBinding.java b/components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/DefaultNettyHttpBinding.java
similarity index 99%
rename from components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/DefaultNettyHttpBinding.java
rename to components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/DefaultNettyHttpBinding.java
index e29d8eb..f7e11d4 100644
--- a/components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/DefaultNettyHttpBinding.java
+++ b/components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/DefaultNettyHttpBinding.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import java.io.ByteArrayOutputStream;
 import java.io.InputStream;
@@ -49,8 +49,8 @@ import org.apache.camel.Exchange;
 import org.apache.camel.Message;
 import org.apache.camel.RuntimeCamelException;
 import org.apache.camel.TypeConverter;
-import org.apache.camel.component.netty4.NettyConstants;
-import org.apache.camel.component.netty4.NettyConverter;
+import org.apache.camel.component.netty.NettyConstants;
+import org.apache.camel.component.netty.NettyConverter;
 import org.apache.camel.spi.HeaderFilterStrategy;
 import org.apache.camel.support.ExchangeHelper;
 import org.apache.camel.support.MessageHelper;
@@ -564,14 +564,14 @@ public class DefaultNettyHttpBinding implements NettyHttpBinding, Cloneable {
                     if (buffer == null) {
                         // fallback to byte array as last resort
                         byte[] data = message.getMandatoryBody(byte[].class);
-    
+
                         if (data.length > 0) {
                             buffer = NettyConverter.toByteBuffer(data);
                         }
                     }
                 }
 
-    
+
                 if (buffer != null) {
                     if (buffer.readableBytes() > 0) {
                         request = ((DefaultFullHttpRequest)request).replace(buffer);
diff --git a/components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/DefaultNettySharedHttpServer.java b/components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/DefaultNettySharedHttpServer.java
similarity index 96%
rename from components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/DefaultNettySharedHttpServer.java
rename to components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/DefaultNettySharedHttpServer.java
index 0ee600b..2a34f77 100644
--- a/components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/DefaultNettySharedHttpServer.java
+++ b/components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/DefaultNettySharedHttpServer.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import java.util.concurrent.ThreadFactory;
 import java.util.regex.Matcher;
@@ -22,8 +22,8 @@ import java.util.regex.Matcher;
 import io.netty.channel.Channel;
 import io.netty.channel.ChannelInitializer;
 import org.apache.camel.CamelContext;
-import org.apache.camel.component.netty4.NettyServerBootstrapFactory;
-import org.apache.camel.component.netty4.http.handlers.HttpServerMultiplexChannelHandler;
+import org.apache.camel.component.netty.http.handlers.HttpServerMultiplexChannelHandler;
+import org.apache.camel.component.netty.NettyServerBootstrapFactory;
 import org.apache.camel.support.service.ServiceHelper;
 import org.apache.camel.support.service.ServiceSupport;
 import org.apache.camel.util.ObjectHelper;
diff --git a/components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/HttpClientInitializerFactory.java b/components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/HttpClientInitializerFactory.java
similarity index 93%
rename from components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/HttpClientInitializerFactory.java
rename to components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/HttpClientInitializerFactory.java
index 81c8b73..a61513e 100644
--- a/components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/HttpClientInitializerFactory.java
+++ b/components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/HttpClientInitializerFactory.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import java.util.List;
 import java.util.concurrent.TimeUnit;
@@ -30,12 +30,13 @@ import io.netty.handler.codec.http.HttpObjectAggregator;
 import io.netty.handler.ssl.SslHandler;
 import io.netty.handler.timeout.ReadTimeoutHandler;
 import org.apache.camel.RuntimeCamelException;
-import org.apache.camel.component.netty4.ChannelHandlerFactory;
-import org.apache.camel.component.netty4.ClientInitializerFactory;
-import org.apache.camel.component.netty4.NettyConfiguration;
-import org.apache.camel.component.netty4.NettyProducer;
-import org.apache.camel.component.netty4.http.handlers.HttpClientChannelHandler;
-import org.apache.camel.component.netty4.ssl.SSLEngineFactory;
+import org.apache.camel.component.netty.http.handlers.HttpClientChannelHandler;
+import org.apache.camel.component.netty.ChannelHandlerFactory;
+import org.apache.camel.component.netty.ClientInitializerFactory;
+import org.apache.camel.component.netty.NettyConfiguration;
+import org.apache.camel.component.netty.NettyProducer;
+import org.apache.camel.component.netty.http.handlers.HttpClientChannelHandler;
+import org.apache.camel.component.netty.ssl.SSLEngineFactory;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
@@ -84,9 +85,9 @@ public class HttpClientInitializerFactory extends ClientInitializerFactory {
             LOG.debug("Client SSL handler configured and added as an interceptor against the ChannelPipeline: {}", sslHandler);
             pipeline.addLast("ssl", sslHandler);
         }
-        
+
         pipeline.addLast("http", new HttpClientCodec());
-        
+
         List<ChannelHandler> encoders = producer.getConfiguration().getEncoders();
         for (int x = 0; x < encoders.size(); x++) {
             ChannelHandler encoder = encoders.get(x);
@@ -116,7 +117,7 @@ public class HttpClientInitializerFactory extends ClientInitializerFactory {
             ChannelHandler timeout = new ReadTimeoutHandler(producer.getConfiguration().getRequestTimeout(), TimeUnit.MILLISECONDS);
             pipeline.addLast("timeout", timeout);
         }
-       
+
         // handler to route Camel messages
         pipeline.addLast("handler", new HttpClientChannelHandler(producer));
     }
diff --git a/components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/HttpPrincipal.java b/components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/HttpPrincipal.java
similarity index 96%
rename from components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/HttpPrincipal.java
rename to components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/HttpPrincipal.java
index 4b4bc02..73ccf4e 100644
--- a/components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/HttpPrincipal.java
+++ b/components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/HttpPrincipal.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import java.security.Principal;
 
diff --git a/components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/HttpServerBootstrapFactory.java b/components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/HttpServerBootstrapFactory.java
similarity index 94%
rename from components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/HttpServerBootstrapFactory.java
rename to components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/HttpServerBootstrapFactory.java
index 823c6f7..37ebf21 100644
--- a/components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/HttpServerBootstrapFactory.java
+++ b/components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/HttpServerBootstrapFactory.java
@@ -14,14 +14,14 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import io.netty.channel.Channel;
 import io.netty.channel.ChannelInitializer;
 import org.apache.camel.CamelContext;
-import org.apache.camel.component.netty4.NettyConsumer;
-import org.apache.camel.component.netty4.NettyServerBootstrapConfiguration;
-import org.apache.camel.component.netty4.SingleTCPNettyServerBootstrapFactory;
+import org.apache.camel.component.netty.NettyConsumer;
+import org.apache.camel.component.netty.NettyServerBootstrapConfiguration;
+import org.apache.camel.component.netty.SingleTCPNettyServerBootstrapFactory;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
diff --git a/components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/HttpServerConsumerChannelFactory.java b/components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/HttpServerConsumerChannelFactory.java
similarity index 97%
rename from components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/HttpServerConsumerChannelFactory.java
rename to components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/HttpServerConsumerChannelFactory.java
index 771b70b..13039fe 100644
--- a/components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/HttpServerConsumerChannelFactory.java
+++ b/components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/HttpServerConsumerChannelFactory.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import io.netty.channel.ChannelHandler;
 
diff --git a/components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/HttpServerInitializerFactory.java b/components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/HttpServerInitializerFactory.java
similarity index 95%
rename from components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/HttpServerInitializerFactory.java
rename to components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/HttpServerInitializerFactory.java
index 2659c84..9f97fe4 100644
--- a/components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/HttpServerInitializerFactory.java
+++ b/components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/HttpServerInitializerFactory.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 
 import java.util.List;
@@ -33,11 +33,11 @@ import io.netty.handler.ssl.SslHandler;
 import io.netty.util.concurrent.EventExecutorGroup;
 import org.apache.camel.CamelContext;
 import org.apache.camel.RuntimeCamelException;
-import org.apache.camel.component.netty4.ChannelHandlerFactory;
-import org.apache.camel.component.netty4.NettyConsumer;
-import org.apache.camel.component.netty4.NettyServerBootstrapConfiguration;
-import org.apache.camel.component.netty4.ServerInitializerFactory;
-import org.apache.camel.component.netty4.ssl.SSLEngineFactory;
+import org.apache.camel.component.netty.ChannelHandlerFactory;
+import org.apache.camel.component.netty.NettyConsumer;
+import org.apache.camel.component.netty.NettyServerBootstrapConfiguration;
+import org.apache.camel.component.netty.ServerInitializerFactory;
+import org.apache.camel.component.netty.ssl.SSLEngineFactory;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
@@ -78,7 +78,7 @@ public class HttpServerInitializerFactory extends ServerInitializerFactory {
     protected void initChannel(Channel ch) throws Exception {
         // create a new pipeline
         ChannelPipeline pipeline = ch.pipeline();
-        
+
         SslHandler sslHandler = configureServerSSLOnDemand();
         if (sslHandler != null) {
             //TODO must close on SSL exception
@@ -112,10 +112,10 @@ public class HttpServerInitializerFactory extends ServerInitializerFactory {
         if (supportCompressed()) {
             pipeline.addLast("deflater", new HttpContentCompressor());
         }
-        
+
         int port = consumer.getConfiguration().getPort();
         ChannelHandler handler = consumer.getEndpoint().getComponent().getMultiplexChannelHandler(port).getChannelHandler();
-        
+
         if (consumer.getConfiguration().isUsingExecutorService()) {
             EventExecutorGroup applicationExecutor = consumer.getEndpoint().getComponent().getExecutorService();
             pipeline.addLast(applicationExecutor, "handler", handler);
diff --git a/components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/HttpServerSharedInitializerFactory.java b/components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/HttpServerSharedInitializerFactory.java
similarity index 96%
rename from components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/HttpServerSharedInitializerFactory.java
rename to components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/HttpServerSharedInitializerFactory.java
index e5c50b5..5e9a328 100644
--- a/components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/HttpServerSharedInitializerFactory.java
+++ b/components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/HttpServerSharedInitializerFactory.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import javax.net.ssl.SSLContext;
 import javax.net.ssl.SSLEngine;
@@ -28,9 +28,9 @@ import io.netty.handler.codec.http.HttpResponseEncoder;
 import io.netty.handler.ssl.SslHandler;
 import org.apache.camel.CamelContext;
 import org.apache.camel.RuntimeCamelException;
-import org.apache.camel.component.netty4.NettyConsumer;
-import org.apache.camel.component.netty4.ServerInitializerFactory;
-import org.apache.camel.component.netty4.ssl.SSLEngineFactory;
+import org.apache.camel.component.netty.NettyConsumer;
+import org.apache.camel.component.netty.ServerInitializerFactory;
+import org.apache.camel.component.netty.ssl.SSLEngineFactory;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
diff --git a/components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/JAASSecurityAuthenticator.java b/components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/JAASSecurityAuthenticator.java
similarity index 98%
rename from components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/JAASSecurityAuthenticator.java
rename to components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/JAASSecurityAuthenticator.java
index 7ff3425..a4641bf 100644
--- a/components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/JAASSecurityAuthenticator.java
+++ b/components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/JAASSecurityAuthenticator.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import java.security.Principal;
 
diff --git a/components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/NettyChannelBufferStreamCache.java b/components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/NettyChannelBufferStreamCache.java
similarity index 98%
rename from components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/NettyChannelBufferStreamCache.java
rename to components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/NettyChannelBufferStreamCache.java
index d530ab3..d034a31 100644
--- a/components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/NettyChannelBufferStreamCache.java
+++ b/components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/NettyChannelBufferStreamCache.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import java.io.IOException;
 import java.io.InputStream;
diff --git a/components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/NettyChannelBufferStreamCacheOnCompletion.java b/components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/NettyChannelBufferStreamCacheOnCompletion.java
similarity index 96%
rename from components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/NettyChannelBufferStreamCacheOnCompletion.java
rename to components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/NettyChannelBufferStreamCacheOnCompletion.java
index 7a28126..fc8fd08 100644
--- a/components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/NettyChannelBufferStreamCacheOnCompletion.java
+++ b/components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/NettyChannelBufferStreamCacheOnCompletion.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import org.apache.camel.Exchange;
 import org.apache.camel.support.SynchronizationAdapter;
diff --git a/components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/NettyHttpBinding.java b/components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/NettyHttpBinding.java
similarity index 99%
rename from components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/NettyHttpBinding.java
rename to components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/NettyHttpBinding.java
index d8280fb..4ccb67c 100644
--- a/components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/NettyHttpBinding.java
+++ b/components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/NettyHttpBinding.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import java.util.Map;
 
diff --git a/components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/NettyHttpComponent.java b/components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/NettyHttpComponent.java
similarity index 97%
rename from components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/NettyHttpComponent.java
rename to components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/NettyHttpComponent.java
index af59ab2..c65d8c5 100644
--- a/components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/NettyHttpComponent.java
+++ b/components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/NettyHttpComponent.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import java.net.URI;
 import java.util.HashMap;
@@ -27,10 +27,10 @@ import org.apache.camel.Endpoint;
 import org.apache.camel.Processor;
 import org.apache.camel.Producer;
 import org.apache.camel.SSLContextParametersAware;
-import org.apache.camel.component.netty4.NettyComponent;
-import org.apache.camel.component.netty4.NettyConfiguration;
-import org.apache.camel.component.netty4.NettyServerBootstrapConfiguration;
-import org.apache.camel.component.netty4.http.handlers.HttpServerMultiplexChannelHandler;
+import org.apache.camel.component.netty.NettyComponent;
+import org.apache.camel.component.netty.NettyConfiguration;
+import org.apache.camel.component.netty.NettyServerBootstrapConfiguration;
+import org.apache.camel.component.netty.http.handlers.HttpServerMultiplexChannelHandler;
 import org.apache.camel.spi.HeaderFilterStrategy;
 import org.apache.camel.spi.HeaderFilterStrategyAware;
 import org.apache.camel.spi.Metadata;
@@ -66,7 +66,7 @@ public class NettyHttpComponent extends NettyComponent implements HeaderFilterSt
     private NettyHttpSecurityConfiguration securityConfiguration;
     @Metadata(label = "security", defaultValue = "false")
     private boolean useGlobalSslContextParameters;
-    
+
     public NettyHttpComponent() {
         // use the http configuration and filter strategy
         super(NettyHttpEndpoint.class);
@@ -237,7 +237,7 @@ public class NettyHttpComponent extends NettyComponent implements HeaderFilterSt
     }
 
     /**
-     * To use a custom org.apache.camel.component.netty4.http.NettyHttpBinding for binding to/from Netty and Camel Message API.
+     * To use a custom org.apache.camel.component.netty.http.NettyHttpBinding for binding to/from Netty and Camel Message API.
      */
     public void setNettyHttpBinding(NettyHttpBinding nettyHttpBinding) {
         this.nettyHttpBinding = nettyHttpBinding;
@@ -270,7 +270,7 @@ public class NettyHttpComponent extends NettyComponent implements HeaderFilterSt
     }
 
     /**
-     * Refers to a org.apache.camel.component.netty4.http.NettyHttpSecurityConfiguration for configuring secure web resources.
+     * Refers to a org.apache.camel.component.netty.http.NettyHttpSecurityConfiguration for configuring secure web resources.
      */
     public void setSecurityConfiguration(NettyHttpSecurityConfiguration securityConfiguration) {
         this.securityConfiguration = securityConfiguration;
@@ -337,7 +337,7 @@ public class NettyHttpComponent extends NettyComponent implements HeaderFilterSt
             }
         }
         path = FileUtil.stripLeadingSeparator(path);
-        
+
         String scheme = "http";
         String host = "";
         int port = 0;
@@ -367,7 +367,7 @@ public class NettyHttpComponent extends NettyComponent implements HeaderFilterSt
                 path = contextPath + "/" + path;
             }
         }
-        
+
         // if no explicit hostname set then resolve the hostname
         if (ObjectHelper.isEmpty(host)) {
             if (config.getHostNameResolver() == RestConfiguration.RestHostNameResolver.allLocalIp) {
@@ -406,11 +406,11 @@ public class NettyHttpComponent extends NettyComponent implements HeaderFilterSt
         }
         // get the endpoint
         url = String.format(url, scheme, host, port, path, restrict);
-        
+
         if (!query.isEmpty()) {
             url = url + "&" + query;
         }
-        
+
         NettyHttpEndpoint endpoint = camelContext.getEndpoint(url, NettyHttpEndpoint.class);
         setProperties(camelContext, endpoint, parameters);
 
diff --git a/components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/NettyHttpConfiguration.java b/components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/NettyHttpConfiguration.java
similarity index 98%
rename from components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/NettyHttpConfiguration.java
rename to components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/NettyHttpConfiguration.java
index af7938b..afb657a 100644
--- a/components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/NettyHttpConfiguration.java
+++ b/components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/NettyHttpConfiguration.java
@@ -14,14 +14,14 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import java.util.ArrayList;
 import java.util.List;
 
 import io.netty.channel.ChannelHandler;
 import org.apache.camel.RuntimeCamelException;
-import org.apache.camel.component.netty4.NettyConfiguration;
+import org.apache.camel.component.netty.NettyConfiguration;
 import org.apache.camel.spi.Metadata;
 import org.apache.camel.spi.UriParam;
 import org.apache.camel.spi.UriParams;
@@ -67,7 +67,7 @@ public class NettyHttpConfiguration extends NettyConfiguration {
     private String okStatusCodeRange = "200-299";
     @UriParam(label = "producer,advanced", defaultValue = "true")
     private boolean useRelativePath = true;
-    
+
     public NettyHttpConfiguration() {
         // we need sync=true as http is request/reply by nature
         setSync(true);
@@ -183,7 +183,7 @@ public class NettyHttpConfiguration extends NettyConfiguration {
     /**
      * If this option is enabled, then during binding from Netty to Camel Message then the header values will be URL decoded
      * (eg %20 will be a space character. Notice this option is used by the default org.apache.camel.component.netty.http.NettyHttpBinding
-     * and therefore if you implement a custom org.apache.camel.component.netty4.http.NettyHttpBinding then you would
+     * and therefore if you implement a custom org.apache.camel.component.netty.http.NettyHttpBinding then you would
      * need to decode the headers accordingly to this option.
      */
     public void setUrlDecodeHeaders(boolean urlDecodeHeaders) {
diff --git a/components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/NettyHttpConstants.java b/components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/NettyHttpConstants.java
similarity index 96%
rename from components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/NettyHttpConstants.java
rename to components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/NettyHttpConstants.java
index b3024ed..2ad5784 100644
--- a/components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/NettyHttpConstants.java
+++ b/components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/NettyHttpConstants.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import org.apache.camel.Exchange;
 
diff --git a/components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/NettyHttpConsumer.java b/components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/NettyHttpConsumer.java
similarity index 93%
rename from components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/NettyHttpConsumer.java
rename to components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/NettyHttpConsumer.java
index 8ef1adf..fec7d31 100644
--- a/components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/NettyHttpConsumer.java
+++ b/components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/NettyHttpConsumer.java
@@ -14,12 +14,12 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import org.apache.camel.Processor;
 import org.apache.camel.Suspendable;
-import org.apache.camel.component.netty4.NettyConfiguration;
-import org.apache.camel.component.netty4.NettyConsumer;
+import org.apache.camel.component.netty.NettyConfiguration;
+import org.apache.camel.component.netty.NettyConsumer;
 import org.apache.camel.util.ObjectHelper;
 
 /**
diff --git a/components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/NettyHttpConverter.java b/components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/NettyHttpConverter.java
similarity index 97%
rename from components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/NettyHttpConverter.java
rename to components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/NettyHttpConverter.java
index 43e7df5..e90a329 100644
--- a/components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/NettyHttpConverter.java
+++ b/components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/NettyHttpConverter.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import java.io.InputStream;
 import java.nio.charset.Charset;
@@ -25,7 +25,7 @@ import io.netty.handler.codec.http.HttpRequest;
 import io.netty.handler.codec.http.HttpResponse;
 import org.apache.camel.Converter;
 import org.apache.camel.Exchange;
-import org.apache.camel.component.netty4.NettyConverter;
+import org.apache.camel.component.netty.NettyConverter;
 import org.apache.camel.spi.TypeConverterRegistry;
 
 
diff --git a/components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/NettyHttpEndpoint.java b/components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/NettyHttpEndpoint.java
similarity index 94%
rename from components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/NettyHttpEndpoint.java
rename to components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/NettyHttpEndpoint.java
index 876513f..efd208f 100644
--- a/components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/NettyHttpEndpoint.java
+++ b/components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/NettyHttpEndpoint.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import java.util.Map;
 
@@ -27,8 +27,8 @@ import org.apache.camel.Message;
 import org.apache.camel.PollingConsumer;
 import org.apache.camel.Processor;
 import org.apache.camel.Producer;
-import org.apache.camel.component.netty4.NettyConfiguration;
-import org.apache.camel.component.netty4.NettyEndpoint;
+import org.apache.camel.component.netty.NettyConfiguration;
+import org.apache.camel.component.netty.NettyEndpoint;
 import org.apache.camel.http.common.cookie.CookieHandler;
 import org.apache.camel.spi.HeaderFilterStrategy;
 import org.apache.camel.spi.HeaderFilterStrategyAware;
@@ -49,7 +49,7 @@ public class NettyHttpEndpoint extends NettyEndpoint implements AsyncEndpoint, H
 
     @UriParam
     private NettyHttpConfiguration configuration;
-    @UriParam(label = "advanced", name = "configuration", javaType = "org.apache.camel.component.netty4.http.NettyHttpConfiguration",
+    @UriParam(label = "advanced", name = "configuration", javaType = "org.apache.camel.component.netty.http.NettyHttpConfiguration",
             description = "To use a custom configured NettyHttpConfiguration for configuring this endpoint.")
     private Object httpConfiguration; // to include in component docs as NettyHttpConfiguration is a @UriParams class
     @UriParam(label = "advanced")
@@ -114,12 +114,12 @@ public class NettyHttpEndpoint extends NettyEndpoint implements AsyncEndpoint, H
     @Override
     public Exchange createExchange(ChannelHandlerContext ctx, Object message) throws Exception {
         Exchange exchange = createExchange();
-        
+
         FullHttpRequest request = (FullHttpRequest) message;
         Message in = getNettyHttpBinding().toCamelMessage(request, exchange, getConfiguration());
         exchange.setIn(in);
-        
-        // setup the common message headers 
+
+        // setup the common message headers
         updateMessageHeader(in, ctx);
 
         // honor the character encoding
@@ -155,7 +155,7 @@ public class NettyHttpEndpoint extends NettyEndpoint implements AsyncEndpoint, H
     }
 
     /**
-     * To use a custom org.apache.camel.component.netty4.http.NettyHttpBinding for binding to/from Netty and Camel Message API.
+     * To use a custom org.apache.camel.component.netty.http.NettyHttpBinding for binding to/from Netty and Camel Message API.
      */
     public void setNettyHttpBinding(NettyHttpBinding nettyHttpBinding) {
         this.nettyHttpBinding = nettyHttpBinding;
@@ -213,7 +213,7 @@ public class NettyHttpEndpoint extends NettyEndpoint implements AsyncEndpoint, H
     }
 
     /**
-     * Refers to a org.apache.camel.component.netty4.http.NettyHttpSecurityConfiguration for configuring secure web resources.
+     * Refers to a org.apache.camel.component.netty.http.NettyHttpSecurityConfiguration for configuring secure web resources.
      */
     public void setSecurityConfiguration(NettyHttpSecurityConfiguration securityConfiguration) {
         this.securityConfiguration = securityConfiguration;
diff --git a/components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/NettyHttpHeaderFilterStrategy.java b/components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/NettyHttpHeaderFilterStrategy.java
similarity index 97%
rename from components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/NettyHttpHeaderFilterStrategy.java
rename to components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/NettyHttpHeaderFilterStrategy.java
index 2f92663..eadaccc 100644
--- a/components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/NettyHttpHeaderFilterStrategy.java
+++ b/components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/NettyHttpHeaderFilterStrategy.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import org.apache.camel.spi.HeaderFilterStrategy;
 import org.apache.camel.support.DefaultHeaderFilterStrategy;
diff --git a/components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/NettyHttpHelper.java b/components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/NettyHttpHelper.java
similarity index 99%
rename from components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/NettyHttpHelper.java
rename to components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/NettyHttpHelper.java
index 75acf2e..c383152 100644
--- a/components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/NettyHttpHelper.java
+++ b/components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/NettyHttpHelper.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import java.io.IOException;
 import java.io.InputStream;
diff --git a/components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/NettyHttpMessage.java b/components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/NettyHttpMessage.java
similarity index 97%
rename from components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/NettyHttpMessage.java
rename to components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/NettyHttpMessage.java
index c3b4857..02566ba 100644
--- a/components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/NettyHttpMessage.java
+++ b/components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/NettyHttpMessage.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import io.netty.handler.codec.http.FullHttpRequest;
 import io.netty.handler.codec.http.FullHttpResponse;
diff --git a/components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/NettyHttpOperationFailedException.java b/components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/NettyHttpOperationFailedException.java
similarity index 96%
rename from components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/NettyHttpOperationFailedException.java
rename to components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/NettyHttpOperationFailedException.java
index 3b49fb4..c6532d4 100644
--- a/components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/NettyHttpOperationFailedException.java
+++ b/components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/NettyHttpOperationFailedException.java
@@ -14,13 +14,13 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import java.io.UnsupportedEncodingException;
 
 import io.netty.handler.codec.http.HttpContent;
 import org.apache.camel.CamelException;
-import org.apache.camel.component.netty4.NettyConverter;
+import org.apache.camel.component.netty.NettyConverter;
 import org.apache.camel.util.ObjectHelper;
 import org.apache.camel.util.URISupport;
 
@@ -99,4 +99,4 @@ public class NettyHttpOperationFailedException extends CamelException {
     public String getContentAsString() {
         return contentAsString;
     }
-}
\ No newline at end of file
+}
diff --git a/components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/NettyHttpProducer.java b/components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/NettyHttpProducer.java
similarity index 96%
rename from components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/NettyHttpProducer.java
rename to components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/NettyHttpProducer.java
index 1352105..ffd5b84 100644
--- a/components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/NettyHttpProducer.java
+++ b/components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/NettyHttpProducer.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import java.net.URI;
 import java.util.List;
@@ -26,9 +26,9 @@ import io.netty.handler.codec.http.HttpUtil;
 import io.netty.util.ReferenceCountUtil;
 import org.apache.camel.AsyncCallback;
 import org.apache.camel.Exchange;
-import org.apache.camel.component.netty4.NettyConfiguration;
-import org.apache.camel.component.netty4.NettyConstants;
-import org.apache.camel.component.netty4.NettyProducer;
+import org.apache.camel.component.netty.NettyConfiguration;
+import org.apache.camel.component.netty.NettyConstants;
+import org.apache.camel.component.netty.NettyProducer;
 import org.apache.camel.http.common.cookie.CookieHandler;
 import org.apache.camel.support.SynchronizationAdapter;
 
diff --git a/components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/NettyHttpRestHeaderFilterStrategy.java b/components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/NettyHttpRestHeaderFilterStrategy.java
similarity index 98%
rename from components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/NettyHttpRestHeaderFilterStrategy.java
rename to components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/NettyHttpRestHeaderFilterStrategy.java
index 90123c1..c9d9879 100644
--- a/components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/NettyHttpRestHeaderFilterStrategy.java
+++ b/components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/NettyHttpRestHeaderFilterStrategy.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import org.apache.camel.Exchange;
 import org.apache.camel.spi.HeaderFilterStrategy;
diff --git a/components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/NettyHttpSecurityConfiguration.java b/components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/NettyHttpSecurityConfiguration.java
similarity index 98%
rename from components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/NettyHttpSecurityConfiguration.java
rename to components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/NettyHttpSecurityConfiguration.java
index 3f9a696..bec640e 100644
--- a/components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/NettyHttpSecurityConfiguration.java
+++ b/components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/NettyHttpSecurityConfiguration.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import org.apache.camel.LoggingLevel;
 
diff --git a/components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/NettyHttpSendDynamicAware.java b/components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/NettyHttpSendDynamicAware.java
similarity index 97%
rename from components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/NettyHttpSendDynamicAware.java
rename to components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/NettyHttpSendDynamicAware.java
index 18b14c1..c0e498b 100644
--- a/components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/NettyHttpSendDynamicAware.java
+++ b/components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/NettyHttpSendDynamicAware.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import org.apache.camel.http.common.HttpSendDynamicAware;
 import org.apache.camel.spi.annotations.SendDynamic;
diff --git a/components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/NettySharedHttpServer.java b/components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/NettySharedHttpServer.java
similarity index 92%
rename from components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/NettySharedHttpServer.java
rename to components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/NettySharedHttpServer.java
index b907ef8..05908d4 100644
--- a/components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/NettySharedHttpServer.java
+++ b/components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/NettySharedHttpServer.java
@@ -14,12 +14,12 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import org.apache.camel.CamelContext;
 import org.apache.camel.Service;
-import org.apache.camel.component.netty4.NettyServerBootstrapConfiguration;
-import org.apache.camel.component.netty4.NettyServerBootstrapFactory;
+import org.apache.camel.component.netty.NettyServerBootstrapConfiguration;
+import org.apache.camel.component.netty.NettyServerBootstrapFactory;
 
 /**
  * A single interface to easily configure and setup a shared Netty HTTP server
diff --git a/components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/NettySharedHttpServerBootstrapConfiguration.java b/components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/NettySharedHttpServerBootstrapConfiguration.java
similarity index 93%
rename from components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/NettySharedHttpServerBootstrapConfiguration.java
rename to components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/NettySharedHttpServerBootstrapConfiguration.java
index 8b858c2..0955181 100644
--- a/components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/NettySharedHttpServerBootstrapConfiguration.java
+++ b/components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/NettySharedHttpServerBootstrapConfiguration.java
@@ -14,9 +14,9 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
-import org.apache.camel.component.netty4.NettyServerBootstrapConfiguration;
+import org.apache.camel.component.netty.NettyServerBootstrapConfiguration;
 
 public class NettySharedHttpServerBootstrapConfiguration extends NettyServerBootstrapConfiguration {
 
diff --git a/components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/RestContextPathMatcher.java b/components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/RestContextPathMatcher.java
similarity index 96%
rename from components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/RestContextPathMatcher.java
rename to components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/RestContextPathMatcher.java
index e7fdbe7..9e55594 100644
--- a/components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/RestContextPathMatcher.java
+++ b/components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/RestContextPathMatcher.java
@@ -14,13 +14,13 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import java.util.Locale;
 
 
 /**
- * A {@link org.apache.camel.component.netty4.http.ContextPathMatcher} that supports the Rest DSL.
+ * A {@link ContextPathMatcher} that supports the Rest DSL.
  */
 public class RestContextPathMatcher extends DefaultContextPathMatcher {
 
@@ -105,7 +105,7 @@ public class RestContextPathMatcher extends DefaultContextPathMatcher {
         // assume matching
         return true;
     }
-    
+
     @Override
     public boolean equals(Object o) {
         if (this == o) {
diff --git a/components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/RestNettyHttpBinding.java b/components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/RestNettyHttpBinding.java
similarity index 95%
rename from components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/RestNettyHttpBinding.java
rename to components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/RestNettyHttpBinding.java
index d733c4e..5eebdb1 100644
--- a/components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/RestNettyHttpBinding.java
+++ b/components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/RestNettyHttpBinding.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import java.net.URI;
 import java.util.Map;
@@ -25,7 +25,7 @@ import org.apache.camel.RuntimeCamelException;
 import org.apache.camel.spi.HeaderFilterStrategy;
 
 /**
- * A {@link org.apache.camel.component.netty4.http.NettyHttpBinding} that supports the Rest DSL.
+ * A {@link NettyHttpBinding} that supports the Rest DSL.
  */
 public class RestNettyHttpBinding extends DefaultNettyHttpBinding {
 
diff --git a/components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/SecurityAuthenticator.java b/components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/SecurityAuthenticator.java
similarity index 98%
rename from components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/SecurityAuthenticator.java
rename to components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/SecurityAuthenticator.java
index 23c5765..fbe188b 100644
--- a/components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/SecurityAuthenticator.java
+++ b/components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/SecurityAuthenticator.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import javax.security.auth.Subject;
 import javax.security.auth.login.LoginException;
diff --git a/components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/SecurityAuthenticatorSupport.java b/components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/SecurityAuthenticatorSupport.java
similarity index 98%
rename from components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/SecurityAuthenticatorSupport.java
rename to components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/SecurityAuthenticatorSupport.java
index c175741..354d316 100644
--- a/components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/SecurityAuthenticatorSupport.java
+++ b/components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/SecurityAuthenticatorSupport.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import java.io.IOException;
 import java.security.Principal;
@@ -125,4 +125,4 @@ public abstract class SecurityAuthenticatorSupport implements SecurityAuthentica
             }
         }
     }
-}
\ No newline at end of file
+}
diff --git a/components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/SecurityConstraint.java b/components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/SecurityConstraint.java
similarity index 96%
rename from components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/SecurityConstraint.java
rename to components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/SecurityConstraint.java
index e53eeb4..60c6050 100644
--- a/components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/SecurityConstraint.java
+++ b/components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/SecurityConstraint.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 public interface SecurityConstraint {
 
diff --git a/components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/SecurityConstraintMapping.java b/components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/SecurityConstraintMapping.java
similarity index 98%
rename from components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/SecurityConstraintMapping.java
rename to components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/SecurityConstraintMapping.java
index 7836994..9429eba 100644
--- a/components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/SecurityConstraintMapping.java
+++ b/components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/SecurityConstraintMapping.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import java.util.LinkedHashSet;
 import java.util.Map;
diff --git a/components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/cloud/Netty4HttpServiceExpression.java b/components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/cloud/NettyHttpServiceExpression.java
similarity index 85%
rename from components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/cloud/Netty4HttpServiceExpression.java
rename to components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/cloud/NettyHttpServiceExpression.java
index b9e7ddf..0a5e3d8 100644
--- a/components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/cloud/Netty4HttpServiceExpression.java
+++ b/components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/cloud/NettyHttpServiceExpression.java
@@ -14,16 +14,16 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http.cloud;
+package org.apache.camel.component.netty.http.cloud;
 
 import org.apache.camel.impl.cloud.DefaultServiceCallExpression;
 import org.apache.camel.util.ObjectHelper;
 
-public final class Netty4HttpServiceExpression extends DefaultServiceCallExpression {
-    public Netty4HttpServiceExpression() {
+public final class NettyHttpServiceExpression extends DefaultServiceCallExpression {
+    public NettyHttpServiceExpression() {
     }
 
-    public Netty4HttpServiceExpression(String hostHeader, String portHeader) {
+    public NettyHttpServiceExpression(String hostHeader, String portHeader) {
         super(hostHeader, portHeader);
     }
 
diff --git a/components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/cloud/Netty4HttpServiceExpressionFactory.java b/components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/cloud/NettyHttpServiceExpressionFactory.java
similarity index 85%
rename from components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/cloud/Netty4HttpServiceExpressionFactory.java
rename to components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/cloud/NettyHttpServiceExpressionFactory.java
index 3ad7eb5..d3fe377 100644
--- a/components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/cloud/Netty4HttpServiceExpressionFactory.java
+++ b/components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/cloud/NettyHttpServiceExpressionFactory.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http.cloud;
+package org.apache.camel.component.netty.http.cloud;
 
 import org.apache.camel.CamelContext;
 import org.apache.camel.Expression;
@@ -22,9 +22,9 @@ import org.apache.camel.cloud.ServiceExpressionFactory;
 import org.apache.camel.spi.annotations.CloudServiceFactory;
 
 @CloudServiceFactory("netty-http-service-expression")
-public class Netty4HttpServiceExpressionFactory implements ServiceExpressionFactory {
+public class NettyHttpServiceExpressionFactory implements ServiceExpressionFactory {
     @Override
     public Expression newInstance(CamelContext camelContext) throws Exception {
-        return new Netty4HttpServiceExpression();
+        return new NettyHttpServiceExpression();
     }
 }
diff --git a/components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/handlers/HttpClientChannelHandler.java b/components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/handlers/HttpClientChannelHandler.java
similarity index 85%
rename from components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/handlers/HttpClientChannelHandler.java
rename to components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/handlers/HttpClientChannelHandler.java
index ec69f10..ba299e5 100644
--- a/components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/handlers/HttpClientChannelHandler.java
+++ b/components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/handlers/HttpClientChannelHandler.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http.handlers;
+package org.apache.camel.component.netty.http.handlers;
 
 import java.net.URI;
 import java.util.HashMap;
@@ -26,12 +26,13 @@ import io.netty.handler.codec.http.FullHttpResponse;
 import io.netty.handler.codec.http.HttpUtil;
 import org.apache.camel.Exchange;
 import org.apache.camel.Message;
-import org.apache.camel.component.netty4.NettyConstants;
-import org.apache.camel.component.netty4.handlers.ClientChannelHandler;
-import org.apache.camel.component.netty4.http.NettyHttpProducer;
+import org.apache.camel.component.netty.http.NettyHttpProducer;
+import org.apache.camel.component.netty.NettyConstants;
+import org.apache.camel.component.netty.handlers.ClientChannelHandler;
+import org.apache.camel.component.netty.http.NettyHttpProducer;
 
 /**
- * Netty HTTP {@link org.apache.camel.component.netty4.handlers.ClientChannelHandler} that handles the response combing
+ * Netty HTTP {@link org.apache.camel.component.netty.handlers.ClientChannelHandler} that handles the response combing
  * back from the HTTP server, called by this client.
  */
 public class HttpClientChannelHandler extends ClientChannelHandler {
diff --git a/components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/handlers/HttpRestConsumerPath.java b/components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/handlers/HttpRestConsumerPath.java
similarity index 96%
rename from components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/handlers/HttpRestConsumerPath.java
rename to components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/handlers/HttpRestConsumerPath.java
index dc351fe..5cad03b 100644
--- a/components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/handlers/HttpRestConsumerPath.java
+++ b/components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/handlers/HttpRestConsumerPath.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http.handlers;
+package org.apache.camel.component.netty.http.handlers;
 
 import org.apache.camel.support.RestConsumerContextPathMatcher;
 
diff --git a/components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/handlers/HttpServerChannelHandler.java b/components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/handlers/HttpServerChannelHandler.java
similarity index 95%
rename from components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/handlers/HttpServerChannelHandler.java
rename to components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/handlers/HttpServerChannelHandler.java
index 8c0b38c..062e824 100644
--- a/components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/handlers/HttpServerChannelHandler.java
+++ b/components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/handlers/HttpServerChannelHandler.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http.handlers;
+package org.apache.camel.component.netty.http.handlers;
 
 import java.net.URI;
 import java.nio.channels.ClosedChannelException;
@@ -36,15 +36,15 @@ import io.netty.handler.codec.http.HttpUtil;
 import org.apache.camel.Exchange;
 import org.apache.camel.LoggingLevel;
 import org.apache.camel.Message;
-import org.apache.camel.component.netty4.NettyConverter;
-import org.apache.camel.component.netty4.NettyHelper;
-import org.apache.camel.component.netty4.handlers.ServerChannelHandler;
-import org.apache.camel.component.netty4.http.HttpPrincipal;
-import org.apache.camel.component.netty4.http.NettyHttpConfiguration;
-import org.apache.camel.component.netty4.http.NettyHttpConstants;
-import org.apache.camel.component.netty4.http.NettyHttpConsumer;
-import org.apache.camel.component.netty4.http.NettyHttpSecurityConfiguration;
-import org.apache.camel.component.netty4.http.SecurityAuthenticator;
+import org.apache.camel.component.netty.http.NettyHttpConstants;
+import org.apache.camel.component.netty.http.SecurityAuthenticator;
+import org.apache.camel.component.netty.NettyConverter;
+import org.apache.camel.component.netty.NettyHelper;
+import org.apache.camel.component.netty.handlers.ServerChannelHandler;
+import org.apache.camel.component.netty.http.HttpPrincipal;
+import org.apache.camel.component.netty.http.NettyHttpConfiguration;
+import org.apache.camel.component.netty.http.NettyHttpConsumer;
+import org.apache.camel.component.netty.http.NettyHttpSecurityConfiguration;
 import org.apache.camel.spi.CamelLogger;
 import org.apache.camel.support.ObjectHelper;
 import org.apache.camel.util.StringHelper;
diff --git a/components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/handlers/HttpServerMultiplexChannelHandler.java b/components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/handlers/HttpServerMultiplexChannelHandler.java
similarity index 96%
rename from components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/handlers/HttpServerMultiplexChannelHandler.java
rename to components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/handlers/HttpServerMultiplexChannelHandler.java
index 1ed1162..3845b88 100644
--- a/components/camel-netty-http/src/main/java/org/apache/camel/component/netty4/http/handlers/HttpServerMultiplexChannelHandler.java
+++ b/components/camel-netty-http/src/main/java/org/apache/camel/component/netty/http/handlers/HttpServerMultiplexChannelHandler.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http.handlers;
+package org.apache.camel.component.netty.http.handlers;
 
 import java.nio.channels.ClosedChannelException;
 import java.util.ArrayList;
@@ -35,9 +35,10 @@ import io.netty.handler.codec.http.HttpResponse;
 import io.netty.util.Attribute;
 import io.netty.util.AttributeKey;
 import org.apache.camel.Exchange;
-import org.apache.camel.component.netty4.http.HttpServerConsumerChannelFactory;
-import org.apache.camel.component.netty4.http.NettyHttpConfiguration;
-import org.apache.camel.component.netty4.http.NettyHttpConsumer;
+import org.apache.camel.component.netty.http.HttpServerInitializerFactory;
+import org.apache.camel.component.netty.http.HttpServerConsumerChannelFactory;
+import org.apache.camel.component.netty.http.NettyHttpConfiguration;
+import org.apache.camel.component.netty.http.NettyHttpConsumer;
 import org.apache.camel.http.common.CamelServlet;
 import org.apache.camel.support.RestConsumerContextPathMatcher;
 import org.apache.camel.util.UnsafeUriCharactersEncoder;
@@ -50,7 +51,7 @@ import static io.netty.handler.codec.http.HttpResponseStatus.OK;
 import static io.netty.handler.codec.http.HttpVersion.HTTP_1_1;
 
 /**
- * A multiplex {@link org.apache.camel.component.netty4.http.HttpServerInitializerFactory} which keeps a list of handlers, and delegates to the
+ * A multiplex {@link HttpServerInitializerFactory} which keeps a list of handlers, and delegates to the
  * target handler based on the http context path in the incoming request. This is used to allow to reuse
  * the same Netty consumer, allowing to have multiple routes on the same netty {@link io.netty.bootstrap.ServerBootstrap}
  */
@@ -109,7 +110,7 @@ public class HttpServerMultiplexChannelHandler extends SimpleChannelInboundHandl
     protected void channelRead0(ChannelHandlerContext ctx, Object msg) throws Exception {
         // store request, as this channel handler is created per pipeline
         HttpRequest request = (HttpRequest) msg;
-      
+
         LOG.debug("Message received: {}", request);
 
         HttpServerChannelHandler handler = getHandler(request, request.method().name());
@@ -195,7 +196,7 @@ public class HttpServerMultiplexChannelHandler extends SimpleChannelInboundHandl
     private boolean isHttpMethodAllowed(HttpRequest request, String method) {
         return getHandler(request, method) != null;
     }
-    
+
     @SuppressWarnings("unchecked")
     private HttpServerChannelHandler getHandler(HttpRequest request, String method) {
         HttpServerChannelHandler answer = null;
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/BaseNettyTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/BaseNettyTest.java
similarity index 98%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/BaseNettyTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/BaseNettyTest.java
index d129005..de4a7c2 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/BaseNettyTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/BaseNettyTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 import java.io.File;
 import java.io.FileOutputStream;
 import java.util.Collection;
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/LogCaptureAppender.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/LogCaptureAppender.java
similarity index 98%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/LogCaptureAppender.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/LogCaptureAppender.java
index 6b841ab..61c8ede 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/LogCaptureAppender.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/LogCaptureAppender.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import java.io.Serializable;
 import java.util.ArrayDeque;
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/LogCaptureTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/LogCaptureTest.java
similarity index 96%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/LogCaptureTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/LogCaptureTest.java
index b8cce31..7f1b93e 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/LogCaptureTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/LogCaptureTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import io.netty.util.ResourceLeakDetector;
 import io.netty.util.internal.logging.InternalLoggerFactory;
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/ManagedNettyEndpointTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/ManagedNettyEndpointTest.java
similarity index 98%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/ManagedNettyEndpointTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/ManagedNettyEndpointTest.java
index 4788b85..a699cea 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/ManagedNettyEndpointTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/ManagedNettyEndpointTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import java.util.Set;
 
@@ -62,7 +62,7 @@ public class ManagedNettyEndpointTest extends BaseNettyTest {
 
         ObjectName on = ObjectName.getInstance("org.apache.camel:context=camel-1,type=endpoints,name=\"http://0.0.0.0:" + getPort() + "/foo\"");
         mbeanServer.isRegistered(on);
-        
+
         // should only be 2 endpoints in JMX
         Set<ObjectName> set = getMBeanServer().queryNames(new ObjectName("*:context=camel-1,type=endpoints,*"), null);
         assertEquals(2, set.size());
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/MyLoginModule.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/MyLoginModule.java
similarity index 98%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/MyLoginModule.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/MyLoginModule.java
index 59ac51e..e85cf6e 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/MyLoginModule.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/MyLoginModule.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import java.io.IOException;
 import java.util.Map;
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/MyRolePrincipal.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/MyRolePrincipal.java
similarity index 95%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/MyRolePrincipal.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/MyRolePrincipal.java
index cea2e23..f7f424f 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/MyRolePrincipal.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/MyRolePrincipal.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import java.security.Principal;
 
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyCamelWebsiteTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyCamelWebsiteTest.java
similarity index 97%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyCamelWebsiteTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyCamelWebsiteTest.java
index 4ce350d..5188622 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyCamelWebsiteTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyCamelWebsiteTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import org.apache.camel.Exchange;
 import org.apache.camel.builder.RouteBuilder;
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyDefaultProtocolTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyDefaultProtocolTest.java
similarity index 97%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyDefaultProtocolTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyDefaultProtocolTest.java
index 02aeb29..eee1854 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyDefaultProtocolTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyDefaultProtocolTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import org.apache.camel.Exchange;
 import org.apache.camel.builder.RouteBuilder;
@@ -50,4 +50,4 @@ public class NettyDefaultProtocolTest extends BaseNettyTest {
             }
         };
     }
-}
\ No newline at end of file
+}
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttp500ErrorTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttp500ErrorTest.java
similarity index 98%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttp500ErrorTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttp500ErrorTest.java
index 0b7f75b..766fbda 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttp500ErrorTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttp500ErrorTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import org.apache.camel.CamelExecutionException;
 import org.apache.camel.Exchange;
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttp500ErrorThrowExceptionOnServerTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttp500ErrorThrowExceptionOnServerTest.java
similarity index 98%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttp500ErrorThrowExceptionOnServerTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttp500ErrorThrowExceptionOnServerTest.java
index 4155921..3147d75 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttp500ErrorThrowExceptionOnServerTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttp500ErrorThrowExceptionOnServerTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import org.apache.camel.CamelExecutionException;
 import org.apache.camel.builder.RouteBuilder;
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpAccessHttpRequestAndResponseBeanTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpAccessHttpRequestAndResponseBeanTest.java
similarity index 96%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpAccessHttpRequestAndResponseBeanTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpAccessHttpRequestAndResponseBeanTest.java
index d9c1713..05cf525 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpAccessHttpRequestAndResponseBeanTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpAccessHttpRequestAndResponseBeanTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import java.nio.charset.Charset;
 
@@ -25,7 +25,7 @@ import io.netty.handler.codec.http.HttpResponse;
 import io.netty.handler.codec.http.HttpResponseStatus;
 import io.netty.handler.codec.http.HttpVersion;
 import org.apache.camel.builder.RouteBuilder;
-import org.apache.camel.component.netty4.NettyConverter;
+import org.apache.camel.component.netty.NettyConverter;
 import org.junit.Test;
 
 public class NettyHttpAccessHttpRequestAndResponseBeanTest extends BaseNettyTest {
@@ -66,7 +66,7 @@ public class NettyHttpAccessHttpRequestAndResponseBeanTest extends BaseNettyTest
 
         HttpResponse response = new DefaultFullHttpResponse(HttpVersion.HTTP_1_1, HttpResponseStatus.OK,
                                                             NettyConverter.toByteBuffer(reply.getBytes()));
-        
+
         response.headers().set(HttpHeaderNames.CONTENT_LENGTH.toString(), reply.length());
 
         return response;
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpAccessHttpRequestBeanTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpAccessHttpRequestBeanTest.java
similarity index 97%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpAccessHttpRequestBeanTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpAccessHttpRequestBeanTest.java
index ab60cb6..e99e095 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpAccessHttpRequestBeanTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpAccessHttpRequestBeanTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import java.nio.charset.Charset;
 
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpAccessHttpRequestTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpAccessHttpRequestTest.java
similarity index 97%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpAccessHttpRequestTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpAccessHttpRequestTest.java
index 6f31290..bd10de0 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpAccessHttpRequestTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpAccessHttpRequestTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import io.netty.handler.codec.http.HttpRequest;
 import org.apache.camel.Exchange;
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpBasicAuthConstraintMapperTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpBasicAuthConstraintMapperTest.java
similarity index 98%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpBasicAuthConstraintMapperTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpBasicAuthConstraintMapperTest.java
index bb7aabe..67d3b98 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpBasicAuthConstraintMapperTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpBasicAuthConstraintMapperTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 import org.apache.camel.BindToRegistry;
 import org.apache.camel.CamelExecutionException;
 import org.apache.camel.builder.RouteBuilder;
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpBasicAuthCustomSecurityAuthenticatorTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpBasicAuthCustomSecurityAuthenticatorTest.java
similarity index 98%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpBasicAuthCustomSecurityAuthenticatorTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpBasicAuthCustomSecurityAuthenticatorTest.java
index 2bcf98e..67a274c 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpBasicAuthCustomSecurityAuthenticatorTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpBasicAuthCustomSecurityAuthenticatorTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import javax.security.auth.Subject;
 import javax.security.auth.login.LoginException;
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpBasicAuthTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpBasicAuthTest.java
similarity index 98%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpBasicAuthTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpBasicAuthTest.java
index 3c780aa..1a0e0f6 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpBasicAuthTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpBasicAuthTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 import org.apache.camel.BindToRegistry;
 import org.apache.camel.CamelExecutionException;
 import org.apache.camel.builder.RouteBuilder;
@@ -59,9 +59,9 @@ public class NettyHttpBasicAuthTest extends BaseNettyTest {
             NettyHttpOperationFailedException cause = assertIsInstanceOf(NettyHttpOperationFailedException.class, e.getCause());
             assertEquals(401, cause.getStatusCode());
         }
-        
+
     }
-   
+
     @Test
     public void testBasicAuthSuccessed() throws Exception {
 
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpBindingPreservePostFormUrlEncodedBodyTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpBindingPreservePostFormUrlEncodedBodyTest.java
similarity index 98%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpBindingPreservePostFormUrlEncodedBodyTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpBindingPreservePostFormUrlEncodedBodyTest.java
index a600c26..f088993 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpBindingPreservePostFormUrlEncodedBodyTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpBindingPreservePostFormUrlEncodedBodyTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import io.netty.handler.codec.http.FullHttpRequest;
 import org.apache.camel.Exchange;
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpBindingUseAbsolutePathTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpBindingUseAbsolutePathTest.java
similarity index 99%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpBindingUseAbsolutePathTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpBindingUseAbsolutePathTest.java
index 76eb99c..d5c398d 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpBindingUseAbsolutePathTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpBindingUseAbsolutePathTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import io.netty.handler.codec.http.FullHttpRequest;
 import org.apache.camel.Exchange;
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpBindingUseRelativePathInPostTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpBindingUseRelativePathInPostTest.java
similarity index 98%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpBindingUseRelativePathInPostTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpBindingUseRelativePathInPostTest.java
index 9e70a7b..ebc196e 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpBindingUseRelativePathInPostTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpBindingUseRelativePathInPostTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import io.netty.handler.codec.http.FullHttpRequest;
 import org.apache.camel.Exchange;
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpBindingUseRelativePathTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpBindingUseRelativePathTest.java
similarity index 98%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpBindingUseRelativePathTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpBindingUseRelativePathTest.java
index 4556b9f..ca63850 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpBindingUseRelativePathTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpBindingUseRelativePathTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import io.netty.handler.codec.http.FullHttpRequest;
 import org.apache.camel.Exchange;
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpBridgeEncodedPathTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpBridgeEncodedPathTest.java
similarity index 99%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpBridgeEncodedPathTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpBridgeEncodedPathTest.java
index a1470a1..5007a69 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpBridgeEncodedPathTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpBridgeEncodedPathTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import java.net.URLEncoder;
 
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpBridgeRouteUsingHttpClientTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpBridgeRouteUsingHttpClientTest.java
similarity index 97%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpBridgeRouteUsingHttpClientTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpBridgeRouteUsingHttpClientTest.java
index 5372bb6..7f6e723 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpBridgeRouteUsingHttpClientTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpBridgeRouteUsingHttpClientTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import java.io.ByteArrayInputStream;
 
@@ -46,7 +46,7 @@ public class NettyHttpBridgeRouteUsingHttpClientTest extends BaseNettyTest {
             assertTrue("We should get a RuntimeCamelException", ex instanceof RuntimeCamelException);
         }
     }
-    
+
     @Test
     public void testSendFormRequestMessage() throws Exception {
         String out = template.requestBodyAndHeader("http://localhost:" + port2 + "/form", "username=abc&pass=password", Exchange.CONTENT_TYPE, "application/x-www-form-urlencoded", String.class);
@@ -73,7 +73,7 @@ public class NettyHttpBridgeRouteUsingHttpClientTest extends BaseNettyTest {
                         .to("http://localhost:" + port1 + "?throwExceptionOnFailure=false&bridgeEndpoint=true");
 
                 from("netty-http:http://localhost:" + port1 + "?matchOnUriPrefix=true").process(serviceProc);
-                
+
                 // check the from request
                 from("netty-http:http://localhost:" + port2 + "/form?bridgeEndpoint=true")
                     .process(new Processor() {
@@ -84,7 +84,7 @@ public class NettyHttpBridgeRouteUsingHttpClientTest extends BaseNettyTest {
                             String request = in.getBody(String.class);
                             exchange.getOut().setBody(request);
                         }
-                        
+
                     });
             }
         };
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpCharacterEncodingTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpCharacterEncodingTest.java
similarity index 98%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpCharacterEncodingTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpCharacterEncodingTest.java
index e8e1b00..5cd0263 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpCharacterEncodingTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpCharacterEncodingTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import org.apache.camel.Exchange;
 import org.apache.camel.Processor;
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpClientChunkedTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpClientChunkedTest.java
similarity index 97%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpClientChunkedTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpClientChunkedTest.java
index 1f58733..fb582a0 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpClientChunkedTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpClientChunkedTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import org.apache.camel.builder.RouteBuilder;
 import org.junit.Test;
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpClientExpectContinueTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpClientExpectContinueTest.java
similarity index 97%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpClientExpectContinueTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpClientExpectContinueTest.java
index bbfa944..0b14b86 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpClientExpectContinueTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpClientExpectContinueTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import org.apache.camel.Exchange;
 import org.apache.camel.builder.RouteBuilder;
@@ -36,7 +36,7 @@ public class NettyHttpClientExpectContinueTest extends BaseNettyTest {
         exchange.getIn().setBody(body);
 
         Exchange result = template.send("netty-http:http://localhost:{{port}}/foo", exchange);
-        
+
         assertFalse(result.isFailed());
         assertEquals("Bye World", result.getIn().getBody(String.class));
 
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpCompressTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpCompressTest.java
similarity index 96%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpCompressTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpCompressTest.java
index b1469f4..c31b5a3 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpCompressTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpCompressTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import java.nio.charset.Charset;
 import java.util.ArrayList;
@@ -30,7 +30,7 @@ import org.apache.camel.builder.RouteBuilder;
 import org.junit.Test;
 
 public class NettyHttpCompressTest extends BaseNettyTest {
-    
+
     // setup the decompress decoder here
     @BindToRegistry("myDecoders")
     public List<ChannelHandler> addChannelHandlers() throws Exception {
@@ -38,11 +38,11 @@ public class NettyHttpCompressTest extends BaseNettyTest {
         decoders.add(new HttpContentDecompressor());
         return decoders;
     }
-    
+
 
     @Test
     public void testContentType() throws Exception {
-        
+
         byte[] data = "Hello World".getBytes(Charset.forName("UTF-8"));
         Map<String, Object> headers = new HashMap<>();
         headers.put("content-type", "text/plain; charset=\"UTF-8\"");
@@ -51,9 +51,9 @@ public class NettyHttpCompressTest extends BaseNettyTest {
                 headers, String.class);
         // The decoded out has some space to clean up.
         assertEquals("Bye World", out.trim());
-        
 
-        
+
+
     }
 
     @Override
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpContentTypeTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpContentTypeTest.java
similarity index 98%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpContentTypeTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpContentTypeTest.java
index 66c61fe..7fc55de 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpContentTypeTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpContentTypeTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import java.nio.charset.Charset;
 
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpConvertPayloadToInputStreamTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpConvertPayloadToInputStreamTest.java
similarity index 97%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpConvertPayloadToInputStreamTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpConvertPayloadToInputStreamTest.java
index 690cc06..270dab6 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpConvertPayloadToInputStreamTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpConvertPayloadToInputStreamTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import java.io.InputStream;
 import java.util.List;
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpCustomOptionsTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpCustomOptionsTest.java
similarity index 97%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpCustomOptionsTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpCustomOptionsTest.java
index 547c35b..f51ecd0 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpCustomOptionsTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpCustomOptionsTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import org.apache.camel.builder.RouteBuilder;
 import org.junit.Test;
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpEmptyQueryParameterTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpEmptyQueryParameterTest.java
similarity index 97%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpEmptyQueryParameterTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpEmptyQueryParameterTest.java
index 10b103a..453d4db 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpEmptyQueryParameterTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpEmptyQueryParameterTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import org.apache.camel.builder.RouteBuilder;
 import org.junit.Test;
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpEndpointUriCustomHeaderFilterStrategyTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpEndpointUriCustomHeaderFilterStrategyTest.java
similarity index 98%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpEndpointUriCustomHeaderFilterStrategyTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpEndpointUriCustomHeaderFilterStrategyTest.java
index 77dce00..61d75d4 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpEndpointUriCustomHeaderFilterStrategyTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpEndpointUriCustomHeaderFilterStrategyTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import org.apache.camel.BindToRegistry;
 import org.apache.camel.Exchange;
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpEndpointUriEncodingIssueTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpEndpointUriEncodingIssueTest.java
similarity index 97%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpEndpointUriEncodingIssueTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpEndpointUriEncodingIssueTest.java
index 0f39551..3191c9f 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpEndpointUriEncodingIssueTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpEndpointUriEncodingIssueTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import org.apache.camel.Exchange;
 import org.apache.camel.Processor;
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpEndpointUriEncodingIssueUrlDecodeDisabledTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpEndpointUriEncodingIssueUrlDecodeDisabledTest.java
similarity index 97%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpEndpointUriEncodingIssueUrlDecodeDisabledTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpEndpointUriEncodingIssueUrlDecodeDisabledTest.java
index 608143a..2dda8ec 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpEndpointUriEncodingIssueUrlDecodeDisabledTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpEndpointUriEncodingIssueUrlDecodeDisabledTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import org.apache.camel.Exchange;
 import org.apache.camel.Processor;
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpFilterCamelHeadersTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpFilterCamelHeadersTest.java
similarity index 98%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpFilterCamelHeadersTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpFilterCamelHeadersTest.java
index 6954064..e1490e1 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpFilterCamelHeadersTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpFilterCamelHeadersTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import java.util.Map;
 
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpGetWithInvalidMessageTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpGetWithInvalidMessageTest.java
similarity index 95%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpGetWithInvalidMessageTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpGetWithInvalidMessageTest.java
index 8e5c307..f1e6f40 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpGetWithInvalidMessageTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpGetWithInvalidMessageTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import java.util.ArrayList;
 import java.util.List;
@@ -32,44 +32,44 @@ import org.apache.camel.test.junit4.CamelTestSupport;
 import org.junit.Test;
 
 public class NettyHttpGetWithInvalidMessageTest extends CamelTestSupport {
-    private static final String REQUEST_STRING = "user: Willem\n" 
+    private static final String REQUEST_STRING = "user: Willem\n"
         + "GET http://localhost:8101/test HTTP/1.1\n" + "another: value\n Host: localhost\n";
     private int port1;
-    
+
     @BindToRegistry("string-decoder")
     private StringDecoder stringDecoder = new StringDecoder();
-    
+
     @BindToRegistry("string-encoder")
     private StringEncoder stringEncoder = new StringEncoder();
-   
+
     @BindToRegistry("encoders")
     public List<ChannelHandler> addEncoders() throws Exception {
 
         List<ChannelHandler> encoders = new ArrayList<>();
         encoders.add(stringEncoder);
-        
+
         return encoders;
     }
-    
+
     @BindToRegistry("decoders")
     public List<ChannelHandler> addDecoders() throws Exception {
 
         List<ChannelHandler> decoders = new ArrayList<>();
         decoders.add(stringDecoder);
-        
+
         return decoders;
     }
-    
+
     @Test
     public void testNettyHttpServer() throws Exception {
         invokeService(8100);
     }
-    
+
     //@Test
     public void testJettyHttpServer() throws Exception {
         invokeService(port1);
     }
-    
+
     private void invokeService(int port) {
         Exchange out = template.request("netty:tcp://localhost:" + port + "?encoders=#encoders&decoders=#decoders&sync=true", new Processor() {
             @Override
@@ -82,22 +82,22 @@ public class NettyHttpGetWithInvalidMessageTest extends CamelTestSupport {
         String result = out.getOut().getBody(String.class);
         assertNotNull(result);
         assertTrue("We should get the 404 response.", result.indexOf("404 Not Found") > 0);
-        
+
     }
-    
 
-    
+
+
     @Override
     protected RouteBuilder createRouteBuilder() throws Exception {
         return new RouteBuilder() {
             @Override
             public void configure() throws Exception {
                 port1 = AvailablePortFinder.getNextAvailable(8100);
-                
+
                // set up a netty http proxy
                 from("netty-http:http://localhost:" + port1 + "/test")
                     .transform().simple("Bye ${header.user}.");
-          
+
             }
         };
     }
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpGetWithParamAsExchangeHeaderTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpGetWithParamAsExchangeHeaderTest.java
similarity index 99%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpGetWithParamAsExchangeHeaderTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpGetWithParamAsExchangeHeaderTest.java
index aff3e5f..2fc67e1 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpGetWithParamAsExchangeHeaderTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpGetWithParamAsExchangeHeaderTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import org.apache.camel.Exchange;
 import org.apache.camel.builder.RouteBuilder;
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpGetWithParamTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpGetWithParamTest.java
similarity index 97%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpGetWithParamTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpGetWithParamTest.java
index a2a9de8..a796477 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpGetWithParamTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpGetWithParamTest.java
@@ -14,13 +14,12 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import org.apache.camel.Exchange;
 import org.apache.camel.Processor;
 import org.apache.camel.builder.RouteBuilder;
 import org.apache.camel.component.mock.MockEndpoint;
-import org.junit.Ignore;
 import org.junit.Test;
 
 public class NettyHttpGetWithParamTest extends BaseNettyTest {
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpHandle404Test.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpHandle404Test.java
similarity index 98%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpHandle404Test.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpHandle404Test.java
index 6bf6c7a..b151660 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpHandle404Test.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpHandle404Test.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import org.apache.camel.AggregationStrategy;
 import org.apache.camel.Exchange;
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpHeaderCaseTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpHeaderCaseTest.java
similarity index 98%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpHeaderCaseTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpHeaderCaseTest.java
index 83fed6f..e6056d5 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpHeaderCaseTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpHeaderCaseTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import java.util.LinkedHashMap;
 import java.util.Map;
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpHeaderFilterStrategyRemovalTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpHeaderFilterStrategyRemovalTest.java
similarity index 98%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpHeaderFilterStrategyRemovalTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpHeaderFilterStrategyRemovalTest.java
index d735f89..1d6a5b2 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpHeaderFilterStrategyRemovalTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpHeaderFilterStrategyRemovalTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import static java.util.Collections.singleton;
 
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpHeaderFilterStrategyTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpHeaderFilterStrategyTest.java
similarity index 99%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpHeaderFilterStrategyTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpHeaderFilterStrategyTest.java
index e62b9bc..69c4be7 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpHeaderFilterStrategyTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpHeaderFilterStrategyTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import org.apache.camel.Exchange;
 import org.apache.camel.impl.DefaultCamelContext;
@@ -26,10 +26,10 @@ import static org.junit.Assert.assertFalse;
 import static org.junit.Assert.assertTrue;
 
 public class NettyHttpHeaderFilterStrategyTest {
-    
+
     private NettyHttpHeaderFilterStrategy filter;
     private Exchange exchange;
-    
+
     @Before
     public void setUp() {
         filter = new NettyHttpHeaderFilterStrategy();
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpHeaderMaxSizeTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpHeaderMaxSizeTest.java
similarity index 97%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpHeaderMaxSizeTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpHeaderMaxSizeTest.java
index a65e0e5..68e59b0 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpHeaderMaxSizeTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpHeaderMaxSizeTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import org.apache.camel.builder.RouteBuilder;
 import org.apache.commons.httpclient.HttpClient;
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpHeadersTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpHeadersTest.java
similarity index 98%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpHeadersTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpHeadersTest.java
index e000dc4..c5babe5 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpHeadersTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpHeadersTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import org.apache.camel.Exchange;
 import org.apache.camel.builder.RouteBuilder;
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpMapHeadersFalseTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpMapHeadersFalseTest.java
similarity index 98%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpMapHeadersFalseTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpMapHeadersFalseTest.java
index 029048b..bdd339c 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpMapHeadersFalseTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpMapHeadersFalseTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import org.apache.camel.Exchange;
 import org.apache.camel.Processor;
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpMethodRestrictTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpMethodRestrictTest.java
similarity index 98%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpMethodRestrictTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpMethodRestrictTest.java
index 7c6fb56..f94d38d 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpMethodRestrictTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpMethodRestrictTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import org.apache.camel.Exchange;
 import org.apache.camel.Message;
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpOkStatusCodeTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpOkStatusCodeTest.java
similarity index 98%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpOkStatusCodeTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpOkStatusCodeTest.java
index c2109b2..c65e9ab 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpOkStatusCodeTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpOkStatusCodeTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import org.apache.camel.CamelExecutionException;
 import org.apache.camel.Exchange;
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpOnExceptionHandledTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpOnExceptionHandledTest.java
similarity index 98%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpOnExceptionHandledTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpOnExceptionHandledTest.java
index bc0bb92..eb8631f 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpOnExceptionHandledTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpOnExceptionHandledTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import org.apache.camel.Exchange;
 import org.apache.camel.builder.RouteBuilder;
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpOperationFailedExceptionTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpOperationFailedExceptionTest.java
similarity index 96%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpOperationFailedExceptionTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpOperationFailedExceptionTest.java
index 3aec32a..b83f545 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpOperationFailedExceptionTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpOperationFailedExceptionTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import io.netty.handler.codec.http.DefaultLastHttpContent;
 import org.junit.Test;
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpProducerBridgeTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpProducerBridgeTest.java
similarity index 98%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpProducerBridgeTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpProducerBridgeTest.java
index f0eca71..2015e60 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpProducerBridgeTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpProducerBridgeTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import org.apache.camel.Exchange;
 import org.apache.camel.Processor;
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpProducerConcurrentTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpProducerConcurrentTest.java
similarity index 98%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpProducerConcurrentTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpProducerConcurrentTest.java
index ade2120..58f310e 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpProducerConcurrentTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpProducerConcurrentTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import java.util.HashMap;
 import java.util.HashSet;
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpProducerHeadersTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpProducerHeadersTest.java
similarity index 98%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpProducerHeadersTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpProducerHeadersTest.java
index a1fc167..08bc05a 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpProducerHeadersTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpProducerHeadersTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import java.util.HashMap;
 import java.util.Map;
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpProducerKeepAliveTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpProducerKeepAliveTest.java
similarity index 97%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpProducerKeepAliveTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpProducerKeepAliveTest.java
index 13b5aef..9e8548f 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpProducerKeepAliveTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpProducerKeepAliveTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import io.netty.handler.codec.http.HttpHeaderNames;
 import io.netty.handler.codec.http.HttpHeaderValues;
@@ -50,7 +50,7 @@ public class NettyHttpProducerKeepAliveTest extends BaseNettyTest {
 
         assertMockEndpointsSatisfied();
     }
-    
+
     @Test
     public void testConnectionClosed() throws Exception {
         getMockEndpoint("mock:input").expectedBodiesReceived("Hello World");
@@ -60,11 +60,11 @@ public class NettyHttpProducerKeepAliveTest extends BaseNettyTest {
                 exchange.getIn().setBody("Hello World");
             }
         });
-        
+
         assertMockEndpointsSatisfied();
         assertEquals(HttpHeaderValues.CLOSE.toString(), ex.getOut().getHeader(HttpHeaderNames.CONNECTION.toString()));
     }
-    
+
 
     @Override
     protected RouteBuilder createRouteBuilder() throws Exception {
@@ -74,12 +74,12 @@ public class NettyHttpProducerKeepAliveTest extends BaseNettyTest {
                 from("netty-http:http://localhost:{{port}}/foo")
                     .to("mock:input")
                     .transform().constant("Bye World");
-                
+
                 from("netty-http:http://localhost:{{port}}/bar").removeHeaders("*").to("mock:input").transform().constant("Bye World");
             }
         };
     }
-    
-    
+
+
 
 }
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpProducerQueryParamTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpProducerQueryParamTest.java
similarity index 98%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpProducerQueryParamTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpProducerQueryParamTest.java
index 765c8e5..1d787c7 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpProducerQueryParamTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpProducerQueryParamTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import java.util.Map;
 
@@ -89,7 +89,7 @@ public class NettyHttpProducerQueryParamTest extends BaseNettyTest {
         assertEquals("Bye World", body);
         assertEquals("Carlsberg", headers.get("beer"));
     }
-    
+
     @Override
     protected RouteBuilder createRouteBuilder() throws Exception {
         return new RouteBuilder() {
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpProducerSendEmptyHeaderTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpProducerSendEmptyHeaderTest.java
similarity index 97%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpProducerSendEmptyHeaderTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpProducerSendEmptyHeaderTest.java
index 06a5843..6deb01d 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpProducerSendEmptyHeaderTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpProducerSendEmptyHeaderTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import org.apache.camel.builder.RouteBuilder;
 import org.apache.camel.component.mock.MockEndpoint;
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpProducerSessionTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpProducerSessionTest.java
similarity index 98%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpProducerSessionTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpProducerSessionTest.java
index 19a7df0..fa0d2da 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpProducerSessionTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpProducerSessionTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import javax.servlet.http.HttpSession;
 
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpProducerSimpleGetTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpProducerSimpleGetTest.java
similarity index 97%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpProducerSimpleGetTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpProducerSimpleGetTest.java
index fb08f29..20b7a3c 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpProducerSimpleGetTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpProducerSimpleGetTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import org.apache.camel.Exchange;
 import org.apache.camel.builder.RouteBuilder;
@@ -30,7 +30,7 @@ public class NettyHttpProducerSimpleGetTest extends BaseNettyTest {
         assertEquals("Bye World", out);
 
         assertMockEndpointsSatisfied();
-        
+
         out = template.requestBody("netty-http:http://localhost:{{port}}/foo", null, String.class);
         assertEquals("Bye World", out);
     }
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpProducerSimpleTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpProducerSimpleTest.java
similarity index 98%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpProducerSimpleTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpProducerSimpleTest.java
index a890153..f153c84 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpProducerSimpleTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpProducerSimpleTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import io.netty.handler.codec.http.HttpResponse;
 import org.apache.camel.Exchange;
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpProducerThrowExceptionOnFailureTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpProducerThrowExceptionOnFailureTest.java
similarity index 97%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpProducerThrowExceptionOnFailureTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpProducerThrowExceptionOnFailureTest.java
index dee9a17..8bc0325 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpProducerThrowExceptionOnFailureTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpProducerThrowExceptionOnFailureTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import org.apache.camel.Exchange;
 import org.apache.camel.builder.RouteBuilder;
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpProducerTwoParametersWithSameKeyTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpProducerTwoParametersWithSameKeyTest.java
similarity index 98%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpProducerTwoParametersWithSameKeyTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpProducerTwoParametersWithSameKeyTest.java
index ca06783..6c5be9d 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpProducerTwoParametersWithSameKeyTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpProducerTwoParametersWithSameKeyTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import java.util.ArrayList;
 import java.util.List;
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpProducerWithHeaderTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpProducerWithHeaderTest.java
similarity index 98%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpProducerWithHeaderTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpProducerWithHeaderTest.java
index fe6064b..eb69e7d 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpProducerWithHeaderTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpProducerWithHeaderTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import org.apache.camel.Exchange;
 import org.apache.camel.builder.RouteBuilder;
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpProtocolNoSlashTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpProtocolNoSlashTest.java
similarity index 98%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpProtocolNoSlashTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpProtocolNoSlashTest.java
index e632bc6..838bae0 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpProtocolNoSlashTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpProtocolNoSlashTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import org.apache.camel.Exchange;
 import org.apache.camel.builder.RouteBuilder;
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpRawQueryTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpRawQueryTest.java
similarity index 97%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpRawQueryTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpRawQueryTest.java
index ab52c4a..e92153b 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpRawQueryTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpRawQueryTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import java.net.URL;
 
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpRedeliveryTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpRedeliveryTest.java
similarity index 98%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpRedeliveryTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpRedeliveryTest.java
index e6a581c..86c4cb2 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpRedeliveryTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpRedeliveryTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import java.util.concurrent.CountDownLatch;
 import java.util.concurrent.TimeUnit;
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpRedirectNoLocationTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpRedirectNoLocationTest.java
similarity index 98%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpRedirectNoLocationTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpRedirectNoLocationTest.java
index 0d9db3c..c6456c1 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpRedirectNoLocationTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpRedirectNoLocationTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import org.apache.camel.Exchange;
 import org.apache.camel.Processor;
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpRedirectTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpRedirectTest.java
similarity index 98%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpRedirectTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpRedirectTest.java
index 789f406..6697088 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpRedirectTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpRedirectTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import org.apache.camel.Exchange;
 import org.apache.camel.Processor;
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpRequestTimeoutTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpRequestTimeoutTest.java
similarity index 98%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpRequestTimeoutTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpRequestTimeoutTest.java
index 4face64..dfbf376 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpRequestTimeoutTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpRequestTimeoutTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import io.netty.handler.timeout.ReadTimeoutException;
 import org.apache.camel.CamelExecutionException;
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpRestContextPathMatcherTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpRestContextPathMatcherTest.java
similarity index 98%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpRestContextPathMatcherTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpRestContextPathMatcherTest.java
index bb680c7..6aa4f3b 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpRestContextPathMatcherTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpRestContextPathMatcherTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import org.apache.camel.builder.RouteBuilder;
 import org.junit.Test;
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpRestOptionsAllowTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpRestOptionsAllowTest.java
similarity index 97%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpRestOptionsAllowTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpRestOptionsAllowTest.java
index 72e3544..389ba5e 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpRestOptionsAllowTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpRestOptionsAllowTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import org.apache.camel.Exchange;
 import org.apache.camel.Processor;
@@ -25,7 +25,7 @@ import org.junit.Test;
 import static org.apache.camel.Exchange.HTTP_RESPONSE_CODE;
 
 public class NettyHttpRestOptionsAllowTest extends BaseNettyTest {
-    
+
     static final String ALLOW_METHODS = "GET,HEAD,POST,PUT,DELETE,TRACE,OPTIONS,CONNECT,PATCH";
 
     @Test
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpReturnDataNotInputStreamConvertableTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpReturnDataNotInputStreamConvertableTest.java
similarity index 97%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpReturnDataNotInputStreamConvertableTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpReturnDataNotInputStreamConvertableTest.java
index 1f355db..aad4347 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpReturnDataNotInputStreamConvertableTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpReturnDataNotInputStreamConvertableTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import org.apache.camel.Exchange;
 import org.apache.camel.Processor;
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpSSLHandshakeErrorTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpSSLHandshakeErrorTest.java
similarity index 98%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpSSLHandshakeErrorTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpSSLHandshakeErrorTest.java
index a893bc3..1f2ebd4 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpSSLHandshakeErrorTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpSSLHandshakeErrorTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import org.apache.camel.Exchange;
 import org.apache.camel.builder.RouteBuilder;
@@ -60,4 +60,4 @@ public class NettyHttpSSLHandshakeErrorTest extends BaseNettyTest {
         assertMockEndpointsSatisfied();
     }
 
-}
\ No newline at end of file
+}
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpSSLTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpSSLTest.java
similarity index 97%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpSSLTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpSSLTest.java
index bf17f48..89375e4 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpSSLTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpSSLTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 import java.net.URL;
 import java.util.Properties;
 
@@ -23,7 +23,7 @@ import javax.net.ssl.SSLSession;
 import org.apache.camel.Exchange;
 import org.apache.camel.Processor;
 import org.apache.camel.builder.RouteBuilder;
-import org.apache.camel.component.netty4.NettyConstants;
+import org.apache.camel.component.netty.NettyConstants;
 import org.apache.camel.test.junit4.CamelTestSupport;
 import org.junit.After;
 import org.junit.Before;
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpSameHostDifferentParametersTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpSameHostDifferentParametersTest.java
similarity index 97%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpSameHostDifferentParametersTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpSameHostDifferentParametersTest.java
index 456dd67..907aefd 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpSameHostDifferentParametersTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpSameHostDifferentParametersTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import org.apache.camel.Exchange;
 import org.apache.camel.builder.RouteBuilder;
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpSendDynamicAwareTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpSendDynamicAwareTest.java
similarity index 98%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpSendDynamicAwareTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpSendDynamicAwareTest.java
index 338a851..2d45606 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpSendDynamicAwareTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpSendDynamicAwareTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import org.apache.camel.RoutesBuilder;
 import org.apache.camel.builder.RouteBuilder;
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpSimpleBasicAuthConstraintMapperTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpSimpleBasicAuthConstraintMapperTest.java
similarity index 98%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpSimpleBasicAuthConstraintMapperTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpSimpleBasicAuthConstraintMapperTest.java
index e7b0659..adc3d3f7 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpSimpleBasicAuthConstraintMapperTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpSimpleBasicAuthConstraintMapperTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 import org.apache.camel.BindToRegistry;
 import org.apache.camel.CamelExecutionException;
 import org.apache.camel.builder.RouteBuilder;
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpSimpleBasicAuthTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpSimpleBasicAuthTest.java
similarity index 97%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpSimpleBasicAuthTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpSimpleBasicAuthTest.java
index 0087f84..3b89fee 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpSimpleBasicAuthTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpSimpleBasicAuthTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 import org.apache.camel.CamelExecutionException;
 import org.apache.camel.builder.RouteBuilder;
 import org.junit.After;
@@ -39,7 +39,7 @@ public class NettyHttpSimpleBasicAuthTest extends BaseNettyTest {
 
     @Test
     public void testBasicAuth() throws Exception {
-        
+
         try {
             template.requestBody("netty-http:http://localhost:{{port}}/foo", "Hello World", String.class);
             fail("Should send back 401");
@@ -47,16 +47,16 @@ public class NettyHttpSimpleBasicAuthTest extends BaseNettyTest {
             NettyHttpOperationFailedException cause = assertIsInstanceOf(NettyHttpOperationFailedException.class, e.getCause());
             assertEquals(401, cause.getStatusCode());
         }
-        
+
         getMockEndpoint("mock:input").expectedBodiesReceived("Hello World");
-        
+
         // username:password is scott:secret
         String auth = "Basic c2NvdHQ6c2VjcmV0";
         String out = template.requestBodyAndHeader("netty-http:http://localhost:{{port}}/foo", "Hello World", "Authorization", auth, String.class);
         assertEquals("Bye World", out);
 
         assertMockEndpointsSatisfied();
-        
+
         try {
             template.requestBody("netty-http:http://localhost:{{port}}/foo", "Hello World", String.class);
             fail("Should send back 401");
@@ -64,7 +64,7 @@ public class NettyHttpSimpleBasicAuthTest extends BaseNettyTest {
             NettyHttpOperationFailedException cause = assertIsInstanceOf(NettyHttpOperationFailedException.class, e.getCause());
             assertEquals(401, cause.getStatusCode());
         }
-        
+
     }
 
     @Override
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpSimpleTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpSimpleTest.java
similarity index 97%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpSimpleTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpSimpleTest.java
index 856fce5..5e0404a 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpSimpleTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpSimpleTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import org.apache.camel.builder.RouteBuilder;
 import org.junit.Test;
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpSimpleUriParametersTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpSimpleUriParametersTest.java
similarity index 97%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpSimpleUriParametersTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpSimpleUriParametersTest.java
index 513bbe3a..532609a 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpSimpleUriParametersTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpSimpleUriParametersTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import org.apache.camel.builder.RouteBuilder;
 import org.junit.Test;
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpStreamCacheFileResponseTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpStreamCacheFileResponseTest.java
similarity index 98%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpStreamCacheFileResponseTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpStreamCacheFileResponseTest.java
index 28dc375..a19a379 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpStreamCacheFileResponseTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpStreamCacheFileResponseTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import java.io.BufferedInputStream;
 import java.io.ByteArrayInputStream;
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpSuspendResume503Test.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpSuspendResume503Test.java
similarity index 98%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpSuspendResume503Test.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpSuspendResume503Test.java
index 889789c..06bf3e3 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpSuspendResume503Test.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpSuspendResume503Test.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import org.apache.camel.builder.RouteBuilder;
 import org.junit.Test;
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpSuspendResumeTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpSuspendResumeTest.java
similarity index 98%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpSuspendResumeTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpSuspendResumeTest.java
index 8f0f817..2b08cea 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpSuspendResumeTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpSuspendResumeTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import org.apache.camel.builder.RouteBuilder;
 import org.junit.Test;
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpTraceDisabledTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpTraceDisabledTest.java
similarity index 97%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpTraceDisabledTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpTraceDisabledTest.java
index e86e841..d95be0a 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpTraceDisabledTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpTraceDisabledTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import org.apache.camel.builder.RouteBuilder;
 import org.apache.commons.httpclient.HttpClient;
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpTransferExceptionTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpTransferExceptionTest.java
similarity index 97%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpTransferExceptionTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpTransferExceptionTest.java
index ea7aff6..66e6039 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpTransferExceptionTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpTransferExceptionTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import org.apache.camel.CamelExecutionException;
 import org.apache.camel.builder.RouteBuilder;
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpTwoRoutesBootstrapConfigurationTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpTwoRoutesBootstrapConfigurationTest.java
similarity index 97%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpTwoRoutesBootstrapConfigurationTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpTwoRoutesBootstrapConfigurationTest.java
index dca5a4e..c492427 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpTwoRoutesBootstrapConfigurationTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpTwoRoutesBootstrapConfigurationTest.java
@@ -14,11 +14,11 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import org.apache.camel.BindToRegistry;
 import org.apache.camel.builder.RouteBuilder;
-import org.apache.camel.component.netty4.NettyServerBootstrapConfiguration;
+import org.apache.camel.component.netty.NettyServerBootstrapConfiguration;
 import org.junit.Test;
 
 public class NettyHttpTwoRoutesBootstrapConfigurationTest extends BaseNettyTest {
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpTwoRoutesMatchOnUriPrefixTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpTwoRoutesMatchOnUriPrefixTest.java
similarity index 98%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpTwoRoutesMatchOnUriPrefixTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpTwoRoutesMatchOnUriPrefixTest.java
index a41f6d5..b173c69 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpTwoRoutesMatchOnUriPrefixTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpTwoRoutesMatchOnUriPrefixTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import org.apache.camel.CamelExecutionException;
 import org.apache.camel.builder.RouteBuilder;
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpTwoRoutesStopOneRouteTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpTwoRoutesStopOneRouteTest.java
similarity index 98%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpTwoRoutesStopOneRouteTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpTwoRoutesStopOneRouteTest.java
index 0fb499e..f212570 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpTwoRoutesStopOneRouteTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpTwoRoutesStopOneRouteTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import org.apache.camel.CamelExecutionException;
 import org.apache.camel.builder.RouteBuilder;
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpTwoRoutesTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpTwoRoutesTest.java
similarity index 97%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpTwoRoutesTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpTwoRoutesTest.java
index bea3373..33ca950 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpTwoRoutesTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpTwoRoutesTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import org.apache.camel.builder.RouteBuilder;
 import org.junit.Test;
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpTwoRoutesValidateBootstrapConfigurationTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpTwoRoutesValidateBootstrapConfigurationTest.java
similarity index 97%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpTwoRoutesValidateBootstrapConfigurationTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpTwoRoutesValidateBootstrapConfigurationTest.java
index 0fdfd9b..4c50fba 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpTwoRoutesValidateBootstrapConfigurationTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpTwoRoutesValidateBootstrapConfigurationTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import org.apache.camel.builder.RouteBuilder;
 import org.junit.Test;
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpXMLXPathResponseTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpXMLXPathResponseTest.java
similarity index 97%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpXMLXPathResponseTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpXMLXPathResponseTest.java
index 9d3949a..bad0f0a 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpXMLXPathResponseTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpXMLXPathResponseTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import org.apache.camel.builder.RouteBuilder;
 import org.junit.Test;
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpXMLXPathTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpXMLXPathTest.java
similarity index 97%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpXMLXPathTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpXMLXPathTest.java
index d80d9d1..fa1655d 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyHttpXMLXPathTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyHttpXMLXPathTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import org.apache.camel.builder.RouteBuilder;
 import org.junit.Test;
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyMDCLoggingTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyMDCLoggingTest.java
similarity index 97%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyMDCLoggingTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyMDCLoggingTest.java
index 6e8c81c..392c0f4 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyMDCLoggingTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyMDCLoggingTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import org.apache.camel.builder.RouteBuilder;
 import org.junit.Test;
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyMixedCaseHttpPathTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyMixedCaseHttpPathTest.java
similarity index 97%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyMixedCaseHttpPathTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyMixedCaseHttpPathTest.java
index 8728a2f..43e600e 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyMixedCaseHttpPathTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyMixedCaseHttpPathTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import org.apache.camel.Exchange;
 import org.apache.camel.builder.RouteBuilder;
@@ -43,4 +43,4 @@ public class NettyMixedCaseHttpPathTest extends BaseNettyTest {
             }
         };
     }
-}
\ No newline at end of file
+}
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyProxyMixedCasePathTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyProxyMixedCasePathTest.java
similarity index 97%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyProxyMixedCasePathTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyProxyMixedCasePathTest.java
index 29518bb..15d7625 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyProxyMixedCasePathTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyProxyMixedCasePathTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import org.apache.camel.builder.RouteBuilder;
 import org.junit.Test;
@@ -41,4 +41,4 @@ public class NettyProxyMixedCasePathTest extends BaseNettyTest {
             }
         };
     }
-}
\ No newline at end of file
+}
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyRecipientListHttpBaseTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyRecipientListHttpBaseTest.java
similarity index 97%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyRecipientListHttpBaseTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyRecipientListHttpBaseTest.java
index 97d013c..2999fe9 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyRecipientListHttpBaseTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyRecipientListHttpBaseTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import org.apache.camel.Exchange;
 import org.apache.camel.builder.RouteBuilder;
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyRequestManagementTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyRequestManagementTest.java
similarity index 97%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyRequestManagementTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyRequestManagementTest.java
index 92013e7..45422a6 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyRequestManagementTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyRequestManagementTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import io.netty.buffer.ByteBuf;
 import io.netty.buffer.PooledByteBufAllocator;
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyRouteSimpleDynamicURITest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyRouteSimpleDynamicURITest.java
similarity index 97%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyRouteSimpleDynamicURITest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyRouteSimpleDynamicURITest.java
index a7a35ec..6579421 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyRouteSimpleDynamicURITest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyRouteSimpleDynamicURITest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import org.apache.camel.builder.RouteBuilder;
 import org.junit.Test;
@@ -50,4 +50,4 @@ public class NettyRouteSimpleDynamicURITest extends BaseNettyTest {
             }
         };
     }
-}
\ No newline at end of file
+}
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyRouteSimpleTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyRouteSimpleTest.java
similarity index 97%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyRouteSimpleTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyRouteSimpleTest.java
index 89cd275..ab72b5d 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyRouteSimpleTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyRouteSimpleTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import org.apache.camel.builder.RouteBuilder;
 import org.junit.Test;
@@ -48,4 +48,4 @@ public class NettyRouteSimpleTest extends BaseNettyTest {
             }
         };
     }
-}
\ No newline at end of file
+}
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettySharedHttpServerTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettySharedHttpServerTest.java
similarity index 98%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettySharedHttpServerTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettySharedHttpServerTest.java
index 960ef91..ceee47f 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettySharedHttpServerTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettySharedHttpServerTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 import org.apache.camel.BindToRegistry;
 import org.apache.camel.builder.RouteBuilder;
 import org.junit.After;
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyUseRawHttpResponseTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyUseRawHttpResponseTest.java
similarity index 96%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyUseRawHttpResponseTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyUseRawHttpResponseTest.java
index b571d49..0c8309f 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/NettyUseRawHttpResponseTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/NettyUseRawHttpResponseTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import io.netty.handler.codec.http.DefaultFullHttpResponse;
 import io.netty.handler.codec.http.HttpHeaderNames;
@@ -24,7 +24,7 @@ import io.netty.handler.codec.http.HttpVersion;
 import org.apache.camel.Exchange;
 import org.apache.camel.Processor;
 import org.apache.camel.builder.RouteBuilder;
-import org.apache.camel.component.netty4.NettyConverter;
+import org.apache.camel.component.netty.NettyConverter;
 import org.junit.Test;
 
 public class NettyUseRawHttpResponseTest extends BaseNettyTest {
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/ProxyProtocolTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/ProxyProtocolTest.java
similarity index 98%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/ProxyProtocolTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/ProxyProtocolTest.java
index d58dab5..bd9841c 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/ProxyProtocolTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/ProxyProtocolTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import java.io.InputStream;
 import java.net.HttpURLConnection;
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/SecurityConstraintMappingTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/SecurityConstraintMappingTest.java
similarity index 98%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/SecurityConstraintMappingTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/SecurityConstraintMappingTest.java
index d7a164d..0dc3177 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/SecurityConstraintMappingTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/SecurityConstraintMappingTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 
 import org.junit.Assert;
 import org.junit.Test;
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/SpringNettyHttpBasicAuthTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/SpringNettyHttpBasicAuthTest.java
similarity index 97%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/SpringNettyHttpBasicAuthTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/SpringNettyHttpBasicAuthTest.java
index 2b73a30..393f2d8 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/SpringNettyHttpBasicAuthTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/SpringNettyHttpBasicAuthTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 import javax.annotation.Resource;
 
 import org.apache.camel.CamelExecutionException;
@@ -31,7 +31,7 @@ import org.springframework.test.context.ContextConfiguration;
 import org.springframework.test.context.junit4.SpringJUnit4ClassRunner;
 
 @RunWith(SpringJUnit4ClassRunner.class)
-@ContextConfiguration(locations = {"/org/apache/camel/component/netty4/http/SpringNettyHttpBasicAuthTest.xml"})
+@ContextConfiguration(locations = {"/org/apache/camel/component/netty/http/SpringNettyHttpBasicAuthTest.xml"})
 public class SpringNettyHttpBasicAuthTest extends Assert {
 
     @Produce
@@ -64,7 +64,7 @@ public class SpringNettyHttpBasicAuthTest extends Assert {
     @Test
     public void testAdminAuth() throws Exception {
         mockEndpoint.reset();
-        
+
         mockEndpoint.expectedBodiesReceived("Hello Public", "Hello Foo", "Hello Admin");
 
         // public do not need authentication
@@ -80,7 +80,7 @@ public class SpringNettyHttpBasicAuthTest extends Assert {
         assertEquals("Bye /foo/admin/users", out);
 
         mockEndpoint.assertIsSatisfied();
-        
+
         try {
             template.requestBody("netty-http:http://localhost:" + port + "/foo", "Hello Foo", String.class);
             fail("Should send back 401");
@@ -89,7 +89,7 @@ public class SpringNettyHttpBasicAuthTest extends Assert {
             assertEquals(401, cause.getStatusCode());
         }
 
-        
+
     }
 
     @Test
@@ -102,7 +102,7 @@ public class SpringNettyHttpBasicAuthTest extends Assert {
         // but we can access foo as that is any roles
         out = template.requestBodyAndHeader("netty-http:http://localhost:" + port + "/foo", "Hello Foo", "Authorization", auth, String.class);
         assertEquals("Bye /foo", out);
-        
+
         // accessing admin is restricted for guest user
         try {
             template.requestBodyAndHeader("netty-http:http://localhost:" + port + "/foo/admin/users", "Hello Admin", "Authorization", auth, String.class);
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/SpringNettyHttpSSLTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/SpringNettyHttpSSLTest.java
similarity index 96%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/SpringNettyHttpSSLTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/SpringNettyHttpSSLTest.java
index a4d1565..cef9d65 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/SpringNettyHttpSSLTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/SpringNettyHttpSSLTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http;
+package org.apache.camel.component.netty.http;
 import java.net.URL;
 
 import javax.annotation.Resource;
@@ -32,7 +32,7 @@ import org.springframework.test.context.ContextConfiguration;
 import org.springframework.test.context.junit4.SpringJUnit4ClassRunner;
 
 @RunWith(SpringJUnit4ClassRunner.class)
-@ContextConfiguration(locations = {"/org/apache/camel/component/netty4/http/SpringNettyHttpSSLTest.xml"})
+@ContextConfiguration(locations = {"/org/apache/camel/component/netty/http/SpringNettyHttpSSLTest.xml"})
 public class SpringNettyHttpSSLTest extends Assert {
 
     @Produce
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/cloud/Netty4HttpServiceCallRouteTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/cloud/NettyHttpServiceCallRouteTest.java
similarity index 95%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/cloud/Netty4HttpServiceCallRouteTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/cloud/NettyHttpServiceCallRouteTest.java
index d1522fd..14dd88a 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/cloud/Netty4HttpServiceCallRouteTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/cloud/NettyHttpServiceCallRouteTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http.cloud;
+package org.apache.camel.component.netty.http.cloud;
 
 import org.apache.camel.ResolveEndpointFailedException;
 import org.apache.camel.RoutesBuilder;
@@ -24,7 +24,7 @@ import org.apache.camel.test.junit4.CamelTestSupport;
 import org.junit.Assert;
 import org.junit.Test;
 
-public class Netty4HttpServiceCallRouteTest extends CamelTestSupport {
+public class NettyHttpServiceCallRouteTest extends CamelTestSupport {
 
     @Test
     public void testCustomCall() throws Exception {
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/rest/CountryPojo.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/rest/CountryPojo.java
similarity index 95%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/rest/CountryPojo.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/rest/CountryPojo.java
index 2a78e08..76f6930 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/rest/CountryPojo.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/rest/CountryPojo.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http.rest;
+package org.apache.camel.component.netty.http.rest;
 
 public class CountryPojo {
 
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/rest/RestApiNettyTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/rest/RestApiNettyTest.java
similarity index 96%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/rest/RestApiNettyTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/rest/RestApiNettyTest.java
index 25bda74..5276750 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/rest/RestApiNettyTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/rest/RestApiNettyTest.java
@@ -14,10 +14,10 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http.rest;
+package org.apache.camel.component.netty.http.rest;
 
 import org.apache.camel.builder.RouteBuilder;
-import org.apache.camel.component.netty4.http.BaseNettyTest;
+import org.apache.camel.component.netty.http.BaseNettyTest;
 import org.apache.camel.model.rest.RestParamType;
 import org.junit.Ignore;
 import org.junit.Test;
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/rest/RestNettyHttpBindingModeAutoWithJsonTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/rest/RestNettyHttpBindingModeAutoWithJsonTest.java
similarity index 95%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/rest/RestNettyHttpBindingModeAutoWithJsonTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/rest/RestNettyHttpBindingModeAutoWithJsonTest.java
index 960c3f7..1e1761d 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/rest/RestNettyHttpBindingModeAutoWithJsonTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/rest/RestNettyHttpBindingModeAutoWithJsonTest.java
@@ -14,11 +14,11 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http.rest;
+package org.apache.camel.component.netty.http.rest;
 
 import org.apache.camel.builder.RouteBuilder;
 import org.apache.camel.component.mock.MockEndpoint;
-import org.apache.camel.component.netty4.http.BaseNettyTest;
+import org.apache.camel.component.netty.http.BaseNettyTest;
 import org.apache.camel.model.rest.RestBindingMode;
 import org.junit.Test;
 
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/rest/RestNettyHttpBindingModeAutoWithXmlTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/rest/RestNettyHttpBindingModeAutoWithXmlTest.java
similarity index 95%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/rest/RestNettyHttpBindingModeAutoWithXmlTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/rest/RestNettyHttpBindingModeAutoWithXmlTest.java
index 1d5423f..38c1332 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/rest/RestNettyHttpBindingModeAutoWithXmlTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/rest/RestNettyHttpBindingModeAutoWithXmlTest.java
@@ -14,11 +14,11 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http.rest;
+package org.apache.camel.component.netty.http.rest;
 
 import org.apache.camel.builder.RouteBuilder;
 import org.apache.camel.component.mock.MockEndpoint;
-import org.apache.camel.component.netty4.http.BaseNettyTest;
+import org.apache.camel.component.netty.http.BaseNettyTest;
 import org.apache.camel.model.rest.RestBindingMode;
 import org.junit.Test;
 
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/rest/RestNettyHttpBindingModeJsonTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/rest/RestNettyHttpBindingModeJsonTest.java
similarity index 96%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/rest/RestNettyHttpBindingModeJsonTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/rest/RestNettyHttpBindingModeJsonTest.java
index 924515a..b7eccc3 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/rest/RestNettyHttpBindingModeJsonTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/rest/RestNettyHttpBindingModeJsonTest.java
@@ -14,11 +14,11 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http.rest;
+package org.apache.camel.component.netty.http.rest;
 
 import org.apache.camel.builder.RouteBuilder;
 import org.apache.camel.component.mock.MockEndpoint;
-import org.apache.camel.component.netty4.http.BaseNettyTest;
+import org.apache.camel.component.netty.http.BaseNettyTest;
 import org.apache.camel.model.rest.RestBindingMode;
 import org.junit.Test;
 
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/rest/RestNettyHttpBindingModeJsonWithContractTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/rest/RestNettyHttpBindingModeJsonWithContractTest.java
similarity index 96%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/rest/RestNettyHttpBindingModeJsonWithContractTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/rest/RestNettyHttpBindingModeJsonWithContractTest.java
index 7ad5b1f..b6f4c4a 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/rest/RestNettyHttpBindingModeJsonWithContractTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/rest/RestNettyHttpBindingModeJsonWithContractTest.java
@@ -14,13 +14,13 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http.rest;
+package org.apache.camel.component.netty.http.rest;
 
 import org.apache.camel.Converter;
 import org.apache.camel.TypeConverters;
 import org.apache.camel.builder.RouteBuilder;
 import org.apache.camel.component.mock.MockEndpoint;
-import org.apache.camel.component.netty4.http.BaseNettyTest;
+import org.apache.camel.component.netty.http.BaseNettyTest;
 import org.apache.camel.model.rest.RestBindingMode;
 import org.junit.Test;
 
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/rest/RestNettyHttpBindingModeOffWithContractTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/rest/RestNettyHttpBindingModeOffWithContractTest.java
similarity index 96%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/rest/RestNettyHttpBindingModeOffWithContractTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/rest/RestNettyHttpBindingModeOffWithContractTest.java
index b328920..ea71032 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/rest/RestNettyHttpBindingModeOffWithContractTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/rest/RestNettyHttpBindingModeOffWithContractTest.java
@@ -14,12 +14,12 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http.rest;
+package org.apache.camel.component.netty.http.rest;
 
 import org.apache.camel.Exchange;
 import org.apache.camel.builder.RouteBuilder;
 import org.apache.camel.component.mock.MockEndpoint;
-import org.apache.camel.component.netty4.http.BaseNettyTest;
+import org.apache.camel.component.netty.http.BaseNettyTest;
 import org.apache.camel.model.dataformat.JsonDataFormat;
 import org.apache.camel.model.dataformat.JsonLibrary;
 import org.apache.camel.model.rest.RestBindingMode;
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/rest/RestNettyHttpBindingModeXmlTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/rest/RestNettyHttpBindingModeXmlTest.java
similarity index 96%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/rest/RestNettyHttpBindingModeXmlTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/rest/RestNettyHttpBindingModeXmlTest.java
index 261c6ee..5820819 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/rest/RestNettyHttpBindingModeXmlTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/rest/RestNettyHttpBindingModeXmlTest.java
@@ -14,11 +14,11 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http.rest;
+package org.apache.camel.component.netty.http.rest;
 
 import org.apache.camel.builder.RouteBuilder;
 import org.apache.camel.component.mock.MockEndpoint;
-import org.apache.camel.component.netty4.http.BaseNettyTest;
+import org.apache.camel.component.netty.http.BaseNettyTest;
 import org.apache.camel.model.rest.RestBindingMode;
 import org.junit.Test;
 
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/rest/RestNettyHttpContextPathConfigurationTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/rest/RestNettyHttpContextPathConfigurationTest.java
similarity index 96%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/rest/RestNettyHttpContextPathConfigurationTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/rest/RestNettyHttpContextPathConfigurationTest.java
index f6fb674..fa59d9f 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/rest/RestNettyHttpContextPathConfigurationTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/rest/RestNettyHttpContextPathConfigurationTest.java
@@ -14,12 +14,12 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http.rest;
+package org.apache.camel.component.netty.http.rest;
 
 import org.apache.camel.Exchange;
 import org.apache.camel.Processor;
 import org.apache.camel.builder.RouteBuilder;
-import org.apache.camel.component.netty4.http.BaseNettyTest;
+import org.apache.camel.component.netty.http.BaseNettyTest;
 import org.junit.Test;
 
 public class RestNettyHttpContextPathConfigurationTest extends BaseNettyTest {
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/rest/RestNettyHttpContextPathMatchGetTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/rest/RestNettyHttpContextPathMatchGetTest.java
similarity index 96%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/rest/RestNettyHttpContextPathMatchGetTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/rest/RestNettyHttpContextPathMatchGetTest.java
index 6419209..510f40e 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/rest/RestNettyHttpContextPathMatchGetTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/rest/RestNettyHttpContextPathMatchGetTest.java
@@ -14,12 +14,12 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http.rest;
+package org.apache.camel.component.netty.http.rest;
 
 import org.apache.camel.Exchange;
 import org.apache.camel.Processor;
 import org.apache.camel.builder.RouteBuilder;
-import org.apache.camel.component.netty4.http.BaseNettyTest;
+import org.apache.camel.component.netty.http.BaseNettyTest;
 import org.junit.Test;
 
 public class RestNettyHttpContextPathMatchGetTest extends BaseNettyTest {
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/rest/RestNettyHttpGetCorsTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/rest/RestNettyHttpGetCorsTest.java
similarity index 96%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/rest/RestNettyHttpGetCorsTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/rest/RestNettyHttpGetCorsTest.java
index d7b1706..9d446b5 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/rest/RestNettyHttpGetCorsTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/rest/RestNettyHttpGetCorsTest.java
@@ -14,12 +14,12 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http.rest;
+package org.apache.camel.component.netty.http.rest;
 
 import org.apache.camel.Exchange;
 import org.apache.camel.Processor;
 import org.apache.camel.builder.RouteBuilder;
-import org.apache.camel.component.netty4.http.BaseNettyTest;
+import org.apache.camel.component.netty.http.BaseNettyTest;
 import org.apache.camel.spi.RestConfiguration;
 import org.junit.Test;
 
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/rest/RestNettyHttpGetTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/rest/RestNettyHttpGetTest.java
similarity index 90%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/rest/RestNettyHttpGetTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/rest/RestNettyHttpGetTest.java
index 5ca1368..e312abc 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/rest/RestNettyHttpGetTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/rest/RestNettyHttpGetTest.java
@@ -14,21 +14,22 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http.rest;
+package org.apache.camel.component.netty.http.rest;
 
 import org.apache.camel.BindToRegistry;
 import org.apache.camel.Exchange;
 import org.apache.camel.Processor;
 import org.apache.camel.builder.RouteBuilder;
-import org.apache.camel.component.netty4.http.BaseNettyTest;
-import org.apache.camel.component.netty4.http.RestNettyHttpBinding;
+import org.apache.camel.component.netty.http.RestNettyHttpBinding;
+import org.apache.camel.component.netty.http.BaseNettyTest;
+import org.apache.camel.component.netty.http.RestNettyHttpBinding;
 import org.junit.Test;
 
 public class RestNettyHttpGetTest extends BaseNettyTest {
-    
+
     @BindToRegistry("mybinding")
     private RestNettyHttpBinding binding = new RestNettyHttpBinding();
-    
+
     @Test
     public void testProducerGet() throws Exception {
         String out = template.requestBody("netty-http:http://localhost:{{port}}/users/123/basic", null, String.class);
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/rest/RestNettyHttpGetWildcardsTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/rest/RestNettyHttpGetWildcardsTest.java
similarity index 92%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/rest/RestNettyHttpGetWildcardsTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/rest/RestNettyHttpGetWildcardsTest.java
index 791be80..0601ab6 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/rest/RestNettyHttpGetWildcardsTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/rest/RestNettyHttpGetWildcardsTest.java
@@ -14,18 +14,19 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http.rest;
+package org.apache.camel.component.netty.http.rest;
 
 import org.apache.camel.BindToRegistry;
 import org.apache.camel.Exchange;
 import org.apache.camel.Processor;
 import org.apache.camel.builder.RouteBuilder;
-import org.apache.camel.component.netty4.http.BaseNettyTest;
-import org.apache.camel.component.netty4.http.RestNettyHttpBinding;
+import org.apache.camel.component.netty.http.RestNettyHttpBinding;
+import org.apache.camel.component.netty.http.BaseNettyTest;
+import org.apache.camel.component.netty.http.RestNettyHttpBinding;
 import org.junit.Test;
 
 public class RestNettyHttpGetWildcardsTest extends BaseNettyTest {
-    
+
     @BindToRegistry("mybinding")
     private RestNettyHttpBinding binding = new RestNettyHttpBinding();
 
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/rest/RestNettyHttpOptionsTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/rest/RestNettyHttpOptionsTest.java
similarity index 96%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/rest/RestNettyHttpOptionsTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/rest/RestNettyHttpOptionsTest.java
index ac2f51e..50abdee 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/rest/RestNettyHttpOptionsTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/rest/RestNettyHttpOptionsTest.java
@@ -14,12 +14,12 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http.rest;
+package org.apache.camel.component.netty.http.rest;
 
 import org.apache.camel.Exchange;
 import org.apache.camel.Processor;
 import org.apache.camel.builder.RouteBuilder;
-import org.apache.camel.component.netty4.http.BaseNettyTest;
+import org.apache.camel.component.netty.http.BaseNettyTest;
 import org.junit.Test;
 
 public class RestNettyHttpOptionsTest extends BaseNettyTest {
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/rest/RestNettyHttpPojoInOutTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/rest/RestNettyHttpPojoInOutTest.java
similarity index 94%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/rest/RestNettyHttpPojoInOutTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/rest/RestNettyHttpPojoInOutTest.java
index 2500dbf..5da5fee 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/rest/RestNettyHttpPojoInOutTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/rest/RestNettyHttpPojoInOutTest.java
@@ -14,10 +14,10 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http.rest;
+package org.apache.camel.component.netty.http.rest;
 
 import org.apache.camel.builder.RouteBuilder;
-import org.apache.camel.component.netty4.http.BaseNettyTest;
+import org.apache.camel.component.netty.http.BaseNettyTest;
 import org.apache.camel.model.rest.RestBindingMode;
 import org.junit.Test;
 
@@ -31,7 +31,7 @@ public class RestNettyHttpPojoInOutTest extends BaseNettyTest {
         assertNotNull(out);
         assertEquals("{\"iso\":\"EN\",\"country\":\"England\"}", out);
     }
-    
+
     @Test
     public void testNettyGetRequest() throws Exception {
         String out = template.requestBody("netty-http:http://localhost:" + getPort() + "/users/lives", null, String.class);
@@ -56,13 +56,13 @@ public class RestNettyHttpPojoInOutTest extends BaseNettyTest {
                     .post("lives").type(UserPojo.class).outType(CountryPojo.class)
                         .route()
                         .bean(new UserService(), "livesWhere");
-            
+
                 CountryPojo country = new CountryPojo();
                 country.setIso("EN");
                 country.setCountry("England");
-                
+
                 from("direct:start").transform().constant(country);
-                
+
             }
         };
     }
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/rest/RestNettyHttpPostJsonJaxbPojoTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/rest/RestNettyHttpPostJsonJaxbPojoTest.java
similarity index 95%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/rest/RestNettyHttpPostJsonJaxbPojoTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/rest/RestNettyHttpPostJsonJaxbPojoTest.java
index e3602ac..bdb3a7e 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/rest/RestNettyHttpPostJsonJaxbPojoTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/rest/RestNettyHttpPostJsonJaxbPojoTest.java
@@ -14,11 +14,11 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http.rest;
+package org.apache.camel.component.netty.http.rest;
 
 import org.apache.camel.builder.RouteBuilder;
 import org.apache.camel.component.mock.MockEndpoint;
-import org.apache.camel.component.netty4.http.BaseNettyTest;
+import org.apache.camel.component.netty.http.BaseNettyTest;
 import org.apache.camel.model.rest.RestBindingMode;
 import org.junit.Test;
 
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/rest/RestNettyHttpPostJsonPojoListTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/rest/RestNettyHttpPostJsonPojoListTest.java
similarity index 95%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/rest/RestNettyHttpPostJsonPojoListTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/rest/RestNettyHttpPostJsonPojoListTest.java
index cf64b98..8f1382f 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/rest/RestNettyHttpPostJsonPojoListTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/rest/RestNettyHttpPostJsonPojoListTest.java
@@ -14,13 +14,13 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http.rest;
+package org.apache.camel.component.netty.http.rest;
 
 import java.util.List;
 
 import org.apache.camel.builder.RouteBuilder;
 import org.apache.camel.component.mock.MockEndpoint;
-import org.apache.camel.component.netty4.http.BaseNettyTest;
+import org.apache.camel.component.netty.http.BaseNettyTest;
 import org.apache.camel.model.rest.RestBindingMode;
 import org.junit.Test;
 
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/rest/RestNettyHttpPostJsonPojoTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/rest/RestNettyHttpPostJsonPojoTest.java
similarity index 95%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/rest/RestNettyHttpPostJsonPojoTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/rest/RestNettyHttpPostJsonPojoTest.java
index d521369..d903c16 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/rest/RestNettyHttpPostJsonPojoTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/rest/RestNettyHttpPostJsonPojoTest.java
@@ -14,11 +14,11 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http.rest;
+package org.apache.camel.component.netty.http.rest;
 
 import org.apache.camel.builder.RouteBuilder;
 import org.apache.camel.component.mock.MockEndpoint;
-import org.apache.camel.component.netty4.http.BaseNettyTest;
+import org.apache.camel.component.netty.http.BaseNettyTest;
 import org.apache.camel.model.rest.RestBindingMode;
 import org.junit.Test;
 
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/rest/RestNettyHttpPostXmlJaxbPojoTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/rest/RestNettyHttpPostXmlJaxbPojoTest.java
similarity index 96%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/rest/RestNettyHttpPostXmlJaxbPojoTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/rest/RestNettyHttpPostXmlJaxbPojoTest.java
index 7047125..a677dd6 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/rest/RestNettyHttpPostXmlJaxbPojoTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/rest/RestNettyHttpPostXmlJaxbPojoTest.java
@@ -14,12 +14,12 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http.rest;
+package org.apache.camel.component.netty.http.rest;
 
 import org.apache.camel.Exchange;
 import org.apache.camel.builder.RouteBuilder;
 import org.apache.camel.component.mock.MockEndpoint;
-import org.apache.camel.component.netty4.http.BaseNettyTest;
+import org.apache.camel.component.netty.http.BaseNettyTest;
 import org.apache.camel.model.rest.RestBindingMode;
 import org.junit.Test;
 
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/rest/RestNettyHttpVerbTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/rest/RestNettyHttpVerbTest.java
similarity index 97%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/rest/RestNettyHttpVerbTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/rest/RestNettyHttpVerbTest.java
index be79550..c200896 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/rest/RestNettyHttpVerbTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/rest/RestNettyHttpVerbTest.java
@@ -14,12 +14,12 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http.rest;
+package org.apache.camel.component.netty.http.rest;
 
 import org.apache.camel.Exchange;
 import org.apache.camel.builder.RouteBuilder;
 import org.apache.camel.component.mock.MockEndpoint;
-import org.apache.camel.component.netty4.http.BaseNettyTest;
+import org.apache.camel.component.netty.http.BaseNettyTest;
 import org.junit.Test;
 
 public class RestNettyHttpVerbTest extends BaseNettyTest {
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/rest/RestNettyMethodNotAllowedTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/rest/RestNettyMethodNotAllowedTest.java
similarity index 95%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/rest/RestNettyMethodNotAllowedTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/rest/RestNettyMethodNotAllowedTest.java
index 2c83c7f..13279af 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/rest/RestNettyMethodNotAllowedTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/rest/RestNettyMethodNotAllowedTest.java
@@ -14,11 +14,11 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http.rest;
+package org.apache.camel.component.netty.http.rest;
 
 import org.apache.camel.Exchange;
 import org.apache.camel.builder.RouteBuilder;
-import org.apache.camel.component.netty4.http.BaseNettyTest;
+import org.apache.camel.component.netty.http.BaseNettyTest;
 import org.apache.camel.http.common.HttpOperationFailedException;
 import org.junit.Test;
 
@@ -33,7 +33,7 @@ public class RestNettyMethodNotAllowedTest extends BaseNettyTest {
             assertEquals(405, hofe.getStatusCode());
         }
     }
-    
+
     @Test
     public void testMethodAllowed() {
         try {
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/rest/RestNettyProducerGetTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/rest/RestNettyProducerGetTest.java
similarity index 95%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/rest/RestNettyProducerGetTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/rest/RestNettyProducerGetTest.java
index 9e955fb..9a08458 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/rest/RestNettyProducerGetTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/rest/RestNettyProducerGetTest.java
@@ -14,12 +14,12 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http.rest;
+package org.apache.camel.component.netty.http.rest;
 
 import org.apache.camel.Exchange;
 import org.apache.camel.Processor;
 import org.apache.camel.builder.RouteBuilder;
-import org.apache.camel.component.netty4.http.BaseNettyTest;
+import org.apache.camel.component.netty.http.BaseNettyTest;
 import org.junit.Test;
 
 public class RestNettyProducerGetTest extends BaseNettyTest {
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/rest/RestNettyProducerGetUriParameterTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/rest/RestNettyProducerGetUriParameterTest.java
similarity index 95%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/rest/RestNettyProducerGetUriParameterTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/rest/RestNettyProducerGetUriParameterTest.java
index 15bd040..67f6c9a 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/rest/RestNettyProducerGetUriParameterTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/rest/RestNettyProducerGetUriParameterTest.java
@@ -14,12 +14,12 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http.rest;
+package org.apache.camel.component.netty.http.rest;
 
 import org.apache.camel.Exchange;
 import org.apache.camel.Processor;
 import org.apache.camel.builder.RouteBuilder;
-import org.apache.camel.component.netty4.http.BaseNettyTest;
+import org.apache.camel.component.netty.http.BaseNettyTest;
 import org.junit.Test;
 
 public class RestNettyProducerGetUriParameterTest extends BaseNettyTest {
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/rest/RestNettyProducerPutTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/rest/RestNettyProducerPutTest.java
similarity index 94%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/rest/RestNettyProducerPutTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/rest/RestNettyProducerPutTest.java
index 90c129b..f0a8bc3 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/rest/RestNettyProducerPutTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/rest/RestNettyProducerPutTest.java
@@ -14,10 +14,10 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http.rest;
+package org.apache.camel.component.netty.http.rest;
 
 import org.apache.camel.builder.RouteBuilder;
-import org.apache.camel.component.netty4.http.BaseNettyTest;
+import org.apache.camel.component.netty.http.BaseNettyTest;
 import org.junit.Test;
 
 public class RestNettyProducerPutTest extends BaseNettyTest {
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/rest/RestNettyProducerThrowExceptionErrorTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/rest/RestNettyProducerThrowExceptionErrorTest.java
similarity index 95%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/rest/RestNettyProducerThrowExceptionErrorTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/rest/RestNettyProducerThrowExceptionErrorTest.java
index 2eb83fb..bc94c0e 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/rest/RestNettyProducerThrowExceptionErrorTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/rest/RestNettyProducerThrowExceptionErrorTest.java
@@ -14,16 +14,16 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http.rest;
+package org.apache.camel.component.netty.http.rest;
 
 import org.apache.camel.Exchange;
 import org.apache.camel.Processor;
 import org.apache.camel.builder.RouteBuilder;
-import org.apache.camel.component.netty4.http.BaseNettyTest;
+import org.apache.camel.component.netty.http.BaseNettyTest;
 import org.junit.Test;
 
 public class RestNettyProducerThrowExceptionErrorTest extends BaseNettyTest {
-    
+
     @Test
     public void testUndertowProducerOk() throws Exception {
         String out = fluentTemplate.withHeader("id", "123").to("direct:start").request(String.class);
@@ -67,6 +67,6 @@ public class RestNettyProducerThrowExceptionErrorTest extends BaseNettyTest {
             }
         };
     }
-   
+
 
 }
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/rest/RestNettyProducerVerbUpperCaseTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/rest/RestNettyProducerVerbUpperCaseTest.java
similarity index 95%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/rest/RestNettyProducerVerbUpperCaseTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/rest/RestNettyProducerVerbUpperCaseTest.java
index 12e4750..953433f 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/rest/RestNettyProducerVerbUpperCaseTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/rest/RestNettyProducerVerbUpperCaseTest.java
@@ -14,12 +14,12 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http.rest;
+package org.apache.camel.component.netty.http.rest;
 
 import org.apache.camel.Exchange;
 import org.apache.camel.Processor;
 import org.apache.camel.builder.RouteBuilder;
-import org.apache.camel.component.netty4.http.BaseNettyTest;
+import org.apache.camel.component.netty.http.BaseNettyTest;
 import org.junit.Test;
 
 public class RestNettyProducerVerbUpperCaseTest extends BaseNettyTest {
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/rest/RestPathMatchingTest.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/rest/RestPathMatchingTest.java
similarity index 97%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/rest/RestPathMatchingTest.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/rest/RestPathMatchingTest.java
index 51a1c50..4ab164e 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/rest/RestPathMatchingTest.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/rest/RestPathMatchingTest.java
@@ -14,9 +14,9 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http.rest;
+package org.apache.camel.component.netty.http.rest;
 
-import org.apache.camel.component.netty4.http.RestContextPathMatcher;
+import org.apache.camel.component.netty.http.RestContextPathMatcher;
 import org.junit.Assert;
 import org.junit.Test;
 
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/rest/UserJaxbPojo.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/rest/UserJaxbPojo.java
similarity index 96%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/rest/UserJaxbPojo.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/rest/UserJaxbPojo.java
index 414fbd5..7aa2a42 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/rest/UserJaxbPojo.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/rest/UserJaxbPojo.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http.rest;
+package org.apache.camel.component.netty.http.rest;
 
 import javax.xml.bind.annotation.XmlAccessType;
 import javax.xml.bind.annotation.XmlAccessorType;
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/rest/UserPojo.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/rest/UserPojo.java
similarity index 95%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/rest/UserPojo.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/rest/UserPojo.java
index 21d3262..bb573e8 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/rest/UserPojo.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/rest/UserPojo.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http.rest;
+package org.apache.camel.component.netty.http.rest;
 
 public class UserPojo {
 
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/rest/UserPojoEx.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/rest/UserPojoEx.java
similarity index 96%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/rest/UserPojoEx.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/rest/UserPojoEx.java
index 47556f9..2585913 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/rest/UserPojoEx.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/rest/UserPojoEx.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http.rest;
+package org.apache.camel.component.netty.http.rest;
 
 public class UserPojoEx {
 
diff --git a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/rest/UserService.java b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/rest/UserService.java
similarity index 95%
rename from components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/rest/UserService.java
rename to components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/rest/UserService.java
index ad38d32..309d381 100644
--- a/components/camel-netty-http/src/test/java/org/apache/camel/component/netty4/http/rest/UserService.java
+++ b/components/camel-netty-http/src/test/java/org/apache/camel/component/netty/http/rest/UserService.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http.rest;
+package org.apache.camel.component.netty.http.rest;
 
 public class UserService {
 
diff --git a/components/camel-netty-http/src/test/resources/log4j2.properties b/components/camel-netty-http/src/test/resources/log4j2.properties
index b78e89c..e55a3c9 100644
--- a/components/camel-netty-http/src/test/resources/log4j2.properties
+++ b/components/camel-netty-http/src/test/resources/log4j2.properties
@@ -15,7 +15,7 @@
 ## limitations under the License.
 ## ---------------------------------------------------------------------------
 
-configuration.packages=org.apache.camel.component.netty4.http
+configuration.packages=org.apache.camel.component.netty.http
 appender.file.type = File
 appender.file.name = file
 appender.file.fileName = target/camel-netty-http-test.log
diff --git a/components/camel-netty-http/src/test/resources/myjaas.config b/components/camel-netty-http/src/test/resources/myjaas.config
index a01157e..9b1ffba 100644
--- a/components/camel-netty-http/src/test/resources/myjaas.config
+++ b/components/camel-netty-http/src/test/resources/myjaas.config
@@ -1,5 +1,5 @@
 /** Test Login Configuration **/
 
 karaf {
-   org.apache.camel.component.netty4.http.MyLoginModule required debug=true;
+   org.apache.camel.component.netty.http.MyLoginModule required debug=true;
 };
diff --git a/components/camel-netty-http/src/test/resources/org/apache/camel/component/netty4/http/SpringNettyHttpBasicAuthTest.xml b/components/camel-netty-http/src/test/resources/org/apache/camel/component/netty/http/SpringNettyHttpBasicAuthTest.xml
similarity index 96%
rename from components/camel-netty-http/src/test/resources/org/apache/camel/component/netty4/http/SpringNettyHttpBasicAuthTest.xml
rename to components/camel-netty-http/src/test/resources/org/apache/camel/component/netty/http/SpringNettyHttpBasicAuthTest.xml
index eec97c1..76f55cf 100644
--- a/components/camel-netty-http/src/test/resources/org/apache/camel/component/netty4/http/SpringNettyHttpBasicAuthTest.xml
+++ b/components/camel-netty-http/src/test/resources/org/apache/camel/component/netty/http/SpringNettyHttpBasicAuthTest.xml
@@ -38,7 +38,7 @@
     </property>
   </bean>
 
-  <bean id="constraint" class="org.apache.camel.component.netty4.http.SecurityConstraintMapping">
+  <bean id="constraint" class="org.apache.camel.component.netty.http.SecurityConstraintMapping">
     <!-- inclusions defines url -> roles restrictions -->
     <!-- a * should be used for any role accepted (or even no roles) -->
     <property name="inclusions">
diff --git a/components/camel-netty-http/src/test/resources/org/apache/camel/component/netty4/http/SpringNettyHttpSSLTest.xml b/components/camel-netty-http/src/test/resources/org/apache/camel/component/netty/http/SpringNettyHttpSSLTest.xml
similarity index 100%
rename from components/camel-netty-http/src/test/resources/org/apache/camel/component/netty4/http/SpringNettyHttpSSLTest.xml
rename to components/camel-netty-http/src/test/resources/org/apache/camel/component/netty/http/SpringNettyHttpSSLTest.xml
diff --git a/components/camel-netty/src/main/docs/netty-component.adoc b/components/camel-netty/src/main/docs/netty-component.adoc
index 64f91d6..55476ec 100644
--- a/components/camel-netty/src/main/docs/netty-component.adoc
+++ b/components/camel-netty/src/main/docs/netty-component.adoc
@@ -526,24 +526,24 @@ be resolved when the endpoint is created.
 [source,java]
 ----
 ChannelHandlerFactory lengthDecoder = ChannelHandlerFactories.newLengthFieldBasedFrameDecoder(1048576, 0, 4, 0, 4);
- 
+
 StringDecoder stringDecoder = new StringDecoder();
 registry.bind("length-decoder", lengthDecoder);
 registry.bind("string-decoder", stringDecoder);
- 
+
 LengthFieldPrepender lengthEncoder = new LengthFieldPrepender(4);
 StringEncoder stringEncoder = new StringEncoder();
 registry.bind("length-encoder", lengthEncoder);
 registry.bind("string-encoder", stringEncoder);
- 
+
 List<ChannelHandler> decoders = new ArrayList<ChannelHandler>();
 decoders.add(lengthDecoder);
 decoders.add(stringDecoder);
- 
+
 List<ChannelHandler> encoders = new ArrayList<ChannelHandler>();
 encoders.add(lengthEncoder);
 encoders.add(stringEncoder);
- 
+
 registry.bind("encoders", encoders);
 registry.bind("decoders", decoders);
 ----
@@ -554,7 +554,7 @@ lists in an application context
 [source,xml]
 ----
 <util:list id="decoders" list-class="java.util.LinkedList">
-        <bean class="org.apache.camel.component.netty4.ChannelHandlerFactories" factory-method="newLengthFieldBasedFrameDecoder">
+        <bean class="org.apache.camel.component.netty.ChannelHandlerFactories" factory-method="newLengthFieldBasedFrameDecoder">
             <constructor-arg value="1048576"/>
             <constructor-arg value="0"/>
             <constructor-arg value="4"/>
@@ -576,7 +576,7 @@ lists in an application context
     </bean>
     <bean id="string-encoder" class="io.netty.handler.codec.string.StringEncoder"/>
 
-    <bean id="length-decoder" class="org.apache.camel.component.netty4.ChannelHandlerFactories" factory-method="newLengthFieldBasedFrameDecoder">
+    <bean id="length-decoder" class="org.apache.camel.component.netty.ChannelHandlerFactories" factory-method="newLengthFieldBasedFrameDecoder">
         <constructor-arg value="1048576"/>
         <constructor-arg value="0"/>
         <constructor-arg value="4"/>
@@ -592,7 +592,7 @@ a comma separated list or contained in a List e.g.
 [source,java]
 ----
  from("direct:multiple-codec").to("netty:tcp://0.0.0.0:{{port}}?encoders=#encoders&sync=false");
-                
+
  from("netty:tcp://0.0.0.0:{{port}}?decoders=#length-decoder,#string-decoder&sync=false").to("mock:multiple-codec");
 ----
 
@@ -738,9 +738,9 @@ using the `NettyWorkerPoolBuilder` with 2 worker threads as shown below:
 ----
 
 TIP: For boss thread pool there is a
-`org.apache.camel.component.netty4.NettyServerBossPoolBuilder` builder
+`org.apache.camel.component.netty.NettyServerBossPoolBuilder` builder
 for Netty consumers, and a
-`org.apache.camel.component.netty4.NettyClientBossPoolBuilder` for the
+`org.apache.camel.component.netty.NettyClientBossPoolBuilder` for the
 Netty producers.
 
 Then in the Camel routes we can refer to this worker pools by
diff --git a/components/camel-netty/src/main/java/org/apache/camel/component/netty4/ChannelHandlerFactories.java b/components/camel-netty/src/main/java/org/apache/camel/component/netty/ChannelHandlerFactories.java
similarity index 85%
rename from components/camel-netty/src/main/java/org/apache/camel/component/netty4/ChannelHandlerFactories.java
rename to components/camel-netty/src/main/java/org/apache/camel/component/netty/ChannelHandlerFactories.java
index d91dc7b..5f57284 100644
--- a/components/camel-netty/src/main/java/org/apache/camel/component/netty4/ChannelHandlerFactories.java
+++ b/components/camel-netty/src/main/java/org/apache/camel/component/netty/ChannelHandlerFactories.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4;
+package org.apache.camel.component.netty;
 
 import java.nio.charset.Charset;
 
@@ -26,18 +26,18 @@ import io.netty.handler.codec.bytes.ByteArrayEncoder;
 import io.netty.handler.codec.serialization.ClassResolvers;
 import io.netty.handler.codec.string.StringDecoder;
 import io.netty.handler.codec.string.StringEncoder;
-import org.apache.camel.component.netty4.codec.DatagramPacketByteArrayDecoder;
-import org.apache.camel.component.netty4.codec.DatagramPacketByteArrayEncoder;
-import org.apache.camel.component.netty4.codec.DatagramPacketDecoder;
-import org.apache.camel.component.netty4.codec.DatagramPacketDelimiterDecoder;
-import org.apache.camel.component.netty4.codec.DatagramPacketEncoder;
-import org.apache.camel.component.netty4.codec.DatagramPacketObjectDecoder;
-import org.apache.camel.component.netty4.codec.DatagramPacketObjectEncoder;
-import org.apache.camel.component.netty4.codec.DatagramPacketStringDecoder;
-import org.apache.camel.component.netty4.codec.DatagramPacketStringEncoder;
-import org.apache.camel.component.netty4.codec.DelimiterBasedFrameDecoder;
-import org.apache.camel.component.netty4.codec.ObjectDecoder;
-import org.apache.camel.component.netty4.codec.ObjectEncoder;
+import org.apache.camel.component.netty.codec.DatagramPacketByteArrayDecoder;
+import org.apache.camel.component.netty.codec.DatagramPacketByteArrayEncoder;
+import org.apache.camel.component.netty.codec.DatagramPacketDecoder;
+import org.apache.camel.component.netty.codec.DatagramPacketDelimiterDecoder;
+import org.apache.camel.component.netty.codec.DatagramPacketEncoder;
+import org.apache.camel.component.netty.codec.DatagramPacketObjectDecoder;
+import org.apache.camel.component.netty.codec.DatagramPacketObjectEncoder;
+import org.apache.camel.component.netty.codec.DatagramPacketStringDecoder;
+import org.apache.camel.component.netty.codec.DatagramPacketStringEncoder;
+import org.apache.camel.component.netty.codec.DelimiterBasedFrameDecoder;
+import org.apache.camel.component.netty.codec.ObjectDecoder;
+import org.apache.camel.component.netty.codec.ObjectEncoder;
 
 
 /**
@@ -58,13 +58,13 @@ public final class ChannelHandlerFactories {
 
     public static ChannelHandlerFactory newStringDecoder(Charset charset, String protocol) {
         if ("udp".equalsIgnoreCase(protocol)) {
-            return new ShareableChannelHandlerFactory(new DatagramPacketStringDecoder(charset)); 
+            return new ShareableChannelHandlerFactory(new DatagramPacketStringDecoder(charset));
         } else {
             return new ShareableChannelHandlerFactory(new StringDecoder(charset));
         }
     }
-    
-    
+
+
     public static ChannelHandlerFactory newObjectDecoder(String protocol) {
         if ("udp".equalsIgnoreCase(protocol)) {
             return new DefaultChannelHandlerFactory() {
@@ -82,7 +82,7 @@ public final class ChannelHandlerFactories {
             };
         }
     }
-    
+
     public static ChannelHandlerFactory newObjectEncoder(String protocol) {
         if ("udp".equals(protocol)) {
             return new ShareableChannelHandlerFactory(new DatagramPacketObjectEncoder());
@@ -90,11 +90,11 @@ public final class ChannelHandlerFactories {
             return new ShareableChannelHandlerFactory(new ObjectEncoder());
         }
     }
-   
+
     public static ChannelHandlerFactory newDelimiterBasedFrameDecoder(final int maxFrameLength, final ByteBuf[] delimiters, String protocol) {
         return newDelimiterBasedFrameDecoder(maxFrameLength, delimiters, true, protocol);
     }
-    
+
     public static ChannelHandlerFactory newDelimiterBasedFrameDecoder(final int maxFrameLength, final ByteBuf[] delimiters, final boolean stripDelimiter, String protocol) {
         if ("udp".equals(protocol)) {
             return new DefaultChannelHandlerFactory() {
@@ -112,11 +112,11 @@ public final class ChannelHandlerFactories {
             };
         }
     }
-    
+
     public static ChannelHandlerFactory newDatagramPacketDecoder() {
         return new ShareableChannelHandlerFactory(new DatagramPacketDecoder());
     }
-    
+
     public static ChannelHandlerFactory newDatagramPacketEncoder() {
         return new ShareableChannelHandlerFactory(new DatagramPacketEncoder());
     }
diff --git a/components/camel-netty/src/main/java/org/apache/camel/component/netty4/ChannelHandlerFactory.java b/components/camel-netty/src/main/java/org/apache/camel/component/netty/ChannelHandlerFactory.java
similarity index 96%
rename from components/camel-netty/src/main/java/org/apache/camel/component/netty4/ChannelHandlerFactory.java
rename to components/camel-netty/src/main/java/org/apache/camel/component/netty/ChannelHandlerFactory.java
index c3b0411..edde0f1 100644
--- a/components/camel-netty/src/main/java/org/apache/camel/component/netty4/ChannelHandlerFactory.java
+++ b/components/camel-netty/src/main/java/org/apache/camel/component/netty/ChannelHandlerFactory.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4;
+package org.apache.camel.component.netty;
 
 import io.netty.channel.ChannelHandler;
 
diff --git a/components/camel-netty/src/main/java/org/apache/camel/component/netty4/ClientInitializerFactory.java b/components/camel-netty/src/main/java/org/apache/camel/component/netty/ClientInitializerFactory.java
similarity index 97%
rename from components/camel-netty/src/main/java/org/apache/camel/component/netty4/ClientInitializerFactory.java
rename to components/camel-netty/src/main/java/org/apache/camel/component/netty/ClientInitializerFactory.java
index 5e4c62d..e2cbd87 100644
--- a/components/camel-netty/src/main/java/org/apache/camel/component/netty4/ClientInitializerFactory.java
+++ b/components/camel-netty/src/main/java/org/apache/camel/component/netty/ClientInitializerFactory.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4;
+package org.apache.camel.component.netty;
 
 import io.netty.channel.Channel;
 import io.netty.channel.ChannelInitializer;
diff --git a/components/camel-netty/src/main/java/org/apache/camel/component/netty4/ClientModeTCPNettyServerBootstrapFactory.java b/components/camel-netty/src/main/java/org/apache/camel/component/netty/ClientModeTCPNettyServerBootstrapFactory.java
similarity index 98%
rename from components/camel-netty/src/main/java/org/apache/camel/component/netty4/ClientModeTCPNettyServerBootstrapFactory.java
rename to components/camel-netty/src/main/java/org/apache/camel/component/netty/ClientModeTCPNettyServerBootstrapFactory.java
index 3729206..0acc31a 100644
--- a/components/camel-netty/src/main/java/org/apache/camel/component/netty4/ClientModeTCPNettyServerBootstrapFactory.java
+++ b/components/camel-netty/src/main/java/org/apache/camel/component/netty/ClientModeTCPNettyServerBootstrapFactory.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4;
+package org.apache.camel.component.netty;
 
 import java.net.ConnectException;
 import java.net.InetSocketAddress;
@@ -42,7 +42,7 @@ import org.slf4j.LoggerFactory;
 public class ClientModeTCPNettyServerBootstrapFactory extends ServiceSupport implements NettyServerBootstrapFactory {
 
     protected static final Logger LOG = LoggerFactory.getLogger(ClientModeTCPNettyServerBootstrapFactory.class);
-    
+
     private CamelContext camelContext;
     private ThreadFactory threadFactory;
     private NettyServerBootstrapConfiguration configuration;
@@ -103,7 +103,7 @@ public class ClientModeTCPNettyServerBootstrapFactory extends ServiceSupport imp
 
     protected void startServerBootstrap() throws Exception {
         // prefer using explicit configured thread pools
-        
+
         EventLoopGroup wg = configuration.getWorkerGroup();
 
         if (wg == null) {
@@ -115,7 +115,7 @@ public class ClientModeTCPNettyServerBootstrapFactory extends ServiceSupport imp
                     .build();
             wg = workerGroup;
         }
-        
+
         clientBootstrap = new Bootstrap();
         if (configuration.isNativeTransport()) {
             clientBootstrap.channel(EpollSocketChannel.class);
@@ -128,7 +128,7 @@ public class ClientModeTCPNettyServerBootstrapFactory extends ServiceSupport imp
         clientBootstrap.option(ChannelOption.SO_REUSEADDR, configuration.isReuseAddress());
         clientBootstrap.option(ChannelOption.CONNECT_TIMEOUT_MILLIS, configuration.getConnectTimeout());
 
-        
+
         LOG.debug("Created ClientBootstrap {}", clientBootstrap);
         clientBootstrap.handler(pipelineFactory);
         ChannelFuture channelFuture = clientBootstrap.connect(new InetSocketAddress(configuration.getHost(), configuration.getPort()));
@@ -143,7 +143,7 @@ public class ClientModeTCPNettyServerBootstrapFactory extends ServiceSupport imp
     protected void stopServerBootstrap() {
         // close all channels
         LOG.info("ClientModeServerBootstrap unbinding from {}:{}", configuration.getHost(), configuration.getPort());
-        
+
         if (workerGroup != null) {
             workerGroup.shutdownGracefully();
             workerGroup = null;
@@ -185,7 +185,7 @@ public class ClientModeTCPNettyServerBootstrapFactory extends ServiceSupport imp
         if (LOG.isDebugEnabled()) {
             LOG.debug("Creating connector to address: {}", configuration.getAddress());
         }
-        
+
         // schedule a reconnect to happen when the channel closes
         if (configuration.isReconnect()) {
             answer.closeFuture().addListener(new ChannelFutureListener() {
@@ -195,7 +195,7 @@ public class ClientModeTCPNettyServerBootstrapFactory extends ServiceSupport imp
                 };
             });
         }
-        
+
         return answer;
     }
 
diff --git a/components/camel-netty/src/main/java/org/apache/camel/component/netty4/DefaultChannelHandlerFactory.java b/components/camel-netty/src/main/java/org/apache/camel/component/netty/DefaultChannelHandlerFactory.java
similarity index 96%
rename from components/camel-netty/src/main/java/org/apache/camel/component/netty4/DefaultChannelHandlerFactory.java
rename to components/camel-netty/src/main/java/org/apache/camel/component/netty/DefaultChannelHandlerFactory.java
index 3370cf0..0962a1c 100644
--- a/components/camel-netty/src/main/java/org/apache/camel/component/netty4/DefaultChannelHandlerFactory.java
+++ b/components/camel-netty/src/main/java/org/apache/camel/component/netty/DefaultChannelHandlerFactory.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4;
+package org.apache.camel.component.netty;
 
 import io.netty.channel.ChannelHandlerContext;
 
diff --git a/components/camel-netty/src/main/java/org/apache/camel/component/netty4/DefaultClientInitializerFactory.java b/components/camel-netty/src/main/java/org/apache/camel/component/netty/DefaultClientInitializerFactory.java
similarity index 97%
rename from components/camel-netty/src/main/java/org/apache/camel/component/netty4/DefaultClientInitializerFactory.java
rename to components/camel-netty/src/main/java/org/apache/camel/component/netty/DefaultClientInitializerFactory.java
index 32debd7..2cfb4d8 100644
--- a/components/camel-netty/src/main/java/org/apache/camel/component/netty4/DefaultClientInitializerFactory.java
+++ b/components/camel-netty/src/main/java/org/apache/camel/component/netty/DefaultClientInitializerFactory.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4;
+package org.apache.camel.component.netty;
 
 import java.util.List;
 import java.util.concurrent.TimeUnit;
@@ -28,8 +28,8 @@ import io.netty.channel.ChannelPipeline;
 import io.netty.handler.ssl.SslHandler;
 import io.netty.handler.timeout.ReadTimeoutHandler;
 import org.apache.camel.RuntimeCamelException;
-import org.apache.camel.component.netty4.handlers.ClientChannelHandler;
-import org.apache.camel.component.netty4.ssl.SSLEngineFactory;
+import org.apache.camel.component.netty.handlers.ClientChannelHandler;
+import org.apache.camel.component.netty.ssl.SSLEngineFactory;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
diff --git a/components/camel-netty/src/main/java/org/apache/camel/component/netty4/DefaultNettyCamelStateCorrelationManager.java b/components/camel-netty/src/main/java/org/apache/camel/component/netty/DefaultNettyCamelStateCorrelationManager.java
similarity index 97%
rename from components/camel-netty/src/main/java/org/apache/camel/component/netty4/DefaultNettyCamelStateCorrelationManager.java
rename to components/camel-netty/src/main/java/org/apache/camel/component/netty/DefaultNettyCamelStateCorrelationManager.java
index 3cb0a88..c8ef99c 100644
--- a/components/camel-netty/src/main/java/org/apache/camel/component/netty4/DefaultNettyCamelStateCorrelationManager.java
+++ b/components/camel-netty/src/main/java/org/apache/camel/component/netty/DefaultNettyCamelStateCorrelationManager.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4;
+package org.apache.camel.component.netty;
 
 import java.util.Map;
 import java.util.concurrent.ConcurrentHashMap;
diff --git a/components/camel-netty/src/main/java/org/apache/camel/component/netty4/DefaultServerInitializerFactory.java b/components/camel-netty/src/main/java/org/apache/camel/component/netty/DefaultServerInitializerFactory.java
similarity index 97%
rename from components/camel-netty/src/main/java/org/apache/camel/component/netty4/DefaultServerInitializerFactory.java
rename to components/camel-netty/src/main/java/org/apache/camel/component/netty/DefaultServerInitializerFactory.java
index 1d102b7a..31c3787 100644
--- a/components/camel-netty/src/main/java/org/apache/camel/component/netty4/DefaultServerInitializerFactory.java
+++ b/components/camel-netty/src/main/java/org/apache/camel/component/netty/DefaultServerInitializerFactory.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4;
+package org.apache.camel.component.netty;
 
 import java.util.List;
 
@@ -28,8 +28,8 @@ import io.netty.handler.ssl.SslHandler;
 import io.netty.util.concurrent.EventExecutorGroup;
 import org.apache.camel.CamelContext;
 import org.apache.camel.RuntimeCamelException;
-import org.apache.camel.component.netty4.handlers.ServerChannelHandler;
-import org.apache.camel.component.netty4.ssl.SSLEngineFactory;
+import org.apache.camel.component.netty.handlers.ServerChannelHandler;
+import org.apache.camel.component.netty.ssl.SSLEngineFactory;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
@@ -103,7 +103,7 @@ public class DefaultServerInitializerFactory extends ServerInitializerFactory {
             // Just use EventExecutorGroup from the Netty Component
             EventExecutorGroup applicationExecutor = consumer.getEndpoint().getComponent().getExecutorService();
             addToPipeline("handler", channelPipeline, applicationExecutor, new ServerChannelHandler(consumer));
-    
+
         } else {
             // still use the worker event loop group here
             addToPipeline("handler", channelPipeline, new ServerChannelHandler(consumer));
@@ -116,7 +116,7 @@ public class DefaultServerInitializerFactory extends ServerInitializerFactory {
     private void addToPipeline(String name, ChannelPipeline pipeline, ChannelHandler handler) {
         pipeline.addLast(name, handler);
     }
-    
+
     private void addToPipeline(String name, ChannelPipeline pipeline, EventExecutorGroup executor, ChannelHandler handler) {
         pipeline.addLast(executor, name, handler);
     }
diff --git a/components/camel-netty/src/main/java/org/apache/camel/component/netty4/NettyCamelState.java b/components/camel-netty/src/main/java/org/apache/camel/component/netty/NettyCamelState.java
similarity index 91%
rename from components/camel-netty/src/main/java/org/apache/camel/component/netty4/NettyCamelState.java
rename to components/camel-netty/src/main/java/org/apache/camel/component/netty/NettyCamelState.java
index 02d844a..dd4a822 100644
--- a/components/camel-netty/src/main/java/org/apache/camel/component/netty4/NettyCamelState.java
+++ b/components/camel-netty/src/main/java/org/apache/camel/component/netty/NettyCamelState.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4;
+package org.apache.camel.component.netty;
 
 import org.apache.camel.AsyncCallback;
 import org.apache.camel.Exchange;
@@ -22,7 +22,7 @@ import org.apache.camel.Exchange;
 /**
  * Stores state for {@link NettyProducer} when sending messages.
  * <p/>
- * This allows the {@link org.apache.camel.component.netty4.handlers.ClientChannelHandler} to access
+ * This allows the {@link org.apache.camel.component.netty.handlers.ClientChannelHandler} to access
  * this state, which is needed so we can get hold of the current {@link Exchange} and the
  * {@link AsyncCallback} so we can continue routing the message in the Camel routing engine.
  */
diff --git a/components/camel-netty/src/main/java/org/apache/camel/component/netty4/NettyCamelStateCorrelationManager.java b/components/camel-netty/src/main/java/org/apache/camel/component/netty/NettyCamelStateCorrelationManager.java
similarity index 98%
rename from components/camel-netty/src/main/java/org/apache/camel/component/netty4/NettyCamelStateCorrelationManager.java
rename to components/camel-netty/src/main/java/org/apache/camel/component/netty/NettyCamelStateCorrelationManager.java
index 576ffad..aab4adf 100644
--- a/components/camel-netty/src/main/java/org/apache/camel/component/netty4/NettyCamelStateCorrelationManager.java
+++ b/components/camel-netty/src/main/java/org/apache/camel/component/netty/NettyCamelStateCorrelationManager.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4;
+package org.apache.camel.component.netty;
 
 import java.util.Map;
 
diff --git a/components/camel-netty/src/main/java/org/apache/camel/component/netty4/NettyComponent.java b/components/camel-netty/src/main/java/org/apache/camel/component/netty/NettyComponent.java
similarity index 98%
rename from components/camel-netty/src/main/java/org/apache/camel/component/netty4/NettyComponent.java
rename to components/camel-netty/src/main/java/org/apache/camel/component/netty/NettyComponent.java
index 95668a9..76c42ca 100644
--- a/components/camel-netty/src/main/java/org/apache/camel/component/netty4/NettyComponent.java
+++ b/components/camel-netty/src/main/java/org/apache/camel/component/netty/NettyComponent.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4;
+package org.apache.camel.component.netty;
 
 import java.net.URI;
 import java.util.HashMap;
@@ -170,7 +170,7 @@ public class NettyComponent extends DefaultComponent implements SSLContextParame
     }
 
     protected EventExecutorGroup createExecutorService() {
-        // Provide the executor service for the application 
+        // Provide the executor service for the application
         // and use a Camel thread factory so we have consistent thread namings
         // we should use a shared thread pool as recommended by Netty
         String pattern = getCamelContext().getExecutorServiceManager().getThreadNamePattern();
@@ -190,7 +190,7 @@ public class NettyComponent extends DefaultComponent implements SSLContextParame
         if (configuration.getWorkerGroup() != null) {
             configuration.getWorkerGroup().shutdownGracefully();
         }
-               
+
         super.doStop();
     }
 
diff --git a/components/camel-netty/src/main/java/org/apache/camel/component/netty4/NettyConfiguration.java b/components/camel-netty/src/main/java/org/apache/camel/component/netty/NettyConfiguration.java
similarity index 99%
rename from components/camel-netty/src/main/java/org/apache/camel/component/netty4/NettyConfiguration.java
rename to components/camel-netty/src/main/java/org/apache/camel/component/netty/NettyConfiguration.java
index d9eb8dd..ec9bacf 100644
--- a/components/camel-netty/src/main/java/org/apache/camel/component/netty4/NettyConfiguration.java
+++ b/components/camel-netty/src/main/java/org/apache/camel/component/netty/NettyConfiguration.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4;
+package org.apache.camel.component.netty;
 
 import java.io.File;
 import java.net.URI;
@@ -446,7 +446,7 @@ public class NettyConfiguration extends NettyServerBootstrapConfiguration implem
     public boolean isAllowSerializedHeaders() {
         return allowSerializedHeaders;
     }
-    
+
     /**
      * Only used for TCP when transferExchange is true. When set to true, serializable objects in headers and properties
      * will be added to the exchange. Otherwise Camel will exclude any non-serializable objects and log it at WARN
@@ -455,7 +455,7 @@ public class NettyConfiguration extends NettyServerBootstrapConfiguration implem
     public void setAllowSerializedHeaders(final boolean allowSerializedHeaders) {
         this.allowSerializedHeaders = allowSerializedHeaders;
     }
-    
+
     public boolean isDisconnectOnNoReply() {
         return disconnectOnNoReply;
     }
@@ -670,7 +670,7 @@ public class NettyConfiguration extends NettyServerBootstrapConfiguration implem
      * When using this, the channel is not returned to the connection pool until the {@link Exchange} is done; or disconnected
      * if the disconnect option is set to true.
      * <p/>
-     * The reused {@link Channel} is stored on the {@link Exchange} as an exchange property with the key {@link NettyConstants#NETTY_CHANNEL} 
+     * The reused {@link Channel} is stored on the {@link Exchange} as an exchange property with the key {@link NettyConstants#NETTY_CHANNEL}
      * which allows you to obtain the channel during routing and use it as well.
      */
     public void setReuseChannel(boolean reuseChannel) {
diff --git a/components/camel-netty/src/main/java/org/apache/camel/component/netty4/NettyConstants.java b/components/camel-netty/src/main/java/org/apache/camel/component/netty/NettyConstants.java
similarity index 98%
rename from components/camel-netty/src/main/java/org/apache/camel/component/netty4/NettyConstants.java
rename to components/camel-netty/src/main/java/org/apache/camel/component/netty/NettyConstants.java
index 9d71023..5510d30 100644
--- a/components/camel-netty/src/main/java/org/apache/camel/component/netty4/NettyConstants.java
+++ b/components/camel-netty/src/main/java/org/apache/camel/component/netty/NettyConstants.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4;
+package org.apache.camel.component.netty;
 
 /**
  * Netty constants
diff --git a/components/camel-netty/src/main/java/org/apache/camel/component/netty4/NettyConsumer.java b/components/camel-netty/src/main/java/org/apache/camel/component/netty/NettyConsumer.java
similarity index 98%
rename from components/camel-netty/src/main/java/org/apache/camel/component/netty4/NettyConsumer.java
rename to components/camel-netty/src/main/java/org/apache/camel/component/netty/NettyConsumer.java
index b337501..4947a98 100644
--- a/components/camel-netty/src/main/java/org/apache/camel/component/netty4/NettyConsumer.java
+++ b/components/camel-netty/src/main/java/org/apache/camel/component/netty/NettyConsumer.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4;
+package org.apache.camel.component.netty;
 
 import org.apache.camel.CamelContext;
 import org.apache.camel.Processor;
diff --git a/components/camel-netty/src/main/java/org/apache/camel/component/netty4/NettyConsumerExceptionHandler.java b/components/camel-netty/src/main/java/org/apache/camel/component/netty/NettyConsumerExceptionHandler.java
similarity index 98%
rename from components/camel-netty/src/main/java/org/apache/camel/component/netty4/NettyConsumerExceptionHandler.java
rename to components/camel-netty/src/main/java/org/apache/camel/component/netty/NettyConsumerExceptionHandler.java
index e3420a1..5ef8657 100644
--- a/components/camel-netty/src/main/java/org/apache/camel/component/netty4/NettyConsumerExceptionHandler.java
+++ b/components/camel-netty/src/main/java/org/apache/camel/component/netty/NettyConsumerExceptionHandler.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4;
+package org.apache.camel.component.netty;
 
 import java.nio.channels.ClosedChannelException;
 
diff --git a/components/camel-netty/src/main/java/org/apache/camel/component/netty4/NettyConverter.java b/components/camel-netty/src/main/java/org/apache/camel/component/netty/NettyConverter.java
similarity index 99%
rename from components/camel-netty/src/main/java/org/apache/camel/component/netty4/NettyConverter.java
rename to components/camel-netty/src/main/java/org/apache/camel/component/netty/NettyConverter.java
index 6a0f2a9..1161b5c 100644
--- a/components/camel-netty/src/main/java/org/apache/camel/component/netty4/NettyConverter.java
+++ b/components/camel-netty/src/main/java/org/apache/camel/component/netty/NettyConverter.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4;
+package org.apache.camel.component.netty;
 
 import java.io.IOException;
 import java.io.InputStream;
diff --git a/components/camel-netty/src/main/java/org/apache/camel/component/netty4/NettyEndpoint.java b/components/camel-netty/src/main/java/org/apache/camel/component/netty/NettyEndpoint.java
similarity index 98%
rename from components/camel-netty/src/main/java/org/apache/camel/component/netty4/NettyEndpoint.java
rename to components/camel-netty/src/main/java/org/apache/camel/component/netty/NettyEndpoint.java
index bb672c4..9ae5ed6 100644
--- a/components/camel-netty/src/main/java/org/apache/camel/component/netty4/NettyEndpoint.java
+++ b/components/camel-netty/src/main/java/org/apache/camel/component/netty/NettyEndpoint.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4;
+package org.apache.camel.component.netty;
 
 import java.math.BigInteger;
 import java.security.Principal;
@@ -44,7 +44,7 @@ import org.apache.camel.util.ObjectHelper;
 public class NettyEndpoint extends DefaultEndpoint implements AsyncEndpoint {
     @UriParam
     private NettyConfiguration configuration;
-    @UriParam(label = "advanced", javaType = "org.apache.camel.component.netty4.NettyServerBootstrapConfiguration",
+    @UriParam(label = "advanced", javaType = "org.apache.camel.component.netty.NettyServerBootstrapConfiguration",
             description = "To use a custom configured NettyServerBootstrapConfiguration for configuring this endpoint.")
     private Object bootstrapConfiguration; // to include in component docs as NettyServerBootstrapConfiguration is a @UriParams class
 
@@ -76,7 +76,7 @@ public class NettyEndpoint extends DefaultEndpoint implements AsyncEndpoint {
         NettyPayloadHelper.setIn(exchange, message);
         return exchange;
     }
-    
+
     @Override
     public NettyComponent getComponent() {
         return (NettyComponent) super.getComponent();
@@ -93,15 +93,15 @@ public class NettyEndpoint extends DefaultEndpoint implements AsyncEndpoint {
     @Override
     protected String createEndpointUri() {
         ObjectHelper.notNull(configuration, "configuration");
-        return "netty:" + getConfiguration().getProtocol() + "://" + getConfiguration().getHost() + ":" + getConfiguration().getPort(); 
+        return "netty:" + getConfiguration().getProtocol() + "://" + getConfiguration().getHost() + ":" + getConfiguration().getPort();
     }
-    
+
     protected SSLSession getSSLSession(ChannelHandlerContext ctx) {
         final SslHandler sslHandler = ctx.pipeline().get(SslHandler.class);
         SSLSession sslSession = null;
         if (sslHandler != null) {
             sslSession = sslHandler.engine().getSession();
-        } 
+        }
         return sslSession;
     }
 
diff --git a/components/camel-netty/src/main/java/org/apache/camel/component/netty4/NettyHelper.java b/components/camel-netty/src/main/java/org/apache/camel/component/netty/NettyHelper.java
similarity index 97%
rename from components/camel-netty/src/main/java/org/apache/camel/component/netty4/NettyHelper.java
rename to components/camel-netty/src/main/java/org/apache/camel/component/netty/NettyHelper.java
index 26a3165..d8abbad 100644
--- a/components/camel-netty/src/main/java/org/apache/camel/component/netty4/NettyHelper.java
+++ b/components/camel-netty/src/main/java/org/apache/camel/component/netty/NettyHelper.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4;
+package org.apache.camel.component.netty;
 
 import java.net.InetSocketAddress;
 import java.net.SocketAddress;
@@ -98,7 +98,7 @@ public final class NettyHelper {
             if (log.isDebugEnabled()) {
                 log.debug("Channel: {} writing body: {}", channel, body);
             }
-            // In netty4 we need to call channel flush to send out the message 
+            // In netty we need to call channel flush to send out the message
             future = channel.writeAndFlush(body);
         }
 
diff --git a/components/camel-netty/src/main/java/org/apache/camel/component/netty4/NettyPayloadHelper.java b/components/camel-netty/src/main/java/org/apache/camel/component/netty/NettyPayloadHelper.java
similarity index 93%
rename from components/camel-netty/src/main/java/org/apache/camel/component/netty4/NettyPayloadHelper.java
rename to components/camel-netty/src/main/java/org/apache/camel/component/netty/NettyPayloadHelper.java
index 4bb1059..db9126a 100644
--- a/components/camel-netty/src/main/java/org/apache/camel/component/netty4/NettyPayloadHelper.java
+++ b/components/camel-netty/src/main/java/org/apache/camel/component/netty/NettyPayloadHelper.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4;
+package org.apache.camel.component.netty;
 
 import java.net.InetSocketAddress;
 
@@ -31,7 +31,7 @@ import org.apache.camel.support.DefaultExchangeHolder;
  * <tt>transferExchange=true</tt> option.
  */
 public final class NettyPayloadHelper {
-    
+
     private NettyPayloadHelper() {
         //Helper class
     }
@@ -42,7 +42,7 @@ public final class NettyPayloadHelper {
             return DefaultExchangeHolder.marshal(exchange, true, endpoint.getConfiguration().isAllowSerializedHeaders());
         } else {
             if (endpoint.getConfiguration().isUseByteBuf()) {
-                // Just leverage the type converter 
+                // Just leverage the type converter
                 return exchange.getIn().getBody(ByteBuf.class);
             } else {
                 // normal transfer using the body only
@@ -66,12 +66,12 @@ public final class NettyPayloadHelper {
             DefaultExchangeHolder.unmarshal(exchange, (DefaultExchangeHolder) payload);
         } else if (payload instanceof AddressedEnvelope) {
             @SuppressWarnings("unchecked")
-            AddressedEnvelope<Object, InetSocketAddress> dp = (AddressedEnvelope<Object, InetSocketAddress>)payload; 
+            AddressedEnvelope<Object, InetSocketAddress> dp = (AddressedEnvelope<Object, InetSocketAddress>)payload;
             // need to check if the content is ExchangeHolder
             if (dp.content() instanceof DefaultExchangeHolder) {
-                DefaultExchangeHolder.unmarshal(exchange, (DefaultExchangeHolder) dp.content());    
+                DefaultExchangeHolder.unmarshal(exchange, (DefaultExchangeHolder) dp.content());
             } else {
-                // need to take out the payload here 
+                // need to take out the payload here
                 exchange.getIn().setBody(dp.content());
             }
             // setup the sender address here for sending the response message back
@@ -92,9 +92,9 @@ public final class NettyPayloadHelper {
             AddressedEnvelope<Object, InetSocketAddress> dp = (AddressedEnvelope<Object, InetSocketAddress>)payload;
             // need to check if the content is ExchangeHolder
             if (dp.content() instanceof DefaultExchangeHolder) {
-                DefaultExchangeHolder.unmarshal(exchange, (DefaultExchangeHolder) dp.content());    
+                DefaultExchangeHolder.unmarshal(exchange, (DefaultExchangeHolder) dp.content());
             } else {
-                // need to take out the payload here 
+                // need to take out the payload here
                 exchange.getOut().setBody(dp.content());
             }
             // setup the sender address here for sending the response message back
@@ -105,6 +105,6 @@ public final class NettyPayloadHelper {
             exchange.getOut().setBody(payload);
         }
     }
-    
+
 
 }
diff --git a/components/camel-netty/src/main/java/org/apache/camel/component/netty4/NettyProducer.java b/components/camel-netty/src/main/java/org/apache/camel/component/netty/NettyProducer.java
similarity index 99%
rename from components/camel-netty/src/main/java/org/apache/camel/component/netty4/NettyProducer.java
rename to components/camel-netty/src/main/java/org/apache/camel/component/netty/NettyProducer.java
index b301c27..5e94974 100644
--- a/components/camel-netty/src/main/java/org/apache/camel/component/netty4/NettyProducer.java
+++ b/components/camel-netty/src/main/java/org/apache/camel/component/netty/NettyProducer.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4;
+package org.apache.camel.component.netty;
 
 import java.net.ConnectException;
 import java.net.InetSocketAddress;
@@ -109,7 +109,7 @@ public class NettyProducer extends DefaultAsyncProducer {
                 .withWorkerCount(configuration.getWorkerCount())
                 .withName("NettyClientTCPWorker").build();
         }
-               
+
         if (configuration.isProducerPoolEnabled()) {
             // setup pool where we want an unbounded pool, which allows the pool to shrink on no demand
             GenericObjectPool.Config config = new GenericObjectPool.Config();
@@ -151,7 +151,7 @@ public class NettyProducer extends DefaultAsyncProducer {
         } else {
             allChannels = configuration.getChannelGroup();
         }
-        
+
         if (!configuration.isLazyChannelCreation()) {
             // ensure the connection can be established when we start up
             ChannelFuture channelFuture = pool.borrowObject();
@@ -316,7 +316,7 @@ public class NettyProducer extends DefaultAsyncProducer {
         // here we need to setup the remote address information here
         InetSocketAddress remoteAddress = null;
         if (!isTcp()) {
-            remoteAddress = new InetSocketAddress(configuration.getHost(), configuration.getPort()); 
+            remoteAddress = new InetSocketAddress(configuration.getHost(), configuration.getPort());
         }
 
         // write body
@@ -451,7 +451,7 @@ public class NettyProducer extends DefaultAsyncProducer {
 
             // set the pipeline factory, which creates the pipeline for each newly created channels
             connectionlessClientBootstrap.handler(pipelineFactory);
-           
+
             // if udp connectionless sending is true we don't do a connect.
             // we just send on the channel created with bind which means
             // really fire and forget. You wont get an PortUnreachableException
diff --git a/components/camel-netty/src/main/java/org/apache/camel/component/netty4/NettyServerBootstrapConfiguration.java b/components/camel-netty/src/main/java/org/apache/camel/component/netty/NettyServerBootstrapConfiguration.java
similarity index 99%
rename from components/camel-netty/src/main/java/org/apache/camel/component/netty4/NettyServerBootstrapConfiguration.java
rename to components/camel-netty/src/main/java/org/apache/camel/component/netty/NettyServerBootstrapConfiguration.java
index 9c85703..1c7753a 100644
--- a/components/camel-netty/src/main/java/org/apache/camel/component/netty4/NettyServerBootstrapConfiguration.java
+++ b/components/camel-netty/src/main/java/org/apache/camel/component/netty/NettyServerBootstrapConfiguration.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4;
+package org.apache.camel.component.netty;
 
 import java.io.File;
 import java.util.Map;
@@ -134,7 +134,7 @@ public class NettyServerBootstrapConfiguration implements Cloneable {
     /**
      * The hostname.
      * <p/>
-     * For the consumer the hostname is localhost or 0.0.0.0. 
+     * For the consumer the hostname is localhost or 0.0.0.0.
      * For the producer the hostname is the remote host to connect to
      */
     public void setHost(String host) {
@@ -484,7 +484,7 @@ public class NettyServerBootstrapConfiguration implements Cloneable {
     }
 
     /**
-     * Set the BossGroup which could be used for handling the new connection of the server side across the NettyEndpoint 
+     * Set the BossGroup which could be used for handling the new connection of the server side across the NettyEndpoint
      */
     public void setBossGroup(EventLoopGroup bossGroup) {
         this.bossGroup = bossGroup;
diff --git a/components/camel-netty/src/main/java/org/apache/camel/component/netty4/NettyServerBootstrapFactory.java b/components/camel-netty/src/main/java/org/apache/camel/component/netty/NettyServerBootstrapFactory.java
similarity index 98%
rename from components/camel-netty/src/main/java/org/apache/camel/component/netty4/NettyServerBootstrapFactory.java
rename to components/camel-netty/src/main/java/org/apache/camel/component/netty/NettyServerBootstrapFactory.java
index 8167d20..82e6087 100644
--- a/components/camel-netty/src/main/java/org/apache/camel/component/netty4/NettyServerBootstrapFactory.java
+++ b/components/camel-netty/src/main/java/org/apache/camel/component/netty/NettyServerBootstrapFactory.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4;
+package org.apache.camel.component.netty;
 import java.util.concurrent.ThreadFactory;
 
 import io.netty.channel.Channel;
diff --git a/components/camel-netty/src/main/java/org/apache/camel/component/netty4/NettyServerBossPoolBuilder.java b/components/camel-netty/src/main/java/org/apache/camel/component/netty/NettyServerBossPoolBuilder.java
similarity index 93%
rename from components/camel-netty/src/main/java/org/apache/camel/component/netty4/NettyServerBossPoolBuilder.java
rename to components/camel-netty/src/main/java/org/apache/camel/component/netty/NettyServerBossPoolBuilder.java
index ed23318..28a9ed4 100644
--- a/components/camel-netty/src/main/java/org/apache/camel/component/netty4/NettyServerBossPoolBuilder.java
+++ b/components/camel-netty/src/main/java/org/apache/camel/component/netty/NettyServerBossPoolBuilder.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4;
+package org.apache.camel.component.netty;
 
 import io.netty.channel.EventLoopGroup;
 import io.netty.channel.epoll.EpollEventLoopGroup;
@@ -24,7 +24,7 @@ import org.apache.camel.util.concurrent.CamelThreadFactory;
 
 /**
  * A builder to create Netty {@link io.netty.channel.EventLoopGroup} which can be used for executor boss events
- * with multiple Netty {@link org.apache.camel.component.netty4.NettyServerBootstrapFactory} server bootstrap configurations.
+ * with multiple Netty {@link org.apache.camel.component.netty.NettyServerBootstrapFactory} server bootstrap configurations.
  */
 public final class NettyServerBossPoolBuilder {
 
diff --git a/components/camel-netty/src/main/java/org/apache/camel/component/netty4/NettyWorkerPoolBuilder.java b/components/camel-netty/src/main/java/org/apache/camel/component/netty/NettyWorkerPoolBuilder.java
similarity index 98%
rename from components/camel-netty/src/main/java/org/apache/camel/component/netty4/NettyWorkerPoolBuilder.java
rename to components/camel-netty/src/main/java/org/apache/camel/component/netty/NettyWorkerPoolBuilder.java
index bf259e2..defc8b6 100644
--- a/components/camel-netty/src/main/java/org/apache/camel/component/netty4/NettyWorkerPoolBuilder.java
+++ b/components/camel-netty/src/main/java/org/apache/camel/component/netty/NettyWorkerPoolBuilder.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4;
+package org.apache.camel.component.netty;
 
 import io.netty.channel.EventLoopGroup;
 import io.netty.channel.epoll.EpollEventLoopGroup;
diff --git a/components/camel-netty/src/main/java/org/apache/camel/component/netty4/ServerInitializerFactory.java b/components/camel-netty/src/main/java/org/apache/camel/component/netty/ServerInitializerFactory.java
similarity index 97%
rename from components/camel-netty/src/main/java/org/apache/camel/component/netty4/ServerInitializerFactory.java
rename to components/camel-netty/src/main/java/org/apache/camel/component/netty/ServerInitializerFactory.java
index f81ef27..2b0be7b 100644
--- a/components/camel-netty/src/main/java/org/apache/camel/component/netty4/ServerInitializerFactory.java
+++ b/components/camel-netty/src/main/java/org/apache/camel/component/netty/ServerInitializerFactory.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4;
+package org.apache.camel.component.netty;
 
 import io.netty.channel.Channel;
 import io.netty.channel.ChannelInitializer;
diff --git a/components/camel-netty/src/main/java/org/apache/camel/component/netty4/ShareableChannelHandlerFactory.java b/components/camel-netty/src/main/java/org/apache/camel/component/netty/ShareableChannelHandlerFactory.java
similarity index 96%
rename from components/camel-netty/src/main/java/org/apache/camel/component/netty4/ShareableChannelHandlerFactory.java
rename to components/camel-netty/src/main/java/org/apache/camel/component/netty/ShareableChannelHandlerFactory.java
index e59f8d7..262613f 100644
--- a/components/camel-netty/src/main/java/org/apache/camel/component/netty4/ShareableChannelHandlerFactory.java
+++ b/components/camel-netty/src/main/java/org/apache/camel/component/netty/ShareableChannelHandlerFactory.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4;
+package org.apache.camel.component.netty;
 
 import io.netty.channel.ChannelHandler;
 
@@ -28,7 +28,7 @@ public class ShareableChannelHandlerFactory extends DefaultChannelHandlerFactory
     public ShareableChannelHandlerFactory(ChannelHandler channelHandler) {
         this.channelHandler = channelHandler;
     }
-    
+
     @Override
     public ChannelHandler newChannelHandler() {
         return channelHandler;
diff --git a/components/camel-netty/src/main/java/org/apache/camel/component/netty4/SharedSingletonObjectPool.java b/components/camel-netty/src/main/java/org/apache/camel/component/netty/SharedSingletonObjectPool.java
similarity index 98%
rename from components/camel-netty/src/main/java/org/apache/camel/component/netty4/SharedSingletonObjectPool.java
rename to components/camel-netty/src/main/java/org/apache/camel/component/netty/SharedSingletonObjectPool.java
index d25c583..b92eb7f 100644
--- a/components/camel-netty/src/main/java/org/apache/camel/component/netty4/SharedSingletonObjectPool.java
+++ b/components/camel-netty/src/main/java/org/apache/camel/component/netty/SharedSingletonObjectPool.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4;
+package org.apache.camel.component.netty;
 
 import java.util.NoSuchElementException;
 
diff --git a/components/camel-netty/src/main/java/org/apache/camel/component/netty4/SingleTCPNettyServerBootstrapFactory.java b/components/camel-netty/src/main/java/org/apache/camel/component/netty/SingleTCPNettyServerBootstrapFactory.java
similarity index 99%
rename from components/camel-netty/src/main/java/org/apache/camel/component/netty4/SingleTCPNettyServerBootstrapFactory.java
rename to components/camel-netty/src/main/java/org/apache/camel/component/netty/SingleTCPNettyServerBootstrapFactory.java
index fb62ef8..3c2a736 100644
--- a/components/camel-netty/src/main/java/org/apache/camel/component/netty4/SingleTCPNettyServerBootstrapFactory.java
+++ b/components/camel-netty/src/main/java/org/apache/camel/component/netty/SingleTCPNettyServerBootstrapFactory.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4;
+package org.apache.camel.component.netty;
 
 import java.net.InetSocketAddress;
 import java.util.Map;
@@ -135,7 +135,7 @@ public class SingleTCPNettyServerBootstrapFactory extends ServiceSupport impleme
                     .build();
             wg = workerGroup;
         }
-        
+
         serverBootstrap = new ServerBootstrap();
         if (configuration.isNativeTransport()) {
             serverBootstrap.group(bg, wg).channel(EpollServerSocketChannel.class);
@@ -183,7 +183,7 @@ public class SingleTCPNettyServerBootstrapFactory extends ServiceSupport impleme
     protected void stopServerBootstrap() {
         // close all channels
         LOG.info("ServerBootstrap unbinding from {}:{}", configuration.getHost(), configuration.getPort());
-        
+
         LOG.trace("Closing {} channels", allChannels.size());
         allChannels.close().awaitUninterruptibly();
 
diff --git a/components/camel-netty/src/main/java/org/apache/camel/component/netty4/SingleUDPNettyServerBootstrapFactory.java b/components/camel-netty/src/main/java/org/apache/camel/component/netty/SingleUDPNettyServerBootstrapFactory.java
similarity index 97%
rename from components/camel-netty/src/main/java/org/apache/camel/component/netty4/SingleUDPNettyServerBootstrapFactory.java
rename to components/camel-netty/src/main/java/org/apache/camel/component/netty/SingleUDPNettyServerBootstrapFactory.java
index 14e7d9e..3f148bb 100644
--- a/components/camel-netty/src/main/java/org/apache/camel/component/netty4/SingleUDPNettyServerBootstrapFactory.java
+++ b/components/camel-netty/src/main/java/org/apache/camel/component/netty/SingleUDPNettyServerBootstrapFactory.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4;
+package org.apache.camel.component.netty;
 
 import java.net.InetSocketAddress;
 import java.net.NetworkInterface;
@@ -35,7 +35,7 @@ import io.netty.channel.socket.DatagramChannel;
 import io.netty.channel.socket.nio.NioDatagramChannel;
 import io.netty.util.concurrent.ImmediateEventExecutor;
 import org.apache.camel.CamelContext;
-import org.apache.camel.component.netty4.util.SubnetUtils;
+import org.apache.camel.component.netty.util.SubnetUtils;
 import org.apache.camel.support.CamelContextHelper;
 import org.apache.camel.support.EndpointHelper;
 import org.apache.camel.support.service.ServiceSupport;
@@ -123,26 +123,26 @@ public class SingleUDPNettyServerBootstrapFactory extends ServiceSupport impleme
                     .build();
             wg = workerGroup;
         }
-        
+
         Bootstrap bootstrap = new Bootstrap();
         if (configuration.isNativeTransport()) {
             bootstrap.group(wg).channel(EpollDatagramChannel.class);
         } else {
             bootstrap.group(wg).channel(NioDatagramChannel.class);
         }
-        // We cannot set the child option here      
+        // We cannot set the child option here
         bootstrap.option(ChannelOption.SO_REUSEADDR, configuration.isReuseAddress());
         bootstrap.option(ChannelOption.SO_SNDBUF, configuration.getSendBufferSize());
         bootstrap.option(ChannelOption.SO_RCVBUF, configuration.getReceiveBufferSize());
         bootstrap.option(ChannelOption.SO_BROADCAST, configuration.isBroadcast());
         bootstrap.option(ChannelOption.CONNECT_TIMEOUT_MILLIS, configuration.getConnectTimeout());
-        
+
         // only set this if user has specified
         if (configuration.getReceiveBufferSizePredictor() > 0) {
             bootstrap.option(ChannelOption.RCVBUF_ALLOCATOR,
                     new FixedRecvByteBufAllocator(configuration.getReceiveBufferSizePredictor()));
         }
-        
+
         if (configuration.getBacklog() > 0) {
             bootstrap.option(ChannelOption.SO_BACKLOG, configuration.getBacklog());
         }
@@ -195,7 +195,7 @@ public class SingleUDPNettyServerBootstrapFactory extends ServiceSupport impleme
 
         LOG.trace("Closing {} channels", allChannels.size());
         allChannels.close().awaitUninterruptibly();
-        
+
         // and then shutdown the thread pools
         if (workerGroup != null) {
             workerGroup.shutdownGracefully();
diff --git a/components/camel-netty/src/main/java/org/apache/camel/component/netty4/TextLineDelimiter.java b/components/camel-netty/src/main/java/org/apache/camel/component/netty/TextLineDelimiter.java
similarity index 95%
rename from components/camel-netty/src/main/java/org/apache/camel/component/netty4/TextLineDelimiter.java
rename to components/camel-netty/src/main/java/org/apache/camel/component/netty/TextLineDelimiter.java
index f9ebda9..4c9cdd3 100644
--- a/components/camel-netty/src/main/java/org/apache/camel/component/netty4/TextLineDelimiter.java
+++ b/components/camel-netty/src/main/java/org/apache/camel/component/netty/TextLineDelimiter.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4;
+package org.apache.camel.component.netty;
 
 /**
  * Possible text line delimiters to be used with the textline codec.
diff --git a/components/camel-netty/src/main/java/org/apache/camel/component/netty4/TimeoutCorrelationManagerSupport.java b/components/camel-netty/src/main/java/org/apache/camel/component/netty/TimeoutCorrelationManagerSupport.java
similarity index 99%
rename from components/camel-netty/src/main/java/org/apache/camel/component/netty4/TimeoutCorrelationManagerSupport.java
rename to components/camel-netty/src/main/java/org/apache/camel/component/netty/TimeoutCorrelationManagerSupport.java
index 86ee821..513cd59 100644
--- a/components/camel-netty/src/main/java/org/apache/camel/component/netty4/TimeoutCorrelationManagerSupport.java
+++ b/components/camel-netty/src/main/java/org/apache/camel/component/netty/TimeoutCorrelationManagerSupport.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4;
+package org.apache.camel.component.netty;
 
 import java.util.concurrent.ExecutorService;
 import java.util.concurrent.ScheduledExecutorService;
diff --git a/components/camel-netty/src/main/java/org/apache/camel/component/netty4/codec/DatagramPacketByteArrayDecoder.java b/components/camel-netty/src/main/java/org/apache/camel/component/netty/codec/DatagramPacketByteArrayDecoder.java
similarity index 97%
rename from components/camel-netty/src/main/java/org/apache/camel/component/netty4/codec/DatagramPacketByteArrayDecoder.java
rename to components/camel-netty/src/main/java/org/apache/camel/component/netty/codec/DatagramPacketByteArrayDecoder.java
index def5749..4f8cc0f 100644
--- a/components/camel-netty/src/main/java/org/apache/camel/component/netty4/codec/DatagramPacketByteArrayDecoder.java
+++ b/components/camel-netty/src/main/java/org/apache/camel/component/netty/codec/DatagramPacketByteArrayDecoder.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.codec;
+package org.apache.camel.component.netty.codec;
 
 import java.net.InetSocketAddress;
 import java.util.List;
diff --git a/components/camel-netty/src/main/java/org/apache/camel/component/netty4/codec/DatagramPacketByteArrayEncoder.java b/components/camel-netty/src/main/java/org/apache/camel/component/netty/codec/DatagramPacketByteArrayEncoder.java
similarity index 97%
rename from components/camel-netty/src/main/java/org/apache/camel/component/netty4/codec/DatagramPacketByteArrayEncoder.java
rename to components/camel-netty/src/main/java/org/apache/camel/component/netty/codec/DatagramPacketByteArrayEncoder.java
index 71b3715..92a8705 100644
--- a/components/camel-netty/src/main/java/org/apache/camel/component/netty4/codec/DatagramPacketByteArrayEncoder.java
+++ b/components/camel-netty/src/main/java/org/apache/camel/component/netty/codec/DatagramPacketByteArrayEncoder.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.codec;
+package org.apache.camel.component.netty.codec;
 
 import java.net.InetSocketAddress;
 import java.util.List;
diff --git a/components/camel-netty/src/main/java/org/apache/camel/component/netty4/codec/DatagramPacketDecoder.java b/components/camel-netty/src/main/java/org/apache/camel/component/netty/codec/DatagramPacketDecoder.java
similarity index 95%
rename from components/camel-netty/src/main/java/org/apache/camel/component/netty4/codec/DatagramPacketDecoder.java
rename to components/camel-netty/src/main/java/org/apache/camel/component/netty/codec/DatagramPacketDecoder.java
index e02cc10..45574cba 100644
--- a/components/camel-netty/src/main/java/org/apache/camel/component/netty4/codec/DatagramPacketDecoder.java
+++ b/components/camel-netty/src/main/java/org/apache/camel/component/netty/codec/DatagramPacketDecoder.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.codec;
+package org.apache.camel.component.netty.codec;
 
 import java.net.InetSocketAddress;
 import java.util.List;
@@ -31,10 +31,10 @@ public class DatagramPacketDecoder extends MessageToMessageDecoder<DatagramPacke
     @Override
     protected void decode(ChannelHandlerContext ctx, DatagramPacket msg, List<Object> out) throws Exception {
         // decode the DatagramPackage to AddressedEnvelope
-        DefaultAddressedEnvelope<Object, InetSocketAddress> addressEvelop = 
+        DefaultAddressedEnvelope<Object, InetSocketAddress> addressEvelop =
             new DefaultAddressedEnvelope<>(msg.content().retain(), msg.recipient(), msg.sender());
         out.add(addressEvelop);
-        
+
     }
 
 }
diff --git a/components/camel-netty/src/main/java/org/apache/camel/component/netty4/codec/DatagramPacketDelimiterDecoder.java b/components/camel-netty/src/main/java/org/apache/camel/component/netty/codec/DatagramPacketDelimiterDecoder.java
similarity index 96%
rename from components/camel-netty/src/main/java/org/apache/camel/component/netty4/codec/DatagramPacketDelimiterDecoder.java
rename to components/camel-netty/src/main/java/org/apache/camel/component/netty/codec/DatagramPacketDelimiterDecoder.java
index 78bdb04..918c2ab 100644
--- a/components/camel-netty/src/main/java/org/apache/camel/component/netty4/codec/DatagramPacketDelimiterDecoder.java
+++ b/components/camel-netty/src/main/java/org/apache/camel/component/netty/codec/DatagramPacketDelimiterDecoder.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.codec;
+package org.apache.camel.component.netty.codec;
 
 import java.net.InetSocketAddress;
 import java.util.List;
@@ -28,26 +28,26 @@ import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
 public class DatagramPacketDelimiterDecoder extends MessageToMessageDecoder<AddressedEnvelope<Object, InetSocketAddress>> {
-    
+
     private static final Logger LOG = LoggerFactory.getLogger(DatagramPacketDelimiterDecoder.class);
-    
+
     private final DelimiterBasedFrameDecoder delegateDecoder;
-    
+
     public DatagramPacketDelimiterDecoder(int maxFrameLength, ByteBuf[] delimiters) {
         this(maxFrameLength, true, delimiters);
     }
-    
+
     public DatagramPacketDelimiterDecoder(int maxFrameLength, boolean stripDelimiter,  ByteBuf[] delimiters) {
         delegateDecoder = new DelimiterBasedFrameDecoder(maxFrameLength, stripDelimiter, delimiters);
     }
-    
+
     @Override
     protected void decode(ChannelHandlerContext ctx, AddressedEnvelope<Object, InetSocketAddress> msg,
                           List<Object> out) throws Exception {
         if (msg.content() instanceof ByteBuf) {
             ByteBuf payload = (ByteBuf)msg.content();
             Object result = delegateDecoder.decode(ctx, payload);
-            AddressedEnvelope<Object, InetSocketAddress> addressEvelop = 
+            AddressedEnvelope<Object, InetSocketAddress> addressEvelop =
                 new DefaultAddressedEnvelope<>(result, msg.recipient(), msg.sender());
             out.add(addressEvelop);
         } else {
diff --git a/components/camel-netty/src/main/java/org/apache/camel/component/netty4/codec/DatagramPacketEncoder.java b/components/camel-netty/src/main/java/org/apache/camel/component/netty/codec/DatagramPacketEncoder.java
similarity index 97%
rename from components/camel-netty/src/main/java/org/apache/camel/component/netty4/codec/DatagramPacketEncoder.java
rename to components/camel-netty/src/main/java/org/apache/camel/component/netty/codec/DatagramPacketEncoder.java
index af1afd7..f62459f 100644
--- a/components/camel-netty/src/main/java/org/apache/camel/component/netty4/codec/DatagramPacketEncoder.java
+++ b/components/camel-netty/src/main/java/org/apache/camel/component/netty/codec/DatagramPacketEncoder.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.codec;
+package org.apache.camel.component.netty.codec;
 
 import java.net.InetSocketAddress;
 import java.util.List;
diff --git a/components/camel-netty/src/main/java/org/apache/camel/component/netty4/codec/DatagramPacketObjectDecoder.java b/components/camel-netty/src/main/java/org/apache/camel/component/netty/codec/DatagramPacketObjectDecoder.java
similarity index 96%
rename from components/camel-netty/src/main/java/org/apache/camel/component/netty4/codec/DatagramPacketObjectDecoder.java
rename to components/camel-netty/src/main/java/org/apache/camel/component/netty/codec/DatagramPacketObjectDecoder.java
index 8e0c21d..8ba0cf1 100644
--- a/components/camel-netty/src/main/java/org/apache/camel/component/netty4/codec/DatagramPacketObjectDecoder.java
+++ b/components/camel-netty/src/main/java/org/apache/camel/component/netty/codec/DatagramPacketObjectDecoder.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.codec;
+package org.apache.camel.component.netty.codec;
 
 import java.net.InetSocketAddress;
 import java.util.List;
@@ -31,18 +31,18 @@ import io.netty.handler.codec.serialization.ClassResolver;
 public class DatagramPacketObjectDecoder extends MessageToMessageDecoder<AddressedEnvelope<Object, InetSocketAddress>> {
 
     private final ObjectDecoder delegateDecoder;
-    
+
     public DatagramPacketObjectDecoder(ClassResolver resolver) {
         delegateDecoder = new ObjectDecoder(resolver);
     }
-    
+
     @Override
     protected void decode(ChannelHandlerContext ctx, AddressedEnvelope<Object, InetSocketAddress> msg,
                           List<Object> out) throws Exception {
         if (msg.content() instanceof ByteBuf) {
             ByteBuf payload = (ByteBuf) msg.content();
             Object result = delegateDecoder.decode(ctx, payload);
-            AddressedEnvelope<Object, InetSocketAddress> addressedEnvelop = 
+            AddressedEnvelope<Object, InetSocketAddress> addressedEnvelop =
                 new DefaultAddressedEnvelope<>(result, msg.recipient(), msg.sender());
             out.add(addressedEnvelop);
         }
diff --git a/components/camel-netty/src/main/java/org/apache/camel/component/netty4/codec/DatagramPacketObjectEncoder.java b/components/camel-netty/src/main/java/org/apache/camel/component/netty/codec/DatagramPacketObjectEncoder.java
similarity index 97%
rename from components/camel-netty/src/main/java/org/apache/camel/component/netty4/codec/DatagramPacketObjectEncoder.java
rename to components/camel-netty/src/main/java/org/apache/camel/component/netty/codec/DatagramPacketObjectEncoder.java
index 7cfe4ac..cc0b5a0 100644
--- a/components/camel-netty/src/main/java/org/apache/camel/component/netty4/codec/DatagramPacketObjectEncoder.java
+++ b/components/camel-netty/src/main/java/org/apache/camel/component/netty/codec/DatagramPacketObjectEncoder.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.codec;
+package org.apache.camel.component.netty.codec;
 
 import java.io.Serializable;
 import java.net.InetSocketAddress;
@@ -44,7 +44,7 @@ public class DatagramPacketObjectEncoder extends
             Serializable payload = (Serializable) msg.content();
             ByteBuf buf = ctx.alloc().buffer();
             delegateObjectEncoder.encode(ctx, payload, buf);
-            AddressedEnvelope<Object, InetSocketAddress> addressedEnvelop = 
+            AddressedEnvelope<Object, InetSocketAddress> addressedEnvelop =
                 new DefaultAddressedEnvelope<>(buf, msg.recipient(), msg.sender());
             out.add(addressedEnvelop);
         } else {
diff --git a/components/camel-netty/src/main/java/org/apache/camel/component/netty4/codec/DatagramPacketStringDecoder.java b/components/camel-netty/src/main/java/org/apache/camel/component/netty/codec/DatagramPacketStringDecoder.java
similarity index 97%
rename from components/camel-netty/src/main/java/org/apache/camel/component/netty4/codec/DatagramPacketStringDecoder.java
rename to components/camel-netty/src/main/java/org/apache/camel/component/netty/codec/DatagramPacketStringDecoder.java
index 2a7d2b7..142dd33 100644
--- a/components/camel-netty/src/main/java/org/apache/camel/component/netty4/codec/DatagramPacketStringDecoder.java
+++ b/components/camel-netty/src/main/java/org/apache/camel/component/netty/codec/DatagramPacketStringDecoder.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.codec;
+package org.apache.camel.component.netty.codec;
 
 import java.net.InetSocketAddress;
 import java.nio.charset.Charset;
@@ -57,7 +57,7 @@ public class DatagramPacketStringDecoder extends MessageToMessageDecoder<Address
     protected void decode(ChannelHandlerContext ctx, AddressedEnvelope<Object, InetSocketAddress> msg, List<Object> out) throws Exception {
         if (msg.content() instanceof ByteBuf) {
             ByteBuf payload = (ByteBuf)msg.content();
-            AddressedEnvelope<Object, InetSocketAddress> addressedEnvelop = 
+            AddressedEnvelope<Object, InetSocketAddress> addressedEnvelop =
                 new DefaultAddressedEnvelope<>(payload.toString(charset), msg.recipient(), msg.sender());
             out.add(addressedEnvelop);
         } else {
diff --git a/components/camel-netty/src/main/java/org/apache/camel/component/netty4/codec/DatagramPacketStringEncoder.java b/components/camel-netty/src/main/java/org/apache/camel/component/netty/codec/DatagramPacketStringEncoder.java
similarity index 97%
rename from components/camel-netty/src/main/java/org/apache/camel/component/netty4/codec/DatagramPacketStringEncoder.java
rename to components/camel-netty/src/main/java/org/apache/camel/component/netty/codec/DatagramPacketStringEncoder.java
index 737c889..159d11a 100644
--- a/components/camel-netty/src/main/java/org/apache/camel/component/netty4/codec/DatagramPacketStringEncoder.java
+++ b/components/camel-netty/src/main/java/org/apache/camel/component/netty/codec/DatagramPacketStringEncoder.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.codec;
+package org.apache.camel.component.netty.codec;
 
 import java.net.InetSocketAddress;
 import java.nio.CharBuffer;
@@ -63,7 +63,7 @@ public class DatagramPacketStringEncoder extends
             if (payload.length() == 0) {
                 return;
             }
-            AddressedEnvelope<Object, InetSocketAddress> addressedEnvelop = 
+            AddressedEnvelope<Object, InetSocketAddress> addressedEnvelop =
                 new DefaultAddressedEnvelope<>(ByteBufUtil.encodeString(ctx.alloc(), CharBuffer.wrap(payload), charset), msg.recipient(), msg.sender());
             out.add(addressedEnvelop);
         } else {
diff --git a/components/camel-netty/src/main/java/org/apache/camel/component/netty4/codec/DelegateByteArrayDecoder.java b/components/camel-netty/src/main/java/org/apache/camel/component/netty/codec/DelegateByteArrayDecoder.java
similarity index 96%
rename from components/camel-netty/src/main/java/org/apache/camel/component/netty4/codec/DelegateByteArrayDecoder.java
rename to components/camel-netty/src/main/java/org/apache/camel/component/netty/codec/DelegateByteArrayDecoder.java
index 3889b87..fbf1058 100644
--- a/components/camel-netty/src/main/java/org/apache/camel/component/netty4/codec/DelegateByteArrayDecoder.java
+++ b/components/camel-netty/src/main/java/org/apache/camel/component/netty/codec/DelegateByteArrayDecoder.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.codec;
+package org.apache.camel.component.netty.codec;
 
 import java.util.List;
 
diff --git a/components/camel-netty/src/main/java/org/apache/camel/component/netty4/codec/DelegateByteArrayEncoder.java b/components/camel-netty/src/main/java/org/apache/camel/component/netty/codec/DelegateByteArrayEncoder.java
similarity index 96%
rename from components/camel-netty/src/main/java/org/apache/camel/component/netty4/codec/DelegateByteArrayEncoder.java
rename to components/camel-netty/src/main/java/org/apache/camel/component/netty/codec/DelegateByteArrayEncoder.java
index ca35214..c92edc8 100644
--- a/components/camel-netty/src/main/java/org/apache/camel/component/netty4/codec/DelegateByteArrayEncoder.java
+++ b/components/camel-netty/src/main/java/org/apache/camel/component/netty/codec/DelegateByteArrayEncoder.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.codec;
+package org.apache.camel.component.netty.codec;
 
 import java.util.List;
 
diff --git a/components/camel-netty/src/main/java/org/apache/camel/component/netty4/codec/DelimiterBasedFrameDecoder.java b/components/camel-netty/src/main/java/org/apache/camel/component/netty/codec/DelimiterBasedFrameDecoder.java
similarity index 97%
rename from components/camel-netty/src/main/java/org/apache/camel/component/netty4/codec/DelimiterBasedFrameDecoder.java
rename to components/camel-netty/src/main/java/org/apache/camel/component/netty/codec/DelimiterBasedFrameDecoder.java
index 5d6d0e0..2d79f70 100644
--- a/components/camel-netty/src/main/java/org/apache/camel/component/netty4/codec/DelimiterBasedFrameDecoder.java
+++ b/components/camel-netty/src/main/java/org/apache/camel/component/netty/codec/DelimiterBasedFrameDecoder.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.codec;
+package org.apache.camel.component.netty.codec;
 
 import io.netty.buffer.ByteBuf;
 import io.netty.channel.ChannelHandlerContext;
@@ -31,7 +31,7 @@ public class DelimiterBasedFrameDecoder extends io.netty.handler.codec.Delimiter
             this.lineBasedFrameDecoder = null;
         }
     }
-    
+
     @Override
     public Object decode(ChannelHandlerContext ctx, ByteBuf in) throws Exception {
         if (lineBasedFrameDecoder != null) {
diff --git a/components/camel-netty/src/main/java/org/apache/camel/component/netty4/codec/LineBasedFrameDecoder.java b/components/camel-netty/src/main/java/org/apache/camel/component/netty/codec/LineBasedFrameDecoder.java
similarity index 96%
rename from components/camel-netty/src/main/java/org/apache/camel/component/netty4/codec/LineBasedFrameDecoder.java
rename to components/camel-netty/src/main/java/org/apache/camel/component/netty/codec/LineBasedFrameDecoder.java
index afbc9ef..05e6f83 100644
--- a/components/camel-netty/src/main/java/org/apache/camel/component/netty4/codec/LineBasedFrameDecoder.java
+++ b/components/camel-netty/src/main/java/org/apache/camel/component/netty/codec/LineBasedFrameDecoder.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.codec;
+package org.apache.camel.component.netty.codec;
 
 import io.netty.buffer.ByteBuf;
 import io.netty.channel.ChannelHandlerContext;
diff --git a/components/camel-netty/src/main/java/org/apache/camel/component/netty4/codec/ObjectDecoder.java b/components/camel-netty/src/main/java/org/apache/camel/component/netty/codec/ObjectDecoder.java
similarity index 95%
rename from components/camel-netty/src/main/java/org/apache/camel/component/netty4/codec/ObjectDecoder.java
rename to components/camel-netty/src/main/java/org/apache/camel/component/netty/codec/ObjectDecoder.java
index c7c3c24..db67a12 100644
--- a/components/camel-netty/src/main/java/org/apache/camel/component/netty4/codec/ObjectDecoder.java
+++ b/components/camel-netty/src/main/java/org/apache/camel/component/netty/codec/ObjectDecoder.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.codec;
+package org.apache.camel.component.netty.codec;
 
 import io.netty.buffer.ByteBuf;
 import io.netty.channel.ChannelHandlerContext;
@@ -29,8 +29,8 @@ public class ObjectDecoder extends io.netty.handler.codec.serialization.ObjectDe
     public ObjectDecoder(ClassResolver classResolver) {
         super(classResolver);
     }
-    
-    
+
+
     @Override
     public Object decode(ChannelHandlerContext ctx, ByteBuf in) throws Exception {
         return super.decode(ctx, in);
diff --git a/components/camel-netty/src/main/java/org/apache/camel/component/netty4/codec/ObjectEncoder.java b/components/camel-netty/src/main/java/org/apache/camel/component/netty/codec/ObjectEncoder.java
similarity index 96%
rename from components/camel-netty/src/main/java/org/apache/camel/component/netty4/codec/ObjectEncoder.java
rename to components/camel-netty/src/main/java/org/apache/camel/component/netty/codec/ObjectEncoder.java
index 8b3983f..21c2e15 100644
--- a/components/camel-netty/src/main/java/org/apache/camel/component/netty4/codec/ObjectEncoder.java
+++ b/components/camel-netty/src/main/java/org/apache/camel/component/netty/codec/ObjectEncoder.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.codec;
+package org.apache.camel.component.netty.codec;
 
 import java.io.Serializable;
 
diff --git a/components/camel-netty/src/main/java/org/apache/camel/component/netty4/handlers/ClientChannelHandler.java b/components/camel-netty/src/main/java/org/apache/camel/component/netty/handlers/ClientChannelHandler.java
similarity index 96%
rename from components/camel-netty/src/main/java/org/apache/camel/component/netty4/handlers/ClientChannelHandler.java
rename to components/camel-netty/src/main/java/org/apache/camel/component/netty/handlers/ClientChannelHandler.java
index 8293ae8..98e1733 100644
--- a/components/camel-netty/src/main/java/org/apache/camel/component/netty4/handlers/ClientChannelHandler.java
+++ b/components/camel-netty/src/main/java/org/apache/camel/component/netty/handlers/ClientChannelHandler.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.handlers;
+package org.apache.camel.component.netty.handlers;
 
 import io.netty.channel.ChannelHandler;
 import io.netty.channel.ChannelHandlerContext;
@@ -23,12 +23,12 @@ import org.apache.camel.AsyncCallback;
 import org.apache.camel.CamelExchangeException;
 import org.apache.camel.Exchange;
 import org.apache.camel.Message;
-import org.apache.camel.component.netty4.NettyCamelState;
-import org.apache.camel.component.netty4.NettyConfiguration;
-import org.apache.camel.component.netty4.NettyConstants;
-import org.apache.camel.component.netty4.NettyHelper;
-import org.apache.camel.component.netty4.NettyPayloadHelper;
-import org.apache.camel.component.netty4.NettyProducer;
+import org.apache.camel.component.netty.NettyCamelState;
+import org.apache.camel.component.netty.NettyConfiguration;
+import org.apache.camel.component.netty.NettyConstants;
+import org.apache.camel.component.netty.NettyHelper;
+import org.apache.camel.component.netty.NettyPayloadHelper;
+import org.apache.camel.component.netty.NettyProducer;
 import org.apache.camel.support.ExchangeHelper;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
@@ -54,7 +54,7 @@ public class ClientChannelHandler extends SimpleChannelInboundHandler<Object> {
         }
         // to keep track of open sockets
         producer.getAllChannels().add(ctx.channel());
-        
+
         super.channelActive(ctx);
     }
 
@@ -136,7 +136,7 @@ public class ClientChannelHandler extends SimpleChannelInboundHandler<Object> {
                 callback.done(false);
             }
         }
-        
+
         // make sure the event can be processed by other handlers
         super.channelInactive(ctx);
     }
diff --git a/components/camel-netty/src/main/java/org/apache/camel/component/netty4/handlers/ServerChannelHandler.java b/components/camel-netty/src/main/java/org/apache/camel/component/netty/handlers/ServerChannelHandler.java
similarity index 96%
rename from components/camel-netty/src/main/java/org/apache/camel/component/netty4/handlers/ServerChannelHandler.java
rename to components/camel-netty/src/main/java/org/apache/camel/component/netty/handlers/ServerChannelHandler.java
index 2baf415..8b370f3 100644
--- a/components/camel-netty/src/main/java/org/apache/camel/component/netty4/handlers/ServerChannelHandler.java
+++ b/components/camel-netty/src/main/java/org/apache/camel/component/netty/handlers/ServerChannelHandler.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.handlers;
+package org.apache.camel.component.netty.handlers;
 
 import java.net.SocketAddress;
 
@@ -24,10 +24,10 @@ import io.netty.channel.SimpleChannelInboundHandler;
 import org.apache.camel.AsyncCallback;
 import org.apache.camel.Exchange;
 import org.apache.camel.ExchangePattern;
-import org.apache.camel.component.netty4.NettyConstants;
-import org.apache.camel.component.netty4.NettyConsumer;
-import org.apache.camel.component.netty4.NettyHelper;
-import org.apache.camel.component.netty4.NettyPayloadHelper;
+import org.apache.camel.component.netty.NettyConstants;
+import org.apache.camel.component.netty.NettyConsumer;
+import org.apache.camel.component.netty.NettyHelper;
+import org.apache.camel.component.netty.NettyPayloadHelper;
 import org.apache.camel.spi.CamelLogger;
 import org.apache.camel.util.IOHelper;
 import org.slf4j.Logger;
@@ -54,7 +54,7 @@ public class ServerChannelHandler extends SimpleChannelInboundHandler<Object> {
         }
         // to keep track of open sockets
         consumer.getNettyServerBootstrapFactory().addChannel(ctx.channel());
-        
+
         super.channelActive(ctx);
     }
 
@@ -65,7 +65,7 @@ public class ServerChannelHandler extends SimpleChannelInboundHandler<Object> {
         }
         // to keep track of open sockets
         consumer.getNettyServerBootstrapFactory().removeChannel(ctx.channel());
-        
+
         super.channelInactive(ctx);
     }
 
diff --git a/components/camel-netty/src/main/java/org/apache/camel/component/netty4/handlers/ServerResponseFutureListener.java b/components/camel-netty/src/main/java/org/apache/camel/component/netty/handlers/ServerResponseFutureListener.java
similarity index 93%
rename from components/camel-netty/src/main/java/org/apache/camel/component/netty4/handlers/ServerResponseFutureListener.java
rename to components/camel-netty/src/main/java/org/apache/camel/component/netty/handlers/ServerResponseFutureListener.java
index 4d6fb23..7ca3e8f 100644
--- a/components/camel-netty/src/main/java/org/apache/camel/component/netty4/handlers/ServerResponseFutureListener.java
+++ b/components/camel-netty/src/main/java/org/apache/camel/component/netty/handlers/ServerResponseFutureListener.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.handlers;
+package org.apache.camel.component.netty.handlers;
 
 import java.net.SocketAddress;
 
@@ -22,9 +22,9 @@ import io.netty.channel.ChannelFuture;
 import io.netty.channel.ChannelFutureListener;
 import org.apache.camel.CamelExchangeException;
 import org.apache.camel.Exchange;
-import org.apache.camel.component.netty4.NettyConstants;
-import org.apache.camel.component.netty4.NettyConsumer;
-import org.apache.camel.component.netty4.NettyHelper;
+import org.apache.camel.component.netty.NettyConstants;
+import org.apache.camel.component.netty.NettyConsumer;
+import org.apache.camel.component.netty.NettyHelper;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
@@ -61,7 +61,7 @@ public class ServerResponseFutureListener implements ChannelFutureListener {
         } else {
             close = exchange.getIn().getHeader(NettyConstants.NETTY_CLOSE_CHANNEL_WHEN_COMPLETE, Boolean.class);
         }
-        
+
         // check the setting on the exchange property
         if (close == null) {
             close = exchange.getProperty(NettyConstants.NETTY_CLOSE_CHANNEL_WHEN_COMPLETE, Boolean.class);
diff --git a/components/camel-netty/src/main/java/org/apache/camel/component/netty4/ssl/SSLEngineFactory.java b/components/camel-netty/src/main/java/org/apache/camel/component/netty/ssl/SSLEngineFactory.java
similarity index 98%
rename from components/camel-netty/src/main/java/org/apache/camel/component/netty4/ssl/SSLEngineFactory.java
rename to components/camel-netty/src/main/java/org/apache/camel/component/netty/ssl/SSLEngineFactory.java
index 0f40695..0d5c336 100644
--- a/components/camel-netty/src/main/java/org/apache/camel/component/netty4/ssl/SSLEngineFactory.java
+++ b/components/camel-netty/src/main/java/org/apache/camel/component/netty/ssl/SSLEngineFactory.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.ssl;
+package org.apache.camel.component.netty.ssl;
 
 import java.io.InputStream;
 import java.security.KeyStore;
@@ -82,5 +82,5 @@ public final class SSLEngineFactory {
         clientEngine.setUseClientMode(true);
         return clientEngine;
     }
-    
+
 }
diff --git a/components/camel-netty/src/main/java/org/apache/camel/component/netty4/util/SubnetUtils.java b/components/camel-netty/src/main/java/org/apache/camel/component/netty/util/SubnetUtils.java
similarity index 95%
rename from components/camel-netty/src/main/java/org/apache/camel/component/netty4/util/SubnetUtils.java
rename to components/camel-netty/src/main/java/org/apache/camel/component/netty/util/SubnetUtils.java
index 252f9bd..d6ac546 100644
--- a/components/camel-netty/src/main/java/org/apache/camel/component/netty4/util/SubnetUtils.java
+++ b/components/camel-netty/src/main/java/org/apache/camel/component/netty/util/SubnetUtils.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.util;
+package org.apache.camel.component.netty.util;
 
 import java.util.regex.Matcher;
 import java.util.regex.Pattern;
@@ -22,7 +22,7 @@ import java.util.regex.Pattern;
 /**
  * A class that performs some subnet calculations given a network address and a subnet mask.
  * @see "http://www.faqs.org/rfcs/rfc1519.html"
- * This class is copied from apache common net 
+ * This class is copied from apache common net
  */
 public class SubnetUtils {
 
@@ -93,28 +93,28 @@ public class SubnetUtils {
         /* Mask to convert unsigned int to a long (i.e. keep 32 bits) */
         private static final long UNSIGNED_INT_MASK = 0x0FFFFFFFFL;
 
-        private SubnetInfo() { 
+        private SubnetInfo() {
         }
 
         private int netmask() {
-            return netmask; 
+            return netmask;
         }
         private int network() {
-            return network; 
+            return network;
         }
         private int address() {
             return address;
         }
         private int broadcast() {
-            return broadcast; 
+            return broadcast;
         }
 
         // long versions of the values (as unsigned int) which are more suitable for range checking
-        private long networkLong()  { 
-            return network &  UNSIGNED_INT_MASK; 
+        private long networkLong()  {
+            return network &  UNSIGNED_INT_MASK;
         }
-        private long broadcastLong() { 
-            return broadcast &  UNSIGNED_INT_MASK; 
+        private long broadcastLong() {
+            return broadcast &  UNSIGNED_INT_MASK;
         }
 
         private int low() {
@@ -123,7 +123,7 @@ public class SubnetUtils {
         }
 
         private int high() {
-            return isInclusiveHostCount() ? broadcast() 
+            return isInclusiveHostCount() ? broadcast()
                 : broadcastLong() - networkLong() > 1 ? broadcast() - 1 : 0;
         }
 
@@ -262,8 +262,8 @@ public class SubnetUtils {
      * Return a {@link SubnetInfo} instance that contains subnet-specific statistics
      * @return new instance
      */
-    public final SubnetInfo getInfo() { 
-        return new SubnetInfo(); 
+    public final SubnetInfo getInfo() {
+        return new SubnetInfo();
     }
 
     /*
diff --git a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/BaseNettyTest.java b/components/camel-netty/src/test/java/org/apache/camel/component/netty/BaseNettyTest.java
similarity index 99%
rename from components/camel-netty/src/test/java/org/apache/camel/component/netty4/BaseNettyTest.java
rename to components/camel-netty/src/test/java/org/apache/camel/component/netty/BaseNettyTest.java
index e9feb3b..a4d8525 100644
--- a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/BaseNettyTest.java
+++ b/components/camel-netty/src/test/java/org/apache/camel/component/netty/BaseNettyTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4;
+package org.apache.camel.component.netty;
 
 import java.io.File;
 import java.io.FileOutputStream;
diff --git a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/DatagramPacketByteArrayCodecTest.java b/components/camel-netty/src/test/java/org/apache/camel/component/netty/DatagramPacketByteArrayCodecTest.java
similarity index 98%
rename from components/camel-netty/src/test/java/org/apache/camel/component/netty4/DatagramPacketByteArrayCodecTest.java
rename to components/camel-netty/src/test/java/org/apache/camel/component/netty/DatagramPacketByteArrayCodecTest.java
index cb16699..3359ae5 100644
--- a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/DatagramPacketByteArrayCodecTest.java
+++ b/components/camel-netty/src/test/java/org/apache/camel/component/netty/DatagramPacketByteArrayCodecTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4;
+package org.apache.camel.component.netty;
 
 import java.net.InetSocketAddress;
 
diff --git a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/LogCaptureAppender.java b/components/camel-netty/src/test/java/org/apache/camel/component/netty/LogCaptureAppender.java
similarity index 98%
rename from components/camel-netty/src/test/java/org/apache/camel/component/netty4/LogCaptureAppender.java
rename to components/camel-netty/src/test/java/org/apache/camel/component/netty/LogCaptureAppender.java
index 2f6bef3..5e3d777 100644
--- a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/LogCaptureAppender.java
+++ b/components/camel-netty/src/test/java/org/apache/camel/component/netty/LogCaptureAppender.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4;
+package org.apache.camel.component.netty;
 
 import java.io.Serializable;
 import java.util.ArrayDeque;
diff --git a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/LogCaptureTest.java b/components/camel-netty/src/test/java/org/apache/camel/component/netty/LogCaptureTest.java
similarity index 96%
rename from components/camel-netty/src/test/java/org/apache/camel/component/netty4/LogCaptureTest.java
rename to components/camel-netty/src/test/java/org/apache/camel/component/netty/LogCaptureTest.java
index b192f9e..b2ab4cc 100644
--- a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/LogCaptureTest.java
+++ b/components/camel-netty/src/test/java/org/apache/camel/component/netty/LogCaptureTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4;
+package org.apache.camel.component.netty;
 
 import io.netty.util.ResourceLeakDetector;
 import io.netty.util.internal.logging.InternalLoggerFactory;
diff --git a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/MultipleCodecsSpringTest.java b/components/camel-netty/src/test/java/org/apache/camel/component/netty/MultipleCodecsSpringTest.java
similarity index 94%
rename from components/camel-netty/src/test/java/org/apache/camel/component/netty4/MultipleCodecsSpringTest.java
rename to components/camel-netty/src/test/java/org/apache/camel/component/netty/MultipleCodecsSpringTest.java
index a9bb604..cbb1291 100644
--- a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/MultipleCodecsSpringTest.java
+++ b/components/camel-netty/src/test/java/org/apache/camel/component/netty/MultipleCodecsSpringTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4;
+package org.apache.camel.component.netty;
 
 import org.apache.camel.component.mock.MockEndpoint;
 import org.apache.camel.test.spring.CamelSpringTestSupport;
@@ -26,7 +26,7 @@ public class MultipleCodecsSpringTest extends CamelSpringTestSupport {
 
     @Override
     protected AbstractXmlApplicationContext createApplicationContext() {
-        return new ClassPathXmlApplicationContext("/org/apache/camel/component/netty4/multiple-codecs.xml");
+        return new ClassPathXmlApplicationContext("/org/apache/camel/component/netty/multiple-codecs.xml");
     }
 
     @Test
diff --git a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/MultipleCodecsTest.java b/components/camel-netty/src/test/java/org/apache/camel/component/netty/MultipleCodecsTest.java
similarity index 98%
rename from components/camel-netty/src/test/java/org/apache/camel/component/netty4/MultipleCodecsTest.java
rename to components/camel-netty/src/test/java/org/apache/camel/component/netty/MultipleCodecsTest.java
index 8cae9ff..1d52a81 100644
--- a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/MultipleCodecsTest.java
+++ b/components/camel-netty/src/test/java/org/apache/camel/component/netty/MultipleCodecsTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4;
+package org.apache.camel.component.netty;
 
 import java.util.ArrayList;
 import java.util.List;
diff --git a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/MyCustomCodec.java b/components/camel-netty/src/test/java/org/apache/camel/component/netty/MyCustomCodec.java
similarity index 98%
rename from components/camel-netty/src/test/java/org/apache/camel/component/netty4/MyCustomCodec.java
rename to components/camel-netty/src/test/java/org/apache/camel/component/netty/MyCustomCodec.java
index cf39526..5d23ed8 100644
--- a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/MyCustomCodec.java
+++ b/components/camel-netty/src/test/java/org/apache/camel/component/netty/MyCustomCodec.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4;
+package org.apache.camel.component.netty;
 
 import java.util.List;
 
@@ -27,9 +27,9 @@ import io.netty.handler.codec.MessageToMessageDecoder;
 import io.netty.handler.codec.MessageToMessageEncoder;
 
 public final class MyCustomCodec {
-    
+
     private static ByteBuf nullDelimiter = Unpooled.wrappedBuffer(new byte[]{0});
-    
+
     private MyCustomCodec() {
         // Helper class
     }
diff --git a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/Netty2978IssueTest.java b/components/camel-netty/src/test/java/org/apache/camel/component/netty/Netty2978IssueTest.java
similarity index 99%
rename from components/camel-netty/src/test/java/org/apache/camel/component/netty4/Netty2978IssueTest.java
rename to components/camel-netty/src/test/java/org/apache/camel/component/netty/Netty2978IssueTest.java
index 49409ab..f2c5049 100644
--- a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/Netty2978IssueTest.java
+++ b/components/camel-netty/src/test/java/org/apache/camel/component/netty/Netty2978IssueTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4;
+package org.apache.camel.component.netty;
 
 import java.util.ArrayList;
 import java.util.HashSet;
diff --git a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyBacklogTest.java b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyBacklogTest.java
similarity index 93%
rename from components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyBacklogTest.java
rename to components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyBacklogTest.java
index 9fb5479..def966c 100644
--- a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyBacklogTest.java
+++ b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyBacklogTest.java
@@ -14,14 +14,14 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4;
+package org.apache.camel.component.netty;
 
 import org.apache.camel.Exchange;
 import org.apache.camel.Processor;
 import org.apache.camel.builder.RouteBuilder;
 
 public class NettyBacklogTest extends NettyTCPSyncTest {
-    
+
     @Override
     protected RouteBuilder createRouteBuilder() throws Exception {
         return new RouteBuilder() {
@@ -36,9 +36,9 @@ public class NettyBacklogTest extends NettyTCPSyncTest {
                                 exchange.getOut().setBody(poetry);
                                 return;
                             }
-                            exchange.getOut().setBody("When You Go Home, Tell Them Of Us And Say, For Your Tomorrow, We Gave Our Today.");                           
+                            exchange.getOut().setBody("When You Go Home, Tell Them Of Us And Say, For Your Tomorrow, We Gave Our Today.");
                         }
-                    });                
+                    });
             }
         };
     }
diff --git a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyComponentWithConfigurationTest.java b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyComponentWithConfigurationTest.java
similarity index 98%
rename from components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyComponentWithConfigurationTest.java
rename to components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyComponentWithConfigurationTest.java
index c3e6357..f321fcb 100644
--- a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyComponentWithConfigurationTest.java
+++ b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyComponentWithConfigurationTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4;
+package org.apache.camel.component.netty;
 
 import org.apache.camel.test.junit4.CamelTestSupport;
 import org.junit.Test;
@@ -36,7 +36,7 @@ public class NettyComponentWithConfigurationTest extends CamelTestSupport {
         // should not be same
         assertNotSame(e1, e2);
         assertNotSame(e1.getConfiguration(), e2.getConfiguration());
-        
+
         assertEquals(0, e2.getConfiguration().getReceiveBufferSizePredictor());
         e2.getConfiguration().setReceiveBufferSizePredictor(1024);
         assertEquals(1024, e2.getConfiguration().getReceiveBufferSizePredictor());
diff --git a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyConcurrentTest.java b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyConcurrentTest.java
similarity index 98%
rename from components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyConcurrentTest.java
rename to components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyConcurrentTest.java
index eaf1434..ffc9dfb 100644
--- a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyConcurrentTest.java
+++ b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyConcurrentTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4;
+package org.apache.camel.component.netty;
 
 import java.util.HashMap;
 import java.util.HashSet;
diff --git a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyConsumerClientModeReconnectTest.java b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyConsumerClientModeReconnectTest.java
similarity index 99%
rename from components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyConsumerClientModeReconnectTest.java
rename to components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyConsumerClientModeReconnectTest.java
index 256c9c2..9651079 100644
--- a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyConsumerClientModeReconnectTest.java
+++ b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyConsumerClientModeReconnectTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4;
+package org.apache.camel.component.netty;
 
 import io.netty.bootstrap.ServerBootstrap;
 import io.netty.channel.Channel;
diff --git a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyConsumerClientModeReuseChannelTest.java b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyConsumerClientModeReuseChannelTest.java
similarity index 99%
rename from components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyConsumerClientModeReuseChannelTest.java
rename to components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyConsumerClientModeReuseChannelTest.java
index 6fb169f..b45ddf1 100644
--- a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyConsumerClientModeReuseChannelTest.java
+++ b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyConsumerClientModeReuseChannelTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4;
+package org.apache.camel.component.netty;
 
 import java.util.ArrayList;
 import java.util.List;
diff --git a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyConsumerClientModeTest.java b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyConsumerClientModeTest.java
similarity index 97%
rename from components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyConsumerClientModeTest.java
rename to components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyConsumerClientModeTest.java
index b38f046..130e29a 100644
--- a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyConsumerClientModeTest.java
+++ b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyConsumerClientModeTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4;
+package org.apache.camel.component.netty;
 
 
 import io.netty.bootstrap.ServerBootstrap;
@@ -40,13 +40,13 @@ import org.junit.Test;
 
 public class NettyConsumerClientModeTest extends BaseNettyTest {
     private MyServer server;
-    
-   
+
+
     public void startNettyServer() throws Exception {
         server = new MyServer(getPort());
         server.start();
     }
-   
+
     public void shutdownServer() {
         if (server != null) {
             server.shutdown();
@@ -63,9 +63,9 @@ public class NettyConsumerClientModeTest extends BaseNettyTest {
         } finally {
             shutdownServer();
         }
-        
+
     }
-      
+
     @Override
     protected RouteBuilder createRouteBuilder() throws Exception {
         return new RouteBuilder() {
@@ -81,14 +81,14 @@ public class NettyConsumerClientModeTest extends BaseNettyTest {
             }
         };
     }
-    
+
     private static class MyServer {
         private int port;
         private ServerBootstrap bootstrap;
         private Channel channel;
         private EventLoopGroup bossGroup;
         private EventLoopGroup workerGroup;
-        
+
         MyServer(int port) {
             this.port = port;
         }
@@ -105,17 +105,17 @@ public class NettyConsumerClientModeTest extends BaseNettyTest {
             channel = cf.channel();
 
         }
-        
+
         public void shutdown() {
             channel.disconnect();
             bossGroup.shutdownGracefully();
             workerGroup.shutdownGracefully();
         }
-        
+
     }
-    
+
     private static class ServerHandler extends SimpleChannelInboundHandler<String> {
-        
+
         @Override
         public void channelActive(ChannelHandlerContext ctx) throws Exception {
             ctx.write("Willem\r\n");
@@ -131,13 +131,13 @@ public class NettyConsumerClientModeTest extends BaseNettyTest {
         protected void channelRead0(ChannelHandlerContext ctx, String msg) throws Exception {
             // Do nothing here
         }
-        
+
         @Override
         public void channelReadComplete(ChannelHandlerContext ctx) throws Exception {
             ctx.flush();
         }
     }
-    
+
     private static class ServerInitializer extends ChannelInitializer<SocketChannel> {
         private static final StringDecoder DECODER = new StringDecoder();
         private static final StringEncoder ENCODER = new StringEncoder();
@@ -158,5 +158,5 @@ public class NettyConsumerClientModeTest extends BaseNettyTest {
             pipeline.addLast("handler", SERVERHANDLER);
         }
     }
-    
+
 }
diff --git a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyConverterTest.java b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyConverterTest.java
similarity index 97%
rename from components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyConverterTest.java
rename to components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyConverterTest.java
index cf7a659..b538136 100644
--- a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyConverterTest.java
+++ b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyConverterTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4;
+package org.apache.camel.component.netty;
 
 import io.netty.buffer.ByteBuf;
 import io.netty.buffer.PooledByteBufAllocator;
diff --git a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyCustomCodecTest.java b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyCustomCodecTest.java
similarity index 98%
rename from components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyCustomCodecTest.java
rename to components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyCustomCodecTest.java
index fcd286d..a69458e 100644
--- a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyCustomCodecTest.java
+++ b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyCustomCodecTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4;
+package org.apache.camel.component.netty;
 
 import io.netty.channel.ChannelHandler;
 
diff --git a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyCustomCorrelationManagerTest.java b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyCustomCorrelationManagerTest.java
similarity index 99%
rename from components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyCustomCorrelationManagerTest.java
rename to components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyCustomCorrelationManagerTest.java
index 2342126..07ae2ae 100644
--- a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyCustomCorrelationManagerTest.java
+++ b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyCustomCorrelationManagerTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4;
+package org.apache.camel.component.netty;
 
 import io.netty.channel.Channel;
 import io.netty.channel.ChannelHandlerContext;
diff --git a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyCustomPipelineFactoryAsynchTest.java b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyCustomPipelineFactoryAsynchTest.java
similarity index 96%
rename from components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyCustomPipelineFactoryAsynchTest.java
rename to components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyCustomPipelineFactoryAsynchTest.java
index 3b8bb7d..6f8a5b0 100644
--- a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyCustomPipelineFactoryAsynchTest.java
+++ b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyCustomPipelineFactoryAsynchTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4;
+package org.apache.camel.component.netty;
 
 import io.netty.channel.Channel;
 import io.netty.channel.ChannelPipeline;
@@ -28,8 +28,8 @@ import org.apache.camel.BindToRegistry;
 import org.apache.camel.Exchange;
 import org.apache.camel.Processor;
 import org.apache.camel.builder.RouteBuilder;
-import org.apache.camel.component.netty4.handlers.ClientChannelHandler;
-import org.apache.camel.component.netty4.handlers.ServerChannelHandler;
+import org.apache.camel.component.netty.handlers.ClientChannelHandler;
+import org.apache.camel.component.netty.handlers.ServerChannelHandler;
 import org.junit.Test;
 
 public class NettyCustomPipelineFactoryAsynchTest extends BaseNettyTest {
diff --git a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyCustomPipelineFactorySynchTest.java b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyCustomPipelineFactorySynchTest.java
similarity index 96%
rename from components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyCustomPipelineFactorySynchTest.java
rename to components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyCustomPipelineFactorySynchTest.java
index 195261a..c465c41 100644
--- a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyCustomPipelineFactorySynchTest.java
+++ b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyCustomPipelineFactorySynchTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4;
+package org.apache.camel.component.netty;
 
 import io.netty.channel.Channel;
 import io.netty.channel.ChannelPipeline;
@@ -28,8 +28,8 @@ import org.apache.camel.BindToRegistry;
 import org.apache.camel.Exchange;
 import org.apache.camel.Processor;
 import org.apache.camel.builder.RouteBuilder;
-import org.apache.camel.component.netty4.handlers.ClientChannelHandler;
-import org.apache.camel.component.netty4.handlers.ServerChannelHandler;
+import org.apache.camel.component.netty.handlers.ClientChannelHandler;
+import org.apache.camel.component.netty.handlers.ServerChannelHandler;
 import org.junit.Test;
 
 public class NettyCustomPipelineFactorySynchTest extends BaseNettyTest {
diff --git a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyDisconnectTest.java b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyDisconnectTest.java
similarity index 97%
rename from components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyDisconnectTest.java
rename to components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyDisconnectTest.java
index 86af6a5..68f577b 100644
--- a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyDisconnectTest.java
+++ b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyDisconnectTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4;
+package org.apache.camel.component.netty;
 
 import org.apache.camel.Exchange;
 import org.apache.camel.Processor;
diff --git a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyFileTcpTest.java b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyFileTcpTest.java
similarity index 97%
rename from components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyFileTcpTest.java
rename to components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyFileTcpTest.java
index f179c36..5b5c8c9 100644
--- a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyFileTcpTest.java
+++ b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyFileTcpTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4;
+package org.apache.camel.component.netty;
 
 import org.apache.camel.builder.RouteBuilder;
 import org.apache.camel.component.mock.MockEndpoint;
diff --git a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyGlobalSSLContextParametersTest.java b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyGlobalSSLContextParametersTest.java
similarity index 97%
rename from components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyGlobalSSLContextParametersTest.java
rename to components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyGlobalSSLContextParametersTest.java
index 54d131b..0895d62 100644
--- a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyGlobalSSLContextParametersTest.java
+++ b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyGlobalSSLContextParametersTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4;
+package org.apache.camel.component.netty;
 
 import org.apache.camel.CamelContext;
 import org.apache.camel.Exchange;
@@ -59,7 +59,7 @@ public class NettyGlobalSSLContextParametersTest extends BaseNettyTest {
         ((SSLContextParametersAware) context.getComponent("netty")).setUseGlobalSslContextParameters(true);
         return context;
     }
-    
+
     @Override
     public boolean isUseRouteBuilder() {
         return false;
@@ -77,7 +77,7 @@ public class NettyGlobalSSLContextParametersTest extends BaseNettyTest {
                 from("netty:tcp://localhost:{{port}}?sync=true&ssl=true")
                     .process(new Processor() {
                         public void process(Exchange exchange) throws Exception {
-                            exchange.getOut().setBody("When You Go Home, Tell Them Of Us And Say, For Your Tomorrow, We Gave Our Today.");                           
+                            exchange.getOut().setBody("When You Go Home, Tell Them Of Us And Say, For Your Tomorrow, We Gave Our Today.");
                         }
                     });
             }
diff --git a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyInOutCloseChannelWhenCompleteTest.java b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyInOutCloseChannelWhenCompleteTest.java
similarity index 97%
rename from components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyInOutCloseChannelWhenCompleteTest.java
rename to components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyInOutCloseChannelWhenCompleteTest.java
index 0924c3d..dfb603e 100644
--- a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyInOutCloseChannelWhenCompleteTest.java
+++ b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyInOutCloseChannelWhenCompleteTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4;
+package org.apache.camel.component.netty;
 
 import org.apache.camel.Exchange;
 import org.apache.camel.Processor;
diff --git a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyInOutFromSedaTest.java b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyInOutFromSedaTest.java
similarity index 97%
rename from components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyInOutFromSedaTest.java
rename to components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyInOutFromSedaTest.java
index 1541acd..627bd01 100644
--- a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyInOutFromSedaTest.java
+++ b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyInOutFromSedaTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4;
+package org.apache.camel.component.netty;
 
 import org.apache.camel.builder.RouteBuilder;
 import org.apache.camel.component.mock.MockEndpoint;
diff --git a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyInOutWithForcedNoResponseTest.java b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyInOutWithForcedNoResponseTest.java
similarity index 97%
rename from components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyInOutWithForcedNoResponseTest.java
rename to components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyInOutWithForcedNoResponseTest.java
index 17a6ac9..55aa72c 100644
--- a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyInOutWithForcedNoResponseTest.java
+++ b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyInOutWithForcedNoResponseTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4;
+package org.apache.camel.component.netty;
 
 import org.apache.camel.RuntimeCamelException;
 import org.apache.camel.builder.RouteBuilder;
diff --git a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyManualEndpointTest.java b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyManualEndpointTest.java
similarity index 98%
rename from components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyManualEndpointTest.java
rename to components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyManualEndpointTest.java
index 9f8a0fe..d8c4757 100644
--- a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyManualEndpointTest.java
+++ b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyManualEndpointTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4;
+package org.apache.camel.component.netty;
 
 import java.util.ArrayList;
 import java.util.List;
diff --git a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyMultipleSimultaneousClientsTest.java b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyMultipleSimultaneousClientsTest.java
similarity index 98%
rename from components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyMultipleSimultaneousClientsTest.java
rename to components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyMultipleSimultaneousClientsTest.java
index d379ee3..ca52d4c 100644
--- a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyMultipleSimultaneousClientsTest.java
+++ b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyMultipleSimultaneousClientsTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4;
+package org.apache.camel.component.netty;
 
 import java.util.Arrays;
 import java.util.concurrent.Callable;
diff --git a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyOptionTest.java b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyOptionTest.java
similarity index 93%
rename from components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyOptionTest.java
rename to components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyOptionTest.java
index 10df704..2f20c66 100644
--- a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyOptionTest.java
+++ b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyOptionTest.java
@@ -14,14 +14,14 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4;
+package org.apache.camel.component.netty;
 
 import org.apache.camel.Exchange;
 import org.apache.camel.Processor;
 import org.apache.camel.builder.RouteBuilder;
 
 public class NettyOptionTest extends NettyTCPSyncTest {
-    
+
     @Override
     protected RouteBuilder createRouteBuilder() throws Exception {
         return new RouteBuilder() {
@@ -36,9 +36,9 @@ public class NettyOptionTest extends NettyTCPSyncTest {
                                 exchange.getOut().setBody(poetry);
                                 return;
                             }
-                            exchange.getOut().setBody("When You Go Home, Tell Them Of Us And Say, For Your Tomorrow, We Gave Our Today.");                           
+                            exchange.getOut().setBody("When You Go Home, Tell Them Of Us And Say, For Your Tomorrow, We Gave Our Today.");
                         }
-                    });                
+                    });
             }
         };
     }
diff --git a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyProducerAsyncEndpointTest.java b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyProducerAsyncEndpointTest.java
similarity index 98%
rename from components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyProducerAsyncEndpointTest.java
rename to components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyProducerAsyncEndpointTest.java
index c13c6a2..6d3f5a4 100644
--- a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyProducerAsyncEndpointTest.java
+++ b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyProducerAsyncEndpointTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4;
+package org.apache.camel.component.netty;
 
 import org.apache.camel.Exchange;
 import org.apache.camel.Processor;
diff --git a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyProducerHangTest.java b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyProducerHangTest.java
similarity index 98%
rename from components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyProducerHangTest.java
rename to components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyProducerHangTest.java
index 9426d48..2d5f9df 100644
--- a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyProducerHangTest.java
+++ b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyProducerHangTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4;
+package org.apache.camel.component.netty;
 
 import java.io.IOException;
 import java.io.InputStream;
@@ -52,7 +52,7 @@ public class NettyProducerHangTest extends CamelTestSupport {
         } catch (Exception e) {
             assertStringContains(e.getCause().getMessage(), "No response received from remote server");
         }
-        
+
         String response2 = template.requestBody("netty:tcp://localhost:" + PORT + "?textline=true&sync=true", "request3", String.class);
         log.info("Received 2nd response <" + response2 + ">");
 
@@ -78,7 +78,7 @@ public class NettyProducerHangTest extends CamelTestSupport {
 
             // reply to the first message
             os.write("response\n".getBytes());
-            
+
             // read second message
             is.read(buf);
 
@@ -90,4 +90,4 @@ public class NettyProducerHangTest extends CamelTestSupport {
         log.info("Close socket");
     }
 
-}
\ No newline at end of file
+}
diff --git a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyProducerPoolDisabledTest.java b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyProducerPoolDisabledTest.java
similarity index 97%
rename from components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyProducerPoolDisabledTest.java
rename to components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyProducerPoolDisabledTest.java
index 29893fb..51565e2 100644
--- a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyProducerPoolDisabledTest.java
+++ b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyProducerPoolDisabledTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4;
+package org.apache.camel.component.netty;
 
 import org.apache.camel.builder.RouteBuilder;
 import org.junit.Test;
@@ -44,4 +44,4 @@ public class NettyProducerPoolDisabledTest extends BaseNettyTest {
             }
         };
     }
-}
\ No newline at end of file
+}
diff --git a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyProxyTest.java b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyProxyTest.java
similarity index 98%
rename from components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyProxyTest.java
rename to components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyProxyTest.java
index 70855df..1033fb8 100644
--- a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyProxyTest.java
+++ b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyProxyTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4;
+package org.apache.camel.component.netty;
 
 import org.apache.camel.builder.RouteBuilder;
 import org.junit.Test;
diff --git a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyRedeliveryTest.java b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyRedeliveryTest.java
similarity index 99%
rename from components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyRedeliveryTest.java
rename to components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyRedeliveryTest.java
index 183b7a7..5ee7fcd 100644
--- a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyRedeliveryTest.java
+++ b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyRedeliveryTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4;
+package org.apache.camel.component.netty;
 import java.io.IOException;
 import java.lang.reflect.InvocationHandler;
 import java.lang.reflect.Method;
diff --git a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyRequestTimeoutIssueTest.java b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyRequestTimeoutIssueTest.java
similarity index 97%
rename from components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyRequestTimeoutIssueTest.java
rename to components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyRequestTimeoutIssueTest.java
index 0b5744e..2c796b10 100644
--- a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyRequestTimeoutIssueTest.java
+++ b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyRequestTimeoutIssueTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4;
+package org.apache.camel.component.netty;
 
 import org.apache.camel.builder.RouteBuilder;
 import org.apache.camel.test.junit4.CamelTestSupport;
diff --git a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyRequestTimeoutTest.java b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyRequestTimeoutTest.java
similarity index 98%
rename from components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyRequestTimeoutTest.java
rename to components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyRequestTimeoutTest.java
index 50f5f12..4ad74c2 100644
--- a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyRequestTimeoutTest.java
+++ b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyRequestTimeoutTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4;
+package org.apache.camel.component.netty;
 
 import io.netty.handler.timeout.ReadTimeoutException;
 import org.apache.camel.CamelExecutionException;
@@ -52,7 +52,7 @@ public class NettyRequestTimeoutTest extends BaseNettyTest {
             assertNotNull(cause);
         }
     }
-    
+
     @Test
     public void testRequestTimeoutAndOk() throws Exception {
         try {
diff --git a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyReuseChannelTest.java b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyReuseChannelTest.java
similarity index 98%
rename from components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyReuseChannelTest.java
rename to components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyReuseChannelTest.java
index e6ab685..d2a100b 100644
--- a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyReuseChannelTest.java
+++ b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyReuseChannelTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4;
+package org.apache.camel.component.netty;
 
 import java.util.ArrayList;
 import java.util.List;
diff --git a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyReuseConnectionTest.java b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyReuseConnectionTest.java
similarity index 97%
rename from components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyReuseConnectionTest.java
rename to components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyReuseConnectionTest.java
index 5c0b4a8..e4eef57 100644
--- a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyReuseConnectionTest.java
+++ b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyReuseConnectionTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4;
+package org.apache.camel.component.netty;
 
 import org.apache.camel.builder.RouteBuilder;
 import org.junit.Test;
diff --git a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettySSLClasspathTest.java b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettySSLClasspathTest.java
similarity index 96%
rename from components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettySSLClasspathTest.java
rename to components/camel-netty/src/test/java/org/apache/camel/component/netty/NettySSLClasspathTest.java
index d8943ae..7913ded 100644
--- a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettySSLClasspathTest.java
+++ b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettySSLClasspathTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4;
+package org.apache.camel.component.netty;
 
 import org.apache.camel.Exchange;
 import org.apache.camel.Processor;
@@ -40,7 +40,7 @@ public class NettySSLClasspathTest extends BaseNettyTest {
                 from("netty:tcp://localhost:{{port}}?sync=true&ssl=true&passphrase=changeit&keyStoreResource=classpath:keystore.jks&trustStoreResource=classpath:keystore.jks")
                     .process(new Processor() {
                         public void process(Exchange exchange) throws Exception {
-                            exchange.getOut().setBody("When You Go Home, Tell Them Of Us And Say, For Your Tomorrow, We Gave Our Today.");                           
+                            exchange.getOut().setBody("When You Go Home, Tell Them Of Us And Say, For Your Tomorrow, We Gave Our Today.");
                         }
                     });
             }
diff --git a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettySSLClientCertHeadersTest.java b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettySSLClientCertHeadersTest.java
similarity index 98%
rename from components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettySSLClientCertHeadersTest.java
rename to components/camel-netty/src/test/java/org/apache/camel/component/netty/NettySSLClientCertHeadersTest.java
index af37080..8d1fdc6 100644
--- a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettySSLClientCertHeadersTest.java
+++ b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettySSLClientCertHeadersTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4;
+package org.apache.camel.component.netty;
 
 import java.io.File;
 
diff --git a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettySSLConsumerClientModeTest.java b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettySSLConsumerClientModeTest.java
similarity index 99%
rename from components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettySSLConsumerClientModeTest.java
rename to components/camel-netty/src/test/java/org/apache/camel/component/netty/NettySSLConsumerClientModeTest.java
index 91c0241..9a70ab1 100644
--- a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettySSLConsumerClientModeTest.java
+++ b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettySSLConsumerClientModeTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4;
+package org.apache.camel.component.netty;
 
 import java.io.File;
 import java.io.FileInputStream;
diff --git a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettySSLContextParametersTest.java b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettySSLContextParametersTest.java
similarity index 98%
rename from components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettySSLContextParametersTest.java
rename to components/camel-netty/src/test/java/org/apache/camel/component/netty/NettySSLContextParametersTest.java
index 36f40fb..e94762d 100644
--- a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettySSLContextParametersTest.java
+++ b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettySSLContextParametersTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4;
+package org.apache.camel.component.netty;
 
 import org.apache.camel.BindToRegistry;
 import org.apache.camel.Exchange;
diff --git a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettySSLPassphaseBeanTest.java b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettySSLPassphaseBeanTest.java
similarity index 98%
rename from components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettySSLPassphaseBeanTest.java
rename to components/camel-netty/src/test/java/org/apache/camel/component/netty/NettySSLPassphaseBeanTest.java
index 5e71966..8d1f588 100644
--- a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettySSLPassphaseBeanTest.java
+++ b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettySSLPassphaseBeanTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4;
+package org.apache.camel.component.netty;
 
 import org.apache.camel.BindToRegistry;
 import org.apache.camel.Exchange;
diff --git a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettySSLTest.java b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettySSLTest.java
similarity index 98%
rename from components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettySSLTest.java
rename to components/camel-netty/src/test/java/org/apache/camel/component/netty/NettySSLTest.java
index 6ad8f80..d9cc1b8 100644
--- a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettySSLTest.java
+++ b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettySSLTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4;
+package org.apache.camel.component.netty;
 
 import java.io.File;
 import java.security.Principal;
diff --git a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettySingleCodecTest.java b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettySingleCodecTest.java
similarity index 98%
rename from components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettySingleCodecTest.java
rename to components/camel-netty/src/test/java/org/apache/camel/component/netty/NettySingleCodecTest.java
index c155699..534d4fa 100644
--- a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettySingleCodecTest.java
+++ b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettySingleCodecTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4;
+package org.apache.camel.component.netty;
 
 import java.util.concurrent.TimeUnit;
 
diff --git a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettySuspendResumeTest.java b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettySuspendResumeTest.java
similarity index 97%
rename from components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettySuspendResumeTest.java
rename to components/camel-netty/src/test/java/org/apache/camel/component/netty/NettySuspendResumeTest.java
index 9f4f3a1..ea8927f 100644
--- a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettySuspendResumeTest.java
+++ b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettySuspendResumeTest.java
@@ -14,13 +14,13 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4;
+package org.apache.camel.component.netty;
 
 import org.apache.camel.builder.RouteBuilder;
 import org.junit.Test;
 
 public class NettySuspendResumeTest extends BaseNettyTest {
-    
+
     @Test
     public void testSuspendResume() throws Exception {
         getMockEndpoint("mock:result").expectedBodiesReceived("Camel", "Again");
diff --git a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyTCPAsyncTest.java b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyTCPAsyncTest.java
similarity index 95%
rename from components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyTCPAsyncTest.java
rename to components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyTCPAsyncTest.java
index fff7574..071cd25 100644
--- a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyTCPAsyncTest.java
+++ b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyTCPAsyncTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4;
+package org.apache.camel.component.netty;
 
 import java.io.FileInputStream;
 import java.io.InputStream;
@@ -55,10 +55,10 @@ public class NettyTCPAsyncTest extends BaseNettyTest {
         MockEndpoint mock = getMockEndpoint("mock:result");
         mock.expectedMessageCount(1);
         sendFile("netty:tcp://localhost:{{port}}?sync=false");
-        
+
         mock.assertIsSatisfied();
     }
-    
+
     @Override
     protected RouteBuilder createRouteBuilder() throws Exception {
         return new RouteBuilder() {
@@ -66,7 +66,7 @@ public class NettyTCPAsyncTest extends BaseNettyTest {
             public void configure() throws Exception {
                 from("netty:tcp://localhost:{{port}}?sync=false")
                     .to("log:result")
-                    .to("mock:result");                
+                    .to("mock:result");
             }
         };
     }
diff --git a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyTCPChainedTest.java b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyTCPChainedTest.java
similarity index 98%
rename from components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyTCPChainedTest.java
rename to components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyTCPChainedTest.java
index 134c184..20e04ac 100644
--- a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyTCPChainedTest.java
+++ b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyTCPChainedTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4;
+package org.apache.camel.component.netty;
 
 import java.io.FileInputStream;
 import java.io.InputStream;
@@ -65,10 +65,10 @@ public class NettyTCPChainedTest extends BaseNettyTest {
         MockEndpoint mock = getMockEndpoint("mock:result");
         mock.expectedMessageCount(2);
         sendFile("direct:chainedCalls");
-        
+
         mock.assertIsSatisfied();
     }
-    
+
     @Override
     protected RouteBuilder createRouteBuilder() throws Exception {
         return new RouteBuilder() {
diff --git a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyTCPSyncNotLazyChannelTest.java b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyTCPSyncNotLazyChannelTest.java
similarity index 98%
rename from components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyTCPSyncNotLazyChannelTest.java
rename to components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyTCPSyncNotLazyChannelTest.java
index ecce11b..0ac6488 100644
--- a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyTCPSyncNotLazyChannelTest.java
+++ b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyTCPSyncNotLazyChannelTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4;
+package org.apache.camel.component.netty;
 
 import org.apache.camel.Exchange;
 import org.apache.camel.Processor;
diff --git a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyTCPSyncTest.java b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyTCPSyncTest.java
similarity index 95%
rename from components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyTCPSyncTest.java
rename to components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyTCPSyncTest.java
index b92e8f4..b04afb21 100644
--- a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyTCPSyncTest.java
+++ b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyTCPSyncTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4;
+package org.apache.camel.component.netty;
 
 import org.apache.camel.Exchange;
 import org.apache.camel.Processor;
@@ -22,12 +22,12 @@ import org.apache.camel.builder.RouteBuilder;
 import org.junit.Test;
 
 public class NettyTCPSyncTest extends BaseNettyTest {
-    
+
     @Test
     public void testTCPStringInOutWithNettyConsumer() throws Exception {
         String response = template.requestBody(
             "netty:tcp://localhost:{{port}}?sync=true",
-            "Epitaph in Kohima, India marking the WWII Battle of Kohima and Imphal, Burma Campaign - Attributed to John Maxwell Edmonds", String.class);        
+            "Epitaph in Kohima, India marking the WWII Battle of Kohima and Imphal, Burma Campaign - Attributed to John Maxwell Edmonds", String.class);
         assertEquals("When You Go Home, Tell Them Of Us And Say, For Your Tomorrow, We Gave Our Today.", response);
     }
 
@@ -50,7 +50,7 @@ public class NettyTCPSyncTest extends BaseNettyTest {
         Poetry response = (Poetry) template.requestBody("netty:tcp://localhost:{{port}}?sync=true", poetry);
         assertEquals("Dr. Sarojini Naidu", response.getPoet());
     }
-    
+
     @Override
     protected RouteBuilder createRouteBuilder() throws Exception {
         return new RouteBuilder() {
@@ -65,9 +65,9 @@ public class NettyTCPSyncTest extends BaseNettyTest {
                                 exchange.getOut().setBody(poetry);
                                 return;
                             }
-                            exchange.getOut().setBody("When You Go Home, Tell Them Of Us And Say, For Your Tomorrow, We Gave Our Today.");                           
+                            exchange.getOut().setBody("When You Go Home, Tell Them Of Us And Say, For Your Tomorrow, We Gave Our Today.");
                         }
-                    });                
+                    });
             }
         };
     }
diff --git a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyTcpWithInOutUsingPlainSocketTest.java b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyTcpWithInOutUsingPlainSocketTest.java
similarity index 99%
rename from components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyTcpWithInOutUsingPlainSocketTest.java
rename to components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyTcpWithInOutUsingPlainSocketTest.java
index b63c4ba..aee89fe 100644
--- a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyTcpWithInOutUsingPlainSocketTest.java
+++ b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyTcpWithInOutUsingPlainSocketTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4;
+package org.apache.camel.component.netty;
 
 import java.io.IOException;
 import java.io.InputStream;
diff --git a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyTextlineInOnlyNullDelimiterTest.java b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyTextlineInOnlyNullDelimiterTest.java
similarity index 97%
rename from components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyTextlineInOnlyNullDelimiterTest.java
rename to components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyTextlineInOnlyNullDelimiterTest.java
index 9e3b3a7..0b8f82e 100644
--- a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyTextlineInOnlyNullDelimiterTest.java
+++ b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyTextlineInOnlyNullDelimiterTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4;
+package org.apache.camel.component.netty;
 
 import org.apache.camel.builder.RouteBuilder;
 import org.junit.Test;
@@ -42,4 +42,4 @@ public class NettyTextlineInOnlyNullDelimiterTest extends BaseNettyTest {
             }
         };
     }
-}
\ No newline at end of file
+}
diff --git a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyTextlineInOnlyTest.java b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyTextlineInOnlyTest.java
similarity index 98%
rename from components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyTextlineInOnlyTest.java
rename to components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyTextlineInOnlyTest.java
index 501e131..7b4d953 100644
--- a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyTextlineInOnlyTest.java
+++ b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyTextlineInOnlyTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4;
+package org.apache.camel.component.netty;
 
 import org.apache.camel.builder.RouteBuilder;
 import org.junit.Test;
diff --git a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyTextlineInOutNonBlockingTest.java b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyTextlineInOutNonBlockingTest.java
similarity index 98%
rename from components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyTextlineInOutNonBlockingTest.java
rename to components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyTextlineInOutNonBlockingTest.java
index b046bbf..0252df6 100644
--- a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyTextlineInOutNonBlockingTest.java
+++ b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyTextlineInOutNonBlockingTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4;
+package org.apache.camel.component.netty;
 
 import org.apache.camel.Exchange;
 import org.apache.camel.Processor;
@@ -81,4 +81,4 @@ public class NettyTextlineInOutNonBlockingTest extends BaseNettyTest {
             }
         };
     }
-}
\ No newline at end of file
+}
diff --git a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyTextlineInOutSynchronousFalseTest.java b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyTextlineInOutSynchronousFalseTest.java
similarity index 98%
rename from components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyTextlineInOutSynchronousFalseTest.java
rename to components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyTextlineInOutSynchronousFalseTest.java
index 9824503..e774ecc 100644
--- a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyTextlineInOutSynchronousFalseTest.java
+++ b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyTextlineInOutSynchronousFalseTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4;
+package org.apache.camel.component.netty;
 
 import org.apache.camel.Exchange;
 import org.apache.camel.Processor;
@@ -66,4 +66,4 @@ public class NettyTextlineInOutSynchronousFalseTest extends BaseNettyTest {
             }
         };
     }
-}
\ No newline at end of file
+}
diff --git a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyTextlineInOutSynchronousTest.java b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyTextlineInOutSynchronousTest.java
similarity index 98%
rename from components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyTextlineInOutSynchronousTest.java
rename to components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyTextlineInOutSynchronousTest.java
index a7f9cc7..a8e43ee 100644
--- a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyTextlineInOutSynchronousTest.java
+++ b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyTextlineInOutSynchronousTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4;
+package org.apache.camel.component.netty;
 
 import org.apache.camel.Exchange;
 import org.apache.camel.Processor;
@@ -66,4 +66,4 @@ public class NettyTextlineInOutSynchronousTest extends BaseNettyTest {
             }
         };
     }
-}
\ No newline at end of file
+}
diff --git a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyTextlineInOutTest.java b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyTextlineInOutTest.java
similarity index 97%
rename from components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyTextlineInOutTest.java
rename to components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyTextlineInOutTest.java
index 14d4bda..44f0f88 100644
--- a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyTextlineInOutTest.java
+++ b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyTextlineInOutTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4;
+package org.apache.camel.component.netty;
 
 import org.apache.camel.builder.RouteBuilder;
 import org.junit.Test;
@@ -44,4 +44,4 @@ public class NettyTextlineInOutTest extends BaseNettyTest {
             }
         };
     }
-}
\ No newline at end of file
+}
diff --git a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyTransferExchangeOptionTest.java b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyTransferExchangeOptionTest.java
similarity index 99%
rename from components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyTransferExchangeOptionTest.java
rename to components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyTransferExchangeOptionTest.java
index d64c582..b508b10 100644
--- a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyTransferExchangeOptionTest.java
+++ b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyTransferExchangeOptionTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4;
+package org.apache.camel.component.netty;
 
 import java.nio.charset.Charset;
 
diff --git a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyUDPAsyncTest.java b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyUDPAsyncTest.java
similarity index 96%
rename from components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyUDPAsyncTest.java
rename to components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyUDPAsyncTest.java
index 7c2f2f2..eae497c 100644
--- a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyUDPAsyncTest.java
+++ b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyUDPAsyncTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4;
+package org.apache.camel.component.netty;
 
 import java.io.File;
 
@@ -54,7 +54,7 @@ public class NettyUDPAsyncTest extends BaseNettyTest {
             public void configure() throws Exception {
                 from("netty:udp://localhost:{{port}}?sync=false")
                     .to("mock:result")
-                    .to("log:Message"); 
+                    .to("log:Message");
             }
         };
     }
diff --git a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyUDPByteArrayConsumerTest.java b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyUDPByteArrayConsumerTest.java
similarity index 98%
rename from components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyUDPByteArrayConsumerTest.java
rename to components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyUDPByteArrayConsumerTest.java
index 10f15ca..49ecf98 100644
--- a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyUDPByteArrayConsumerTest.java
+++ b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyUDPByteArrayConsumerTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4;
+package org.apache.camel.component.netty;
 
 import java.util.List;
 
diff --git a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyUDPByteArrayProviderTest.java b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyUDPByteArrayProviderTest.java
similarity index 98%
rename from components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyUDPByteArrayProviderTest.java
rename to components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyUDPByteArrayProviderTest.java
index d402b6b..90a5e3a 100644
--- a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyUDPByteArrayProviderTest.java
+++ b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyUDPByteArrayProviderTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4;
+package org.apache.camel.component.netty;
 
 import java.net.InetSocketAddress;
 import java.util.List;
diff --git a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyUDPLargeMessageInOnlyTest.java b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyUDPLargeMessageInOnlyTest.java
similarity index 98%
rename from components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyUDPLargeMessageInOnlyTest.java
rename to components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyUDPLargeMessageInOnlyTest.java
index 22d4572..fa8ff25 100644
--- a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyUDPLargeMessageInOnlyTest.java
+++ b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyUDPLargeMessageInOnlyTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4;
+package org.apache.camel.component.netty;
 
 import org.apache.camel.builder.RouteBuilder;
 import org.junit.Test;
diff --git a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyUDPMessageLargerThanDefaultBufferSizeTest.java b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyUDPMessageLargerThanDefaultBufferSizeTest.java
similarity index 98%
rename from components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyUDPMessageLargerThanDefaultBufferSizeTest.java
rename to components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyUDPMessageLargerThanDefaultBufferSizeTest.java
index 8401de9..4b39df2 100644
--- a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyUDPMessageLargerThanDefaultBufferSizeTest.java
+++ b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyUDPMessageLargerThanDefaultBufferSizeTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4;
+package org.apache.camel.component.netty;
 
 import io.netty.channel.ChannelOption;
 import io.netty.channel.FixedRecvByteBufAllocator;
diff --git a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyUDPMulticastAsyncTest.java b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyUDPMulticastAsyncTest.java
similarity index 97%
rename from components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyUDPMulticastAsyncTest.java
rename to components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyUDPMulticastAsyncTest.java
index 5c843c6..930ed79 100644
--- a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyUDPMulticastAsyncTest.java
+++ b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyUDPMulticastAsyncTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4;
+package org.apache.camel.component.netty;
 
 import java.io.File;
 
@@ -38,11 +38,11 @@ import org.junit.Test;
  * "http://blogs.agilefaqs.com/2009/11/08/enabling-multicast-on-your-macos-unix/"
  * >here</a>. Now running the test manually should succeed (<b>but only</b> when
  * using Java7+):
- * 
+ *
  * <pre>
  *   mvn test -Djava.net.preferIPv4Stack=true -Dtest=NettyUDPMulticastAsyncTest
  * </pre>
- * 
+ *
  * Please note that using the JUnit {@link BeforeClass} annotation together with
  * the corresponding {@link System#setProperty(String, String) Java API} to set
  * the {@code java.net.preferIPv4Stack} system property would not work here as
@@ -82,7 +82,7 @@ public class NettyUDPMulticastAsyncTest extends BaseNettyTest {
             public void configure() throws Exception {
                 from("netty:udp://224.1.2.3:{{port}}?sync=false&networkInterface=en0")
                     .to("mock:result")
-                    .to("log:Message"); 
+                    .to("log:Message");
             }
         };
     }
diff --git a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyUDPObjectSyncTest.java b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyUDPObjectSyncTest.java
similarity index 93%
rename from components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyUDPObjectSyncTest.java
rename to components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyUDPObjectSyncTest.java
index cc9ef9d..8f18991 100644
--- a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyUDPObjectSyncTest.java
+++ b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyUDPObjectSyncTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4;
+package org.apache.camel.component.netty;
 
 import org.apache.camel.Exchange;
 import org.apache.camel.Processor;
@@ -29,12 +29,12 @@ public class NettyUDPObjectSyncTest extends BaseNettyTest {
         Poetry response = template.requestBody("netty:udp://localhost:{{port}}?sync=true", poetry, Poetry.class);
         assertEquals("Dr. Sarojini Naidu", response.getPoet());
     }
-    
+
     @Override
     protected RouteBuilder createRouteBuilder() throws Exception {
         return new RouteBuilder() {
             @Override
-            public void configure() throws Exception {                
+            public void configure() throws Exception {
                 from("netty:udp://localhost:{{port}}?sync=true")
                     .process(new Processor() {
                         public void process(Exchange exchange) throws Exception {
@@ -46,5 +46,5 @@ public class NettyUDPObjectSyncTest extends BaseNettyTest {
             }
         };
     }
-    
-}  
+
+}
diff --git a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyUDPSyncTest.java b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyUDPSyncTest.java
similarity index 91%
rename from components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyUDPSyncTest.java
rename to components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyUDPSyncTest.java
index 9f8cd8f..4869aaa 100644
--- a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyUDPSyncTest.java
+++ b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyUDPSyncTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4;
+package org.apache.camel.component.netty;
 
 import org.apache.camel.Exchange;
 import org.apache.camel.Processor;
@@ -30,25 +30,25 @@ public class NettyUDPSyncTest extends BaseNettyTest {
         for (int i = 0; i < 5; i++) {
             String response = template.requestBody(
                 "netty:udp://localhost:{{port}}?sync=true",
-                REQUEST, String.class);        
+                REQUEST, String.class);
             assertEquals(RESPONSE, response);
         }
     }
-    
+
     @Override
     protected RouteBuilder createRouteBuilder() throws Exception {
         return new RouteBuilder() {
             @Override
-            public void configure() throws Exception {                
+            public void configure() throws Exception {
                 from("netty:udp://localhost:{{port}}?sync=true")
                     .process(new Processor() {
                         public void process(Exchange exchange) throws Exception {
-                            exchange.getOut().setBody(RESPONSE);                           
+                            exchange.getOut().setBody(RESPONSE);
                         }
                     });
             }
         };
     }
-    
 
-} 
+
+}
diff --git a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyUdpConnectedSendTest.java b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyUdpConnectedSendTest.java
similarity index 99%
rename from components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyUdpConnectedSendTest.java
rename to components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyUdpConnectedSendTest.java
index a8e6087..79fbdfe 100644
--- a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyUdpConnectedSendTest.java
+++ b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyUdpConnectedSendTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4;
+package org.apache.camel.component.netty;
 
 import java.net.InetSocketAddress;
 import java.util.List;
diff --git a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyUdpConnectionlessSendTest.java b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyUdpConnectionlessSendTest.java
similarity index 98%
rename from components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyUdpConnectionlessSendTest.java
rename to components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyUdpConnectionlessSendTest.java
index b975465..1a92570 100644
--- a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyUdpConnectionlessSendTest.java
+++ b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyUdpConnectionlessSendTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4;
+package org.apache.camel.component.netty;
 
 import java.net.InetSocketAddress;
 import java.util.List;
diff --git a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyUdpWithInOutUsingPlainSocketTest.java b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyUdpWithInOutUsingPlainSocketTest.java
similarity index 98%
rename from components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyUdpWithInOutUsingPlainSocketTest.java
rename to components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyUdpWithInOutUsingPlainSocketTest.java
index 6ffa801..64cac7c 100644
--- a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyUdpWithInOutUsingPlainSocketTest.java
+++ b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyUdpWithInOutUsingPlainSocketTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4;
+package org.apache.camel.component.netty;
 
 import java.net.DatagramPacket;
 import java.net.DatagramSocket;
diff --git a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyUseSharedWorkerThreadPoolManyRoutesTest.java b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyUseSharedWorkerThreadPoolManyRoutesTest.java
similarity index 98%
rename from components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyUseSharedWorkerThreadPoolManyRoutesTest.java
rename to components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyUseSharedWorkerThreadPoolManyRoutesTest.java
index e78cc02..6437e9e 100644
--- a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyUseSharedWorkerThreadPoolManyRoutesTest.java
+++ b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyUseSharedWorkerThreadPoolManyRoutesTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4;
+package org.apache.camel.component.netty;
 
 import io.netty.channel.EventLoopGroup;
 
diff --git a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyUseSharedWorkerThreadPoolTest.java b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyUseSharedWorkerThreadPoolTest.java
similarity index 98%
rename from components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyUseSharedWorkerThreadPoolTest.java
rename to components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyUseSharedWorkerThreadPoolTest.java
index 328f1e5..185a706 100644
--- a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/NettyUseSharedWorkerThreadPoolTest.java
+++ b/components/camel-netty/src/test/java/org/apache/camel/component/netty/NettyUseSharedWorkerThreadPoolTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4;
+package org.apache.camel.component.netty;
 
 import io.netty.channel.EventLoopGroup;
 
diff --git a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/Poetry.java b/components/camel-netty/src/test/java/org/apache/camel/component/netty/Poetry.java
similarity index 88%
rename from components/camel-netty/src/test/java/org/apache/camel/component/netty4/Poetry.java
rename to components/camel-netty/src/test/java/org/apache/camel/component/netty/Poetry.java
index 20c0981..b8ffb9e 100644
--- a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/Poetry.java
+++ b/components/camel-netty/src/test/java/org/apache/camel/component/netty/Poetry.java
@@ -14,43 +14,43 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4;
+package org.apache.camel.component.netty;
 
 import java.io.Serializable;
 
 public class Poetry implements Serializable {
     private static final long serialVersionUID = 1L;
     private String poet = "?";
-    private String poem = "ONCE in the dream of a night I stood\n" 
-                          + "Lone in the light of a magical wood,\n"  
-                          + "Soul-deep in visions that poppy-like sprang;\n"  
-                          + "And spirits of Truth were the birds that sang,\n"  
-                          + "And spirits of Love were the stars that glowed,\n" 
-                          + "And spirits of Peace were the streams that flowed\n"  
-                          + "In that magical wood in the land of sleep." 
-                          + "\n" 
-                          + "Lone in the light of that magical grove,\n"  
-                          + "I felt the stars of the spirits of Love\n" 
-                          + "Gather and gleam round my delicate youth,\n" 
-                          + "And I heard the song of the spirits of Truth;\n" 
-                          + "To quench my longing I bent me low\n"  
-                          + "By the streams of the spirits of Peace that flow\n" 
+    private String poem = "ONCE in the dream of a night I stood\n"
+                          + "Lone in the light of a magical wood,\n"
+                          + "Soul-deep in visions that poppy-like sprang;\n"
+                          + "And spirits of Truth were the birds that sang,\n"
+                          + "And spirits of Love were the stars that glowed,\n"
+                          + "And spirits of Peace were the streams that flowed\n"
+                          + "In that magical wood in the land of sleep."
+                          + "\n"
+                          + "Lone in the light of that magical grove,\n"
+                          + "I felt the stars of the spirits of Love\n"
+                          + "Gather and gleam round my delicate youth,\n"
+                          + "And I heard the song of the spirits of Truth;\n"
+                          + "To quench my longing I bent me low\n"
+                          + "By the streams of the spirits of Peace that flow\n"
                           + "In that magical wood in the land of sleep.";
 
     public String getPoet() {
         return poet;
     }
-    
+
     public void setPoet(String poet) {
         this.poet = poet;
     }
-    
+
     public String getPoem() {
         return poem;
     }
-    
+
     public void setPoem(String poem) {
         this.poem = poem;
-    } 
-    
+    }
+
 }
diff --git a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/SpringNettyUseSharedWorkerThreadPoolTest.java b/components/camel-netty/src/test/java/org/apache/camel/component/netty/SpringNettyUseSharedWorkerThreadPoolTest.java
similarity index 94%
rename from components/camel-netty/src/test/java/org/apache/camel/component/netty4/SpringNettyUseSharedWorkerThreadPoolTest.java
rename to components/camel-netty/src/test/java/org/apache/camel/component/netty/SpringNettyUseSharedWorkerThreadPoolTest.java
index 4c45012..70bd747 100644
--- a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/SpringNettyUseSharedWorkerThreadPoolTest.java
+++ b/components/camel-netty/src/test/java/org/apache/camel/component/netty/SpringNettyUseSharedWorkerThreadPoolTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4;
+package org.apache.camel.component.netty;
 
 import org.apache.camel.test.spring.CamelSpringTestSupport;
 import org.junit.Test;
@@ -43,6 +43,6 @@ public class SpringNettyUseSharedWorkerThreadPoolTest extends CamelSpringTestSup
 
     @Override
     protected AbstractApplicationContext createApplicationContext() {
-        return new ClassPathXmlApplicationContext("org/apache/camel/component/netty4/SpringNettyUseSharedWorkerThreadPoolTest.xml");
+        return new ClassPathXmlApplicationContext("org/apache/camel/component/netty/SpringNettyUseSharedWorkerThreadPoolTest.xml");
     }
-}
\ No newline at end of file
+}
diff --git a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/UnsharableCodecsConflicts2Test.java b/components/camel-netty/src/test/java/org/apache/camel/component/netty/UnsharableCodecsConflicts2Test.java
similarity index 98%
rename from components/camel-netty/src/test/java/org/apache/camel/component/netty4/UnsharableCodecsConflicts2Test.java
rename to components/camel-netty/src/test/java/org/apache/camel/component/netty/UnsharableCodecsConflicts2Test.java
index 6e14917..58ede3d 100644
--- a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/UnsharableCodecsConflicts2Test.java
+++ b/components/camel-netty/src/test/java/org/apache/camel/component/netty/UnsharableCodecsConflicts2Test.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4;
+package org.apache.camel.component.netty;
 
 import java.io.BufferedOutputStream;
 import java.io.IOException;
diff --git a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/UnsharableCodecsConflictsTest.java b/components/camel-netty/src/test/java/org/apache/camel/component/netty/UnsharableCodecsConflictsTest.java
similarity index 98%
rename from components/camel-netty/src/test/java/org/apache/camel/component/netty4/UnsharableCodecsConflictsTest.java
rename to components/camel-netty/src/test/java/org/apache/camel/component/netty/UnsharableCodecsConflictsTest.java
index 18debed..0807eae 100644
--- a/components/camel-netty/src/test/java/org/apache/camel/component/netty4/UnsharableCodecsConflictsTest.java
+++ b/components/camel-netty/src/test/java/org/apache/camel/component/netty/UnsharableCodecsConflictsTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4;
+package org.apache.camel.component.netty;
 
 import java.io.BufferedOutputStream;
 import java.io.IOException;
diff --git a/components/camel-netty/src/test/resources/log4j2.properties b/components/camel-netty/src/test/resources/log4j2.properties
index 05d847e..5005aef 100644
--- a/components/camel-netty/src/test/resources/log4j2.properties
+++ b/components/camel-netty/src/test/resources/log4j2.properties
@@ -15,7 +15,7 @@
 ## limitations under the License.
 ## ---------------------------------------------------------------------------
 
-configuration.packages=org.apache.camel.component.netty4
+configuration.packages=org.apache.camel.component.netty
 appender.file.type = File
 appender.file.name = file
 appender.file.fileName = target/camel-netty-test.log
diff --git a/components/camel-netty/src/test/resources/org/apache/camel/component/netty4/SpringNettyUseSharedWorkerThreadPoolTest.xml b/components/camel-netty/src/test/resources/org/apache/camel/component/netty/SpringNettyUseSharedWorkerThreadPoolTest.xml
similarity index 98%
rename from components/camel-netty/src/test/resources/org/apache/camel/component/netty4/SpringNettyUseSharedWorkerThreadPoolTest.xml
rename to components/camel-netty/src/test/resources/org/apache/camel/component/netty/SpringNettyUseSharedWorkerThreadPoolTest.xml
index 7a53960..40ec4f5 100644
--- a/components/camel-netty/src/test/resources/org/apache/camel/component/netty4/SpringNettyUseSharedWorkerThreadPoolTest.xml
+++ b/components/camel-netty/src/test/resources/org/apache/camel/component/netty/SpringNettyUseSharedWorkerThreadPoolTest.xml
@@ -22,7 +22,7 @@
        http://camel.apache.org/schema/spring http://camel.apache.org/schema/spring/camel-spring.xsd">
 
   <!-- use the worker pool builder to help create the shared thread pool -->
-  <bean id="poolBuilder" class="org.apache.camel.component.netty4.NettyWorkerPoolBuilder">
+  <bean id="poolBuilder" class="org.apache.camel.component.netty.NettyWorkerPoolBuilder">
     <property name="workerCount" value="2"/>
   </bean>
 
diff --git a/components/camel-netty/src/test/resources/org/apache/camel/component/netty4/multiple-codecs.xml b/components/camel-netty/src/test/resources/org/apache/camel/component/netty/multiple-codecs.xml
similarity index 93%
rename from components/camel-netty/src/test/resources/org/apache/camel/component/netty4/multiple-codecs.xml
rename to components/camel-netty/src/test/resources/org/apache/camel/component/netty/multiple-codecs.xml
index 581c14a..987691a 100644
--- a/components/camel-netty/src/test/resources/org/apache/camel/component/netty4/multiple-codecs.xml
+++ b/components/camel-netty/src/test/resources/org/apache/camel/component/netty/multiple-codecs.xml
@@ -39,7 +39,7 @@
 
     <!-- START SNIPPET: registry-beans -->
     <util:list id="decoders" list-class="java.util.LinkedList">
-        <bean class="org.apache.camel.component.netty4.ChannelHandlerFactories" factory-method="newLengthFieldBasedFrameDecoder">
+        <bean class="org.apache.camel.component.netty.ChannelHandlerFactories" factory-method="newLengthFieldBasedFrameDecoder">
             <constructor-arg value="1048576"/>
             <constructor-arg value="0"/>
             <constructor-arg value="4"/>
@@ -61,7 +61,7 @@
     </bean>
     <bean id="string-encoder" class="io.netty.handler.codec.string.StringEncoder"/>
 
-    <bean id="length-decoder" class="org.apache.camel.component.netty4.ChannelHandlerFactories" factory-method="newLengthFieldBasedFrameDecoder">
+    <bean id="length-decoder" class="org.apache.camel.component.netty.ChannelHandlerFactories" factory-method="newLengthFieldBasedFrameDecoder">
         <constructor-arg value="1048576"/>
         <constructor-arg value="0"/>
         <constructor-arg value="4"/>
diff --git a/components/camel-syslog/src/main/java/org/apache/camel/component/syslog/netty/Rfc5425FrameDecoder.java b/components/camel-syslog/src/main/java/org/apache/camel/component/syslog/netty/Rfc5425FrameDecoder.java
index 5155520..87299c2 100644
--- a/components/camel-syslog/src/main/java/org/apache/camel/component/syslog/netty/Rfc5425FrameDecoder.java
+++ b/components/camel-syslog/src/main/java/org/apache/camel/component/syslog/netty/Rfc5425FrameDecoder.java
@@ -23,7 +23,7 @@ import io.netty.buffer.Unpooled;
 import io.netty.channel.ChannelHandler;
 import io.netty.channel.ChannelHandlerContext;
 import io.netty.handler.codec.ByteToMessageDecoder;
-import org.apache.camel.component.netty4.ChannelHandlerFactory;
+import org.apache.camel.component.netty.ChannelHandlerFactory;
 
 public class Rfc5425FrameDecoder extends ByteToMessageDecoder implements ChannelHandlerFactory {
 
diff --git a/core/camel-cloud/src/main/java/org/apache/camel/impl/cloud/DefaultServiceCallExpression.java b/core/camel-cloud/src/main/java/org/apache/camel/impl/cloud/DefaultServiceCallExpression.java
index 06d1552..accb521 100644
--- a/core/camel-cloud/src/main/java/org/apache/camel/impl/cloud/DefaultServiceCallExpression.java
+++ b/core/camel-cloud/src/main/java/org/apache/camel/impl/cloud/DefaultServiceCallExpression.java
@@ -28,7 +28,7 @@ import org.slf4j.LoggerFactory;
  serviceCall("myService/foo") -> http://hostname:port/foo
  serviceCall("http:myService/foo") -> http:hostname:port/foo
  serviceCall("myService", "http:myService.host:myService.port/foo") -> http:hostname:port/foo
- serviceCall("myService", "netty4:tcp:myService?connectTimeout=1000") -> netty:tcp:hostname:port?connectTimeout=1000
+ serviceCall("myService", "netty:tcp:myService?connectTimeout=1000") -> netty:tcp:hostname:port?connectTimeout=1000
  * </pre>
  */
 public class DefaultServiceCallExpression extends ServiceCallExpressionSupport {
diff --git a/core/camel-endpointdsl/src/main/java/org/apache/camel/builder/endpoint/dsl/NettyEndpointBuilderFactory.java b/core/camel-endpointdsl/src/main/java/org/apache/camel/builder/endpoint/dsl/NettyEndpointBuilderFactory.java
index 89a2669..068abcf 100644
--- a/core/camel-endpointdsl/src/main/java/org/apache/camel/builder/endpoint/dsl/NettyEndpointBuilderFactory.java
+++ b/core/camel-endpointdsl/src/main/java/org/apache/camel/builder/endpoint/dsl/NettyEndpointBuilderFactory.java
@@ -471,8 +471,7 @@ public interface NettyEndpointBuilderFactory {
          * and NULL.
          * 
          * The option is a:
-         * <code>org.apache.camel.component.netty4.TextLineDelimiter</code>
-         * type.
+         * <code>org.apache.camel.component.netty.TextLineDelimiter</code> type.
          * 
          * Group: codec
          */
@@ -486,8 +485,7 @@ public interface NettyEndpointBuilderFactory {
          * and NULL.
          * 
          * The option will be converted to a
-         * <code>org.apache.camel.component.netty4.TextLineDelimiter</code>
-         * type.
+         * <code>org.apache.camel.component.netty.TextLineDelimiter</code> type.
          * 
          * Group: codec
          */
@@ -1023,7 +1021,7 @@ public interface NettyEndpointBuilderFactory {
          * To use a custom NettyServerBootstrapFactory.
          * 
          * The option is a:
-         * <code>org.apache.camel.component.netty4.NettyServerBootstrapFactory</code> type.
+         * <code>org.apache.camel.component.netty.NettyServerBootstrapFactory</code> type.
          * 
          * Group: consumer (advanced)
          */
@@ -1036,7 +1034,7 @@ public interface NettyEndpointBuilderFactory {
          * To use a custom NettyServerBootstrapFactory.
          * 
          * The option will be converted to a
-         * <code>org.apache.camel.component.netty4.NettyServerBootstrapFactory</code> type.
+         * <code>org.apache.camel.component.netty.NettyServerBootstrapFactory</code> type.
          * 
          * Group: consumer (advanced)
          */
@@ -1149,7 +1147,7 @@ public interface NettyEndpointBuilderFactory {
          * To use a custom ServerInitializerFactory.
          * 
          * The option is a:
-         * <code>org.apache.camel.component.netty4.ServerInitializerFactory</code> type.
+         * <code>org.apache.camel.component.netty.ServerInitializerFactory</code> type.
          * 
          * Group: consumer (advanced)
          */
@@ -1162,7 +1160,7 @@ public interface NettyEndpointBuilderFactory {
          * To use a custom ServerInitializerFactory.
          * 
          * The option will be converted to a
-         * <code>org.apache.camel.component.netty4.ServerInitializerFactory</code> type.
+         * <code>org.apache.camel.component.netty.ServerInitializerFactory</code> type.
          * 
          * Group: consumer (advanced)
          */
@@ -1990,8 +1988,7 @@ public interface NettyEndpointBuilderFactory {
          * and NULL.
          * 
          * The option is a:
-         * <code>org.apache.camel.component.netty4.TextLineDelimiter</code>
-         * type.
+         * <code>org.apache.camel.component.netty.TextLineDelimiter</code> type.
          * 
          * Group: codec
          */
@@ -2005,8 +2002,7 @@ public interface NettyEndpointBuilderFactory {
          * and NULL.
          * 
          * The option will be converted to a
-         * <code>org.apache.camel.component.netty4.TextLineDelimiter</code>
-         * type.
+         * <code>org.apache.camel.component.netty.TextLineDelimiter</code> type.
          * 
          * Group: codec
          */
@@ -2352,7 +2348,7 @@ public interface NettyEndpointBuilderFactory {
          * To use a custom ClientInitializerFactory.
          * 
          * The option is a:
-         * <code>org.apache.camel.component.netty4.ClientInitializerFactory</code> type.
+         * <code>org.apache.camel.component.netty.ClientInitializerFactory</code> type.
          * 
          * Group: producer (advanced)
          */
@@ -2365,7 +2361,7 @@ public interface NettyEndpointBuilderFactory {
          * To use a custom ClientInitializerFactory.
          * 
          * The option will be converted to a
-         * <code>org.apache.camel.component.netty4.ClientInitializerFactory</code> type.
+         * <code>org.apache.camel.component.netty.ClientInitializerFactory</code> type.
          * 
          * Group: producer (advanced)
          */
@@ -2390,7 +2386,7 @@ public interface NettyEndpointBuilderFactory {
          * producerPoolEnabled option for more details.
          * 
          * The option is a:
-         * <code>org.apache.camel.component.netty4.NettyCamelStateCorrelationManager</code> type.
+         * <code>org.apache.camel.component.netty.NettyCamelStateCorrelationManager</code> type.
          * 
          * Group: producer (advanced)
          */
@@ -2415,7 +2411,7 @@ public interface NettyEndpointBuilderFactory {
          * producerPoolEnabled option for more details.
          * 
          * The option will be converted to a
-         * <code>org.apache.camel.component.netty4.NettyCamelStateCorrelationManager</code> type.
+         * <code>org.apache.camel.component.netty.NettyCamelStateCorrelationManager</code> type.
          * 
          * Group: producer (advanced)
          */
@@ -3351,8 +3347,7 @@ public interface NettyEndpointBuilderFactory {
          * and NULL.
          * 
          * The option is a:
-         * <code>org.apache.camel.component.netty4.TextLineDelimiter</code>
-         * type.
+         * <code>org.apache.camel.component.netty.TextLineDelimiter</code> type.
          * 
          * Group: codec
          */
@@ -3365,8 +3360,7 @@ public interface NettyEndpointBuilderFactory {
          * and NULL.
          * 
          * The option will be converted to a
-         * <code>org.apache.camel.component.netty4.TextLineDelimiter</code>
-         * type.
+         * <code>org.apache.camel.component.netty.TextLineDelimiter</code> type.
          * 
          * Group: codec
          */
@@ -4092,7 +4086,7 @@ public interface NettyEndpointBuilderFactory {
 
     /**
      * Proxy enum for
-     * <code>org.apache.camel.component.netty4.TextLineDelimiter</code> enum.
+     * <code>org.apache.camel.component.netty.TextLineDelimiter</code> enum.
      */
     enum TextLineDelimiter {
         LINE,
diff --git a/core/camel-endpointdsl/src/main/java/org/apache/camel/builder/endpoint/dsl/NettyHttpEndpointBuilderFactory.java b/core/camel-endpointdsl/src/main/java/org/apache/camel/builder/endpoint/dsl/NettyHttpEndpointBuilderFactory.java
index 0b2a837..ce9e753 100644
--- a/core/camel-endpointdsl/src/main/java/org/apache/camel/builder/endpoint/dsl/NettyHttpEndpointBuilderFactory.java
+++ b/core/camel-endpointdsl/src/main/java/org/apache/camel/builder/endpoint/dsl/NettyHttpEndpointBuilderFactory.java
@@ -510,11 +510,11 @@ public interface NettyHttpEndpointBuilderFactory {
         }
         /**
          * Refers to a
-         * org.apache.camel.component.netty4.http.NettyHttpSecurityConfiguration
+         * org.apache.camel.component.netty.http.NettyHttpSecurityConfiguration
          * for configuring secure web resources.
          * 
          * The option is a:
-         * <code>org.apache.camel.component.netty4.http.NettyHttpSecurityConfiguration</code> type.
+         * <code>org.apache.camel.component.netty.http.NettyHttpSecurityConfiguration</code> type.
          * 
          * Group: security
          */
@@ -525,11 +525,11 @@ public interface NettyHttpEndpointBuilderFactory {
         }
         /**
          * Refers to a
-         * org.apache.camel.component.netty4.http.NettyHttpSecurityConfiguration
+         * org.apache.camel.component.netty.http.NettyHttpSecurityConfiguration
          * for configuring secure web resources.
          * 
          * The option will be converted to a
-         * <code>org.apache.camel.component.netty4.http.NettyHttpSecurityConfiguration</code> type.
+         * <code>org.apache.camel.component.netty.http.NettyHttpSecurityConfiguration</code> type.
          * 
          * Group: security
          */
@@ -1011,7 +1011,7 @@ public interface NettyHttpEndpointBuilderFactory {
          * To use a custom NettyServerBootstrapFactory.
          * 
          * The option is a:
-         * <code>org.apache.camel.component.netty4.NettyServerBootstrapFactory</code> type.
+         * <code>org.apache.camel.component.netty.NettyServerBootstrapFactory</code> type.
          * 
          * Group: consumer (advanced)
          */
@@ -1024,7 +1024,7 @@ public interface NettyHttpEndpointBuilderFactory {
          * To use a custom NettyServerBootstrapFactory.
          * 
          * The option will be converted to a
-         * <code>org.apache.camel.component.netty4.NettyServerBootstrapFactory</code> type.
+         * <code>org.apache.camel.component.netty.NettyServerBootstrapFactory</code> type.
          * 
          * Group: consumer (advanced)
          */
@@ -1038,7 +1038,7 @@ public interface NettyHttpEndpointBuilderFactory {
          * more details.
          * 
          * The option is a:
-         * <code>org.apache.camel.component.netty4.http.NettySharedHttpServer</code> type.
+         * <code>org.apache.camel.component.netty.http.NettySharedHttpServer</code> type.
          * 
          * Group: consumer (advanced)
          */
@@ -1052,7 +1052,7 @@ public interface NettyHttpEndpointBuilderFactory {
          * more details.
          * 
          * The option will be converted to a
-         * <code>org.apache.camel.component.netty4.http.NettySharedHttpServer</code> type.
+         * <code>org.apache.camel.component.netty.http.NettySharedHttpServer</code> type.
          * 
          * Group: consumer (advanced)
          */
@@ -1152,7 +1152,7 @@ public interface NettyHttpEndpointBuilderFactory {
          * To use a custom ServerInitializerFactory.
          * 
          * The option is a:
-         * <code>org.apache.camel.component.netty4.ServerInitializerFactory</code> type.
+         * <code>org.apache.camel.component.netty.ServerInitializerFactory</code> type.
          * 
          * Group: consumer (advanced)
          */
@@ -1165,7 +1165,7 @@ public interface NettyHttpEndpointBuilderFactory {
          * To use a custom ServerInitializerFactory.
          * 
          * The option will be converted to a
-         * <code>org.apache.camel.component.netty4.ServerInitializerFactory</code> type.
+         * <code>org.apache.camel.component.netty.ServerInitializerFactory</code> type.
          * 
          * Group: consumer (advanced)
          */
@@ -1206,8 +1206,8 @@ public interface NettyHttpEndpointBuilderFactory {
          * space character. Notice this option is used by the default
          * org.apache.camel.component.netty.http.NettyHttpBinding and therefore
          * if you implement a custom
-         * org.apache.camel.component.netty4.http.NettyHttpBinding then you
-         * would need to decode the headers accordingly to this option.
+         * org.apache.camel.component.netty.http.NettyHttpBinding then you would
+         * need to decode the headers accordingly to this option.
          * 
          * The option is a: <code>boolean</code> type.
          * 
@@ -1224,8 +1224,8 @@ public interface NettyHttpEndpointBuilderFactory {
          * space character. Notice this option is used by the default
          * org.apache.camel.component.netty.http.NettyHttpBinding and therefore
          * if you implement a custom
-         * org.apache.camel.component.netty4.http.NettyHttpBinding then you
-         * would need to decode the headers accordingly to this option.
+         * org.apache.camel.component.netty.http.NettyHttpBinding then you would
+         * need to decode the headers accordingly to this option.
          * 
          * The option will be converted to a <code>boolean</code> type.
          * 
@@ -1323,7 +1323,7 @@ public interface NettyHttpEndpointBuilderFactory {
          * this endpoint.
          * 
          * The option is a:
-         * <code>org.apache.camel.component.netty4.http.NettyHttpConfiguration</code> type.
+         * <code>org.apache.camel.component.netty.http.NettyHttpConfiguration</code> type.
          * 
          * Group: advanced
          */
@@ -1337,7 +1337,7 @@ public interface NettyHttpEndpointBuilderFactory {
          * this endpoint.
          * 
          * The option will be converted to a
-         * <code>org.apache.camel.component.netty4.http.NettyHttpConfiguration</code> type.
+         * <code>org.apache.camel.component.netty.http.NettyHttpConfiguration</code> type.
          * 
          * Group: advanced
          */
@@ -1462,11 +1462,11 @@ public interface NettyHttpEndpointBuilderFactory {
         }
         /**
          * To use a custom
-         * org.apache.camel.component.netty4.http.NettyHttpBinding for binding
+         * org.apache.camel.component.netty.http.NettyHttpBinding for binding
          * to/from Netty and Camel Message API.
          * 
          * The option is a:
-         * <code>org.apache.camel.component.netty4.http.NettyHttpBinding</code>
+         * <code>org.apache.camel.component.netty.http.NettyHttpBinding</code>
          * type.
          * 
          * Group: advanced
@@ -1478,11 +1478,11 @@ public interface NettyHttpEndpointBuilderFactory {
         }
         /**
          * To use a custom
-         * org.apache.camel.component.netty4.http.NettyHttpBinding for binding
+         * org.apache.camel.component.netty.http.NettyHttpBinding for binding
          * to/from Netty and Camel Message API.
          * 
          * The option will be converted to a
-         * <code>org.apache.camel.component.netty4.http.NettyHttpBinding</code>
+         * <code>org.apache.camel.component.netty.http.NettyHttpBinding</code>
          * type.
          * 
          * Group: advanced
@@ -2582,7 +2582,7 @@ public interface NettyHttpEndpointBuilderFactory {
          * To use a custom ClientInitializerFactory.
          * 
          * The option is a:
-         * <code>org.apache.camel.component.netty4.ClientInitializerFactory</code> type.
+         * <code>org.apache.camel.component.netty.ClientInitializerFactory</code> type.
          * 
          * Group: producer (advanced)
          */
@@ -2595,7 +2595,7 @@ public interface NettyHttpEndpointBuilderFactory {
          * To use a custom ClientInitializerFactory.
          * 
          * The option will be converted to a
-         * <code>org.apache.camel.component.netty4.ClientInitializerFactory</code> type.
+         * <code>org.apache.camel.component.netty.ClientInitializerFactory</code> type.
          * 
          * Group: producer (advanced)
          */
@@ -2880,7 +2880,7 @@ public interface NettyHttpEndpointBuilderFactory {
          * this endpoint.
          * 
          * The option is a:
-         * <code>org.apache.camel.component.netty4.http.NettyHttpConfiguration</code> type.
+         * <code>org.apache.camel.component.netty.http.NettyHttpConfiguration</code> type.
          * 
          * Group: advanced
          */
@@ -2894,7 +2894,7 @@ public interface NettyHttpEndpointBuilderFactory {
          * this endpoint.
          * 
          * The option will be converted to a
-         * <code>org.apache.camel.component.netty4.http.NettyHttpConfiguration</code> type.
+         * <code>org.apache.camel.component.netty.http.NettyHttpConfiguration</code> type.
          * 
          * Group: advanced
          */
@@ -3019,11 +3019,11 @@ public interface NettyHttpEndpointBuilderFactory {
         }
         /**
          * To use a custom
-         * org.apache.camel.component.netty4.http.NettyHttpBinding for binding
+         * org.apache.camel.component.netty.http.NettyHttpBinding for binding
          * to/from Netty and Camel Message API.
          * 
          * The option is a:
-         * <code>org.apache.camel.component.netty4.http.NettyHttpBinding</code>
+         * <code>org.apache.camel.component.netty.http.NettyHttpBinding</code>
          * type.
          * 
          * Group: advanced
@@ -3035,11 +3035,11 @@ public interface NettyHttpEndpointBuilderFactory {
         }
         /**
          * To use a custom
-         * org.apache.camel.component.netty4.http.NettyHttpBinding for binding
+         * org.apache.camel.component.netty.http.NettyHttpBinding for binding
          * to/from Netty and Camel Message API.
          * 
          * The option will be converted to a
-         * <code>org.apache.camel.component.netty4.http.NettyHttpBinding</code>
+         * <code>org.apache.camel.component.netty.http.NettyHttpBinding</code>
          * type.
          * 
          * Group: advanced
@@ -3979,7 +3979,7 @@ public interface NettyHttpEndpointBuilderFactory {
          * this endpoint.
          * 
          * The option is a:
-         * <code>org.apache.camel.component.netty4.http.NettyHttpConfiguration</code> type.
+         * <code>org.apache.camel.component.netty.http.NettyHttpConfiguration</code> type.
          * 
          * Group: advanced
          */
@@ -3993,7 +3993,7 @@ public interface NettyHttpEndpointBuilderFactory {
          * this endpoint.
          * 
          * The option will be converted to a
-         * <code>org.apache.camel.component.netty4.http.NettyHttpConfiguration</code> type.
+         * <code>org.apache.camel.component.netty.http.NettyHttpConfiguration</code> type.
          * 
          * Group: advanced
          */
@@ -4118,11 +4118,11 @@ public interface NettyHttpEndpointBuilderFactory {
         }
         /**
          * To use a custom
-         * org.apache.camel.component.netty4.http.NettyHttpBinding for binding
+         * org.apache.camel.component.netty.http.NettyHttpBinding for binding
          * to/from Netty and Camel Message API.
          * 
          * The option is a:
-         * <code>org.apache.camel.component.netty4.http.NettyHttpBinding</code>
+         * <code>org.apache.camel.component.netty.http.NettyHttpBinding</code>
          * type.
          * 
          * Group: advanced
@@ -4134,11 +4134,11 @@ public interface NettyHttpEndpointBuilderFactory {
         }
         /**
          * To use a custom
-         * org.apache.camel.component.netty4.http.NettyHttpBinding for binding
+         * org.apache.camel.component.netty.http.NettyHttpBinding for binding
          * to/from Netty and Camel Message API.
          * 
          * The option will be converted to a
-         * <code>org.apache.camel.component.netty4.http.NettyHttpBinding</code>
+         * <code>org.apache.camel.component.netty.http.NettyHttpBinding</code>
          * type.
          * 
          * Group: advanced
diff --git a/docs/components/modules/ROOT/pages/hl7-dataformat.adoc b/docs/components/modules/ROOT/pages/hl7-dataformat.adoc
index 6b55962..ed91242 100644
--- a/docs/components/modules/ROOT/pages/hl7-dataformat.adoc
+++ b/docs/components/modules/ROOT/pages/hl7-dataformat.adoc
@@ -32,7 +32,7 @@ for this component:
 == HL7 MLLP protocol
 
 HL7 is often used with the HL7 MLLP protocol, which is a text based TCP
-socket based protocol. This component ships with a Mina and Netty4 Codec
+socket based protocol. This component ships with a Mina and Netty Codec
 that conforms to the MLLP protocol so you can easily expose an HL7
 listener accepting HL7 requests over the TCP transport layer. To expose
 a HL7 listener service, the xref:mina-component.adoc[camel-mina] or
diff --git a/docs/components/modules/ROOT/pages/netty-component.adoc b/docs/components/modules/ROOT/pages/netty-component.adoc
index 64f91d6..55476ec 100644
--- a/docs/components/modules/ROOT/pages/netty-component.adoc
+++ b/docs/components/modules/ROOT/pages/netty-component.adoc
@@ -526,24 +526,24 @@ be resolved when the endpoint is created.
 [source,java]
 ----
 ChannelHandlerFactory lengthDecoder = ChannelHandlerFactories.newLengthFieldBasedFrameDecoder(1048576, 0, 4, 0, 4);
- 
+
 StringDecoder stringDecoder = new StringDecoder();
 registry.bind("length-decoder", lengthDecoder);
 registry.bind("string-decoder", stringDecoder);
- 
+
 LengthFieldPrepender lengthEncoder = new LengthFieldPrepender(4);
 StringEncoder stringEncoder = new StringEncoder();
 registry.bind("length-encoder", lengthEncoder);
 registry.bind("string-encoder", stringEncoder);
- 
+
 List<ChannelHandler> decoders = new ArrayList<ChannelHandler>();
 decoders.add(lengthDecoder);
 decoders.add(stringDecoder);
- 
+
 List<ChannelHandler> encoders = new ArrayList<ChannelHandler>();
 encoders.add(lengthEncoder);
 encoders.add(stringEncoder);
- 
+
 registry.bind("encoders", encoders);
 registry.bind("decoders", decoders);
 ----
@@ -554,7 +554,7 @@ lists in an application context
 [source,xml]
 ----
 <util:list id="decoders" list-class="java.util.LinkedList">
-        <bean class="org.apache.camel.component.netty4.ChannelHandlerFactories" factory-method="newLengthFieldBasedFrameDecoder">
+        <bean class="org.apache.camel.component.netty.ChannelHandlerFactories" factory-method="newLengthFieldBasedFrameDecoder">
             <constructor-arg value="1048576"/>
             <constructor-arg value="0"/>
             <constructor-arg value="4"/>
@@ -576,7 +576,7 @@ lists in an application context
     </bean>
     <bean id="string-encoder" class="io.netty.handler.codec.string.StringEncoder"/>
 
-    <bean id="length-decoder" class="org.apache.camel.component.netty4.ChannelHandlerFactories" factory-method="newLengthFieldBasedFrameDecoder">
+    <bean id="length-decoder" class="org.apache.camel.component.netty.ChannelHandlerFactories" factory-method="newLengthFieldBasedFrameDecoder">
         <constructor-arg value="1048576"/>
         <constructor-arg value="0"/>
         <constructor-arg value="4"/>
@@ -592,7 +592,7 @@ a comma separated list or contained in a List e.g.
 [source,java]
 ----
  from("direct:multiple-codec").to("netty:tcp://0.0.0.0:{{port}}?encoders=#encoders&sync=false");
-                
+
  from("netty:tcp://0.0.0.0:{{port}}?decoders=#length-decoder,#string-decoder&sync=false").to("mock:multiple-codec");
 ----
 
@@ -738,9 +738,9 @@ using the `NettyWorkerPoolBuilder` with 2 worker threads as shown below:
 ----
 
 TIP: For boss thread pool there is a
-`org.apache.camel.component.netty4.NettyServerBossPoolBuilder` builder
+`org.apache.camel.component.netty.NettyServerBossPoolBuilder` builder
 for Netty consumers, and a
-`org.apache.camel.component.netty4.NettyClientBossPoolBuilder` for the
+`org.apache.camel.component.netty.NettyClientBossPoolBuilder` for the
 Netty producers.
 
 Then in the Camel routes we can refer to this worker pools by
diff --git a/docs/components/modules/ROOT/pages/netty-http-component.adoc b/docs/components/modules/ROOT/pages/netty-http-component.adoc
index d9d199b..358ce10 100644
--- a/docs/components/modules/ROOT/pages/netty-http-component.adoc
+++ b/docs/components/modules/ROOT/pages/netty-http-component.adoc
@@ -19,7 +19,7 @@ of the stream *once*. If you find a situation where the message body appears to
 you need to access the data multiple times (eg: doing multicasting, or
 redelivery error handling) you should use Stream caching or convert the
 message body to a `String` which is safe to be re-read multiple times. 
-Notice Netty4 HTTP reads the entire stream into memory using
+Notice Netty HTTP reads the entire stream into memory using
 `io.netty.handler.codec.http.HttpObjectAggregator` to build the entire
 full http message. But the resulting message is still a stream based
 message which is readable once.
@@ -80,7 +80,7 @@ This component inherits all the options from
 xref:netty-component.adoc[Netty], so make sure to look at
 the xref:netty-component.adoc[Netty] documentation as well.
 Notice that some options from xref:netty-component.adoc[Netty] is not
-applicable when using this Netty4 HTTP component, such as options
+applicable when using this Netty HTTP component, such as options
 related to UDP transport.
 ====
 
@@ -95,10 +95,10 @@ The Netty HTTP component supports 9 options, which are listed below.
 [width="100%",cols="2,5,^1,2",options="header"]
 |===
 | Name | Description | Default | Type
-| *nettyHttpBinding* (advanced) | To use a custom org.apache.camel.component.netty4.http.NettyHttpBinding for binding to/from Netty and Camel Message API. |  | NettyHttpBinding
+| *nettyHttpBinding* (advanced) | To use a custom org.apache.camel.component.netty.http.NettyHttpBinding for binding to/from Netty and Camel Message API. |  | NettyHttpBinding
 | *configuration* (common) | To use the NettyConfiguration as configuration when creating endpoints. |  | NettyHttpConfiguration
 | *headerFilterStrategy* (advanced) | To use a custom org.apache.camel.spi.HeaderFilterStrategy to filter headers. |  | HeaderFilterStrategy
-| *securityConfiguration* (security) | Refers to a org.apache.camel.component.netty4.http.NettyHttpSecurityConfiguration for configuring secure web resources. |  | NettyHttpSecurity Configuration
+| *securityConfiguration* (security) | Refers to a org.apache.camel.component.netty.http.NettyHttpSecurityConfiguration for configuring secure web resources. |  | NettyHttpSecurity Configuration
 | *useGlobalSslContext Parameters* (security) | Enable usage of global SSL context parameters. | false | boolean
 | *maximumPoolSize* (advanced) | The thread pool size for the EventExecutorGroup if its in use. The default value is 16. | 16 | int
 | *executorService* (advanced) | To use the given EventExecutorGroup. |  | EventExecutorGroup
@@ -169,7 +169,7 @@ with the following path and query parameters:
 | *serverExceptionCaughtLog Level* (consumer) | If the server (NettyConsumer) catches an exception then its logged using this logging level. | WARN | LoggingLevel
 | *serverInitializerFactory* (consumer) | To use a custom ServerInitializerFactory |  | ServerInitializer Factory
 | *traceEnabled* (consumer) | Specifies whether to enable HTTP TRACE for this Netty HTTP consumer. By default TRACE is turned off. | false | boolean
-| *urlDecodeHeaders* (consumer) | If this option is enabled, then during binding from Netty to Camel Message then the header values will be URL decoded (eg %20 will be a space character. Notice this option is used by the default org.apache.camel.component.netty.http.NettyHttpBinding and therefore if you implement a custom org.apache.camel.component.netty4.http.NettyHttpBinding then you would need to decode the headers accordingly to this option. | false | boolean
+| *urlDecodeHeaders* (consumer) | If this option is enabled, then during binding from Netty to Camel Message then the header values will be URL decoded (eg %20 will be a space character. Notice this option is used by the default org.apache.camel.component.netty.http.NettyHttpBinding and therefore if you implement a custom org.apache.camel.component.netty.http.NettyHttpBinding then you would need to decode the headers accordingly to this option. | false | boolean
 | *usingExecutorService* (consumer) | Whether to use ordered thread pool, to ensure events are processed orderly on the same channel. | true | boolean
 | *connectTimeout* (producer) | Time to wait for a socket connection to be available. Value is in milliseconds. | 10000 | int
 | *cookieHandler* (producer) | Configure a cookie handler to maintain a HTTP session |  | CookieHandler
@@ -190,7 +190,7 @@ with the following path and query parameters:
 | *disableStreamCache* (advanced) | Determines whether or not the raw input stream from Netty HttpRequest#getContent() or HttpResponset#getContent() is cached or not (Camel will read the stream into a in light-weight memory based Stream caching) cache. By default Camel will cache the Netty input stream to support reading it multiple times to ensure it Camel can retrieve all data from the stream. However you can set this option to true when you for example need to access the raw stream, s [...]
 | *headerFilterStrategy* (advanced) | To use a custom org.apache.camel.spi.HeaderFilterStrategy to filter headers. |  | HeaderFilterStrategy
 | *nativeTransport* (advanced) | Whether to use native transport instead of NIO. Native transport takes advantage of the host operating system and is only supported on some platforms. You need to add the netty JAR for the host operating system you are using. See more details at: \http://netty.io/wiki/native-transports.html | false | boolean
-| *nettyHttpBinding* (advanced) | To use a custom org.apache.camel.component.netty4.http.NettyHttpBinding for binding to/from Netty and Camel Message API. |  | NettyHttpBinding
+| *nettyHttpBinding* (advanced) | To use a custom org.apache.camel.component.netty.http.NettyHttpBinding for binding to/from Netty and Camel Message API. |  | NettyHttpBinding
 | *options* (advanced) | Allows to configure additional netty options using option. as prefix. For example option.child.keepAlive=false to set the netty option child.keepAlive=false. See the Netty documentation for possible options that can be used. |  | Map
 | *receiveBufferSize* (advanced) | The TCP/UDP buffer sizes to be used during inbound communication. Size is bytes. | 65536 | int
 | *receiveBufferSizePredictor* (advanced) | Configures the buffer size predictor. See details at Jetty documentation and this mail thread. |  | int
@@ -209,7 +209,7 @@ with the following path and query parameters:
 | *keyStoreResource* (security) | Client side certificate keystore to be used for encryption. Is loaded by default from classpath, but you can prefix with classpath:, file:, or http: to load the resource from different systems. |  | String
 | *needClientAuth* (security) | Configures whether the server needs client authentication when using SSL. | false | boolean
 | *passphrase* (security) | Password setting to use in order to encrypt/decrypt payloads sent using SSH |  | String
-| *securityConfiguration* (security) | Refers to a org.apache.camel.component.netty4.http.NettyHttpSecurityConfiguration for configuring secure web resources. |  | NettyHttpSecurity Configuration
+| *securityConfiguration* (security) | Refers to a org.apache.camel.component.netty.http.NettyHttpSecurityConfiguration for configuring secure web resources. |  | NettyHttpSecurity Configuration
 | *securityOptions* (security) | To configure NettyHttpSecurityConfiguration using key/value pairs from the map |  | Map
 | *securityProvider* (security) | Security provider to be used for payload encryption. Defaults to SunX509 if not set. |  | String
 | *ssl* (security) | Setting to specify whether SSL encryption is applied to this endpoint | false | boolean
@@ -266,13 +266,13 @@ The component supports 32 options, which are listed below.
 | *camel.component.netty-http.configuration.send503when-suspended* | Whether to send back HTTP status code 503 when the consumer has been suspended. If the option is false then the Netty Acceptor is unbound when the consumer is suspended, so clients cannot connect anymore. | true | Boolean
 | *camel.component.netty-http.configuration.throw-exception-on-failure* | Option to disable throwing the HttpOperationFailedException in case of failed responses from the remote server. This allows you to get all responses regardless of the HTTP status code. | true | Boolean
 | *camel.component.netty-http.configuration.transfer-exception* | If enabled and an Exchange failed processing on the consumer side, and if the caused Exception was send back serialized in the response as a application/x-java-serialized-object content type. On the producer side the exception will be deserialized and thrown as is, instead of the HttpOperationFailedException. The caused exception is required to be serialized. <p/> This is by default turned off. If you enable this then be a [...]
-| *camel.component.netty-http.configuration.url-decode-headers* | If this option is enabled, then during binding from Netty to Camel Message then the header values will be URL decoded (eg %20 will be a space character. Notice this option is used by the default org.apache.camel.component.netty.http.NettyHttpBinding and therefore if you implement a custom org.apache.camel.component.netty4.http.NettyHttpBinding then you would need to decode the headers accordingly to this option. | false | Boolean
+| *camel.component.netty-http.configuration.url-decode-headers* | If this option is enabled, then during binding from Netty to Camel Message then the header values will be URL decoded (eg %20 will be a space character. Notice this option is used by the default org.apache.camel.component.netty.http.NettyHttpBinding and therefore if you implement a custom org.apache.camel.component.netty.http.NettyHttpBinding then you would need to decode the headers accordingly to this option. | false | Boolean
 | *camel.component.netty-http.configuration.use-relative-path* | Sets whether to use a relative path in HTTP requests. | true | Boolean
 | *camel.component.netty-http.enabled* | Whether to enable auto configuration of the netty-http component. This is enabled by default. |  | Boolean
 | *camel.component.netty-http.executor-service* | To use the given EventExecutorGroup. The option is a io.netty.util.concurrent.EventExecutorGroup type. |  | String
 | *camel.component.netty-http.header-filter-strategy* | To use a custom org.apache.camel.spi.HeaderFilterStrategy to filter headers. The option is a org.apache.camel.spi.HeaderFilterStrategy type. |  | String
 | *camel.component.netty-http.maximum-pool-size* | The thread pool size for the EventExecutorGroup if its in use. The default value is 16. | 16 | Integer
-| *camel.component.netty-http.netty-http-binding* | To use a custom org.apache.camel.component.netty4.http.NettyHttpBinding for binding to/from Netty and Camel Message API. The option is a org.apache.camel.component.netty4.http.NettyHttpBinding type. |  | String
+| *camel.component.netty-http.netty-http-binding* | To use a custom org.apache.camel.component.netty.http.NettyHttpBinding for binding to/from Netty and Camel Message API. The option is a org.apache.camel.component.netty.http.NettyHttpBinding type. |  | String
 | *camel.component.netty-http.security-configuration.authenticate* | Whether to enable authentication <p/> This is by default enabled. |  | Boolean
 | *camel.component.netty-http.security-configuration.constraint* | The supported restricted. <p/> Currently only Basic is supported. |  | String
 | *camel.component.netty-http.security-configuration.login-denied-logging-level* | Sets a logging level to use for logging denied login attempts (incl stacktraces) <p/> This level is by default DEBUG. |  | LoggingLevel
@@ -321,7 +321,7 @@ success, and 500 for failure.
 |=======================================================================
 
 The following headers is provided as meta-data when a route starts from
-an Netty4 HTTP endpoint:
+an Netty HTTP endpoint:
 
 The description in the table takes offset in a route having:
 `from("netty-http:http:0.0.0.0:8080/myapp")...`
@@ -360,7 +360,7 @@ with the value `Basic`.
 == Access to Netty types
 
 This component uses the
-`org.apache.camel.component.netty4.http.NettyHttpMessage` as the message
+`org.apache.camel.component.netty.http.NettyHttpMessage` as the message
 implementation on the Exchange. This allows end
 users to get access to the original Netty request/response instances if
 needed, as shown below. Mind that the original response may not be
@@ -373,7 +373,7 @@ io.netty.handler.codec.http.HttpRequest request = exchange.getIn(NettyHttpMessag
 
 == Examples
 
-In the route below we use Netty4 HTTP as a HTTP server, which returns
+In the route below we use Netty HTTP as a HTTP server, which returns
 back a hardcoded "Bye World" message.
 
 [source,java]
@@ -395,7 +395,7 @@ And we get back "Bye World" as the output.
 
 === How do I let Netty match wildcards
 
-By default Netty4 HTTP will only match on exact uri's. But you can
+By default Netty HTTP will only match on exact uri's. But you can
 instruct Netty to match prefixes. For example
 
 [source,java]
@@ -403,7 +403,7 @@ instruct Netty to match prefixes. For example
 from("netty-http:http://0.0.0.0:8123/foo").to("mock:foo");
 -----------------------------------------------------------
 
-In the route above Netty4 HTTP will only match if the uri is an exact
+In the route above Netty HTTP will only match if the uri is an exact
 match, so it will match if you enter +
  `\http://0.0.0.0:8123/foo` but not match if you do
 `\http://0.0.0.0:8123/foo/bar`.
@@ -427,7 +427,7 @@ from("netty-http:http://0.0.0.0:8123?matchOnUriPrefix=true").to("mock:foo");
 === Using multiple routes with same port
 
 In the same CamelContext you can have multiple
-routes from Netty4 HTTP that shares the same port (eg a
+routes from Netty HTTP that shares the same port (eg a
 `io.netty.bootstrap.ServerBootstrap` instance). Doing this requires a
 number of bootstrap options to be identical in the routes, as the routes
 will share the same `io.netty.bootstrap.ServerBootstrap` instance. The
@@ -436,7 +436,7 @@ created.
 
 The options the routes must be identical configured is all the options
 defined in the
-`org.apache.camel.component.netty4.NettyServerBootstrapConfiguration`
+`org.apache.camel.component.netty.NettyServerBootstrapConfiguration`
 configuration class. If you have configured another route with different
 options, Camel will throw an exception on startup, indicating the
 options is not identical. To mitigate this ensure all options is
@@ -459,7 +459,7 @@ from("netty-http:http://0.0.0.0:{{port}}/bar")
 
 And here is an example of a mis configured 2nd route that do not have
 identical
-`org.apache.camel.component.netty4.NettyServerBootstrapConfiguration`
+`org.apache.camel.component.netty.NettyServerBootstrapConfiguration`
 option as the 1st route. This will cause Camel to fail on startup.
 
 *Two routes sharing the same port, but the 2nd route is misconfigured
@@ -481,13 +481,13 @@ from("netty-http:http://0.0.0.0:{{port}}/bar?ssl=true")
 
 By configuring the common server bootstrap option in an single instance
 of a
-`org.apache.camel.component.netty4.NettyServerBootstrapConfiguration`
-type, we can use the `bootstrapConfiguration` option on the Netty4 HTTP
+`org.apache.camel.component.netty.NettyServerBootstrapConfiguration`
+type, we can use the `bootstrapConfiguration` option on the Netty HTTP
 consumers to refer and reuse the same options across all consumers.
 
 [source,xml]
 -----------------------------------------------------------------------------------------------------------------
-<bean id="nettyHttpBootstrapOptions" class="org.apache.camel.component.netty4.NettyServerBootstrapConfiguration">
+<bean id="nettyHttpBootstrapOptions" class="org.apache.camel.component.netty.NettyServerBootstrapConfiguration">
   <property name="backlog" value="200"/>
   <property name="connectionTimeout" value="20000"/>
   <property name="workerCount" value="16"/>
@@ -574,7 +574,7 @@ containers.
 
 === Specifying ACL on web resources
 
-The `org.apache.camel.component.netty4.http.SecurityConstraint` allows
+The `org.apache.camel.component.netty.http.SecurityConstraint` allows
 to define constrains on web resources. And the
 `org.apache.camel.component.netty.http.SecurityConstraintMapping` is
 provided out of the box, allowing to easily define inclusions and
@@ -585,7 +585,7 @@ bean:
 
 [source,xml]
 -------------------------------------------------------------------------------------------------
-  <bean id="constraint" class="org.apache.camel.component.netty4.http.SecurityConstraintMapping">
+  <bean id="constraint" class="org.apache.camel.component.netty.http.SecurityConstraintMapping">
     <!-- inclusions defines url -> roles restrictions -->
     <!-- a * should be used for any role accepted (or even no roles) -->
     <property name="inclusions">
diff --git a/examples/camel-example-main-artemis/src/main/resources/META-INF/spring-configuration-metadata.json b/examples/camel-example-main-artemis/src/main/resources/META-INF/spring-configuration-metadata.json
index 8efef32..6274334 100644
--- a/examples/camel-example-main-artemis/src/main/resources/META-INF/spring-configuration-metadata.json
+++ b/examples/camel-example-main-artemis/src/main/resources/META-INF/spring-configuration-metadata.json
@@ -752,7 +752,7 @@
 			"name":"camel.rest.context-path",
 			"type":"java.lang.String",
 			"sourceType":"org.apache.camel.spi.RestConfiguration",
-			"description":"Sets a leading context-path the REST services will be using. This can be used when using components such as camel-servlet where the deployed web application is deployed using a context-path. Or for components such as camel-jetty or camel-netty4-http that includes a HTTP server."
+			"description":"Sets a leading context-path the REST services will be using. This can be used when using components such as camel-servlet where the deployed web application is deployed using a context-path. Or for components such as camel-jetty or camel-netty-http that includes a HTTP server."
 		},
 		{
 			"name":"camel.rest.cors-headers",
diff --git a/examples/camel-example-main-tiny/src/main/resources/META-INF/spring-configuration-metadata.json b/examples/camel-example-main-tiny/src/main/resources/META-INF/spring-configuration-metadata.json
index d1fcda2..76c501f 100644
--- a/examples/camel-example-main-tiny/src/main/resources/META-INF/spring-configuration-metadata.json
+++ b/examples/camel-example-main-tiny/src/main/resources/META-INF/spring-configuration-metadata.json
@@ -632,7 +632,7 @@
 			"name":"camel.rest.context-path",
 			"type":"java.lang.String",
 			"sourceType":"org.apache.camel.spi.RestConfiguration",
-			"description":"Sets a leading context-path the REST services will be using. This can be used when using components such as camel-servlet where the deployed web application is deployed using a context-path. Or for components such as camel-jetty or camel-netty4-http that includes a HTTP server."
+			"description":"Sets a leading context-path the REST services will be using. This can be used when using components such as camel-servlet where the deployed web application is deployed using a context-path. Or for components such as camel-jetty or camel-netty-http that includes a HTTP server."
 		},
 		{
 			"name":"camel.rest.cors-headers",
diff --git a/examples/camel-example-main/src/main/resources/META-INF/spring-configuration-metadata.json b/examples/camel-example-main/src/main/resources/META-INF/spring-configuration-metadata.json
index b0453f9..33e1b21 100644
--- a/examples/camel-example-main/src/main/resources/META-INF/spring-configuration-metadata.json
+++ b/examples/camel-example-main/src/main/resources/META-INF/spring-configuration-metadata.json
@@ -742,7 +742,7 @@
 			"name":"camel.rest.context-path",
 			"type":"java.lang.String",
 			"sourceType":"org.apache.camel.spi.RestConfiguration",
-			"description":"Sets a leading context-path the REST services will be using. This can be used when using components such as camel-servlet where the deployed web application is deployed using a context-path. Or for components such as camel-jetty or camel-netty4-http that includes a HTTP server."
+			"description":"Sets a leading context-path the REST services will be using. This can be used when using components such as camel-servlet where the deployed web application is deployed using a context-path. Or for components such as camel-jetty or camel-netty-http that includes a HTTP server."
 		},
 		{
 			"name":"camel.rest.cors-headers",
diff --git a/examples/camel-example-netty-custom-correlation/src/main/java/org/apache/camel/example/netty/MyCodecDecoderFactory.java b/examples/camel-example-netty-custom-correlation/src/main/java/org/apache/camel/example/netty/MyCodecDecoderFactory.java
index 6e1e226..6a5f160 100644
--- a/examples/camel-example-netty-custom-correlation/src/main/java/org/apache/camel/example/netty/MyCodecDecoderFactory.java
+++ b/examples/camel-example-netty-custom-correlation/src/main/java/org/apache/camel/example/netty/MyCodecDecoderFactory.java
@@ -17,7 +17,7 @@
 package org.apache.camel.example.netty;
 
 import io.netty.channel.ChannelHandler;
-import org.apache.camel.component.netty4.DefaultChannelHandlerFactory;
+import org.apache.camel.component.netty.DefaultChannelHandlerFactory;
 
 public class MyCodecDecoderFactory extends DefaultChannelHandlerFactory {
 
diff --git a/examples/camel-example-netty-custom-correlation/src/main/java/org/apache/camel/example/netty/MyCodecEncoderFactory.java b/examples/camel-example-netty-custom-correlation/src/main/java/org/apache/camel/example/netty/MyCodecEncoderFactory.java
index 023d937..2008a89 100644
--- a/examples/camel-example-netty-custom-correlation/src/main/java/org/apache/camel/example/netty/MyCodecEncoderFactory.java
+++ b/examples/camel-example-netty-custom-correlation/src/main/java/org/apache/camel/example/netty/MyCodecEncoderFactory.java
@@ -17,7 +17,7 @@
 package org.apache.camel.example.netty;
 
 import io.netty.channel.ChannelHandler;
-import org.apache.camel.component.netty4.DefaultChannelHandlerFactory;
+import org.apache.camel.component.netty.DefaultChannelHandlerFactory;
 
 public class MyCodecEncoderFactory extends DefaultChannelHandlerFactory {
 
diff --git a/examples/camel-example-netty-custom-correlation/src/main/java/org/apache/camel/example/netty/MyCorrelationManager.java b/examples/camel-example-netty-custom-correlation/src/main/java/org/apache/camel/example/netty/MyCorrelationManager.java
index 59f170d..b16bb8e 100644
--- a/examples/camel-example-netty-custom-correlation/src/main/java/org/apache/camel/example/netty/MyCorrelationManager.java
+++ b/examples/camel-example-netty-custom-correlation/src/main/java/org/apache/camel/example/netty/MyCorrelationManager.java
@@ -16,11 +16,11 @@
  */
 package org.apache.camel.example.netty;
 
-import org.apache.camel.component.netty4.TimeoutCorrelationManagerSupport;
+import org.apache.camel.component.netty.TimeoutCorrelationManagerSupport;
 import org.apache.camel.util.StringHelper;
 
 /**
- * Implement a timeout aware {@link org.apache.camel.component.netty4.NettyCamelStateCorrelationManager}
+ * Implement a timeout aware {@link org.apache.camel.component.netty.NettyCamelStateCorrelationManager}
  * that handles all the complexities for us, so we only need to implement how to extract the correlation id.
  */
 public class MyCorrelationManager extends TimeoutCorrelationManagerSupport {
diff --git a/examples/camel-example-netty-http/myapp-cdi/pom.xml b/examples/camel-example-netty-http/myapp-cdi/pom.xml
index 6ad4258..d40b253 100644
--- a/examples/camel-example-netty-http/myapp-cdi/pom.xml
+++ b/examples/camel-example-netty-http/myapp-cdi/pom.xml
@@ -66,8 +66,8 @@
                     <instructions>
                         <Bundle-SymbolicName>${project.groupId}.${project.artifactId}</Bundle-SymbolicName>
                         <Import-Package>
-                            org.apache.camel.component.netty4,
-                            org.apache.camel.component.netty4.http,
+                            org.apache.camel.component.netty,
+                            org.apache.camel.component.netty.http,
                             org.apache.camel.spi,
                             *
                         </Import-Package>
diff --git a/examples/camel-example-netty-http/myapp-cdi/src/main/java/org/apache/camel/example/netty/cdi/NettyHttpRoute.java b/examples/camel-example-netty-http/myapp-cdi/src/main/java/org/apache/camel/example/netty/cdi/NettyHttpRoute.java
index 2099e09..23f0eec 100644
--- a/examples/camel-example-netty-http/myapp-cdi/src/main/java/org/apache/camel/example/netty/cdi/NettyHttpRoute.java
+++ b/examples/camel-example-netty-http/myapp-cdi/src/main/java/org/apache/camel/example/netty/cdi/NettyHttpRoute.java
@@ -22,7 +22,7 @@ import javax.inject.Inject;
 import javax.inject.Named;
 
 import org.apache.camel.builder.RouteBuilder;
-import org.apache.camel.component.netty4.http.NettySharedHttpServer;
+import org.apache.camel.component.netty.http.NettySharedHttpServer;
 import org.ops4j.pax.cdi.api.Service;
 
 @ApplicationScoped
diff --git a/examples/camel-example-netty-http/myapp-one/pom.xml b/examples/camel-example-netty-http/myapp-one/pom.xml
index e7f64ac..82fe402 100644
--- a/examples/camel-example-netty-http/myapp-one/pom.xml
+++ b/examples/camel-example-netty-http/myapp-one/pom.xml
@@ -34,8 +34,8 @@
 
     <properties>
         <camel.osgi.import.pkg>
-            org.apache.camel.component.netty4,
-            org.apache.camel.component.netty4.http,
+            org.apache.camel.component.netty,
+            org.apache.camel.component.netty.http,
             org.osgi.service.blueprint,
             *
         </camel.osgi.import.pkg>
diff --git a/examples/camel-example-netty-http/myapp-one/src/main/resources/OSGI-INF/blueprint/camel-one.xml b/examples/camel-example-netty-http/myapp-one/src/main/resources/OSGI-INF/blueprint/camel-one.xml
index 5233d22..67243d1 100644
--- a/examples/camel-example-netty-http/myapp-one/src/main/resources/OSGI-INF/blueprint/camel-one.xml
+++ b/examples/camel-example-netty-http/myapp-one/src/main/resources/OSGI-INF/blueprint/camel-one.xml
@@ -23,7 +23,7 @@
            http://www.osgi.org/xmlns/blueprint/v1.0.0 https://www.osgi.org/xmlns/blueprint/v1.0.0/blueprint.xsd">
 
   <!-- reference the shared http server -->
-  <reference id="sharedNettyHttpServer" interface="org.apache.camel.component.netty4.http.NettySharedHttpServer"/>
+  <reference id="sharedNettyHttpServer" interface="org.apache.camel.component.netty.http.NettySharedHttpServer"/>
 
   <!-- Camel application which uses the netty-http component and the shared Netty HTTP server -->
   <camelContext xmlns="http://camel.apache.org/schema/blueprint">
diff --git a/examples/camel-example-netty-http/myapp-two/pom.xml b/examples/camel-example-netty-http/myapp-two/pom.xml
index b4a0936..eaffac6 100644
--- a/examples/camel-example-netty-http/myapp-two/pom.xml
+++ b/examples/camel-example-netty-http/myapp-two/pom.xml
@@ -34,8 +34,8 @@
 
     <properties>
         <camel.osgi.import.pkg>
-            org.apache.camel.component.netty4,
-            org.apache.camel.component.netty4.http,
+            org.apache.camel.component.netty,
+            org.apache.camel.component.netty.http,
             org.osgi.service.blueprint,
             *
         </camel.osgi.import.pkg>
diff --git a/examples/camel-example-netty-http/myapp-two/src/main/resources/OSGI-INF/blueprint/camel-two.xml b/examples/camel-example-netty-http/myapp-two/src/main/resources/OSGI-INF/blueprint/camel-two.xml
index 1276e01..33ebb45 100644
--- a/examples/camel-example-netty-http/myapp-two/src/main/resources/OSGI-INF/blueprint/camel-two.xml
+++ b/examples/camel-example-netty-http/myapp-two/src/main/resources/OSGI-INF/blueprint/camel-two.xml
@@ -23,7 +23,7 @@
            http://www.osgi.org/xmlns/blueprint/v1.0.0 https://www.osgi.org/xmlns/blueprint/v1.0.0/blueprint.xsd">
 
   <!-- reference the shared http server -->
-  <reference id="sharedNettyHttpServer" interface="org.apache.camel.component.netty4.http.NettySharedHttpServer"/>
+  <reference id="sharedNettyHttpServer" interface="org.apache.camel.component.netty.http.NettySharedHttpServer"/>
 
   <!-- Camel application which uses the netty-http component and the shared Netty HTTP server -->
   <camelContext xmlns="http://camel.apache.org/schema/blueprint">
diff --git a/examples/camel-example-netty-http/shared-netty-http-server/pom.xml b/examples/camel-example-netty-http/shared-netty-http-server/pom.xml
index 0ada20e..d4b65a6 100644
--- a/examples/camel-example-netty-http/shared-netty-http-server/pom.xml
+++ b/examples/camel-example-netty-http/shared-netty-http-server/pom.xml
@@ -34,8 +34,8 @@
 
     <properties>
         <camel.osgi.import.pkg>
-            org.apache.camel.component.netty4,
-            org.apache.camel.component.netty4.http,
+            org.apache.camel.component.netty,
+            org.apache.camel.component.netty.http,
             org.osgi.service.blueprint
         </camel.osgi.import.pkg>
         <camel.osgi.export.pkg>
diff --git a/examples/camel-example-netty-http/shared-netty-http-server/src/main/resources/OSGI-INF/blueprint/http-server.xml b/examples/camel-example-netty-http/shared-netty-http-server/src/main/resources/OSGI-INF/blueprint/http-server.xml
index 02c869e..e78e388 100644
--- a/examples/camel-example-netty-http/shared-netty-http-server/src/main/resources/OSGI-INF/blueprint/http-server.xml
+++ b/examples/camel-example-netty-http/shared-netty-http-server/src/main/resources/OSGI-INF/blueprint/http-server.xml
@@ -23,7 +23,7 @@
            http://www.osgi.org/xmlns/blueprint/v1.0.0 https://www.osgi.org/xmlns/blueprint/v1.0.0/blueprint.xsd">
 
   <!-- netty http bootstrap configuration -->
-  <bean id="configuration" class="org.apache.camel.component.netty4.http.NettySharedHttpServerBootstrapConfiguration">
+  <bean id="configuration" class="org.apache.camel.component.netty.http.NettySharedHttpServerBootstrapConfiguration">
      <!-- the port and host is mandatory and must be set -->
     <property name="port" value="8888"/>
     <property name="host" value="0.0.0.0"/>
@@ -32,12 +32,12 @@
   </bean>
 
   <!-- the netty http server -->
-  <bean id="httpServer" class="org.apache.camel.component.netty4.http.DefaultNettySharedHttpServer"
+  <bean id="httpServer" class="org.apache.camel.component.netty.http.DefaultNettySharedHttpServer"
         init-method="start" destroy-method="stop">
     <property name="nettyServerBootstrapConfiguration" ref="configuration"/>
   </bean>
 
   <!-- export in the OSGi server registry so we can use it from the Camel application bundles -->
-  <service ref="httpServer" interface="org.apache.camel.component.netty4.http.NettySharedHttpServer"/>
+  <service ref="httpServer" interface="org.apache.camel.component.netty.http.NettySharedHttpServer"/>
 
 </blueprint>
diff --git a/platforms/spring-boot/components-starter/camel-netty-http-starter/src/main/java/org/apache/camel/component/netty4/http/springboot/NettyHttpComponentAutoConfiguration.java b/platforms/spring-boot/components-starter/camel-netty-http-starter/src/main/java/org/apache/camel/component/netty/http/springboot/NettyHttpComponentAutoConfiguration.java
similarity index 97%
rename from platforms/spring-boot/components-starter/camel-netty-http-starter/src/main/java/org/apache/camel/component/netty4/http/springboot/NettyHttpComponentAutoConfiguration.java
rename to platforms/spring-boot/components-starter/camel-netty-http-starter/src/main/java/org/apache/camel/component/netty/http/springboot/NettyHttpComponentAutoConfiguration.java
index 38542e8..ca63c19 100644
--- a/platforms/spring-boot/components-starter/camel-netty-http-starter/src/main/java/org/apache/camel/component/netty4/http/springboot/NettyHttpComponentAutoConfiguration.java
+++ b/platforms/spring-boot/components-starter/camel-netty-http-starter/src/main/java/org/apache/camel/component/netty/http/springboot/NettyHttpComponentAutoConfiguration.java
@@ -14,14 +14,14 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http.springboot;
+package org.apache.camel.component.netty.http.springboot;
 
 import java.util.HashMap;
 import java.util.List;
 import java.util.Map;
 import javax.annotation.Generated;
 import org.apache.camel.CamelContext;
-import org.apache.camel.component.netty4.http.NettyHttpComponent;
+import org.apache.camel.component.netty.http.NettyHttpComponent;
 import org.apache.camel.spi.ComponentCustomizer;
 import org.apache.camel.spi.HasId;
 import org.apache.camel.spring.boot.CamelAutoConfiguration;
diff --git a/platforms/spring-boot/components-starter/camel-netty-http-starter/src/main/java/org/apache/camel/component/netty4/http/springboot/NettyHttpComponentConfiguration.java b/platforms/spring-boot/components-starter/camel-netty-http-starter/src/main/java/org/apache/camel/component/netty/http/springboot/NettyHttpComponentConfiguration.java
similarity index 96%
rename from platforms/spring-boot/components-starter/camel-netty-http-starter/src/main/java/org/apache/camel/component/netty4/http/springboot/NettyHttpComponentConfiguration.java
rename to platforms/spring-boot/components-starter/camel-netty-http-starter/src/main/java/org/apache/camel/component/netty/http/springboot/NettyHttpComponentConfiguration.java
index 8d52e94..a1fb5f5 100644
--- a/platforms/spring-boot/components-starter/camel-netty-http-starter/src/main/java/org/apache/camel/component/netty4/http/springboot/NettyHttpComponentConfiguration.java
+++ b/platforms/spring-boot/components-starter/camel-netty-http-starter/src/main/java/org/apache/camel/component/netty/http/springboot/NettyHttpComponentConfiguration.java
@@ -14,12 +14,12 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.http.springboot;
+package org.apache.camel.component.netty.http.springboot;
 
 import javax.annotation.Generated;
 import org.apache.camel.LoggingLevel;
-import org.apache.camel.component.netty4.http.SecurityAuthenticator;
-import org.apache.camel.component.netty4.http.SecurityConstraint;
+import org.apache.camel.component.netty.http.SecurityAuthenticator;
+import org.apache.camel.component.netty.http.SecurityConstraint;
 import org.apache.camel.spring.boot.ComponentConfigurationPropertiesCommon;
 import org.springframework.boot.context.properties.ConfigurationProperties;
 
@@ -40,9 +40,9 @@ public class NettyHttpComponentConfiguration
      */
     private Boolean enabled;
     /**
-     * To use a custom org.apache.camel.component.netty4.http.NettyHttpBinding
+     * To use a custom org.apache.camel.component.netty.http.NettyHttpBinding
      * for binding to/from Netty and Camel Message API. The option is a
-     * org.apache.camel.component.netty4.http.NettyHttpBinding type.
+     * org.apache.camel.component.netty.http.NettyHttpBinding type.
      */
     private String nettyHttpBinding;
     /**
@@ -56,7 +56,7 @@ public class NettyHttpComponentConfiguration
     private String headerFilterStrategy;
     /**
      * Refers to a
-     * org.apache.camel.component.netty4.http.NettyHttpSecurityConfiguration for
+     * org.apache.camel.component.netty.http.NettyHttpSecurityConfiguration for
      * configuring secure web resources.
      */
     private NettyHttpSecurityConfigurationNestedConfiguration securityConfiguration;
@@ -161,7 +161,7 @@ public class NettyHttpComponentConfiguration
     }
 
     public static class NettyHttpConfigurationNestedConfiguration {
-        public static final Class CAMEL_NESTED_CLASS = org.apache.camel.component.netty4.http.NettyHttpConfiguration.class;
+        public static final Class CAMEL_NESTED_CLASS = org.apache.camel.component.netty.http.NettyHttpConfiguration.class;
         /**
          * The protocol to use which is either http, https or proxy - a consumer
          * only option.
@@ -205,8 +205,8 @@ public class NettyHttpComponentConfiguration
          * space character. Notice this option is used by the default
          * org.apache.camel.component.netty.http.NettyHttpBinding and therefore
          * if you implement a custom
-         * org.apache.camel.component.netty4.http.NettyHttpBinding then you
-         * would need to decode the headers accordingly to this option.
+         * org.apache.camel.component.netty.http.NettyHttpBinding then you would
+         * need to decode the headers accordingly to this option.
          */
         private Boolean urlDecodeHeaders = false;
         /**
@@ -425,7 +425,7 @@ public class NettyHttpComponentConfiguration
     }
 
     public static class NettyHttpSecurityConfigurationNestedConfiguration {
-        public static final Class CAMEL_NESTED_CLASS = org.apache.camel.component.netty4.http.NettyHttpSecurityConfiguration.class;
+        public static final Class CAMEL_NESTED_CLASS = org.apache.camel.component.netty.http.NettyHttpSecurityConfiguration.class;
         /**
          * Whether to enable authentication <p/> This is by default enabled.
          */
diff --git a/platforms/spring-boot/components-starter/camel-netty-http-starter/src/main/resources/META-INF/spring.factories b/platforms/spring-boot/components-starter/camel-netty-http-starter/src/main/resources/META-INF/spring.factories
index fbf34a4..bd1235a 100644
--- a/platforms/spring-boot/components-starter/camel-netty-http-starter/src/main/resources/META-INF/spring.factories
+++ b/platforms/spring-boot/components-starter/camel-netty-http-starter/src/main/resources/META-INF/spring.factories
@@ -16,4 +16,4 @@
 ## ---------------------------------------------------------------------------
 
 org.springframework.boot.autoconfigure.EnableAutoConfiguration=\
-org.apache.camel.component.netty4.http.springboot.NettyHttpComponentAutoConfiguration
+org.apache.camel.component.netty.http.springboot.NettyHttpComponentAutoConfiguration
diff --git a/platforms/spring-boot/components-starter/camel-netty-starter/src/main/java/org/apache/camel/component/netty4/springboot/NettyComponentAutoConfiguration.java b/platforms/spring-boot/components-starter/camel-netty-starter/src/main/java/org/apache/camel/component/netty/springboot/NettyComponentAutoConfiguration.java
similarity index 98%
rename from platforms/spring-boot/components-starter/camel-netty-starter/src/main/java/org/apache/camel/component/netty4/springboot/NettyComponentAutoConfiguration.java
rename to platforms/spring-boot/components-starter/camel-netty-starter/src/main/java/org/apache/camel/component/netty/springboot/NettyComponentAutoConfiguration.java
index 96b55c7..bfc5a18 100644
--- a/platforms/spring-boot/components-starter/camel-netty-starter/src/main/java/org/apache/camel/component/netty4/springboot/NettyComponentAutoConfiguration.java
+++ b/platforms/spring-boot/components-starter/camel-netty-starter/src/main/java/org/apache/camel/component/netty/springboot/NettyComponentAutoConfiguration.java
@@ -14,14 +14,14 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.springboot;
+package org.apache.camel.component.netty.springboot;
 
 import java.util.HashMap;
 import java.util.List;
 import java.util.Map;
 import javax.annotation.Generated;
 import org.apache.camel.CamelContext;
-import org.apache.camel.component.netty4.NettyComponent;
+import org.apache.camel.component.netty.NettyComponent;
 import org.apache.camel.spi.ComponentCustomizer;
 import org.apache.camel.spi.HasId;
 import org.apache.camel.spring.boot.CamelAutoConfiguration;
diff --git a/platforms/spring-boot/components-starter/camel-netty-starter/src/main/java/org/apache/camel/component/netty4/springboot/NettyComponentConfiguration.java b/platforms/spring-boot/components-starter/camel-netty-starter/src/main/java/org/apache/camel/component/netty/springboot/NettyComponentConfiguration.java
similarity index 98%
rename from platforms/spring-boot/components-starter/camel-netty-starter/src/main/java/org/apache/camel/component/netty4/springboot/NettyComponentConfiguration.java
rename to platforms/spring-boot/components-starter/camel-netty-starter/src/main/java/org/apache/camel/component/netty/springboot/NettyComponentConfiguration.java
index 2598699..cebf1ce 100644
--- a/platforms/spring-boot/components-starter/camel-netty-starter/src/main/java/org/apache/camel/component/netty4/springboot/NettyComponentConfiguration.java
+++ b/platforms/spring-boot/components-starter/camel-netty-starter/src/main/java/org/apache/camel/component/netty/springboot/NettyComponentConfiguration.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.component.netty4.springboot;
+package org.apache.camel.component.netty.springboot;
 
 import java.io.File;
 import java.util.List;
@@ -25,11 +25,11 @@ import io.netty.channel.EventLoopGroup;
 import io.netty.channel.group.ChannelGroup;
 import io.netty.handler.ssl.SslHandler;
 import org.apache.camel.LoggingLevel;
-import org.apache.camel.component.netty4.ClientInitializerFactory;
-import org.apache.camel.component.netty4.NettyCamelStateCorrelationManager;
-import org.apache.camel.component.netty4.NettyServerBootstrapFactory;
-import org.apache.camel.component.netty4.ServerInitializerFactory;
-import org.apache.camel.component.netty4.TextLineDelimiter;
+import org.apache.camel.component.netty.ClientInitializerFactory;
+import org.apache.camel.component.netty.NettyCamelStateCorrelationManager;
+import org.apache.camel.component.netty.NettyServerBootstrapFactory;
+import org.apache.camel.component.netty.ServerInitializerFactory;
+import org.apache.camel.component.netty.TextLineDelimiter;
 import org.apache.camel.spring.boot.ComponentConfigurationPropertiesCommon;
 import org.apache.camel.support.jsse.SSLContextParameters;
 import org.springframework.boot.context.properties.ConfigurationProperties;
@@ -131,7 +131,7 @@ public class NettyComponentConfiguration
     }
 
     public static class NettyConfigurationNestedConfiguration {
-        public static final Class CAMEL_NESTED_CLASS = org.apache.camel.component.netty4.NettyConfiguration.class;
+        public static final Class CAMEL_NESTED_CLASS = org.apache.camel.component.netty.NettyConfiguration.class;
         /**
          * Allows to use a timeout for the Netty producer when calling a remote
          * server. By default no timeout is in use. The value is in milli
diff --git a/platforms/spring-boot/components-starter/camel-netty-starter/src/main/resources/META-INF/spring.factories b/platforms/spring-boot/components-starter/camel-netty-starter/src/main/resources/META-INF/spring.factories
index 4c1bf9b..22ae890 100644
--- a/platforms/spring-boot/components-starter/camel-netty-starter/src/main/resources/META-INF/spring.factories
+++ b/platforms/spring-boot/components-starter/camel-netty-starter/src/main/resources/META-INF/spring.factories
@@ -16,4 +16,4 @@
 ## ---------------------------------------------------------------------------
 
 org.springframework.boot.autoconfigure.EnableAutoConfiguration=\
-org.apache.camel.component.netty4.springboot.NettyComponentAutoConfiguration
+org.apache.camel.component.netty.springboot.NettyComponentAutoConfiguration
diff --git a/tooling/apt/src/main/java/org/apache/camel/tools/apt/DocumentationHelper.java b/tooling/apt/src/main/java/org/apache/camel/tools/apt/DocumentationHelper.java
index c0901e8..fb243e3 100644
--- a/tooling/apt/src/main/java/org/apache/camel/tools/apt/DocumentationHelper.java
+++ b/tooling/apt/src/main/java/org/apache/camel/tools/apt/DocumentationHelper.java
@@ -103,7 +103,7 @@ public final class DocumentationHelper {
         } else if ("https".equals(extendsScheme)) {
             return new File("../camel-http/target/classes/org/apache/camel/component/http/https.json");
         } else if ("netty".equals(extendsScheme)) {
-            return new File("../camel-netty/target/classes/org/apache/camel/component/netty4/netty.json");
+            return new File("../camel-netty/target/classes/org/apache/camel/component/netty/netty.json");
         } else if ("servlet".equals(extendsScheme)) {
             return new File("../camel-servlet/target/classes/org/apache/camel/component/servlet/servlet.json");
         }