Red Hat Training

A Red Hat training course is available for Red Hat Fuse

Release Notes

Red Hat JBoss Fuse

What's new in Red Hat JBoss Fuse

Red Hat

Version 6.0
13 Oct 2017

Abstract

These notes provide an overview of the changes between each release of Red Hat JBoss Fuse.

Chapter 1. Security Alerts

The following security alerts are know to affect 6.0:
Security vulnerability in Camel Restlet component
The APPLICATION_JAVA_OBJECT and APPLICATION_JAVA_OBJECT_XML media types are not safe to use from a security perspective. There is a weakness in the XML deserialization mechanism used by these media types, which allows a remote attacker to force the JVM to execute unwanted Java code embedded inside a specially-crafted request to the REST endpoint. By default, camel-restlet uses the APPLICATION_WWW_FORM media type, which is not affected by this issue. It is possible to change the media type by setting the Content-Type message header. If you do so, it is important to ensure you do not use the APPLICATION_JAVA_OBJECT and APPLICATION_JAVA_OBJECT_XML media types. These media types will be disabled entirely in a future release.

Chapter 2. Known issues

The following issues are known to exist in 6.0:
Cannot use the help in the generic Apache Karaf shell
Red Hat JBoss A-MQ's console is normally launched using the fusemq command which is fully functional. However, Red Hat JBoss A-MQ also includes a generic Apache Karaf shell that can be launched using the shell command. In the generic shell, the help command throws an exception.
We do not recommend using the generic Apache Karaf shell.
ls can cause an exception
The ls console command, which is used for inspecting OSGi bundles, will throw an exception when listing the contents of some bundles.
Microsoft Visual C++ Runtime required on Windows 7 64-bit
On certain 64bit Windows platforms you need Microsoft Visual C++ 2008 Redistributable Package (x64) installed or Red Hat JBoss A-MQ will not start.
Java hash code security vulnerability
It was found that the Java hashCode() method implementation was susceptible to predictable hash collisions. A remote attacker could use this flaw to cause the Jetty HTTP server (a component of Apache Karaf used by Red Hat JBoss Fuse) to use an excessive amount of CPU time by sending an HTTP request with a large number of parameters whose names map to the same hash value. This update introduces a limit of 1000 on the number of parameters processed per request to mitigate this issue.
The Fuse IDE's Properties view sometimes gets stuck displaying the status or properties of a process previously selected in Fuse JMX Navigator.
When this happens, click the unpin button on the Properties view tool bar to populate the Properties view with the status or properties of a newly selected process.
Red Hat JBoss Fuse IDE may fail to download all Maven dependencies when you create a project
When this happens, you may not be able to run the project as a Local Camel Context. You can force the downloading of missing Maven dependencies by right-clicking the newly created project's root folder (not the pom.xml file) in Package Explorer/Project Explorer, and selecting MavenUpdate Project with the Force Update of Snapshots/Releases option enabled.
Fast switching between a node's configuration tabs in the Fuse IDE's Properties view can cause a StackOverflowException
For example, switching quickly between the data format tabs of a Marshal or Unmarshal node can cause this exception.
For a few EIPs, adding them to a route in the Fuse IDE's Design view can generate a duplicate <from/> element within the <route/> element
Typically, this happens when, for example, you have a route that contains a choice node with its own internal target endpoints followed by another target endpoint outside the choice node. Instead of one flow in which messages first traverse the choice node then continue through the trailing endpoint, the route editor's Design view creates and inserts a duplicate<from/> element inside the <route/> element to generate two separate flows—one going through the choice node, and the other going directly to the trailing endpoint.
Used similarly, these EIPs also generate duplicate <from/> elements:
  • multicast
  • pipeline
  • splitter
  • load balance
  • filter
  • resequence
  • throttle
When you create such routes using these EIPs, and you want to retain a single flow, create the routes in Source view, not Design view, to avoid generating a duplicate <from/> element in your route.

Chapter 3. Resolved Issues

Fuse

Table 3.1, “Fuse Issues Resolved in 6.0” lists the issues resolved between Fuse ESB Enterprise 7.1 and 6.0.

Table 3.1. Fuse Issues Resolved in 6.0

Issue NumberDescription
ENTESB-568smx4-nmr-1.6.0.fuse-7-2-x-stable builds are failing
ENTESB-668Plug in provder should be Red Hat, Inc.
ENTESB-454jruby.jar as shipped with Fuse ESB Enterprise exposes CVE-2012-5370
ENTESB-487camel-spring is listed 2 times in boot features in esb-minimum
ENTESB-498Serp dependency is not being installed in Fabric container when installing the camel-jpa feature
ENTESB-522Camel Master Component Ignoring parameters
ENTESB-523Camel Fabric component doesn't take the parameters into consideration
ENTESB-541Unable to deploy Sample camel-web archetype to Fuse ESB 7.1 - Unexpected exception parsing XML document from ServletContext resource
ENTESB-556Doc links should point to customer portal
ENTESB-580Change Copyright Fusesource to RedHat
ENTESB-585Demo readmes refer to fuseesb.bat - redhat-006
ENTESB-587ER1: Warning building demos - redhat-007
ENTESB-588ER1: Running container-list gives error - redhat-007 kits
ENTESB-591ER1: Error when creating child container with "default" profile (-007 kit)
ENTESB-600ER1: soap example - Error reading XMLStreamReader
ENTESB-601ER1: rest example (and other examples) - wrong resources package
ENTESB-605pax-url does not handle escaped characters in url
ENTESB-614Unable to install demos redhat-012 kits
ENTESB-615Typo in README.md in rest and secure-rest examples
ENTESB-616Executing Rest example throws java.lang.reflect.UndeclaredThrowableException
ENTESB-624activemq-camel doesn't import the package from camel-core and camel-jms
ENTESB-626Fuse Examples document links should point to RedHat Portal
ENTESB-628example/jms has the dependency of activemq-camel
ENTESB-637gnoring converter type: org.apache.activemq.camel.converter.ActiveMQMessageConverter as a dependent class could not be found: java.lang.NoClassDefFoundError: org/apache/camel/component/jms/JmsBinding
ENTESB-639Different default credentials expected by fabric examples
ENTESB-648Null Pointer if invalid patch command syntax is used
ENTESB-652cxf-codefirst archetype has an error
ENTESB-658fabric-cxf bundle should exports the version
ENTESB-665In Fabric you can assign same profile to container more than once
ENTESB-669Few features can't be installed
ENTESB-674NullPointer exception on HttpGenerator.toString(HttpGenerator.java:1079)
ENTESB-682try to install unzip if unavailable
ENTESB-566smx4-features-4.5.0.fuse-7-2-x-stable builds are failing
ENTESB-569smx-components-2012.01.0.fuse-7-2-x-stable tests fail with multiple NoClassDefFoundError
ENTESB-638Sync jetty version between poms and features
SMXCOMP-956AsyncBaseLifeCycle should be able to return Error MessageExchange if provider threadpool is run out
SMXCOMP-963StaticRoutingSlip doesn't propagate errors to the caller endpoint when some endpoints in in the slip doesn't exist
SMXCOMP-964Camel doesn't return error while invoking jbi endpoint which doesn't exist, setting up a infinite loop on retry
SMXCOMP-965HttpConsumerEndpoint invokes sendError with null exchange
SMX4-1273cxf-nmr trasport should copy the message header which value is String as the Protocol Header
SMX4-1424Use official org.jruby:jruby lib
SMX4NMR-307org.apache.servicemix.nmr.osgi can throw an exception when shutting down
SMX4NMR-312Upgrade to Woodstox 4.2.0
SMX4NMR-308Upgrade to ActiveMQ 5.8.0
SMX4-1373infinite loop in BundleFactoryLoader

Messaging

Table 3.2, “Messaging Issues Resolved in 6.0” lists the issues resolved between Fuse ESB Enterprise 7.1 and 6.0.

Table 3.2. Messaging Issues Resolved in 6.0

Issue NumberDescription
AMQ-1870JDBC exception when sending and receiving a lot of messages
AMQ-2098Advisory messages are empty when received with a Stomp subscription
AMQ-2740NullPointerException in Web Console when using an existing browser session with a restarted broker instance
AMQ-3016Race condition in DemandForwardingBridgeSupport can cause remote connection to be leaked.
AMQ-3038Possible Memory-Leak as ActiveMQTempDestinations don't get deleted when ActiveMQConnection.close() is called
AMQ-3261Setup writes incorrect jmx port
AMQ-3485TransactedSession returns invalid MessageConsumer after the first MessageConsumer for the same destination.
AMQ-3539Prefetch state can be incorrect when transacted redelivery of duplicates occurs, causing stalled queue
AMQ-3746Non Durable Topic subscription with prefetch=0, MessageConsumer.receivenowait() hangs indefinitely
AMQ-3791Flexibility, concurrency, security, and compatibility issues in CachedLDAPAuthorizationMap
AMQ-3906Repeated error message regarding chunk stream logged
AMQ-3930DataFileNotDeletedTest.testForDataFileNotDeletedTransacted() fails intermittently
AMQ-4033Broker uses custom RMIServerSocketFactory class which cannot be unloaded due socket reuse
AMQ-4062durableTopicPrefetch attribute in policyEntry in activemq.xml doesn't take effect
AMQ-4103LeaseDatabaseLocker can not be changed from 5 sec poll
AMQ-4106STOMP+NIO and Heartbeats gives consistent InactivityIOException
AMQ-4108Cannot receive ActiveMQ.Advisory.MasterBroker messages when master dies and slave takes control
AMQ-4116Memory usage is not cleared from the source queue when a message is moved to another queue over the VMTransport
AMQ-4117MQTT Inactivity Monitor doesn't respect client keep alive setting.
AMQ-4122Lease Database Locker failover broken
AMQ-4123Improve MQTT Inactivity Monitoring
AMQ-4126stomp+nio+ssl + jaasDualAuthenticationPlugin + certificate authentication fails
AMQ-4132Openwire+nio+ssl require to specify transport.enabledCipherSuites property
AMQ-4133Different behaviour with similar connectors with identical option, URI validation would be nice to have
AMQ-4134Add XA support to the LevelDB store
AMQ-4137Create a store import/export command line tool to covert between store types
AMQ-4140maven-activemq-plugin fails to resolve path to XBean file in multi-module builds, and does not have a skip flag
AMQ-4142SimpleAuthenticationPluginTest hangs intermittently on Hudson
AMQ-4145IntrospectionSupport does not convert from primitive to Wrapper classes appropriately
AMQ-4147Memory usage incorrectly updated across network of brokers when VMTransport is used
AMQ-4148Static subscriptions from network bridges do not respect TTL (off by one in calculation), resulting in duplicate consumers
AMQ-4149Removal of inactive durable subscribers not working after broker restart
AMQ-4153ActiveMQWASInitialContextFactory issue in transform logic
AMQ-4154Karaf activemq feature can't be installed due to the unresolved dependencies
AMQ-4157KahaDBTransactionStore.removeAyncMessage may cancel addMessage when in transaction leading to unpersisted messages
AMQ-4158BTreeIndexTest hangs when run on Windows
AMQ-4159Race condition in SimpleDiscoveryAgent creates multiple concurrent threads attempting to connect to the same bridge
AMQ-4160DiscoveryNetworkConnector can lose track of active bridges, resulting in permanent bridge failure or continued attempts to re-connect existing bridges
AMQ-4166RedeliveryPlugin causes a deadlock with JobSchedulerImpl
AMQ-4167MQTTTest.testInactivityTimeoutDisconnectsClient is failing
AMQ-4168MQTTSSLTest.testTurnOffInactivityMonitor Disabled
AMQ-4171KahaDB / Journal rotateWriteFIle() sometimes too fast?
AMQ-4172RAR needs additional module includes post module refactor
AMQ-4179Can't install activemq-extra feature
AMQ-4182Memory leak for ActiveMQBytesMessage with compression
AMQ-4183AMQ 5.7 lost long queue names with filteredKahaDB
AMQ-4186web-console xml views have duplicate contenttype headers - jsp errors
AMQ-4195activemq-admin bstat command predefined query isn't even run
AMQ-4196Race condition between removal of subscriptions and removal of destinations in a network of brokers
AMQ-4201JMSX* properties not included in the getPropertyNames() enumeration
AMQ-4209NetworkConnector and NetworkBridgeConfiguration have same named private variables for excludedDestination
AMQ-4210DynamicallyIncludedDestinations is not enforced for the other end of duplex bridge
AMQ-4215Simplify PList interface and provide a LevelDB store implementation
AMQ-4218JMS selector statement not displayed correctly in subscribers web view if contains XML-prohibited characters
AMQ-4220PageFile is not loaded when recreating queue and perDestination="true"
AMQ-4222ProducerBrokerExchange holds reference to "region" destination after message has been sent
AMQ-4226Broker destination zero prefetch and RAR endpoint listener are incompatible b/c RAR is starved of messages - log an error to highlight
AMQ-4227ActiveMQSslConnectionFactory does not allow for regular files to be found unless a valid URL is provided or is located on the classpath
AMQ-4234Broker destination policy prefetch value is ignored by stomp consumers
AMQ-4246Change Type of offlineDurableSubscriberTimeout and offlineDurableSubscriberTaskSchedule to long
AMQ-4249Race condition in PropertiesLoginModule
AMQ-4254BrokerXmlConfigStartTest fails intermittently
AMQ-4258Endless loop when received incorrect AMQP message
AMQ-4260MessageGroupLateArrivalsTest fails intermittently
AMQ-4265AMQ4220Test is failing
AMQ-4266Missing proton-api as dependency
AMQ-4268DurableSubscriptionOfflineTest has several failures
AMQ-4270BrokerNetworkWithStuckMessagesTest hangs occasionally
AMQ-4272No connection could be found for ID NC_
AMQ-4273JobSchedulerTest has 2 test cases that fail intermittently
AMQ-4274Potential deadlock between FailoverTransport and AbstractInactivityMonitor
AMQ-4275maven plugin goal "activemq:run" cannot run in latest 5.8 snapshot
AMQ-4278Deprecate XMPP transport
AMQ-4281ActiveMQConnectionFactoryTest fails intermittently
AMQ-4282Deadlock in test BrokerNetworkwithStuckMessageTest
AMQ-4285NetworkFailoverTest failing
AMQ-4286NioQueueSubscriptionTest.testLotsOfConcurrentConnections fails
AMQ-4288OptimizedAckTest fails intermittently
AMQ-4289activemq-perf-maven-plugin is unusable because of bug in ReflectionUtil helper class
AMQ-4291org.apache.activemq.transport.stomp.StompTest#testReplyToAcrossConnections mostly fails
AMQ-4296Unit tests fail intermittently when using LevelDB adapter
AMQ-4297Stomp deadlock on commit
AMQ-4306BTreeIndexTest.testRandomAddRemove() is very slow on Solaris
AMQ-4307org.apache.activemq.transport.http.HttpClientReconnectTest hangs occasionally
AMQ-4308HttpsTransportBrokerTest hangs occasionally
AMQ-4312NIO+SSL Connector fails with SSL exception under high concurrency
AMQ-4315Duplicate files in distribution
AMQ-4317activemq-camel feature doesn't work
AMQ-4319ActiveMQ destination are tracked by securitycontext and never cleaned up, causes ActiveMQ to crash
AMQ-4320Destinations are not auto created when using Composite Destination configured on the broker
AMQ-4321NIO+SSL Connector corrupts stream when data size exceeds SSL buffer size
AMQ-4322org.apache.activemq.leveldb.LevelDBFastEnqueueTest hangs on Windows
AMQ-4323Last modified producer audit checkpoint can prevent gc with cached bursty producers
AMQ-4330Removal of Master/Slave removed isSlave() JMX api
AMQ-4331MessageSelectorTest fails because of dated config file
AMQ-4332LargeQueueSparseDeleteTest gets timeouts on testMoveMessages and testRemoveMessages
AMQ-4333ActiveMQ 5.8: Failed to execute purge task
AMQ-4338MQTTSSLTest has multiple test cases that fail frequently
AMQ-4342MemoryUsageCleanupTest fails intermittently
AMQ-4345NIOSSLConcurrencyTest.testLoad fails on slow boxes
AMQ-4351Deadlock when unsubscribing durable subscriber
AMQ-4355RedeliveryRestartTest hangs intermittently
AMQ-4363org.apache.activemq.store.jdbc.JDBCXACommitExceptionTest has 2 test failures
AMQ-4364Cannot delete queue via JMX or JConsole
AMQ-4366PooledConnectionFactory closes connections that are in use
AMQ-4369Default IOException handler needs to be set before Persistence adapter and network connectors are started
AMQ-4373JMS Client isn't throwing JMSSecuirtyException with invalid login credentials
AMQ-4375org.apache.activemq.transport.amqp.joram.JoramJmsTest UnifiedSessionTest hangs on Windows
AMQ-4377Bring back activemq-blueprint module and feature
AMQ-4379org.apache.activemq.transport.amqp.JMSClientTest fails on Windows
AMQ-4384KahaDBStoreRecoveryBrokerTest has multiple failures on windows
AMQ-4385LevelDBXARecoveryBrokerTest has multiple failures on Windows
AMQ-4386AMQ4133Test has 2 additional test case failures on Windows
AMQ-4387AMQ4126Test has additional test failures on Windows
AMQ-4388org.apache.activemq.bugs.AMQ3625Test fails on Windows
AMQ-4389AMQ4351Test fails on slow boxes
AMQ-4392MQTT BlockingConnection disconnect doesn't disconnects the client connection
AMQ-4393Web console does not show connections info
AMQ-4397XSS vulnerability in scheduled.jsp
AMQ-4398XSS vulnerability in demo web application
AMQ-4400org.apache.bugs.LoadBalanceTest fails intermittently
AMQ-4406Remove command agent
AMQ-4407mKahaDB: PageFile is not loaded when recreating queue
AMQ-4408no network bridge loopback suppression with url scheme mismatch
AMQ-4410Typo in PooledConnectionFactory.java
AMQ-4411activemq-osgi <Bundle-NativeCode> directive is too strict - needs to be optional
AMQ-4415AMQ2584Test, AMQ2870Test, and several others hang or fail on some platforms when using LevelDB
AMQ-4427Many of the activemq-http tests are failing on Jenkins
AMQ-4432Validate camel context within activemq.xml in Apache Karaf
APLO-282org.iq80.leveldb.DBException - possible LevelDB store corruption?
ENTESB-668Plug in provder should be Red Hat, Inc.
ENTMQ-177PListImplTest fails on AIX and Solaris
ENTMQ-187MQTTSSLTest has multiple test cases that fail frequently
ENTMQ-236Re-enable excluded tests after platform builds
ENTMQ-244QueueMasterSlaveSingleUrlTest hangs on Windows
ENTMQ-265JoramJmsTest hangs on several platforms
MB-1185JConsole browse() function does not work if useCache=false
MB-1218Durable subscription not getting unregistered on networked broker
MB-1221Setting queue policy queuePrefetch=0 in broker configuration causes messages to stay in pending state in broker
MB-1224ExpiredMessages > Prefetch Queue results in messages no longer being dequeued
MB-1239NIO + SSL: Client certificates are null
MB-1242kahaDB Commit Failed with NPE using XA Transactions
MB-1246Browsing a queue is not returning the actual number messages on the queue
MB-1247InactivityMonitor thread does not catch ThreadPoolExecutor exceptions
MB-1250Missing Data file for plist temp store on file pending message queue cursor overflow
MB-1251Messages lost on Virtual Topic when no active consumer attached
MB-1255next() and hasNext() are never called without first calling reset()
MB-1260Prefetch limit not remembered during failover
MB-1261conditionalNetworkBridgeFilterFactory ignores NetworkTTL when replayWhenNoConsumers is set to true and forward messages to network consumer
MB-1263Network Dead Lock using duplex network connector for NOB
MB-1264Job Scheduler Store Growth is Unrestricted
MB-1266SessionPool of activemq-pool needs to destroy connection object if it failed to start the connection
MB-936Change way Broker MBean name is generated so that port is not used
MB-991When a producer from a network bridge is blocked by producer flow control, all producers from the network bridge get blocked
ENTMQ-184Remove references to Fuse
ENTMQ-205Windows commands in readme.txt should have \
ENTMQ-242Web Demo doesn't work

Routing

Table 3.3, “Routing Issues Resolved in 6.0” lists the issues resolved between Fuse ESB Enterprise 7.1 and 6.0.

Table 3.3. Routing Issues Resolved in 6.0

IssueDescription
CAMEL-5358camel-castor does not work in apache service mix modules
CAMEL-5748Classloader mixup in Direct VM component
CAMEL-5774ActiveMQ target endpoint with transferExchange=true does not work together with source File endpoint with preMove option set
CAMEL-5821Camel Jetty chunked parameter appears broken
CAMEL-5837Problem with nested schema imports when upgrading from 2.8.6 to 2.10.2
CAMEL-5839camel-zookeeper: The usage of the endpoint's option 'awaitExistence' would have no effect
CAMEL-5866Pass Exchange param to TypeConverter.convertTo calls where possible
CAMEL-5877Sporadic Source Conversion issues with CxfPayload
CAMEL-5887Unexpected behavior when combining onException and multiple adviceWith in camel-core
CAMEL-5888When call removeRouteDefinition the route doesn't removed from collection of route Definitions
CAMEL-5890NPE when jaxb fallback converter is used with RequestEntityConverter
CAMEL-5897Nullcheck missing in CxfPayloadConverter
CAMEL-5899camel-netty - Producer should avoid blocking while waiting for connection
CAMEL-5900StreamResequencer does not resequence correctly
CAMEL-5907Camel leaks memory on undeploy / redeploy in app server when JMX enabled and createConnector = true
CAMEL-5908Websocket consumer cannot be started, because of NPE
CAMEL-5917camel-jms - JmsPollingConsumer use the constant fields from JmsTemplate for receiveNoWait etc
CAMEL-5925NullPointerException in RouteContextProcessor
CAMEL-5942Custom URIResolve not used to load XSTL script
CAMEL-5943camel-hl7 marshal charset error
CAMEL-5948ObjectHelper.createIterator() should properly handle the array of primitive types e.g. int[]
CAMEL-5949XML DSL - Should not have default values in errorhandler
CAMEL-5950Cache producer is not thread safe
CAMEL-5951Camel-syslog dataformat broken with netty transport
CAMEL-5953Java DSL: unmarshal() inside choice() blocks adding more conditions
CAMEL-5957Bug with completionSize on AggregatorProcessor
CAMEL-5965Camel feature file doesn't validate
CAMEL-5968ClassNotFoundException: weblogic.jndi.WLInitialContextFactory when starting the route via Karaf start-route(camel:route-start) command
CAMEL-5973Property placeholder with both blueprint and jasypt seems not working
CAMEL-5981Enrich EIP may cause async callback done twice
CAMEL-5987Using annotations DSL in beans may cause async callback to be called twice
CAMEL-5994CamelJob implementation rely on some inconsistent endpoints LRU cache - Camel endpoints may not be called on quartz fire after some days of uptime
CAMEL-5999RestletComponent component is not removing added route from routers list although route is removed from Context
CAMEL-6005multicase shareUnitOfWork just throw one exception in the first time
CAMEL-6013Validator component fails on XSD with indirect relative import
CAMEL-6025NumberFormatException when using File over JMS
CAMEL-6035interceptSendToEndpoint with a DelegateAsyncProcessor fails
CAMEL-6038Possible NPE is OSGi bundle has no symbolic name
CAMEL-6045Camel Email Component Missing Attachments
CAMEL-6046sftp: noop=true&idempotent=false doesn't work
CAMEL-6048XML-files containing attributes called "type" does not get converted to json
CAMEL-6056Moving files on FTP not working
CAMEL-6059camel-rss and camel-atom - Not installable in Karaf
CAMEL-6064Wire Tap onPrepare should process new Exchange
CAMEL-6068CamelBlueprintContext may be wrongly started and this may lead to a deadlock
CAMEL-6069java.io.IOException: Permission denied from MarkerFileExclusiveReadLockStrategy.acquireExclusiveReadLock on NAS
CAMEL-6072Service Shutdown logic may execute N times
CAMEL-6073Pairs of VM producer-consumer disconnect when OSGi bundle is restarted
CAMEL-6079grails - class cast exception on startup
CAMEL-6081gzip dataformat - Ensure input stream is closed if exception thrown
CAMEL-6089CXFEndpoint blueprint config having binding element may lead to NPE
CAMEL-6097Race condition in AggregatorProcessor recovery sometimes causes duplicates
CAMEL-6123camel-jms: InOut exchange can time out even if response was received
CAMEL-6127Its impossible to inject a custom InflightRepository due to a copy-and-paste bug
CAMEL-6128JAXB fallbackConveter unmarshal falls with XStreamReader
CAMEL-6129Simple language - bean function - issue when parameter value has comma
CAMEL-6130EndpointHelper.setReferenceProperties() does not work with OSGiServiceRegistry
CAMEL-6135CompositeRegistry should catch the exception when it lookup the component across the registry
CAMEL-6154NPE when using the imap mail component with quartz or the timer and pollEnrich
CAMEL-6155Camel stream producer never close the stream of file
CAMEL-6172Aggregate EIP - Completion from batch consumer should trigger first
CAMEL-6173camel-http - When bridging endpoints then there may be double parameter values if client sends uri parameters
CAMEL-6175camel-jetty - Issue when bridging with jetty http producer and uri query parameter has encoded value
CAMEL-6179Simple expression in spring XML not work if it come in multiple xml lines
CAMEL-6189Camel cache: CamelCacheCheck and expiry on cached elements
CAMEL-6202Missing log parameter placeholder in routepolicy.quartz.ScheduledRoutePolicy
CAMEL-6204loadResourceAsStream in ObjectHelper could not load resource with leading "/"
CAMEL-6218TransferExchage InOut ActiveMQ Exception
ENTESB-668Plug in provder should be Red Hat, Inc.
MR-681Merge changes from CAMEL-5871 to Fuse Branches
MR-682HdfsOutputStream is not closing
MR-683camel-example-jmx - Does not work in Fuse ESB
MR-685Camel Transformer using inconsistent sources
MR-686ConfigAdmin changes that trigger a reload will not restart Blueprint Camel routes
MR-691camel-hdfs component does not work in Fuse ESB 7.1 OSGi environment
MR-697SOAP over JMS does not work with camel-cxf endpoint (async)
MR-698camel-jms component tries to use deleted temp destination
MR-703Camel double encoding uri parameters
MR-706Connection Pools and other resources are not cleaned up when route is shutdown and removed
MR-707number of child services started seems to be increasing by one each time the route is restarted

Web services

Table 3.4, “Web Services Issues Resolved in 6.0” lists the issues resolved between Fuse ESB Enterprise 7.1 and 6.0.

Table 3.4. Web Services Issues Resolved in 6.0

Issue NumbersDescription
CXF-4629Security issue with GET methods: WSS4JInInterceptor always allows HTTP Get requests from browser
CXF-4776UsernameTokenValidator do not validate that password is not provided
ENTESB-520java.lang.ClassCastException: sun.reflect.generics.reflectiveObjects.TypeVariableImpl cannot be cast to java.lang.Class
ENTESB-586ensure the context class loader is set correctly
ENTESB-644ActiveMQ 5.4.2 artifacts in full assembly
ENTESB-645cxf wsn-core bundle require bundle org.apache.activemq.activemq-core
SF-434Problem with WS-RM InOrder Assurance when using a multi-threaded client

Container

Table 3.5, “Container Issues Resolved in 6.0” lists the issues resolved between Fuse ESB Enterprise 7.1 and 6.0.

Table 3.5. Container Issues Resolved in 6.0

Issue NumberDescription
ARIES-1004When the framework is being shut down, blueprint bundles are not shut down orderly
ARIES-1020Blueprint disables service too soon at shutdown
ARIES-1025Orderly shutdown is ineffective for containers using the ext/cm namespace
ARIES-1040Exception during jpa-container shutdown
ARIES-1043Error in Export-Service header in blueprint-core
ARIES-962Deadlock while stopping OSGi container
ARIES-983The BundleHookBundleTracker has an invalid logic wrt initially tracked bundles
ARIES-984When shutting down, the JMX agent should wait for threads to be terminated
ARIES-985Improve robustness of JMX Blueprint bundle activator
ARIES-986The blueprint extender does not support high concurrency very well
ARIES-988The proxy manager should unregister its service
ARIES-991Concurrency issue which can cause a service to be kept registered
ENTESB-583SNAPSHOT dependency in Aries' proxy-api
ENTESB-517Deploying war throws java.lang.IllegalArgumentException: bundle context should be set before refreshing the application context
ENTESB-607karaf-2.3.0.fuse-7-2-x-stable build has 23 test failures
ENTESB-619Progress bar stops at 98%
ENTESB-647Exception with tx decorated bean as ref argument of factory method
ENTESB-649Karaf console wraps on Windows 7 when connecting using the client
KARAF-1814Cursor keys do not work when using bin/client on windows
KARAF-1815When ssh'ing from a windows box into a unix box, arrow keys are not correctly interpreted
KARAF-1824tooling-exam contains reference to wrong commons-io artifact
KARAF-1858itests look stuck (use 100% CPU)
KARAF-1882Provide Level attribute in the LogMBean
KARAF-1921Upgrade to Spring 3.1.x for Karaf 2.3.x
KARAF-2117LDAP login module is broken
KARAF-2154Entering an empty command removes previous command in history
KARAF-2167KarafManipulatorFactory creates invalid version qualifier
KARAF-2209Allow overriding system properties
KARAF-2221The admin service is not safe when used to create / start agents quickly
KARAF-2244BundleWatcher should wait for refresh to be finished before updating another bundle
FELIX-3242Concurrent modification problem in StatefulResolver$ResolverStateImpl.getCandidates
FELIX-3273Possible exception when accessing headers
FELIX-3367getClassloader permission
FELIX-3411The implementation of org.osgi.service.startlevel.StartLevel#setStartLevel(int) does not follow the spec
FELIX-3618Should not allow bundles to use generic cap/req headers for osgi.wiring.* namespaces
FELIX-3632Parsing of delimited strings in manifest parser collapses all consecutive escapes
FELIX-3670PackageAdmin.isBundleType throws NPE for uninstalled bundle
FELIX-3713Bundle.start() returns without starting the bundle
FELIX-3743Potential endless loop setting the active framework startlevel
FELIX-3753Felix crashes when embedded within Felix
FELIX-3761When a bundle registers a service, the bundle lock is obtained without any real purpose
FELIX-3803Bundle#getResource always try to resolve the bundle
FELIX-3821FileInstall does not support correctly ConfigAdmin being shut down
FELIX-3822FileInstall should unregister its services
FELIX-3823ConfigAdmin should explicitely unregister services
FELIX-3824Possible InvalidStateException thrown while unregistering bundle services
FELIX-3840problem with URLHandlers when running 2 frameworks in one jvm in separate class loaders
FELIX-3844Native bundles cannot be installed on Windows 8 and Windows Server 2012
FELIX-3852InstallBundle throws ClassCastException: java.util.jar.Attributes$Name cannot be cast to java.lang.String
FELIX-3907NullPointerException in BundleWiringImpl when m_disposed is true
FELIX-3957Error events can be thrown when refreshing fragment bundles

Fuse Fabric

Table 3.6, “Fuse Fabric Issues Resolved in 6.0” lists the issues resolved between Fuse ESB Enterprise 7.1 and 6.0.

Table 3.6. Fuse Fabric Issues Resolved in 6.0

Issue NumberDescription
FABRIC-204Provide support for bundles and features that use the fab url handler inside Fabric
FABRIC-348The fabric profiles ensemble-xxxx should not be allowed to be manually added to a container
FABRIC-349Containers that are added using fabric:join cannot be added to the ensemble
FABRIC-351Child container cannot be started when both -Xmx and "-Xrunjdwp:transport..." JVM options passed in on creation
FABRIC-352The installation path for a remote ssh container is ignored
FABRIC-353Manually Modifying the karaf.name causes problems when adding containers to an ensemble
FABRIC-357Invalidate both username and password when authentication fails
FABRIC-358Property placeholders should not always substituted by empty string when are not resolved
FABRIC-359Fabric loadbalancer atttempts to access inactive container
FABRIC-363Version create and update does not properly propagate entries in the registry
FABRIC-364fabric:container-list can displays profiles with commas out of place
FABRIC-365Modifying the ensemble will not work if the version of the containers has changed
FABRIC-366features:info inside fabric sometimes returns feature not found, for existing features
FABRIC-367Error moving to an earlier profile version
FABRIC-368fabric-camel component doesn't support password when managing the zookeeper client
FABRIC-369fabric-cxf doesn't support password when managing the zookeeper client
FABRIC-370Incomplete cleanup of registry entries when deleting containers
FABRIC-376Error installing transaction feature on fabric child container
FABRIC-380ensemble:add changes zookeeper password
FABRIC-383User creation and prompts from shell shouldn't add username to history
FABRIC-390Fabric should prevent you from setting a non-existent resolver
FABRIC-395cluster-list throws NPE
FABRIC-397Unable to provision FAB on remote fabric container
FABRIC-398Features Repository not able to be resolved
FABRIC-400StringIndexOutOfBoundsException thrown when trying to deploy artifacts
FABRIC-404Possible corruption of jars when downloading SNAPSHOTS from the maven proxy
FABRIC-405Deploying the eip example project to a fabric fails
FABRIC-407Repeated creation of container via ssh makes Fuse Fabric unstartable
FABRIC-408fabric:create failure due to connection loss
FABRIC-411NullPointerException when try to upgrade version of non-existing container
FABRIC-412Please add a warning message when changing ensembles to indicate the port is changing
FABRIC-416Missing dependency in profile activemq-client
FABRIC-418Client connections not being picked up by fabric-activemq-facade
FABRIC-420ChildContainerProvider should not use the build version to identify the feature repo version

Management Console

Table 3.7, “Issues Resolved in 6.0:” lists the issues resolved between Fuse ESB Enterprise 7.1 and 6.0.

Table 3.7. Issues Resolved in 6.0:

Issue NumberDescription
FMC-442Save profiles to file does not store the abstract attribute
FMC-443Export and import of profiles has some issues - eg version numbers not honored, and truncating data
FMC-447Can't create user with password 5 characters long through FMC
FMC-453Profiles page needs initial loading widget
FMC-454ActiveMQ broker not working when creating child through fabric management console
FMC-455Creating profiles with spaces cause an Error Failed to access container details message in the FMC Containers tab
FMC-457Not seeing anything in Message Broker | Network Connectors tab for a network of brokers
FMC-458Wrong table layout when inputting a very long string to input fields in Web Console
FMC-459Wrong behaviour of input fields, when using right arrow button to edit text while creating container in Web Console
FMC-460'Error uploading patch file' occurs when no patch is specified for upload in Web Console
FMC-461Patching Successful message occurs, no matter which .zip file was uploaded as patch(or no file was uploaded)
FMC-462User always has admin rights, no matter if he has admin role assigned to him in Web Console

Chapter 4. Enhancements

Fuse

Table 4.1, “Fuse Enhancements in 6.0” lists the enhancements between Fuse ESB Enterprise 7.1 and 6.0.

Table 4.1. Fuse Enhancements in 6.0

EnhancementDescription
ENTESB-539remove geronimo-servlet_2.5 bundle from servicemix-http feature
ENTESB-611README.md for soap & soap-secure isn't correct
ENTESB-627README for errors example isn't accurate
ENTESB-603cxf-fabric need to support to publish the full qualified address when it uses the OSGi servlet transport
ENTESB-604cxf-fabric need to support to webclient which is used for the CXF JAXRS
ENTESB-536ensure to use wss4j 1.6.9 for JBoss Fuse 6
ENTESB-543Remove CXF from minimal distro
ENTESB-544Review contents of minimal distro
ENTESB-546Rebrand Fuse ESB to JBoss Fuse
ENTESB-564Camel - Use OSGi 4.3.1 which is compatible with Java 7
ENTESB-573Upgrade to hawt.io 1.0.0
ENTESB-582Upgrade to maven-notices-plugin 1.28
ENTESB-597ER1: Package both Unix and WIndows kits in same distro
ENTESB-631Update EULA
ENTESB-671align jackson version
ENTESB-672stop releasing fabric virt bundles
SMX4-1316add address/endpintName for dispatch process for CXF NMR transport
SMX4-1378cxf-nmr trasport should copy the message header from CXF the Protocol Header
SM-2174Upgrade to ActiveMQ 5.8.0
ENTESB-646should be able to install servicemix-wsn2005/cxf-wsn feature OOTB
SMXCOMP-971Update to jruby 1.7.2

Messaging

Table 4.2, “Messaging Enhancements in 6.0” lists the enhancements between Fuse ESB Enterprise 7.1 and 6.0.

Table 4.2. Messaging Enhancements in 6.0

EnhancementDescription
AMQ-1469Change the Default Local Process Name to Something More Descriptive Than "run.jar"
AMQ-3215Drop-down list to move messages from one queue to another is not wide enough to show complete queue names
AMQ-3707Dynamic failover client connection params broker side attribute
AMQ-3883activemq-jaas authorization doesn't work with Karaf JAAS LoginModule
AMQ-3914Add support for MS SQL JDBC driver 4.0
AMQ-4005Implement pluggable broker lockers
AMQ-4019Make better use of commons-pool in activemq-pool
AMQ-4024Use FQDNs when updating cluster clients
AMQ-4034Create Karaf Integration Test
AMQ-4078Unable to start ActiveMQ as Windows Service when there is space in the folder path
AMQ-4082Refactor network bridge start/stop to reduce async tasks and synchronisation - it is way to complicated atm
AMQ-4124Disable sample web application from out of the box broker
AMQ-4125deprecate kaha and amq store
AMQ-4129Add support for Stomp v1.2
AMQ-4161List of Messages from StatsPlugin is not delimited
AMQ-4165Remove pure master/slave functionality
AMQ-4169correct maven-X-plugin naming to respect convention
AMQ-4177browseMessages() fails when using Jolokia to browse JMX
AMQ-4180Use hawtbuf in activemq-client to make message properties and MapMessage body unmarshal more lazy
AMQ-4190Figure out what was intended with transactions and producer flow control for topics
AMQ-4198Include username in ConnectionInfo for ActiveMQ.Advisory.Connection messages
AMQ-4202JMSXUserID missing from ActiveMQConnectionMetaData getter
AMQ-4213ActiveMQMessageProducer sends producer registration async which causes it to miss possible exceptions on creation like security exceptions
AMQ-4225PooledConnectionFactory should track Session checkouts and close associated resources
AMQ-4233Allow ActiveMQMessageAudit to have cache value for producers set for lower values
AMQ-4237JMX ObjectNames do not follow JMX Best practices to use a Hierarchical format
AMQ-4241ActiveMQOutputStream shoud reserve the user property only once
AMQ-4250activemq-spring should not depend on spring-test at compile scope
AMQ-4253Upgrade to Spring 3.1.3
AMQ-4279deprecate udp transport
AMQ-4298Add mutual authentication (needClientAuth) to https transport
AMQ-4303Health status MBean - Feeling ill
AMQ-4309Add usage limit check when limit for destinations is present
AMQ-4360Remove deprecated methods from activemq-pool
AMQ-4362Broker-based redelivery plugin - support for maximumRedeliveries="-1"
AMQ-4414Combine windows and unix distros
AMQ-4418Make web apps (demos, rest api, etc) running in Karaf
AMQ-4119Add memory usage *count* to destination MBean for better detection of memory leaks
AMQ-4121Expose Destination.setMemoryUsage so that custom policies can override default MemoryUsage (e.g., to specify message count limits)
AMQ-4144When used in a message selector, the JMSDeliveryMode header field should be treated as having the values 'PERSISTENT' and 'NON_PERSISTENT'
AMQ-4146String properties in JMS selector expression should not get auto converted to numbers per spec
AMQ-4162Provide JMX visibility into options applied via destination name query parameters
AMQ-4191Have a getHappyStatus() method on the BrokerViewMBean so that tools can enquire on the happy status of a broker to see early warning signs of things that could be bad
AMQ-4200STOMP 1.1 Over WebSocket
AMQ-4219Expose ActiveMQ JMX interface via REST API using Jolokia
AMQ-4305Support destination lookup by JNDI name in resource adapter
AMQ-4426Allow XAPooledConnectionFactory to be used from ee ( implement ObjectFactory, [Queue|Topic]ConnectionFactory
AMQ-4054Deprecate axis support and remove it in AMQ 5.8
AMQ-4056Remove activemq-jmdns module
AMQ-4163Remove old cruft from activemq-camel component such as the kaha journal component
AMQ-4206HawtBuf lib in assembly is put into /extra folder when it's not optional
AMQ-4228implement/investigate persistent producer audit for leveldb store
AMQ-4238Check AMQ JMX connector code if having same issue as CAMEL-5907
AMQ-4252Make OSGi JARs fully optional
AMQ-4256Upgrade to OSGi 4.3.0
AMQ-4257Upgrade to Aries 1.0
AMQ-4280Rename module activemq-core
AMQ-4341activemq-broker feature can not be installed when OBR is enabled
AMQ-4412align jackson version with Camel
ENTMQ-63Broker and web console security
MB-1116Dynamic Failover Host Name Resolver
MB-1157Support for more sophisticated redelivery semantics
MB-1195reduce maxRows default value from 10,000 to a lower value like 200 in JDBC persistence adapter
MB-1257Don't restart the network bridge on race condition where respondent sends to a temp dest that has just been deleted
MB-835Reduce the number of KahaProducerAuditCommand entries in the KahaDB journal
ENTMQ-155mq-client should contain mq-fabric
ENTMQ-185org.fusesource.fabric.itests.paxexam.mq.MQProfileTest
ENTMQ-206Add camel route to xml config in pax-exam-tests for mqdistro test
ENTMQ-219Update doc links to point to Customer Portal
ENTMQ-229Remove the '-' from the start script (bin//a-mq -> bin/amq) and reference in doc and readme
ENTMQ-231Create an a-mq fabric profile that mirrors the out-of-box config of the a-mq distro
ENTMQ-251use admin/admin as default username/password for org.apache.activemq.webconsole.cfg

Routing

Table 4.3, “Routing Enhancements in 6.0” lists the enhancements between Fuse ESB Enterprise 7.1 and 6.0.

Table 4.3. Routing Enhancements in 6.0

EnhancementDescription
CAMEL-5708Make camel-smpp component get username from parameters instead of address
CAMEL-5872camel-scala - Add convertBodyTo to its DSL
CAMEL-5889Scala DSL: no tokenize("...") method
CAMEL-5926SpringIntegrationConsumer should honor the 'inOut' instance variable by setting the MEP and sending back message headers
CAMEL-5938MailConverters fails with uppercase content type TEXT/PLAIN
CAMEL-5944Setting extendMessageVisibility on an SQS consumer doesn't make visibilityTimeout compulsory
CAMEL-5945Add delimiter to recipient list eip in Java DSL
CAMEL-5955Put the LocalAddress into the message header
CAMEL-5959Dead Letter Channel - Store failed route id on Exchange
CAMEL-5962xslt component - Should fallback and use same scheme prefix as endpoint configured for included resources
CAMEL-5974camel-jms: Make ThreadPoolTaskExecutor the default Task Executor
CAMEL-5990Upgrade to QuickFIX/J 1.5.3
CAMEL-5995Improvment of InstrumentationProcessor
CAMEL-6008camel-netty - Initialize SSLContext once if using camel JSSE configuration
CAMEL-6051ClassResolver - Add support for Object[] arrays
CAMEL-6055Add export service information to camel bundles
CAMEL-6075Upgrade to jclouds 1.5.7
CAMEL-6100ManagedAttribute annotated method in JmsEndpoint does not return a standard type
CAMEL-6102direct-vm component - Should support the async routing engine
CAMEL-6105Make DirectProducer throw a specific exception when it cannot find the corresponding consumer, instead of a generic CamelExchangeException
CAMEL-6110camel-xmlbeans: Improve the test coverage
CAMEL-6116Populate all optional parameters from DeliverSm (if it is DeliveryReceipt)
CAMEL-6117Allow empty service_type and system_type
CAMEL-6121While creation of submit_sm from Exchange no optional params are being set to submit_sm
CAMEL-6145JXPath language - Allow to configure lenient option
CAMEL-6166camel-jms - Allow to configure jmsKeyFormatStrategy directly on component level
CAMEL-6177Camel-AWS should support any implementation of AmazonXXX (not only AmazonXXXClient)
CAMEL-6178Camel Flatpack should respect the ignoreExtraColumns and allowShortLines options for delimited files
CAMEL-6205Add option to disable file system sync on File Producer
CAMEL-6217Camel-test-blueprint supports to create bundle context per class
CAMEL-6233BridgePropertyPlaceholderConfigurer does not support nested Spring properties
MR-671Camel-Jetty Proxy is configured at JVM level using system properties
MR-700adding getTaskQueueRemainingCapacity() on org.apache.camel.api.management.mbean.ManagedThreadPoolMBean
CAMEL-5896camel-netty - Allow to configure netty options in uri using prefix
CAMEL-5901camel-netty - Allow to turn netty producer pool on or off
CAMEL-5979Camel-Quickfix dynamic SenderSubId/TargetSubId issue
CAMEL-6054camel-hazelcast - Manage transactions with SEDA Consumer and improve the mapstore lifecycle
CAMEL-6216Support user metadata on files stored in S3
MR-690overriding blueprint placeholders when using CamelBlueprintTestSupport/pojosr framework
CAMEL-5935clean up the camel schema
CAMEL-5983Avoid the negative-tests to behave as false-positive
CAMEL-5998Avoid using deprecated AbstractJUnit38SpringContextTests but use junit 4 test class instead
CAMEL-6066camel-atom and camel-rss - Issue in karaf
CAMEL-6074Upgrade to ActiveMQ 5.8.0
CAMEL-6169add camel's component.properties file into the maven repo as camelComponent/properties so folks can easily query maven repos for camel components
ENTESB-564Camel - Use OSGi 4.3.1 which is compatible with Java 7
ENTESB-596Upgrade Fuse Camel 2.10 to use Spring 3.1.3 to be aligned with JBoss Fuse 6
ENTESB-634camel-msv - Backport the pom.xml changes from ASF to Fuse Camel 2.10 to fix assembly issue on RHEL
ENTESB-641maven-dependency-plugin upgrade
MR-705Include camelComponent.properties in JAR and m2 repo so we can detect the available camel components we have
CAMEL-5792Validator component - Error loading resource on windows

Web services

Table 4.4, “Web services Enhancements in 6.0” lists the enhancements between Fuse ESB Enterprise 7.1 and 6.0.

Table 4.4. Web services Enhancements in 6.0

EnhancementDescription
CXF-4646Use AlgorithmSuite functionality in WSS4J 1.6.8
CXF-4731add dependency='true' for stax-api bundle in cxf features.xml
ENTESB-646should be able to install servicemix-wsn2005/cxf-wsn feature OOTB
CXF-4791Passing arguments to JAXB compiler from WADL2Java
ENTESB-641maven-dependency-plugin upgrade
SF-431update to javax.mail 1.4.5
SF-432Use Fuse specs

Container

Table 4.5, “Container Enhancements in 6.0” lists the enhancements between Fuse ESB Enterprise 7.1 and 6.0.

Table 4.5. Container Enhancements in 6.0

EnhancementDescription
KARAF-1951Remove workaround for KARAF-1117
KARAF-2223Update to pax url 1.3.6
KARAF-1572Add SQL Server Support for JDBC Lock
KARAF-1798Use exam framework for our itests and increase tests coverage
KARAF-2105Karaf features for Spring should all be same name and use version ranges
KARAF-1910Provide Spring 3.1.2.RELEASE features
KARAF-2050Ability to configure ssh session idle timeout - currently hardcode as 5 minutes
FELIX-3344Filter parsing treats ** as invalid syntax
FELIX-3553Use of parallel class loading capability of JDK7
FELIX-3807Refreshing bundles should first grab all the bundle locks to avoid concurrent modifications of those bundles
FELIX-3808Upgrade ConfigAdmin to pax-exam 2
ENTESB-529endorse stax-api spec jar
ENTESB-539remove geronimo-servlet_2.5 bundle from servicemix-http feature
ENTESB-506Add a pojosr unit test to validate that we can use OSGI Config Admin with value encrypted
ENTESB-542Upgrade to Pax Logging 1.7.1 when available
ENTESB-622JBoss FUSE 6 should use fuse side aries jpa module
ENTESB-641maven-dependency-plugin upgrade

Fuse Fabric

Table 4.6, “Fabric Enhancements in 6.0” lists the enhancements between Fuse ESB Enterprise 7.1 and 6.0.

Table 4.6. Fabric Enhancements in 6.0

EnhancementDescription
FABRIC-377Create a command for profiles to pick up new versions
FABRIC-387Allow fabric agent and maven proxy to retrieve repos from maven settings.xml
FABRIC-391Unable to create child container on remote root container using oracle JDK 7 on linux
FABRIC-394Fabric ensemble should not be versioned
FABRIC-406Add some validation to container-add-profile so it doesn't allow spaces in profile names
FABRIC-409Revisit CXF example and integration tests
FABRIC-419Ability to Create Root Container on the Local Host
FABRIC-421fabric-cxf FabricLoadBalancerFeature should support to configure the options of the zookeeper client
FABRIC-360Allow editing of znodes and profile in a text editor

Management Console

Table 4.7, “Enhancements in 6.0” lists the enhancements between Fuse ESB Enterprise 7.1 and 6.0.

Table 4.7. Enhancements in 6.0

EnhancementDescription
FMC-444Add field to specify imported version name and allow an existing version to be overwritten

Chapter 5. Apache Dependencies

The following Apache projects are used in 6.0:
Apache ActiveMQ
Red Hat JBoss Fuse includes Apache ActiveMQ 5.8
Apache Karaf
Red Hat JBoss Fuse includes Apache Karaf 2.3
Apache CXF
Red Hat JBoss Fuse includes Apache CXF 2.6
Apache ServiceMix
Red Hat JBoss Fuse includes Apache ServiceMix 4.5
Apache Camel
Red Hat JBoss Fuse includes Apache Camel 2.10

Legal Notice

Trademark Disclaimer

The text of and illustrations in this document are licensed by Red Hat under a Creative Commons Attribution–Share Alike 3.0 Unported license ("CC-BY-SA"). An explanation of CC-BY-SA is available at http://creativecommons.org/licenses/by-sa/3.0/. In accordance with CC-BY-SA, if you distribute this document or an adaptation of it, you must provide the URL for the original version.
Red Hat, as the licensor of this document, waives the right to enforce, and agrees not to assert, Section 4d of CC-BY-SA to the fullest extent permitted by applicable law.
Red Hat, Red Hat Enterprise Linux, the Shadowman logo, JBoss, MetaMatrix, Fedora, the Infinity Logo, and RHCE are trademarks of Red Hat, Inc., registered in the United States and other countries.
Apache, ServiceMix, Camel, CXF, and ActiveMQ are trademarks of Apache Software Foundation. Any other names contained herein may be trademarks of their respective owners.

Legal Notice

Third Party Acknowledgements

One or more products in the Red Hat JBoss Fuse release includes third party components covered by licenses that require that the following documentation notices be provided:
  • JLine (http://jline.sourceforge.net) jline:jline:jar:1.0
    License: BSD (LICENSE.txt) - Copyright (c) 2002-2006, Marc Prud'hommeaux
    All rights reserved.
    Redistribution and use in source and binary forms, with or without modification, are permitted provided that the following conditions are met:
    • Redistributions of source code must retain the above copyright notice, this list of conditions and the following disclaimer.
    • Redistributions in binary form must reproduce the above copyright notice, this list of conditions and the following disclaimer in the documentation and/or other materials provided with the distribution.
    • Neither the name of JLine nor the names of its contributors may be used to endorse or promote products derived from this software without specific prior written permission.
    THIS SOFTWARE IS PROVIDED BY THE COPYRIGHT HOLDERS AND CONTRIBUTORS "AS IS" AND ANY EXPRESS OR IMPLIED WARRANTIES, INCLUDING, BUT NOT LIMITED TO, THE IMPLIED WARRANTIES OF MERCHANTABILITY AND FITNESS FOR A PARTICULAR PURPOSE ARE DISCLAIMED. IN NO EVENT SHALL THE COPYRIGHT OWNER OR CONTRIBUTORS BE LIABLE FOR ANY DIRECT, INDIRECT, INCIDENTAL, SPECIAL, EXEMPLARY, OR CONSEQUENTIAL DAMAGES (INCLUDING, BUT NOT LIMITED TO, PROCUREMENT OF SUBSTITUTE GOODS OR SERVICES; LOSS OF USE, DATA, OR PROFITS; OR BUSINESS INTERRUPTION) HOWEVER CAUSED AND ON ANY THEORY OF LIABILITY, WHETHER IN CONTRACT, STRICT LIABILITY, OR TORT (INCLUDING NEGLIGENCE OR OTHERWISE) ARISING IN ANY WAY OUT OF THE USE OF THIS SOFTWARE, EVEN IF ADVISED OF THE POSSIBILITY OF SUCH DAMAGE.
  • Stax2 API (http://woodstox.codehaus.org/StAX2) org.codehaus.woodstox:stax2-api:jar:3.1.1
    Copyright (c) <YEAR>, <OWNER> All rights reserved.
    Redistribution and use in source and binary forms, with or without modification, are permitted provided that the following conditions are met:
    • Redistributions of source code must retain the above copyright notice, this list of conditions and the following disclaimer.
    • Redistributions in binary form must reproduce the above copyright notice, this list of conditions and the following disclaimer in the documentation and/or other materials provided with the distribution.
    THIS SOFTWARE IS PROVIDED BY THE COPYRIGHT HOLDERS AND CONTRIBUTORS "AS IS" AND ANY EXPRESS OR IMPLIED WARRANTIES, INCLUDING, BUT NOT LIMITED TO, THE IMPLIED WARRANTIES OF MERCHANTABILITY AND FITNESS FOR A PARTICULAR PURPOSE ARE DISCLAIMED. IN NO EVENT SHALL THE COPYRIGHT HOLDER OR CONTRIBUTORS BE LIABLE FOR ANY DIRECT, INDIRECT, INCIDENTAL, SPECIAL, EXEMPLARY, OR CONSEQUENTIAL DAMAGES (INCLUDING, BUT NOT LIMITED TO, PROCUREMENT OF SUBSTITUTE GOODS OR SERVICES; LOSS OF USE, DATA, OR PROFITS; OR BUSINESS INTERRUPTION) HOWEVER CAUSED AND ON ANY THEORY OF LIABILITY, WHETHER IN CONTRACT, STRICT LIABILITY, OR TORT (INCLUDING NEGLIGENCE OR OTHERWISE) ARISING IN ANY WAY OUT OF THE USE OF THIS SOFTWARE, EVEN IF ADVISED OF THE POSSIBILITY OF SUCH DAMAGE.
  • jibx-run - JiBX runtime (http://www.jibx.org/main-reactor/jibx-run) org.jibx:jibx-run:bundle:1.2.3
    License: BSD (http://jibx.sourceforge.net/jibx-license.html) Copyright (c) 2003-2010, Dennis M. Sosnoski.
    All rights reserved.
    Redistribution and use in source and binary forms, with or without modification, are permitted provided that the following conditions are met:
    • Redistributions of source code must retain the above copyright notice, this list of conditions and the following disclaimer.
    • Redistributions in binary form must reproduce the above copyright notice, this list of conditions and the following disclaimer in the documentation and/or other materials provided with the distribution.
    • Neither the name of JiBX nor the names of its contributors may be used to endorse or promote products derived from this software without specific prior written permission.
    THIS SOFTWARE IS PROVIDED BY THE COPYRIGHT HOLDERS AND CONTRIBUTORS "AS IS" AND ANY EXPRESS OR IMPLIED WARRANTIES, INCLUDING, BUT NOT LIMITED TO, THE IMPLIED WARRANTIES OF MERCHANTABILITY AND FITNESS FOR A PARTICULAR PURPOSE ARE DISCLAIMED. IN NO EVENT SHALL THE COPYRIGHT OWNER OR CONTRIBUTORS BE LIABLE FOR ANY DIRECT, INDIRECT, INCIDENTAL, SPECIAL, EXEMPLARY, OR CONSEQUENTIAL DAMAGES (INCLUDING, BUT NOT LIMITED TO, PROCUREMENT OF SUBSTITUTE GOODS OR SERVICES; LOSS OF USE, DATA, OR PROFITS; OR BUSINESS INTERRUPTION) HOWEVER CAUSED AND ON ANY THEORY OF LIABILITY, WHETHER IN CONTRACT, STRICT LIABILITY, OR TORT (INCLUDING NEGLIGENCE OR OTHERWISE) ARISING IN ANY WAY OUT OF THE USE OF THIS SOFTWARE, EVEN IF ADVISED OF THE POSSIBILITY OF SUCH DAMAGE.
  • JavaAssist (http://www.jboss.org/javassist) org.jboss.javassist:com.springsource.javassist:jar:3.9.0.GA:compile
  • HAPI-OSGI-Base Module (http://hl7api.sourceforge.net/hapi-osgi-base/) ca.uhn.hapi:hapi-osgi-base:bundle:1.2
    License: Mozilla Public License 1.1 (http://www.mozilla.org/MPL/MPL-1.1.txt)