You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@activemq.apache.org by ma...@apache.org on 2016/09/30 15:26:51 UTC

[51/52] [partial] activemq-artemis git commit: ARTEMIS-765 Improve Checkstyle

ARTEMIS-765 Improve Checkstyle


Project: http://git-wip-us.apache.org/repos/asf/activemq-artemis/repo
Commit: http://git-wip-us.apache.org/repos/asf/activemq-artemis/commit/ec48f9ed
Tree: http://git-wip-us.apache.org/repos/asf/activemq-artemis/tree/ec48f9ed
Diff: http://git-wip-us.apache.org/repos/asf/activemq-artemis/diff/ec48f9ed

Branch: refs/heads/master
Commit: ec48f9ed00bdd25f9e8727dba42f6645dc552a24
Parents: 04925bb
Author: Clebert Suconic <cl...@apache.org>
Authored: Thu Sep 29 17:07:38 2016 -0400
Committer: Clebert Suconic <cl...@apache.org>
Committed: Fri Sep 30 11:12:09 2016 -0400

----------------------------------------------------------------------
 .../apache/activemq/artemis/boot/Artemis.java   |   22 +-
 .../apache/activemq/artemis/cli/Artemis.java    |   42 +-
 .../activemq/artemis/cli/CLIException.java      |    4 +-
 .../artemis/cli/commands/Configurable.java      |    5 +-
 .../activemq/artemis/cli/commands/Create.java   |   63 +-
 .../artemis/cli/commands/InputAbstract.java     |    6 +-
 .../activemq/artemis/cli/commands/Run.java      |   12 +-
 .../commands/destination/CreateDestination.java |   19 +-
 .../commands/destination/DeleteDestination.java |   19 +-
 .../commands/destination/DestinationAction.java |   28 +-
 .../commands/destination/HelpDestination.java   |    8 +-
 .../artemis/cli/commands/messages/Browse.java   |   11 +-
 .../artemis/cli/commands/messages/Consumer.java |    3 +-
 .../artemis/cli/commands/messages/Producer.java |    3 +-
 .../cli/commands/tools/CompactJournal.java      |    3 +-
 .../cli/commands/tools/DecodeJournal.java       |   45 +-
 .../cli/commands/tools/EncodeJournal.java       |    3 +-
 .../cli/commands/tools/LockAbstract.java        |   21 +-
 .../cli/commands/tools/OptionalLocking.java     |    4 +-
 .../artemis/cli/commands/tools/PrintData.java   |   27 +-
 .../cli/commands/tools/XmlDataExporter.java     |  101 +-
 .../cli/commands/tools/XmlDataImporter.java     |  162 +--
 .../cli/commands/util/ConsumerThread.java       |   45 +-
 .../cli/commands/util/ProducerThread.java       |   33 +-
 .../cli/commands/util/SyncCalculation.java      |   17 +-
 .../artemis/cli/process/ProcessBuilder.java     |    9 +-
 .../artemis/cli/process/package-info.java       |    4 +-
 .../activemq/artemis/factory/BrokerFactory.java |   15 +-
 .../artemis/factory/BrokerFactoryHandler.java   |    4 +-
 .../artemis/factory/JaasSecurityHandler.java    |    1 +
 .../artemis/factory/SecurityManagerFactory.java |    7 +-
 .../factory/XmlBrokerFactoryHandler.java        |    6 +-
 .../activemq/artemis/integration/Broker.java    |    1 +
 .../artemis/integration/FileBroker.java         |    8 +-
 .../activemq/artemis/util/ServerUtil.java       |   14 +-
 .../apache/activemq/cli/test/ArtemisTest.java   |   28 +-
 .../activemq/cli/test/FileBrokerTest.java       |   12 +-
 .../activemq/artemis/ArtemisConstants.java      |    3 +-
 .../apache/activemq/artemis/api/core/Pair.java  |    3 +-
 .../activemq/artemis/api/core/SimpleString.java |   12 +-
 .../core/buffers/impl/ChannelBufferWrapper.java |   36 +-
 .../core/server/ActiveMQScheduledComponent.java |   12 +-
 .../artemis/logs/ActiveMQUtilBundle.java        |    2 +-
 .../artemis/logs/AssertionLoggerHandler.java    |    9 +-
 .../artemis/utils/ActiveMQThreadFactory.java    |    7 +-
 .../utils/ActiveMQThreadPoolExecutor.java       |    9 +-
 .../apache/activemq/artemis/utils/Base64.java   |  213 +--
 .../apache/activemq/artemis/utils/ByteUtil.java |   14 +-
 .../activemq/artemis/utils/CertificateUtil.java |   15 +-
 .../artemis/utils/ClassloadingUtil.java         |   27 +-
 .../activemq/artemis/utils/ConcurrentUtil.java  |    2 +-
 .../utils/DefaultSensitiveStringCodec.java      |    9 +-
 .../activemq/artemis/utils/FactoryFinder.java   |    9 +-
 .../apache/activemq/artemis/utils/FileUtil.java |   13 +-
 .../apache/activemq/artemis/utils/IPV6Util.java |    4 +-
 .../artemis/utils/PasswordMaskingUtil.java      |    3 +-
 .../activemq/artemis/utils/PendingTask.java     |    8 +-
 .../activemq/artemis/utils/RandomUtil.java      |    2 +-
 .../artemis/utils/ReferenceCounterUtil.java     |    3 +-
 .../artemis/utils/SelectorTranslator.java       |    6 +-
 .../artemis/utils/StringEscapeUtils.java        |   20 +-
 .../activemq/artemis/utils/TypedProperties.java |  156 +-
 .../apache/activemq/artemis/utils/UTF8Util.java |   21 +-
 .../org/apache/activemq/artemis/utils/UUID.java |    9 +-
 .../activemq/artemis/utils/UUIDGenerator.java   |   21 +-
 .../activemq/artemis/utils/UUIDTimer.java       |   18 +-
 .../activemq/artemis/utils/uri/BeanSupport.java |    6 +-
 ...uentPropertyBeanIntrospectorWithIgnores.java |    7 +-
 .../activemq/artemis/utils/uri/URIFactory.java  |    4 +-
 .../activemq/artemis/utils/uri/URISchema.java   |    9 +-
 .../activemq/artemis/utils/uri/URISupport.java  |   32 +-
 .../utils/ActiveMQScheduledComponentTest.java   |    7 +-
 .../artemis/utils/ConcurrentHashSetTest.java    |    4 +-
 .../apache/activemq/artemis/utils/PairTest.java |    5 +-
 .../artemis/utils/ReferenceCounterTest.java     |    3 +-
 .../artemis/utils/ThreadLeakCheckRule.java      |   61 +-
 .../utils/TypedPropertiesConversionTest.java    |   48 +-
 .../artemis/utils/TypedPropertiesTest.java      |    3 +-
 .../activemq/artemis/utils/URIParserTest.java   |    4 +-
 artemis-core-client/pom.xml                     |    6 +-
 .../config/ActiveMQDefaultConfiguration.java    |   13 +-
 .../api/core/BroadcastGroupConfiguration.java   |    9 +-
 .../artemis/api/core/FilterConstants.java       |    1 -
 .../api/core/JGroupsBroadcastEndpoint.java      |   22 +-
 .../core/JGroupsChannelBroadcastEndpoint.java   |    2 +-
 .../api/core/JGroupsFileBroadcastEndpoint.java  |    8 +-
 .../JGroupsFileBroadcastEndpointFactory.java    |    1 -
 .../JGroupsPropertiesBroadcastEndpoint.java     |    6 +-
 .../activemq/artemis/api/core/JsonUtil.java     |  193 +--
 .../activemq/artemis/api/core/Message.java      |    4 +-
 .../api/core/TransportConfiguration.java        |   55 +-
 .../api/core/UDPBroadcastEndpointFactory.java   |   29 +-
 .../artemis/api/core/client/ActiveMQClient.java |   29 +-
 .../artemis/api/core/client/ClientMessage.java  |    2 +-
 .../artemis/api/core/client/TopologyMember.java |    1 -
 ...RoundRobinConnectionLoadBalancingPolicy.java |    3 +-
 .../api/core/jgroups/JChannelWrapper.java       |   17 +-
 .../api/core/jgroups/JGroupsReceiver.java       |    6 +-
 .../core/management/AddressSettingsInfo.java    |   18 +-
 .../artemis/api/core/management/Attribute.java  |    1 +
 .../api/core/management/DayCounterInfo.java     |   10 +-
 .../api/core/management/ManagementHelper.java   |   31 +-
 .../api/core/management/ObjectNameBuilder.java  |   17 +-
 .../artemis/api/core/management/Operation.java  |    3 +-
 .../api/core/management/QueueControl.java       |   13 +-
 .../artemis/api/core/management/RoleInfo.java   |    9 +-
 .../client/ActiveMQClientMessageBundle.java     |    2 +-
 .../core/client/impl/ClientConsumerImpl.java    |   79 +-
 .../client/impl/ClientLargeMessageImpl.java     |   18 +-
 .../core/client/impl/ClientMessageImpl.java     |    6 +-
 .../impl/ClientProducerCreditManagerImpl.java   |    8 +-
 .../client/impl/ClientProducerCreditsImpl.java  |   14 +-
 .../core/client/impl/ClientProducerImpl.java    |   45 +-
 .../client/impl/ClientSessionFactoryImpl.java   |  139 +-
 .../core/client/impl/ClientSessionImpl.java     |  162 +--
 .../core/client/impl/ClientSessionInternal.java |    4 +-
 .../CompressedLargeMessageControllerImpl.java   |   53 +-
 .../client/impl/LargeMessageControllerImpl.java |   99 +-
 .../core/client/impl/ServerLocatorImpl.java     |  108 +-
 .../artemis/core/client/impl/Topology.java      |   56 +-
 .../core/client/impl/TopologyMemberImpl.java    |    7 +-
 .../artemis/core/cluster/DiscoveryGroup.java    |   27 +-
 .../artemis/core/message/impl/MessageImpl.java  |   16 +-
 .../core/protocol/ClientPacketDecoder.java      |    6 +-
 .../artemis/core/protocol/core/Channel.java     |    1 +
 .../impl/ActiveMQClientProtocolManager.java     |   67 +-
 .../core/impl/ActiveMQSessionContext.java       |   80 +-
 .../core/protocol/core/impl/ChannelImpl.java    |   46 +-
 .../core/protocol/core/impl/PacketDecoder.java  |  132 +-
 .../core/impl/RemotingConnectionImpl.java       |   13 +-
 .../wireformat/ActiveMQExceptionMessage.java    |    3 +-
 .../ClusterTopologyChangeMessage.java           |   18 +-
 .../ClusterTopologyChangeMessage_V2.java        |   15 +-
 .../ClusterTopologyChangeMessage_V3.java        |    3 +-
 .../impl/wireformat/CreateQueueMessage.java     |    9 +-
 .../impl/wireformat/CreateSessionMessage.java   |   12 +-
 .../wireformat/CreateSharedQueueMessage.java    |    9 +-
 .../DisconnectConsumerWithKillMessage.java      |    2 +-
 .../core/impl/wireformat/DisconnectMessage.java |    3 +-
 .../impl/wireformat/DisconnectMessage_V2.java   |    3 +-
 .../core/impl/wireformat/MessagePacket.java     |    1 -
 .../core/impl/wireformat/MessagePacketI.java    |    3 +-
 .../impl/wireformat/ReattachSessionMessage.java |    3 +-
 .../wireformat/SessionAddMetaDataMessage.java   |    6 +-
 .../wireformat/SessionAddMetaDataMessageV2.java |    6 +-
 .../wireformat/SessionBindingQueryMessage.java  |    3 +-
 .../SessionBindingQueryResponseMessage.java     |    3 +-
 .../wireformat/SessionContinuationMessage.java  |    3 +-
 .../SessionCreateConsumerMessage.java           |    6 +-
 .../wireformat/SessionDeleteQueueMessage.java   |    3 +-
 .../SessionProducerCreditsFailMessage.java      |    3 +-
 .../SessionProducerCreditsMessage.java          |    3 +-
 .../wireformat/SessionQueueQueryMessage.java    |    3 +-
 .../SessionQueueQueryResponseMessage.java       |    9 +-
 .../SessionReceiveContinuationMessage.java      |    3 +-
 .../wireformat/SessionReceiveLargeMessage.java  |    3 +-
 .../SessionRequestProducerCreditsMessage.java   |    3 +-
 .../SessionSendContinuationMessage.java         |    3 +-
 .../wireformat/SessionSendLargeMessage.java     |    3 +-
 .../impl/wireformat/SessionSendMessage.java     |    3 +-
 .../wireformat/SessionXAAfterFailedMessage.java |    3 +-
 .../impl/wireformat/SessionXACommitMessage.java |    3 +-
 .../impl/wireformat/SessionXAEndMessage.java    |    3 +-
 .../impl/wireformat/SessionXAForgetMessage.java |    3 +-
 .../SessionXAGetInDoubtXidsResponseMessage.java |    6 +-
 .../impl/wireformat/SessionXAJoinMessage.java   |    3 +-
 .../wireformat/SessionXAPrepareMessage.java     |    3 +-
 .../wireformat/SessionXAResponseMessage.java    |    3 +-
 .../impl/wireformat/SessionXAResumeMessage.java |    3 +-
 .../wireformat/SessionXARollbackMessage.java    |    3 +-
 .../impl/wireformat/SessionXAStartMessage.java  |    3 +-
 .../impl/TransportConfigurationUtil.java        |    9 +-
 .../impl/netty/ActiveMQChannelHandler.java      |    3 +-
 .../remoting/impl/netty/NettyConnection.java    |   56 +-
 .../remoting/impl/netty/NettyConnector.java     |   80 +-
 .../impl/netty/SharedNioEventLoopGroup.java     |   22 +-
 .../remoting/impl/netty/TransportConstants.java |    3 +-
 .../core/remoting/impl/ssl/SSLSupport.java      |   29 +-
 .../activemq/artemis/core/security/Role.java    |   14 +-
 .../artemis/core/transaction/impl/XidImpl.java  |    3 +-
 .../artemis/core/version/impl/VersionImpl.java  |    3 +-
 .../artemis/reader/BytesMessageUtil.java        |   30 +-
 .../activemq/artemis/reader/MessageUtil.java    |   21 +-
 .../artemis/reader/StreamMessageUtil.java       |    9 +-
 .../protocol/AbstractRemotingConnection.java    |   10 +-
 .../spi/core/protocol/RemotingConnection.java   |    4 +-
 .../artemis/spi/core/remoting/Connection.java   |    4 +-
 .../remoting/ConnectionLifeCycleListener.java   |    1 +
 .../InVMTransportConfigurationSchema.java       |    6 +-
 .../AbstractServerLocatorSchema.java            |    6 +-
 .../serverLocator/InVMServerLocatorSchema.java  |    8 +-
 .../JGroupsServerLocatorSchema.java             |   20 +-
 .../serverLocator/TCPServerLocatorSchema.java   |   10 +-
 .../serverLocator/UDPServerLocatorSchema.java   |    3 +-
 .../utils/ActiveMQBufferInputStream.java        |    3 +-
 .../activemq/artemis/utils/BufferHelper.java    |   15 +-
 .../artemis/utils/ConfigurationHelper.java      |   42 +-
 .../activemq/artemis/utils/DeflaterReader.java  |   12 +-
 .../activemq/artemis/utils/FutureLatch.java     |    3 +-
 .../activemq/artemis/utils/InflaterReader.java  |   15 +-
 .../activemq/artemis/utils/InflaterWriter.java  |    6 +-
 .../apache/activemq/artemis/utils/JNDIUtil.java |    9 +-
 .../activemq/artemis/utils/JsonLoader.java      |   14 +-
 .../activemq/artemis/utils/LinkedListImpl.java  |   27 +-
 .../activemq/artemis/utils/MemorySize.java      |   10 +-
 .../utils/ObjectInputStreamWithClassLoader.java |   43 +-
 .../artemis/utils/OrderedExecutorFactory.java   |   10 +-
 .../artemis/utils/PriorityLinkedListImpl.java   |    3 +-
 .../artemis/utils/SecurityFormatter.java        |    4 +-
 .../artemis/utils/SizeFormatterUtil.java        |    6 +-
 .../artemis/utils/SoftValueHashMap.java         |   18 +-
 .../activemq/artemis/utils/StringUtil.java      |    2 +
 .../utils/TimeAndCounterIDGenerator.java        |    3 +-
 .../artemis/utils/TokenBucketLimiterImpl.java   |    9 +-
 .../activemq/artemis/utils/VersionLoader.java   |   24 +-
 .../apache/activemq/artemis/utils/XMLUtil.java  |   21 +-
 .../activemq/artemis/ClientThreadPoolsTest.java |   24 +-
 .../activemq/artemis/api/core/JsonUtilTest.java |    2 +-
 .../api/core/TransportConfigurationTest.java    |    3 +-
 .../management/AddressSettingsInfoTest.java     |   44 +-
 .../activemq/artemis/tests/util/RandomUtil.java |    1 +
 .../artemis/tests/util/SilentTestCase.java      |    5 +-
 .../artemis/util/CompressionUtilTest.java       |    6 +-
 .../activemq/artemis/util/StringUtilTest.java   |    6 +-
 .../util/TimeAndCounterIDGeneratorTest.java     |   12 +-
 .../activemq/artemis/util/XMLUtilTest.java      |   12 +-
 artemis-dto/pom.xml                             |  273 ++--
 .../apache/activemq/artemis/dto/XmlUtil.java    |   12 +-
 .../activemq/artemis/dto/package-info.java      |    4 +-
 artemis-jdbc-store/pom.xml                      |    3 +-
 .../activemq/artemis/jdbc/store/JDBCUtils.java  |   28 +-
 .../jdbc/store/drivers/AbstractJDBCDriver.java  |   12 +-
 .../store/drivers/mysql/MySQLSQLProvider.java   |    3 +-
 .../drivers/postgres/PostgresSQLProvider.java   |    1 -
 .../PostgresSequentialSequentialFileDriver.java |   23 +-
 .../jdbc/store/file/JDBCSequentialFile.java     |   21 +-
 .../store/file/JDBCSequentialFileFactory.java   |   12 +-
 .../file/JDBCSequentialFileFactoryDriver.java   |   39 +-
 .../jdbc/store/journal/JDBCJournalImpl.java     |   43 +-
 .../journal/JDBCJournalReaderCallback.java      |    8 +-
 .../jdbc/store/journal/JDBCJournalRecord.java   |   14 +-
 .../artemis/jdbc/store/sql/SQLProvider.java     |    1 +
 .../file/JDBCSequentialFileFactoryTest.java     |    3 +-
 .../journal/JDBCJournalLoaderCallbackTest.java  |    4 +-
 .../artemis/api/jms/ActiveMQJMSClient.java      |   60 +-
 .../api/jms/management/JMSConnectionInfo.java   |    8 +-
 .../api/jms/management/JMSConsumerInfo.java     |    9 +-
 .../api/jms/management/JMSManagementHelper.java |    6 +-
 .../api/jms/management/JMSQueueControl.java     |   38 +-
 .../api/jms/management/JMSSessionInfo.java      |    7 +-
 .../api/jms/management/SubscriptionInfo.java    |    9 +-
 .../api/jms/management/TopicControl.java        |    3 +-
 .../jms/client/ActiveMQBytesMessage.java        |   42 +-
 .../artemis/jms/client/ActiveMQConnection.java  |   48 +-
 .../jms/client/ActiveMQConnectionFactory.java   |   71 +-
 .../ActiveMQConnectionForContextImpl.java       |    3 +-
 .../jms/client/ActiveMQConnectionMetaData.java  |    5 +-
 .../artemis/jms/client/ActiveMQDestination.java |   36 +-
 .../jms/client/ActiveMQJMSClientBundle.java     |    2 +-
 .../artemis/jms/client/ActiveMQJMSConsumer.java |   33 +-
 .../artemis/jms/client/ActiveMQJMSContext.java  |  120 +-
 .../artemis/jms/client/ActiveMQJMSProducer.java |  135 +-
 .../artemis/jms/client/ActiveMQMapMessage.java  |   38 +-
 .../artemis/jms/client/ActiveMQMessage.java     |  110 +-
 .../jms/client/ActiveMQMessageConsumer.java     |   31 +-
 .../jms/client/ActiveMQMessageProducer.java     |   60 +-
 .../jms/client/ActiveMQObjectMessage.java       |   29 +-
 .../jms/client/ActiveMQQueueBrowser.java        |   20 +-
 .../artemis/jms/client/ActiveMQSession.java     |  124 +-
 .../jms/client/ActiveMQStreamMessage.java       |  102 +-
 .../artemis/jms/client/ActiveMQTextMessage.java |    8 +-
 .../jms/client/ConnectionFactoryOptions.java    |    7 +-
 .../jms/client/JMSMessageListenerWrapper.java   |   22 +-
 .../artemis/jms/client/ThreadAwareContext.java  |   10 +-
 .../ConnectionFactoryObjectFactory.java         |    3 +-
 .../referenceable/DestinationObjectFactory.java |    3 +-
 .../SerializableObjectRefAddr.java              |    8 +-
 .../jndi/ActiveMQInitialContextFactory.java     |    3 +-
 .../artemis/jndi/LazyCreateContext.java         |    3 +-
 .../activemq/artemis/jndi/ReadOnlyContext.java  |   54 +-
 .../apache/activemq/artemis/uri/InVMSchema.java |    8 +-
 .../activemq/artemis/uri/JGroupsSchema.java     |    9 +-
 .../artemis/uri/JMSConnectionOptions.java       |    6 +-
 .../apache/activemq/artemis/uri/TCPSchema.java  |   13 +-
 .../apache/activemq/artemis/uri/UDPSchema.java  |    3 +-
 .../artemis/uri/ConnectionFactoryURITest.java   |   17 +-
 .../jms/bridge/ActiveMQJMSBridgeLogger.java     |   16 +-
 .../jms/bridge/impl/JMSBridgeControlImpl.java   |    7 +-
 .../artemis/jms/bridge/impl/JMSBridgeImpl.java  |  260 ++--
 .../impl/JNDIConnectionFactoryFactory.java      |    4 +-
 .../jms/bridge/impl/JNDIDestinationFactory.java |    5 +-
 .../jms/bridge/impl/JNDIFactorySupport.java     |    9 +-
 .../impl/JMSConnectionFactoryControlImpl.java   |    4 +-
 .../management/impl/JMSQueueControlImpl.java    |   32 +-
 .../management/impl/JMSServerControlImpl.java   |  116 +-
 .../management/impl/JMSTopicControlImpl.java    |   31 +-
 .../openmbean/JMSCompositeDataConstants.java    |    3 +-
 .../impl/openmbean/JMSOpenTypeSupport.java      |   28 +-
 .../jms/persistence/JMSStorageManager.java      |    2 +-
 .../journal/JMSJournalStorageManagerImpl.java   |   30 +-
 .../impl/nullpm/NullJMSStorageManagerImpl.java  |    2 +-
 .../jms/server/ActiveMQJMSServerBundle.java     |    2 +-
 .../artemis/jms/server/JMSServerManager.java    |    1 -
 .../config/ConnectionFactoryConfiguration.java  |    2 +-
 .../ConnectionFactoryConfigurationImpl.java     |    8 +-
 .../config/impl/FileJMSConfiguration.java       |   13 +-
 .../jms/server/embedded/EmbeddedJMS.java        |   21 +-
 .../jms/server/impl/JMSServerManagerImpl.java   |  104 +-
 .../jms/transaction/JMSTransactionDetail.java   |    6 +-
 artemis-journal/pom.xml                         |    3 +-
 .../artemis/core/io/AbstractSequentialFile.java |   37 +-
 .../core/io/AbstractSequentialFileFactory.java  |    6 +-
 .../artemis/core/io/SequentialFile.java         |    2 +-
 .../artemis/core/io/aio/AIOSequentialFile.java  |   23 +-
 .../core/io/aio/AIOSequentialFileFactory.java   |   44 +-
 .../artemis/core/io/buffer/TimedBuffer.java     |   27 +-
 .../core/io/mapped/MappedByteBufferCache.java   |   36 +-
 .../artemis/core/io/mapped/MappedFile.java      |   47 +-
 .../core/io/mapped/MappedSequentialFile.java    |   23 +-
 .../io/mapped/MappedSequentialFileFactory.java  |    8 +-
 .../artemis/core/io/nio/NIOSequentialFile.java  |   71 +-
 .../core/io/nio/NIOSequentialFileFactory.java   |    6 +-
 .../artemis/core/io/util/FileIOUtil.java        |    9 +-
 .../journal/impl/AbstractJournalUpdateTask.java |   12 +-
 .../core/journal/impl/FileWrapperJournal.java   |    8 +-
 .../core/journal/impl/JournalCompactor.java     |   32 +-
 .../core/journal/impl/JournalConstants.java     |    4 +-
 .../core/journal/impl/JournalFileImpl.java      |    6 +-
 .../journal/impl/JournalFilesRepository.java    |   49 +-
 .../artemis/core/journal/impl/JournalImpl.java  |  267 ++--
 .../core/journal/impl/JournalTransaction.java   |   18 +-
 .../artemis/core/journal/impl/Reclaimer.java    |    8 +-
 .../impl/dataformat/JournalAddRecord.java       |    5 +-
 .../impl/dataformat/JournalAddRecordTX.java     |    3 +-
 .../dataformat/JournalCompleteRecordTX.java     |    6 +-
 .../impl/dataformat/JournalInternalRecord.java  |    3 +-
 .../artemis/journal/ActiveMQJournalBundle.java  |    2 +-
 .../artemis/journal/ActiveMQJournalLogger.java  |    4 +-
 .../artemis/core/io/aio/CallbackOrderTest.java  |    2 +-
 .../artemis/core/io/aio/FileIOUtilTest.java     |    2 -
 artemis-junit/pom.xml                           |   86 +-
 .../junit/AbstractActiveMQClientResource.java   |   18 +-
 .../artemis/junit/ActiveMQConsumerResource.java |   24 +-
 .../junit/ActiveMQDynamicProducerResource.java  |   12 +-
 .../artemis/junit/ActiveMQProducerResource.java |   12 +-
 .../artemis/junit/EmbeddedActiveMQResource.java |   66 +-
 .../artemis/junit/EmbeddedJMSResource.java      |   87 +-
 .../artemis/junit/ThreadLeakCheckRule.java      |   26 +-
 .../junit/ActiveMQConsumerResourceTest.java     |    4 +-
 ...ActiveMQResourceCustomConfigurationTest.java |    5 +-
 ...edActiveMQResourceFileConfigurationTest.java |    3 +-
 .../resources/embedded-artemis-jms-only.xml     |   10 +-
 .../resources/embedded-artemis-jms-server.xml   |   10 +-
 .../embedded-artemis-minimal-server.xml         |    6 +-
 .../test/resources/embedded-artemis-server.xml  |    6 +-
 .../artemis/maven/ArtemisAbstractPlugin.java    |   17 +-
 .../artemis/maven/ArtemisCLIPlugin.java         |   20 +-
 .../artemis/maven/ArtemisClientPlugin.java      |    3 +-
 .../artemis/maven/ArtemisCreatePlugin.java      |   26 +-
 .../maven/ArtemisDependencyScanPlugin.java      |    6 +-
 .../activemq/artemis/jlibaio/LibaioContext.java |   24 +-
 .../activemq/artemis/jlibaio/LibaioFile.java    |    3 +-
 .../artemis/jlibaio/util/CallbackCache.java     |    5 +-
 .../jlibaio/test/CallbackCachelTest.java        |    5 +-
 .../artemis/jlibaio/test/LibaioTest.java        |   49 +-
 .../jlibaio/test/OpenCloseContextTest.java      |   18 +-
 artemis-protocols/artemis-amqp-protocol/pom.xml |    3 +-
 .../amqp/broker/AMQPConnectionCallback.java     |   39 +-
 .../amqp/broker/AMQPSessionCallback.java        |   81 +-
 .../ActiveMQProtonRemotingConnection.java       |    2 +-
 .../amqp/broker/ProtonProtocolManager.java      |   10 +-
 .../broker/ProtonProtocolManagerFactory.java    |    8 +-
 .../amqp/converter/ActiveMQJMSVendor.java       |   19 +-
 .../amqp/converter/ProtonMessageConverter.java  |   19 +-
 .../amqp/converter/jms/ServerDestination.java   |    5 +-
 .../amqp/converter/jms/ServerJMSMapMessage.java |   36 +-
 .../amqp/converter/jms/ServerJMSMessage.java    |   27 +-
 .../converter/jms/ServerJMSObjectMessage.java   |   14 +-
 .../converter/jms/ServerJMSStreamMessage.java   |   99 +-
 .../converter/jms/ServerJMSTextMessage.java     |    8 +-
 .../converter/message/AMQPMessageIdHelper.java  |   47 +-
 .../converter/message/AMQPMessageTypes.java     |    1 +
 .../message/AMQPNativeOutboundTransformer.java  |    6 +-
 .../converter/message/InboundTransformer.java   |   75 +-
 .../message/JMSMappingInboundTransformer.java   |   36 +-
 .../message/JMSMappingOutboundTransformer.java  |  110 +-
 .../ActiveMQAMQPProtocolMessageBundle.java      |    4 +-
 .../amqp/proton/AMQPConnectionContext.java      |   50 +-
 .../amqp/proton/AMQPSessionContext.java         |   34 +-
 .../protocol/amqp/proton/AmqpSupport.java       |   21 +-
 .../proton/ProtonServerReceiverContext.java     |   26 +-
 .../amqp/proton/ProtonServerSenderContext.java  |  112 +-
 .../amqp/proton/ProtonTransactionHandler.java   |   26 +-
 .../amqp/proton/handler/ExtCapability.java      |    4 +-
 .../amqp/proton/handler/ProtonHandler.java      |   26 +-
 .../artemis/protocol/amqp/sasl/PlainSASL.java   |    6 +-
 .../protocol/amqp/util/CreditsSemaphore.java    |    5 +-
 .../protocol/amqp/util/ProtonServerMessage.java |   18 +-
 .../amqp/converter/TestConversions.java         |   25 +-
 .../protocol/amqp/sasl/ClientSASLPlain.java     |    2 +-
 .../amqp/util/CreditsSemaphoreTest.java         |    3 +-
 .../java/org/apache/blacklist/ABadClass.java    |    1 +
 .../artemis-hornetq-protocol/pom.xml            |    3 +-
 .../hornetq/HornetQProtocolManager.java         |    3 +-
 .../artemis-hqclient-protocol/pom.xml           |   33 +-
 .../HQPropertiesConversionInterceptor.java      |    4 +-
 .../client/HornetQClientProtocolManager.java    |    6 +-
 .../HornetQClientProtocolManagerFactory.java    |    3 +-
 .../client/HornetQClientSessionContext.java     |    5 +-
 .../hornetq/util/HQPropertiesConverter.java     |    2 +-
 artemis-protocols/artemis-mqtt-protocol/pom.xml |   45 +-
 .../core/protocol/mqtt/MQTTConnection.java      |    2 +-
 .../protocol/mqtt/MQTTConnectionManager.java    |   34 +-
 .../core/protocol/mqtt/MQTTFailureListener.java |    2 +-
 .../core/protocol/mqtt/MQTTInterceptor.java     |    1 +
 .../artemis/core/protocol/mqtt/MQTTLogger.java  |    2 +-
 .../core/protocol/mqtt/MQTTMessageInfo.java     |    2 +-
 .../core/protocol/mqtt/MQTTProtocolHandler.java |    5 +-
 .../core/protocol/mqtt/MQTTProtocolManager.java |   13 +-
 .../mqtt/MQTTProtocolManagerFactory.java        |    2 +-
 .../core/protocol/mqtt/MQTTPublishManager.java  |   16 +-
 .../protocol/mqtt/MQTTRetainMessageManager.java |    2 +-
 .../artemis/core/protocol/mqtt/MQTTSession.java |   10 +-
 .../core/protocol/mqtt/MQTTSessionCallback.java |   21 +-
 .../core/protocol/mqtt/MQTTSessionState.java    |    6 +-
 .../protocol/mqtt/MQTTSubscriptionManager.java  |    3 +-
 .../artemis/core/protocol/mqtt/MQTTUtil.java    |    5 +-
 .../artemis-openwire-protocol/pom.xml           |    7 +-
 .../protocol/openwire/OpenWireConnection.java   |  138 +-
 .../openwire/OpenWireMessageConverter.java      |   67 +-
 .../openwire/OpenWireProtocolManager.java       |   21 +-
 .../amq/AMQCompositeConsumerBrokerExchange.java |    8 +-
 .../core/protocol/openwire/amq/AMQConsumer.java |   43 +-
 .../core/protocol/openwire/amq/AMQSession.java  |   24 +-
 .../protocol/openwire/util/OpenWireUtil.java    |   14 +-
 .../artemis-stomp-protocol/pom.xml              |    3 +-
 .../protocol/stomp/ActiveMQStompException.java  |    6 +-
 .../ActiveMQStompProtocolMessageBundle.java     |    2 +-
 .../core/protocol/stomp/StompConnection.java    |   78 +-
 .../core/protocol/stomp/StompDecoder.java       |   38 +-
 .../artemis/core/protocol/stomp/StompFrame.java |   23 +-
 .../protocol/stomp/StompProtocolManager.java    |   26 +-
 .../core/protocol/stomp/StompSession.java       |   29 +-
 .../artemis/core/protocol/stomp/StompUtils.java |    3 +-
 .../stomp/VersionedStompFrameHandler.java       |   78 +-
 .../stomp/v10/StompFrameHandlerV10.java         |   18 +-
 .../stomp/v11/StompFrameHandlerV11.java         |   76 +-
 .../core/protocol/stomp/v11/StompFrameV11.java  |    3 +-
 .../stomp/v12/StompFrameHandlerV12.java         |   34 +-
 artemis-protocols/pom.xml                       |    3 +-
 .../activemq/artemis/ra/ActiveMQRABundle.java   |    8 +-
 .../artemis/ra/ActiveMQRABytesMessage.java      |    3 +-
 .../ra/ActiveMQRAConnectionFactoryImpl.java     |   18 +-
 .../artemis/ra/ActiveMQRAConnectionManager.java |    3 +-
 .../ra/ActiveMQRAConnectionMetaData.java        |    3 +-
 .../ra/ActiveMQRAConnectionRequestInfo.java     |    3 +-
 .../artemis/ra/ActiveMQRACredential.java        |   15 +-
 .../artemis/ra/ActiveMQRAJMSContext.java        |    6 +-
 .../artemis/ra/ActiveMQRALocalTransaction.java  |   12 +-
 .../artemis/ra/ActiveMQRAMCFProperties.java     |   15 +-
 .../artemis/ra/ActiveMQRAManagedConnection.java |   57 +-
 .../ra/ActiveMQRAManagedConnectionFactory.java  |    6 +-
 .../artemis/ra/ActiveMQRAMapMessage.java        |    5 +-
 .../activemq/artemis/ra/ActiveMQRAMessage.java  |    3 +-
 .../artemis/ra/ActiveMQRAMessageConsumer.java   |   39 +-
 .../artemis/ra/ActiveMQRAMessageProducer.java   |   15 +-
 .../artemis/ra/ActiveMQRAObjectMessage.java     |    3 +-
 .../artemis/ra/ActiveMQRAProperties.java        |    3 +-
 .../artemis/ra/ActiveMQRAQueueSender.java       |    6 +-
 .../activemq/artemis/ra/ActiveMQRAService.java  |    6 +-
 .../activemq/artemis/ra/ActiveMQRASession.java  |  102 +-
 .../ra/ActiveMQRASessionFactoryImpl.java        |   38 +-
 .../artemis/ra/ActiveMQRAStreamMessage.java     |    3 +-
 .../artemis/ra/ActiveMQRATopicPublisher.java    |   12 +-
 .../artemis/ra/ActiveMQRAXAJMSContext.java      |    4 +-
 .../artemis/ra/ActiveMQRAXAResource.java        |   12 +-
 .../activemq/artemis/ra/ActiveMQRaUtils.java    |   12 +-
 .../artemis/ra/ActiveMQResourceAdapter.java     |   69 +-
 .../artemis/ra/ConnectionFactoryProperties.java |  132 +-
 .../artemis/ra/inflow/ActiveMQActivation.java   |   87 +-
 .../ra/inflow/ActiveMQActivationSpec.java       |   80 +-
 .../ra/inflow/ActiveMQMessageHandler.java       |   60 +-
 .../artemis/ra/recovery/RecoveryManager.java    |   22 +-
 .../apache/activemq/artemis/rest/ActiveMQ.java  |    9 +-
 .../org/apache/activemq/artemis/rest/Jms.java   |   28 +-
 .../artemis/rest/MessageServiceManager.java     |   12 +-
 .../integration/ActiveMQBootstrapListener.java  |   10 +-
 .../rest/integration/EmbeddedRestActiveMQ.java  |    8 +-
 .../RestMessagingBootstrapListener.java         |    5 +-
 .../ServletContextBindingRegistry.java          |    4 +-
 .../rest/queue/AcknowledgedQueueConsumer.java   |   20 +-
 .../artemis/rest/queue/ConsumedHttpMessage.java |    7 +-
 .../artemis/rest/queue/ConsumedMessage.java     |   12 +-
 .../rest/queue/ConsumedObjectMessage.java       |    9 +-
 .../artemis/rest/queue/ConsumersResource.java   |   27 +-
 .../rest/queue/DestinationServiceManager.java   |    5 +-
 .../artemis/rest/queue/PostMessage.java         |   20 +-
 .../artemis/rest/queue/PostMessageDupsOk.java   |   21 +-
 .../artemis/rest/queue/PostMessageNoDups.java   |    4 +-
 .../artemis/rest/queue/QueueConsumer.java       |   21 +-
 .../rest/queue/QueueDestinationsResource.java   |   32 +-
 .../artemis/rest/queue/QueueResource.java       |   10 +-
 .../artemis/rest/queue/QueueServiceManager.java |    5 +-
 .../rest/queue/push/ActiveMQPushStrategy.java   |    3 +-
 .../artemis/rest/queue/push/FilePushStore.java  |    3 +-
 .../artemis/rest/queue/push/PushConsumer.java   |   24 +-
 .../queue/push/PushConsumerMessageHandler.java  |   12 +-
 .../rest/queue/push/PushConsumerResource.java   |    5 +-
 .../artemis/rest/queue/push/PushStore.java      |    4 +-
 .../artemis/rest/queue/push/UriStrategy.java    |   24 +-
 .../rest/queue/push/xml/Authentication.java     |    3 +-
 .../rest/queue/push/xml/XmlHttpHeader.java      |    3 +-
 .../artemis/rest/queue/push/xml/XmlLink.java    |    3 +-
 .../artemis/rest/topic/PushSubscription.java    |   11 +-
 .../rest/topic/PushSubscriptionsResource.java   |   45 +-
 .../rest/topic/SubscriptionsResource.java       |   61 +-
 .../rest/topic/TopicDestinationsResource.java   |   25 +-
 .../artemis/rest/topic/TopicPushStore.java      |    4 +-
 .../artemis/rest/topic/TopicResource.java       |   11 +-
 .../artemis/rest/topic/TopicServiceManager.java |   14 +-
 .../rest/util/CustomHeaderLinkStrategy.java     |    6 +-
 .../artemis/rest/util/HttpMessageHelper.java    |   25 +-
 .../rest/util/LinkHeaderLinkStrategy.java       |    4 +-
 .../activemq/artemis/rest/util/TimeoutTask.java |   24 +-
 .../artemis/rest/test/AutoAckTopicTest.java     |    6 +-
 .../artemis/rest/test/ClientAckQueueTest.java   |    6 +-
 .../artemis/rest/test/ClientAckTopicTest.java   |    4 +-
 .../artemis/rest/test/EmbeddedTest.java         |    3 +-
 .../activemq/artemis/rest/test/JMSTest.java     |   15 +-
 .../artemis/rest/test/MessageTestBase.java      |    9 +-
 .../test/PersistentPushQueueConsumerTest.java   |    6 +-
 .../test/PersistentPushTopicConsumerTest.java   |    8 +-
 .../rest/test/PushQueueConsumerTest.java        |   38 +-
 .../rest/test/PushTopicConsumerTest.java        |    3 +-
 .../activemq/artemis/rest/test/RawAckTest.java  |    3 +-
 .../artemis/rest/test/SelectorTest.java         |    5 +-
 .../activemq/artemis/rest/test/SessionTest.java |    2 +-
 .../artemis/rest/test/TransformTest.java        |   12 +-
 .../activemq/artemis/rest/test/XmlTest.java     |    6 +-
 artemis-selector/pom.xml                        |  111 +-
 .../selector/filter/ArithmeticExpression.java   |   18 +-
 .../selector/filter/ComparisonExpression.java   |  135 +-
 .../selector/filter/ConstantExpression.java     |    3 +-
 .../selector/filter/UnaryExpression.java        |   24 +-
 .../selector/filter/XPathExpression.java        |    3 +-
 .../selector/filter/XalanXPathEvaluator.java    |    3 +-
 .../artemis/selector/impl/SelectorParser.java   |   15 +-
 .../activemq/artemis/selector/SelectorTest.java |    3 +-
 artemis-server-osgi/pom.xml                     |  225 +--
 .../activemq/artemis/osgi/OsgiBroker.java       |    9 +-
 .../activemq/artemis/osgi/ProtocolTracker.java  |   25 +-
 .../artemis/osgi/ProtocolTrackerCallBack.java   |    1 +
 .../artemis/osgi/ProtocolTrackerTest.java       |    5 +-
 artemis-server/pom.xml                          |   12 +-
 .../api/core/management/MessageCounterInfo.java |   16 +-
 .../core/config/BridgeConfiguration.java        |   27 +-
 .../config/ClusterConnectionConfiguration.java  |   24 +-
 .../artemis/core/config/Configuration.java      |   23 +-
 .../artemis/core/config/ConfigurationUtils.java |   18 +-
 .../core/config/CoreQueueConfiguration.java     |    9 +-
 .../core/config/DivertConfiguration.java        |   21 +-
 .../core/config/ScaleDownConfiguration.java     |    4 +-
 .../config/ha/ColocatedPolicyConfiguration.java |    6 +-
 .../core/config/impl/ConfigurationImpl.java     |   78 +-
 .../core/config/impl/FileConfiguration.java     |    3 +-
 .../config/impl/FileSecurityConfiguration.java  |    6 +-
 .../core/config/impl/SecurityConfiguration.java |   11 +-
 .../artemis/core/config/impl/Validators.java    |   15 +-
 .../artemis/core/deployers/Deployable.java      |    8 +-
 .../deployers/impl/FileConfigurationParser.java |  210 +--
 .../artemis/core/filter/impl/FilterImpl.java    |   40 +-
 .../core/management/impl/AbstractControl.java   |    3 +-
 .../management/impl/AcceptorControlImpl.java    |   24 +-
 .../impl/ActiveMQServerControlImpl.java         |  400 ++----
 .../management/impl/AddressControlImpl.java     |   39 +-
 .../core/management/impl/BridgeControlImpl.java |   48 +-
 .../impl/BroadcastGroupControlImpl.java         |   32 +-
 .../impl/ClusterConnectionControlImpl.java      |   50 +-
 .../core/management/impl/DivertControlImpl.java |   21 +-
 .../core/management/impl/MBeanInfoHelper.java   |   15 +-
 .../core/management/impl/QueueControlImpl.java  |  183 +--
 .../impl/openmbean/CompositeDataConstants.java  |    2 -
 .../impl/openmbean/OpenTypeSupport.java         |   51 +-
 .../core/messagecounter/MessageCounter.java     |   12 +-
 .../impl/MessageCounterHelper.java              |    6 +-
 .../impl/MessageCounterManagerImpl.java         |   10 +-
 .../artemis/core/paging/PagingManager.java      |    6 +-
 .../artemis/core/paging/PagingStore.java        |    4 +-
 .../artemis/core/paging/PagingStoreFactory.java |    5 +-
 .../core/paging/cursor/NonExistentPage.java     |    8 +-
 .../core/paging/cursor/PageCursorProvider.java  |    4 +-
 .../core/paging/cursor/PagedReferenceImpl.java  |   18 +-
 .../paging/cursor/impl/LivePageCacheImpl.java   |    3 +-
 .../core/paging/cursor/impl/PageCacheImpl.java  |    3 +-
 .../cursor/impl/PageCursorProviderImpl.java     |   56 +-
 .../paging/cursor/impl/PagePositionImpl.java    |   12 +-
 .../impl/PageSubscriptionCounterImpl.java       |   24 +-
 .../cursor/impl/PageSubscriptionImpl.java       |   90 +-
 .../activemq/artemis/core/paging/impl/Page.java |   24 +-
 .../artemis/core/paging/impl/PageSyncTimer.java |    6 +-
 .../paging/impl/PageTransactionInfoImpl.java    |   12 +-
 .../core/paging/impl/PagedMessageImpl.java      |    3 +-
 .../core/paging/impl/PagingManagerImpl.java     |   21 +-
 .../core/paging/impl/PagingStoreFactoryNIO.java |    8 +-
 .../core/paging/impl/PagingStoreImpl.java       |   86 +-
 .../core/persistence/OperationContext.java      |    5 +-
 .../core/persistence/StorageManager.java        |    8 +-
 .../core/persistence/config/PersistedRoles.java |   27 +-
 .../journal/AbstractJournalStorageManager.java  |  225 +--
 .../impl/journal/BatchingIDGenerator.java       |    9 +-
 .../impl/journal/DescribeJournal.java           |   42 +-
 .../impl/journal/JDBCJournalStorageManager.java |   40 +-
 .../impl/journal/JournalStorageManager.java     |   92 +-
 .../journal/LargeMessageTXFailureCallback.java  |    3 +-
 .../impl/journal/LargeServerMessageImpl.java    |   45 +-
 .../impl/journal/LargeServerMessageInSync.java  |   15 +-
 .../impl/journal/OperationContextImpl.java      |   27 +-
 .../TXLargeMessageConfirmationOperation.java    |    3 +-
 .../impl/journal/codec/DuplicateIDEncoding.java |    6 +-
 .../artemis/core/postoffice/BindingType.java    |    9 +-
 .../artemis/core/postoffice/PostOffice.java     |   27 +-
 .../core/postoffice/impl/AddressImpl.java       |   15 +-
 .../core/postoffice/impl/BindingsImpl.java      |   51 +-
 .../postoffice/impl/DuplicateIDCacheImpl.java   |   24 +-
 .../core/postoffice/impl/PostOfficeImpl.java    |   86 +-
 .../postoffice/impl/SimpleAddressManager.java   |    1 +
 .../postoffice/impl/WildcardAddressManager.java |   18 +-
 .../artemis/core/protocol/ProtocolHandler.java  |    7 +-
 .../core/protocol/ServerPacketDecoder.java      |   54 +-
 .../core/ServerSessionPacketHandler.java        |   54 +-
 .../core/impl/ActiveMQPacketHandler.java        |   32 +-
 .../protocol/core/impl/CoreProtocolManager.java |   24 +-
 .../protocol/core/impl/CoreSessionCallback.java |   16 +-
 .../wireformat/BackupRegistrationMessage.java   |    9 +-
 .../impl/wireformat/NodeAnnounceMessage.java    |   18 +-
 .../impl/wireformat/ReplicationAddMessage.java  |    3 +-
 .../wireformat/ReplicationAddTXMessage.java     |    3 +-
 .../wireformat/ReplicationDeleteTXMessage.java  |    3 +-
 .../wireformat/ReplicationPageEventMessage.java |    3 +-
 .../wireformat/ReplicationPageWriteMessage.java |    3 +-
 .../wireformat/ReplicationPrepareMessage.java   |    3 +-
 .../ReplicationResponseMessageV2.java           |    1 +
 .../wireformat/ReplicationStartSyncMessage.java |    3 +-
 .../wireformat/ReplicationSyncFileMessage.java  |   12 +-
 .../core/registry/JndiBindingRegistry.java      |   27 +-
 .../core/remoting/impl/AbstractAcceptor.java    |    7 +-
 .../core/remoting/impl/invm/InVMAcceptor.java   |    6 +-
 .../core/remoting/impl/invm/InVMConnection.java |   12 +-
 .../core/remoting/impl/invm/InVMConnector.java  |   11 +-
 .../core/remoting/impl/invm/InVMRegistry.java   |    4 +-
 .../impl/netty/HttpAcceptorHandler.java         |   21 +-
 .../core/remoting/impl/netty/NettyAcceptor.java |   49 +-
 .../server/impl/RemotingServiceImpl.java        |   56 +-
 .../core/replication/ReplicatedJournal.java     |    2 +-
 .../core/replication/ReplicationEndpoint.java   |   89 +-
 .../core/replication/ReplicationManager.java    |   43 +-
 .../core/security/impl/SecurityStoreImpl.java   |   26 +-
 .../core/server/ActiveMQMessageBundle.java      |    2 +-
 .../core/server/ActiveMQServerLogger.java       |    4 +-
 .../core/server/ConnectorServiceFactory.java    |    6 +-
 .../artemis/core/server/LiveNodeLocator.java    |    3 +-
 .../artemis/core/server/MemoryManager.java      |   13 +-
 .../artemis/core/server/MessageReference.java   |   12 +-
 .../artemis/core/server/NodeManager.java        |   15 +-
 .../artemis/core/server/QueueConfig.java        |   14 +-
 .../core/server/ScheduledDeliveryHandler.java   |    4 +-
 .../core/server/SecuritySettingPlugin.java      |    1 +
 .../artemis/core/server/ServerConsumer.java     |   18 +-
 .../artemis/core/server/ServerSession.java      |    5 +-
 .../artemis/core/server/ServiceRegistry.java    |   10 +-
 .../server/SlowConsumerDetectionListener.java   |    1 +
 ...ctiveMQServerSideProtocolManagerFactory.java |    3 +-
 .../core/server/cluster/BackupManager.java      |   12 +-
 .../artemis/core/server/cluster/Bridge.java     |    2 +-
 .../core/server/cluster/ClusterConnection.java  |    1 -
 .../core/server/cluster/ClusterControl.java     |    6 +-
 .../core/server/cluster/ClusterController.java  |   30 +-
 .../core/server/cluster/ClusterManager.java     |   50 +-
 .../server/cluster/ha/ColocatedHAManager.java   |   18 +-
 .../core/server/cluster/ha/ColocatedPolicy.java |   10 +-
 .../core/server/cluster/ha/HAManager.java       |    4 +-
 .../core/server/cluster/ha/LiveOnlyPolicy.java  |    4 +-
 .../core/server/cluster/ha/ReplicaPolicy.java   |    4 +-
 .../server/cluster/ha/ReplicatedPolicy.java     |    9 +-
 .../core/server/cluster/ha/ScaleDownPolicy.java |    6 +-
 .../cluster/ha/SharedStoreMasterPolicy.java     |    4 +-
 .../cluster/ha/SharedStoreSlavePolicy.java      |    4 +-
 .../server/cluster/ha/StandaloneHAManager.java  |    4 +-
 .../core/server/cluster/impl/BridgeImpl.java    |  120 +-
 .../server/cluster/impl/BroadcastGroupImpl.java |   12 +-
 .../cluster/impl/ClusterConnectionBridge.java   |   29 +-
 .../cluster/impl/ClusterConnectionImpl.java     |   68 +-
 .../cluster/impl/MessageLoadBalancingType.java  |   11 +-
 .../core/server/cluster/impl/Redistributor.java |   24 +-
 .../cluster/impl/RemoteQueueBindingImpl.java    |   12 +-
 .../core/server/cluster/qourum/BooleanVote.java |    4 +-
 .../server/cluster/qourum/QuorumManager.java    |   15 +-
 .../cluster/qourum/QuorumVoteServerConnect.java |   41 +-
 .../qourum/SharedNothingBackupQuorum.java       |    9 +-
 .../core/server/cluster/qourum/Vote.java        |    4 +-
 .../core/server/embedded/EmbeddedActiveMQ.java  |   14 +-
 .../core/server/files/FileMoveManager.java      |   15 +-
 .../core/server/files/FileStoreMonitor.java     |   25 +-
 .../group/impl/GroupHandlingAbstract.java       |    9 +-
 .../impl/GroupingHandlerConfiguration.java      |    6 +-
 .../server/group/impl/LocalGroupingHandler.java |   48 +-
 .../group/impl/RemoteGroupingHandler.java       |   12 +-
 .../server/impl/AIOFileLockNodeManager.java     |    6 +-
 .../core/server/impl/ActiveMQServerImpl.java    |  181 +--
 .../impl/AnyLiveNodeLocatorForReplication.java  |   21 +-
 .../impl/AnyLiveNodeLocatorForScaleDown.java    |   23 +-
 .../impl/AutoCreatedQueueManagerImpl.java       |    3 +-
 .../server/impl/BackupTopologyListener.java     |    3 +-
 .../core/server/impl/ColocatedActivation.java   |   24 +-
 .../core/server/impl/ConnectorsService.java     |   16 +-
 .../artemis/core/server/impl/DivertImpl.java    |    3 +-
 .../core/server/impl/FileLockNodeManager.java   |   30 +-
 .../core/server/impl/InVMNodeManager.java       |    9 +-
 .../core/server/impl/LastValueQueue.java        |   25 +-
 .../impl/LegacyLDAPSecuritySettingPlugin.java   |   67 +-
 .../core/server/impl/LiveOnlyActivation.java    |   22 +-
 .../core/server/impl/MessageReferenceImpl.java  |    8 +-
 .../NamedLiveNodeLocatorForReplication.java     |   15 +-
 .../impl/NamedLiveNodeLocatorForScaleDown.java  |   23 +-
 .../server/impl/PostOfficeJournalLoader.java    |   18 +-
 .../core/server/impl/QueueFactoryImpl.java      |    6 +-
 .../artemis/core/server/impl/QueueImpl.java     |  221 +--
 .../artemis/core/server/impl/RefsOperation.java |   12 +-
 .../core/server/impl/ReplicationError.java      |    2 +-
 .../core/server/impl/RoutingContextImpl.java    |    3 +-
 .../core/server/impl/ScaleDownHandler.java      |   40 +-
 .../impl/ScheduledDeliveryHandlerImpl.java      |   19 +-
 .../core/server/impl/ServerConsumerImpl.java    |  162 +--
 .../artemis/core/server/impl/ServerInfo.java    |    3 +-
 .../core/server/impl/ServerMessageImpl.java     |   30 +-
 .../core/server/impl/ServerSessionImpl.java     |  258 ++--
 .../core/server/impl/ServiceRegistryImpl.java   |   23 +-
 .../impl/SharedNothingBackupActivation.java     |   48 +-
 .../impl/SharedNothingLiveActivation.java       |   41 +-
 .../impl/SharedStoreBackupActivation.java       |   33 +-
 .../server/impl/SharedStoreLiveActivation.java  |    6 +-
 .../server/impl/TransientQueueManagerImpl.java  |    6 +-
 .../server/management/ManagementService.java    |    5 +-
 .../management/impl/ManagementServiceImpl.java  |   40 +-
 .../websocket/WebSocketServerHandler.java       |   17 +-
 .../core/server/reload/ReloadCallback.java      |    1 +
 .../core/server/reload/ReloadManager.java       |    5 +-
 .../core/server/reload/ReloadManagerImpl.java   |   10 +-
 .../core/settings/impl/AddressSettings.java     |   84 +-
 .../impl/HierarchicalObjectRepository.java      |   60 +-
 .../artemis/core/settings/impl/Match.java       |    3 +-
 .../settings/impl/ResourceLimitSettings.java    |    6 +-
 .../core/transaction/ResourceManager.java       |    4 +-
 .../artemis/core/transaction/Transaction.java   |   23 +-
 .../core/transaction/TransactionDetail.java     |   19 +-
 .../transaction/impl/CoreTransactionDetail.java |    3 +-
 .../transaction/impl/ResourceManagerImpl.java   |    3 +-
 .../core/transaction/impl/TransactionImpl.java  |   28 +-
 .../core/protocol/AbstractProtocolManager.java  |   14 +-
 .../AbstractProtocolManagerFactory.java         |    3 +-
 .../spi/core/protocol/ProtocolManager.java      |    8 +-
 .../spi/core/protocol/SessionCallback.java      |   17 +-
 .../artemis/spi/core/remoting/Acceptor.java     |   10 +-
 .../ServerConnectionLifeCycleListener.java      |    1 +
 .../security/ActiveMQJAASSecurityManager.java   |   43 +-
 .../core/security/ActiveMQSecurityManager2.java |   19 +-
 .../core/security/ActiveMQSecurityManager3.java |   19 +-
 .../security/ActiveMQSecurityManagerImpl.java   |    6 +-
 .../security/jaas/CertificateLoginModule.java   |   14 +-
 .../core/security/jaas/GuestLoginModule.java    |    9 +-
 .../spi/core/security/jaas/InVMLoginModule.java |   17 +-
 .../core/security/jaas/JaasCallbackHandler.java |   15 +-
 .../spi/core/security/jaas/LDAPLoginModule.java |   56 +-
 .../core/security/jaas/PropertiesLoader.java    |    5 +-
 .../security/jaas/PropertiesLoginModule.java    |    8 +-
 .../security/jaas/ReloadableProperties.java     |   12 +-
 .../jaas/TextFileCertificateLoginModule.java    |    5 +-
 .../ClusterConnectionConfigurationParser.java   |    2 +-
 ...TCPAcceptorTransportConfigurationSchema.java |    6 +-
 .../ClusterConnectionMulticastSchema.java       |    5 +-
 .../ClusterConnectionStaticSchema.java          |    5 +-
 .../activemq/artemis/utils/TimeUtils.java       |    2 -
 .../artemis/utils/XMLConfigurationUtil.java     |   18 +-
 .../main/resources/schema/artemis-server.xsd    |   20 +-
 .../core/config/impl/ConfigurationImplTest.java |   12 +-
 .../impl/FileConfigurationParserTest.java       |    3 +-
 .../core/config/impl/FileConfigurationTest.java |   21 +-
 .../config/impl/HAPolicyConfigurationTest.java  |   49 +-
 .../core/config/impl/ValidatorsTest.java        |    9 +-
 .../WrongRoleFileConfigurationParserTest.java   |    6 +-
 .../artemis/core/filter/impl/FilterTest.java    |   15 +-
 .../jaas/CertificateLoginModuleTest.java        |   24 +-
 .../core/security/jaas/LDAPLoginModuleTest.java |   15 +-
 .../jaas/LDAPModuleRoleExpansionTest.java       |    6 +-
 .../PropertiesLoginModuleRaceConditionTest.java |    6 +-
 .../jaas/PropertiesLoginModuleTest.java         |   12 +-
 .../core/security/jaas/RolePrincipalTest.java   |    3 +-
 .../TextFileCertificateLoginModuleTest.java     |    5 +-
 .../core/security/jaas/UserPrincipalTest.java   |    3 +-
 .../cluster/impl/BroadcastGroupImplTest.java    |   15 +-
 .../core/server/files/FileMoveManagerTest.java  |   17 +-
 .../core/server/files/FileStoreMonitorTest.java |    6 +-
 .../group/impl/ClusteredResetMockTest.java      |   21 +-
 .../core/server/impl/EmbeddedServerTest.java    |   14 +-
 .../impl/ScheduledDeliveryHandlerTest.java      |   16 +-
 .../artemis/core/settings/RepositoryTest.java   |   14 +-
 .../transaction/impl/TransactionImplTest.java   |    3 +-
 .../core/version/impl/VersionImplTest.java      |    3 +-
 .../artemis/tests/util/ActiveMQTestBase.java    |  171 +--
 .../tests/util/ColocatedActiveMQServer.java     |    9 +-
 .../tests/util/InVMNodeManagerServer.java       |    1 -
 .../artemis/tests/util/SimpleStringTest.java    |   36 +-
 .../uri/ClusterConnectionConfigurationTest.java |    2 +-
 .../resources/ConfigurationTest-defaults.xml    |    6 +-
 .../resources/ConfigurationTest-full-config.xml |    6 +-
 .../resources/InvalidConfigurationTest0.xml     |    6 +-
 .../resources/InvalidConfigurationTest1.xml     |    6 +-
 .../resources/InvalidConfigurationTest2.xml     |    6 +-
 .../resources/InvalidConfigurationTest3.xml     |    6 +-
 .../resources/InvalidConfigurationTest4.xml     |    6 +-
 .../resources/InvalidConfigurationTest5.xml     |    6 +-
 .../resources/InvalidConfigurationTest6.xml     |    9 +-
 .../colocated-hapolicy-config-null-backup.xml   |    6 +-
 .../resources/colocated-hapolicy-config.xml     |    6 +-
 .../colocated-hapolicy-config2-null-backup.xml  |    6 +-
 .../resources/colocated-hapolicy-config2.xml    |    6 +-
 .../test/resources/database-store-config.xml    |    6 +-
 .../resources/divertRoutingNameNotRequired.xml  |    9 +-
 .../resources/live-only-hapolicy-config.xml     |    6 +-
 .../resources/live-only-hapolicy-config2.xml    |    6 +-
 .../resources/live-only-hapolicy-config3.xml    |    6 +-
 .../resources/live-only-hapolicy-config4.xml    |    6 +-
 .../resources/live-only-hapolicy-config5.xml    |    6 +-
 .../test/resources/replica-hapolicy-config.xml  |    6 +-
 .../test/resources/replica-hapolicy-config2.xml |    6 +-
 .../test/resources/replica-hapolicy-config3.xml |    6 +-
 .../resources/replicated-hapolicy-config.xml    |    6 +-
 .../test/resources/securitySettingPlugin.xml    |    9 +-
 .../shared-store-master-hapolicy-config.xml     |    6 +-
 .../shared-store-slave-hapolicy-config.xml      |    6 +-
 .../shared-store-slave-hapolicy-config2.xml     |    6 +-
 .../shared-store-slave-hapolicy-config3.xml     |    6 +-
 artemis-service-extensions/pom.xml              |    3 +-
 .../service/extensions/ServiceUtils.java        |   18 +-
 .../xa/ActiveMQXAResourceWrapperImpl.java       |    2 +-
 .../xa/recovery/ActiveMQXAResourceWrapper.java  |   65 +-
 .../xa/recovery/XARecoveryConfig.java           |   15 +-
 .../tests/recovery/XARecoveryConfigTest.java    |   15 +-
 .../DummyTransactionManagerLocator.java         |    4 +-
 .../xa/ActiveMQXAResourceWrapperImplTest.java   |    1 -
 .../extensions/tests/xa/ServiceUtilsTest.java   |    4 +-
 artemis-web/pom.xml                             |   13 +-
 .../artemis/component/WebServerComponent.java   |   19 +-
 .../cli/test/WebServerComponentTest.java        |   19 +-
 artemis-website/package.json                    |    2 +-
 artemis-website/pom.xml                         |   49 +-
 .../src/main/resources/examples/index.html      |   30 +-
 .../src/main/resources/hacking-guide/index.html |   17 +-
 artemis-website/src/main/resources/index.html   |    3 +-
 .../src/main/resources/user-manual/index.html   |   17 +-
 docs/hacking-guide/en/formatting.md             |    6 +-
 docs/hacking-guide/en/ide.md                    |    4 +-
 etc/checkstyle.xml                              |    6 +-
 etc/ide-settings/IDEA-artemis-inspections.xml   |    8 -
 etc/ide-settings/IDEA-style.jar                 |  Bin 3509 -> 0 bytes
 etc/ide-settings/idea/IDEA-style.jar            |  Bin 0 -> 3286 bytes
 etc/ide-settings/idea/artemis-codestyle.xml     |   52 +
 etc/ide-settings/idea/artemis-inspections.xml   |    8 +
 .../example/ClientSideLoadBalancingExample.java |   11 +-
 .../ClusteredDurableSubscriptionExample.java    |    3 +-
 .../jms/example/ClusteredGroupingExample.java   |    3 +-
 .../jms/example/ClusteredJgroupsExample.java    |    3 +-
 .../jms/example/ClusteredQueueExample.java      |    3 +-
 .../example/StaticClusteredQueueExample.java    |    3 +-
 .../example/StaticClusteredQueueExample.java    |    3 +-
 .../jms/example/ClusterStaticOnewayExample.java |    3 +-
 .../jms/example/ClusteredTopicExample.java      |    3 +-
 .../jms/example/ClusteredTopicExample.java      |    3 +-
 .../QueueMessageRedistributionExample.java      |    3 +-
 .../jms/example/SymmetricClusterExample.java    |    3 +-
 .../ApplicationLayerFailoverExample.java        |   21 +-
 .../ClientSideFailoverListerExample.java        |   13 +-
 .../ColocatedFailoverScaleDownExample.java      |    3 +-
 .../jms/example/ColocatedFailoverExample.java   |    3 +-
 .../jms/example/HAPolicyAutoBackupExample.java  |    3 +-
 .../MultipleFailoverFailbackExample.java        |   13 +-
 .../jms/example/MultipleFailoverExample.java    |   13 +-
 .../example/NonTransactionFailoverExample.java  |   10 +-
 .../ReplicatedFailbackStaticExample.java        |   13 +-
 .../jms/example/ReplicatedFailbackExample.java  |   13 +-
 .../ReplicatedMultipleFailoverExample.java      |   13 +-
 .../ReplicatedTransactionFailoverExample.java   |   12 +-
 .../artemis/jms/example/ScaleDownExample.java   |    7 +-
 .../jms/example/StopServerFailoverExample.java  |    6 +-
 .../jms/example/TransactionFailoverExample.java |   12 +-
 .../activemq/artemis/jms/example/PerfBase.java  |   41 +-
 .../artemis/jms/example/PerfListener.java       |    3 +-
 .../artemis/jms/example/PerfParams.java         |    1 -
 .../artemis/jms/example/PerfSender.java         |    3 +-
 .../artemis/jms/soak/example/SoakReceiver.java  |   24 +-
 .../artemis/jms/soak/example/SoakSender.java    |   21 +-
 .../artemis/jms/example/BridgeExample.java      |    6 +-
 .../jms/example/QueueBrowserExample.java        |    3 +-
 .../jms/example/ClientKickoffExample.java       |    3 +-
 .../jms/example/ConsumerRateLimitExample.java   |    3 +-
 .../artemis/jms/example/DeadLetterExample.java  |    3 +-
 .../jms/example/DelayedRedeliveryExample.java   |    3 +-
 .../artemis/jms/example/DivertExample.java      |    3 +-
 .../jms/example/DurableSubscriptionExample.java |    3 +-
 .../artemis/jms/example/EmbeddedExample.java    |    3 +-
 .../artemis/jms/example/EmbeddedExample.java    |   27 +-
 .../artemis/jms/example/ExpiryExample.java      |    3 +-
 .../jms/example/HttpTransportExample.java       |    3 +-
 .../InstantiateConnectionFactoryExample.java    |    3 +-
 .../artemis/jms/example/InterceptorExample.java |    3 +-
 .../artemis/jms/example/JMSBridgeExample.java   |    3 +-
 .../example/JMSCompletionListenerExample.java   |    4 +-
 .../jms/example/JMSSharedConsumerExample.java   |    3 +-
 .../artemis/jms/example/JMXExample.java         |    6 +-
 .../jms/example/LargeMessageExample.java        |    7 +-
 .../jms/example/LastValueQueueExample.java      |    3 +-
 .../example/ManagementNotificationExample.java  |   12 +-
 .../artemis/jms/example/ManagementExample.java  |    3 +-
 .../jms/example/MessageCounterExample.java      |    6 +-
 .../jms/example/MessageGroupExample.java        |    8 +-
 .../jms/example/MessageGroup2Example.java       |    8 +-
 .../jms/example/MessagePriorityExample.java     |   13 +-
 .../jms/example/NoConsumerBufferingExample.java |    3 +-
 .../artemis/jms/example/PagingExample.java      |    3 +-
 .../jms/example/PreacknowledgeExample.java      |    3 +-
 .../jms/example/ProducerRateLimitExample.java   |    3 +-
 .../jms/example/QueueRequestorExample.java      |    6 +-
 .../jms/example/TextReverserService.java        |    6 +-
 .../jms/example/QueueSelectorExample.java       |    6 +-
 .../artemis/jms/example/QueueExample.java       |    3 +-
 .../artemis/jms/example/ReattachExample.java    |    6 +-
 .../jms/example/RequestReplyExample.java        |   11 +-
 .../dup-send/src/main/java/ReceiveOrder.java    |    8 +-
 .../messaging/test/AutoAckTopicTest.java        |    4 +-
 .../jms-to-rest/src/main/java/JmsReceive.java   |   24 +-
 .../rest/jms-to-rest/src/main/java/JmsSend.java |    6 +-
 .../jms-to-rest/src/main/java/RestReceive.java  |    6 +-
 .../rest/push/src/main/java/PostOrder.java      |    6 +-
 .../push/src/main/java/ReceiveShipping.java     |   24 +-
 .../jms/example/ScheduledMessageExample.java    |    8 +-
 .../artemis/jms/example/SecurityExample.java    |   30 +-
 .../ldap/InMemoryDirectoryServiceFactory.java   |   18 +-
 .../example/ldap/InMemorySchemaPartition.java   |    3 +-
 .../artemis/jms/example/ldap/LdapServer.java    |   16 +-
 .../artemis/jms/example/SecurityExample.java    |   30 +-
 .../example/SendAcknowledgementsExample.java    |    3 +-
 .../artemis/jms/example/ExampleListener.java    |    3 +-
 .../artemis/jms/example/MessageSender.java      |    9 +-
 .../example/SSLDualAuthenticationExample.java   |    3 +-
 .../artemis/jms/example/SSLExample.java         |    3 +-
 .../jms/example/StaticSelectorExample.java      |    6 +-
 .../jms/example/TemporaryQueueExample.java      |    6 +-
 .../jms/example/TopicHierarchyExample.java      |    3 +-
 .../jms/example/TopicSelectorExample1.java      |    3 +-
 .../jms/example/TopicSelectorExample2.java      |    8 +-
 .../artemis/jms/example/TopicExample.java       |    3 +-
 .../jms/example/TransactionalExample.java       |    3 +-
 .../artemis/jms/example/XAHeuristicExample.java |    6 +-
 .../activemq/artemis/jms/example/DummyXid.java  |    4 +-
 .../artemis/jms/example/XAReceiveExample.java   |    6 +-
 .../activemq/artemis/jms/example/DummyXid.java  |    4 +-
 .../artemis/jms/example/XASendExample.java      |    6 +-
 .../artemis/jms/example/AerogearExample.java    |    3 +-
 .../artemis/core/example/ExampleVerticle.java   |    3 +-
 .../core/example/VertxConnectorExample.java     |    6 +-
 .../artemis/jms/example/ProtonCPPExample.java   |    6 +-
 .../artemis/jms/example/AMQPQueueExample.java   |    3 +-
 .../activemq/artemis/openwire/example/Chat.java |   21 +-
 .../artemis/openwire/example/Server.java        |    7 +-
 .../artemis/jms/example/QueueExample.java       |   10 +-
 .../artemis/jms/example/QueueExample.java       |   10 +-
 .../artemis/jms/example/QueueExample.java       |    3 +-
 .../example/StompDualAuthenticationExample.java |    3 +-
 .../artemis/jms/example/MyStompInterceptor.java |    5 +-
 .../artemis/jms/example/RegularInterceptor.java |    4 +-
 .../artemis/jms/example/StompExample.java       |    1 -
 .../jms/example/StompWebSocketExample.java      |    5 +-
 .../artemis/jms/example/StompExample.java       |   12 +-
 .../artemis/jms/example/StompExample.java       |   12 +-
 .../artemis/jms/example/StompExample.java       |   12 +-
 .../aerogear/ActiveMQAeroGearBundle.java        |    2 +-
 .../aerogear/AeroGearConnectorService.java      |   22 +-
 .../AeroGearConnectorServiceFactory.java        |    8 +-
 .../integration/aerogear/AeroGearConstants.java |    4 +-
 .../spring/SpringBindingRegistry.java           |    3 +-
 .../vertx/IncomingVertxEventHandler.java        |   48 +-
 .../vertx/OutgoingVertxEventHandler.java        |    6 +-
 .../cdi/extension/ArtemisClientConfigBean.java  |    6 +-
 .../ArtemisEmbeddedServerConfigBean.java        |   10 +-
 .../client/cdi/extension/ArtemisExtension.java  |   14 +-
 .../cdi/factory/ConnectionFactoryProvider.java  |   28 +-
 .../client/cdi/logger/ActiveMQCDILogger.java    |    7 +-
 .../artemis/cdi/bootstrap/CDIBootstrapTest.java |   17 +-
 pom.xml                                         |    2 +-
 .../activemq/ActiveMQConnectionFactory.java     |   72 +-
 .../artemiswrapper/ArtemisBrokerHelper.java     |   30 +-
 .../broker/ArtemisBrokerWrapperFactory.java     |    5 +-
 .../apache/activemq/broker/BrokerService.java   |   65 +-
 .../activemq/broker/FakeTransportConnector.java |    2 +-
 .../activemq/broker/SslBrokerService.java       |    5 +-
 .../artemiswrapper/ArtemisBrokerBase.java       |   14 +-
 .../artemiswrapper/ArtemisBrokerWrapper.java    |   21 +-
 .../artemiswrapper/CleanupThreadRule.java       |    6 +-
 .../broker/artemiswrapper/InVMNameParser.java   |    7 +-
 .../artemiswrapper/InVMNamingContext.java       |   28 +-
 .../artemiswrapper/NonSerializableFactory.java  |    7 +-
 .../artemiswrapper/OpenwireArtemisBaseTest.java |   59 +-
 .../transport/tcp/TcpTransportFactory.java      |   32 +-
 .../org/apache/activemq/usage/SystemUsage.java  |    8 +-
 .../activemq/ActiveMQConnectionFactoryTest.java |   21 +-
 .../activemq/ActiveMQMessageAuditTest.java      |    2 +-
 .../ActiveMQSslConnectionFactoryTest.java       |   23 +-
 .../ActiveMQXAConnectionFactoryTest.java        |   63 +-
 .../apache/activemq/AutoFailTestSupport.java    |  250 ++--
 .../org/apache/activemq/ClientTestSupport.java  |   11 +-
 .../apache/activemq/CombinationTestSupport.java |   47 +-
 .../apache/activemq/ConnectionCleanupTest.java  |    8 +-
 ...nectionCloseMultipleTimesConcurrentTest.java |    9 +-
 .../ConnectionCloseMultipleTimesTest.java       |    2 +-
 .../ConsumerReceiveWithTimeoutTest.java         |    5 +-
 ...nsumerButDontStartConnectionWarningTest.java |    5 +-
 .../EmbeddedBrokerAndConnectionTestSupport.java |    2 +-
 .../activemq/EmbeddedBrokerTestSupport.java     |   35 +-
 ...ExclusiveConsumerStartupDestinationTest.java |   11 +-
 .../apache/activemq/ExclusiveConsumerTest.java  |   20 +-
 .../java/org/apache/activemq/ExpiryHogTest.java |    4 +-
 .../org/apache/activemq/JMSConsumerTest.java    |   39 +-
 .../activemq/JMSDurableTopicRedeliverTest.java  |    2 +-
 .../activemq/JMSExclusiveConsumerTest.java      |    5 +-
 .../apache/activemq/JMSIndividualAckTest.java   |    2 +-
 .../org/apache/activemq/JMSMessageTest.java     |   20 +-
 .../apache/activemq/JMSQueueRedeliverTest.java  |    2 +-
 .../org/apache/activemq/JMSUsecaseTest.java     |    5 +-
 .../org/apache/activemq/JMSXAConsumerTest.java  |    2 +-
 .../apache/activemq/JmsAutoAckListenerTest.java |    2 +-
 .../org/apache/activemq/JmsAutoAckTest.java     |    2 +-
 .../java/org/apache/activemq/JmsBenchmark.java  |   25 +-
 .../activemq/JmsClientAckListenerTest.java      |    5 +-
 .../org/apache/activemq/JmsClientAckTest.java   |    2 +-
 .../activemq/JmsConnectionStartStopTest.java    |   19 +-
 .../JmsConsumerResetActiveListenerTest.java     |   23 +-
 .../JmsCreateConsumerInOnMessageTest.java       |    5 +-
 .../JmsDurableQueueWildcardSendReceiveTest.java |    2 +-
 .../activemq/JmsDurableTopicSelectorTest.java   |    2 +-
 .../JmsDurableTopicSendReceiveTest.java         |    2 +-
 .../JmsDurableTopicTransactionTest.java         |    2 +-
 .../JmsDurableTopicWildcardSendReceiveTest.java |    2 +-
 .../apache/activemq/JmsMessageConsumerTest.java |   17 +-
 .../activemq/JmsMultipleBrokersTestSupport.java |   45 +-
 .../activemq/JmsMultipleClientsTestSupport.java |   41 +-
 .../apache/activemq/JmsQueueBrowserTest.java    |    9 +-
 .../JmsQueueCompositeSendReceiveTest.java       |    5 +-
 .../activemq/JmsQueueRequestReplyTest.java      |    2 +-
 .../apache/activemq/JmsQueueSelectorTest.java   |    2 +-
 .../activemq/JmsQueueSendReceiveTest.java       |    2 +-
 ...eiveTwoConnectionsStartBeforeBrokerTest.java |    8 +-
 .../JmsQueueSendReceiveTwoConnectionsTest.java  |    2 +-
 ...JmsQueueSendReceiveUsingTwoSessionsTest.java |    2 +-
 .../JmsQueueTopicCompositeSendReceiveTest.java  |    5 +-
 .../activemq/JmsQueueTransactionTest.java       |  395 ++---
 .../JmsQueueWildcardSendReceiveTest.java        |    2 +-
 .../org/apache/activemq/JmsRedeliveredTest.java |    4 +-
 .../activemq/JmsRollbackRedeliveryTest.java     |   31 +-
 .../activemq/JmsSendReceiveTestSupport.java     |   18 +-
 ...JmsSendReceiveWithMessageExpirationTest.java |    9 +-
 .../activemq/JmsSendWithAsyncCallbackTest.java  |    5 +-
 .../apache/activemq/JmsSessionRecoverTest.java  |   19 +-
 .../apache/activemq/JmsTempDestinationTest.java |   28 +-
 .../org/apache/activemq/JmsTestSupport.java     |   32 +-
 .../JmsTopicCompositeSendReceiveTest.java       |    5 +-
 .../apache/activemq/JmsTopicRedeliverTest.java  |    5 +-
 .../activemq/JmsTopicRequestReplyTest.java      |   28 +-
 .../apache/activemq/JmsTopicSelectorTest.java   |    5 +-
 .../JmsTopicSendReceiveSubscriberTest.java      |    5 +-
 .../activemq/JmsTopicSendReceiveTest.java       |    5 +-
 ...sTopicSendReceiveWithTwoConnectionsTest.java |    9 +-
 ...endReceiveWithTwoConnectionsWithJMXTest.java |    2 +-
 .../activemq/JmsTopicSendSameMessageTest.java   |    2 +-
 .../activemq/JmsTopicTransactionTest.java       |    2 +-
 .../JmsTopicWildcardSendReceiveTest.java        |    2 +-
 .../activemq/JmsTransactionTestSupport.java     | 1345 +++++++++---------
 .../activemq/LargeMessageTestSupport.java       |   20 +-
 .../org/apache/activemq/LoadTestBurnIn.java     |   28 +-
 .../apache/activemq/MessageEvictionTest.java    |   48 +-
 .../activemq/MessageListenerRedeliveryTest.java |   50 +-
 .../activemq/MessageTransformationTest.java     |    2 +-
 .../activemq/OnePrefetchAsyncConsumerTest.java  |   19 +-
 .../org/apache/activemq/OptimizedAckTest.java   |    5 +-
 .../activemq/PerDestinationStoreLimitTest.java  |   19 +-
 .../ProducerFlowControlSendFailTest.java        |   13 +-
 .../activemq/ProducerFlowControlTest.java       |   29 +-
 .../activemq/QueueConsumerPriorityTest.java     |    5 +-
 .../activemq/ReconnectWithSameClientIDTest.java |   13 +-
 .../apache/activemq/RedeliveryPolicyTest.java   |   52 +-
 .../apache/activemq/RemoveDestinationTest.java  |   22 +-
 .../org/apache/activemq/SpringTestSupport.java  |    2 +-
 .../java/org/apache/activemq/TestSupport.java   |   12 +-
 .../java/org/apache/activemq/TimeStampTest.java |    3 +-
 .../apache/activemq/TransactionContextTest.java |   17 +-
 .../activemq/ZeroPrefetchConsumerTest.java      |    5 +-
 .../advisory/AdvisoryTempDestinationTests.java  |    7 +-
 .../apache/activemq/advisory/AdvisoryTests.java |    2 +-
 .../activemq/advisory/ConsumerListenerTest.java |    9 +-
 .../advisory/DestinationListenerTest.java       |   14 +-
 .../activemq/advisory/ProducerListenerTest.java |    9 +-
 .../activemq/advisory/TempDestDeleteTest.java   |    9 +-
 .../activemq/advisory/TempDestLoadTest.java     |    2 +-
 .../activemq/advisory/TempQueueMemoryTest.java  |   14 +-
 .../blob/BlobTransferPolicyUriTest.java         |    2 +-
 .../blob/FTPBlobDownloadStrategyTest.java       |   20 +-
 .../org/apache/activemq/blob/FTPBlobTest.java   |   11 +-
 .../blob/FTPBlobUploadStrategyTest.java         |   10 +-
 .../apache/activemq/blob/FTPTestSupport.java    |    5 +-
 .../activemq/blob/FilesystemBlobTest.java       |   11 +-
 .../apache/activemq/broker/BrokerBenchmark.java |   17 +-
 .../activemq/broker/BrokerRedeliveryTest.java   |    7 +-
 .../broker/BrokerRestartTestSupport.java        |    2 +-
 .../activemq/broker/BrokerServiceTest.java      |    2 +-
 .../org/apache/activemq/broker/BrokerTest.java  |    5 +-
 .../activemq/broker/BrokerTestSupport.java      |   19 +-
 .../broker/ConcurrentConnectSimulationTest.java |    2 +-
 ...CreateDestinationsOnStartupViaXBeanTest.java |    2 +-
 .../broker/DedicatedTaskRunnerBrokerTest.java   |    2 +-
 .../activemq/broker/DoubleSubscriptionTest.java |    2 +-
 .../DurablePersistentFalseRestartTest.java      |    2 +-
 .../broker/JdbcXARecoveryBrokerTest.java        |    5 +-
 .../java/org/apache/activemq/broker/Main.java   |    8 +-
 .../activemq/broker/MarshallingBrokerTest.java  |    2 +-
 .../activemq/broker/MessageExpirationTest.java  |    5 +-
 .../broker/NioQueueSubscriptionTest.java        |   27 +-
 .../activemq/broker/OutOfOrderXMLTest.java      |    2 +-
 .../apache/activemq/broker/ProgressPrinter.java |    2 +-
 .../activemq/broker/QueueMbeanRestartTest.java  |   11 +-
 .../activemq/broker/QueueSubscriptionTest.java  |    2 +-
 .../broker/ReconnectWithJMXEnabledTest.java     |    2 +-
 .../activemq/broker/RecoveryBrokerTest.java     |    5 +-
 .../activemq/broker/RedeliveryRestartTest.java  |    4 +-
 .../RedeliveryRestartWithExceptionTest.java     |   28 +-
 .../org/apache/activemq/broker/SpringTest.java  |    5 +-
 .../org/apache/activemq/broker/StubBroker.java  |    2 +-
 .../apache/activemq/broker/StubConnection.java  |   14 +-
 .../activemq/broker/TopicSubscriptionTest.java  |    2 +-
 .../activemq/broker/XARecoveryBrokerTest.java   |   36 +-
 .../broker/advisory/AdvisoryBrokerTest.java     |    2 +-
 .../AdvisoryDuplexNetworkBridgeTest.java        |    6 +-
 .../broker/advisory/AdvisoryJmxTest.java        |   21 +-
 .../advisory/AdvisoryNetworkBridgeTest.java     |   12 +-
 ...artJDBCQueueMasterSlaveLeaseQuiesceTest.java |   11 +-
 .../DbRestartJDBCQueueMasterSlaveLeaseTest.java |    2 +-
 .../ft/DbRestartJDBCQueueMasterSlaveTest.java   |   31 +-
 .../broker/ft/DbRestartJDBCQueueTest.java       |   21 +-
 .../broker/ft/JDBCQueueMasterSlaveTest.java     |   10 +-
 .../ft/QueueMasterSlaveSingleUrlTest.java       |    5 +-
 .../broker/ft/QueueMasterSlaveTestSupport.java  |    9 +-
 ...QueueMasterSlaveTestUsingSharedFileTest.java |    5 +-
 .../broker/ft/SyncCreateDataSource.java         |    6 +-
 .../ft/kahaDbJdbcLeaseQueueMasterSlaveTest.java |   10 +-
 .../broker/ft/mKahaDbQueueMasterSlaveTest.java  |    8 +-
 .../broker/mKahaDBXARecoveryBrokerTest.java     |    2 +-
 .../broker/mLevelDBXARecoveryBrokerTest.java    |    8 +-
 .../security/MessageAuthenticationTest.java     |   15 +-
 .../partition/SpringPartitionBrokerTest.java    |    2 +-
 .../policy/AbortSlowAckConsumer0Test.java       |   20 +-
 .../policy/AbortSlowAckConsumer1Test.java       |    2 +-
 .../policy/AbortSlowAckConsumer2Test.java       |    2 +-
 .../broker/policy/AbortSlowConsumer0Test.java   |   23 +-
 .../broker/policy/AbortSlowConsumer1Test.java   |   16 +-
 .../broker/policy/AbortSlowConsumer2Test.java   |    6 +-
 .../broker/policy/AbortSlowConsumerBase.java    |   12 +-
 .../activemq/broker/policy/DeadLetterTest.java  |    2 +-
 .../broker/policy/DeadLetterTestSupport.java    |    8 +-
 .../policy/DestinationCursorConfigTest.java     |    2 +-
 .../policy/DiscardingDeadLetterPolicyTest.java  |    2 +-
 .../broker/policy/IndividualDeadLetterTest.java |    5 +-
 .../policy/IndividualDeadLetterViaXmlTest.java  |    2 +-
 .../broker/policy/MessageGroupConfigTest.java   |    2 +-
 .../policy/MessageListenerDeadLetterTest.java   |   11 +-
 .../broker/policy/NoConsumerDeadLetterTest.java |    5 +-
 .../broker/policy/NoRetryDeadLetterTest.java    |    2 +-
 .../PerDurableConsumerDeadLetterTest.java       |    2 +-
 .../PriorityNetworkDispatchPolicyTest.java      |    6 +-
 .../policy/RoundRobinDispatchPolicyTest.java    |   12 +-
 .../activemq/broker/policy/SecureDLQTest.java   |   21 +-
 .../broker/policy/SimpleDispatchPolicyTest.java |   11 +-
 .../policy/StrictOrderDispatchPolicyTest.java   |    7 +-
 .../broker/region/DestinationGCTest.java        |    5 +-
 .../region/DestinationRemoveRestartTest.java    |    2 +-
 .../region/QueueDuplicatesFromStoreTest.java    |   75 +-
 .../QueueOptimizedDispatchExceptionTest.java    |   10 +-
 .../activemq/broker/region/QueuePurgeTest.java  |   10 +-
 .../region/QueueResendDuringShutdownTest.java   |   24 +-
 .../region/SubscriptionAddRemoveQueueTest.java  |   38 +-
 ...iquePropertyMessageEvictionStrategyTest.java |   17 +-
 .../region/cursors/CursorDurableTest.java       |    2 +-
 .../region/cursors/CursorQueueStoreTest.java    |    2 +-
 .../broker/region/cursors/CursorSupport.java    |   27 +-
 .../FilePendingMessageCursorTestSupport.java    |    5 +-
 .../region/cursors/OrderPendingListTest.java    |   13 +-
 .../cursors/PrioritizedPendingListTest.java     |   10 +-
 .../region/cursors/StoreBasedCursorTest.java    |   10 +-
 .../StoreQueueCursorJDBCNoDuplicateTest.java    |    2 +-
 .../StoreQueueCursorKahaDBNoDuplicateTest.java  |    2 +-
 .../StoreQueueCursorLevelDBNoDuplicateTest.java |    5 +-
 .../StoreQueueCursorMemoryNoDuplicateTest.java  |    2 +-
 .../StoreQueueCursorNoDuplicateTest.java        |    2 +-
 .../cursors/StoreQueueCursorOrderTest.java      |    2 +-
 .../group/MessageGroupHashBucketTest.java       |    2 +-
 .../region/group/MessageGroupMapTest.java       |    2 +-
 .../broker/region/group/MessageGroupTest.java   |    2 +-
 .../broker/scheduler/JmsCronSchedulerTest.java  |   28 +-
 .../broker/scheduler/JmsSchedulerTest.java      |   20 +-
 .../JobSchedulerBrokerShutdownTest.java         |    5 +-
 .../JobSchedulerJmxManagementTests.java         |   15 +-
 .../scheduler/JobSchedulerManagementTest.java   |   23 +-
 .../JobSchedulerStoreCheckpointTest.java        |    8 +-
 .../broker/scheduler/JobSchedulerStoreTest.java |    6 +-
 .../broker/scheduler/JobSchedulerTest.java      |    8 +-
 .../scheduler/JobSchedulerTestSupport.java      |    5 +-
 .../broker/scheduler/JobSchedulerTxTest.java    |   11 +-
 .../KahaDBSchedulerIndexRebuildTest.java        |   22 +-
 .../KahaDBSchedulerMissingJournalLogsTest.java  |   25 +-
 .../scheduler/LostScheduledMessagesTest.java    |   15 +-
 .../scheduler/SchedulerDBVersionTest.java       |   22 +-
 .../memory/InMemeoryJmsSchedulerTest.java       |    2 +-
 .../memory/InMemoryJmsCronSchedulerTest.java    |    2 +-
 .../InMemoryJobSchedulerJmxManagementTests.java |    2 +-
 .../InMemoryJobSchedulerManagementTest.java     |    2 +-
 .../memory/InMemoryJobSchedulerStoreTest.java   |    6 +-
 .../memory/InMemoryJobSchedulerTest.java        |    2 +-
 .../memory/InMemoryJobSchedulerTxTest.java      |    2 +-
 .../broker/store/DefaultStoreBrokerTest.java    |    2 +-
 .../store/DefaultStoreRecoveryBrokerTest.java   |    2 +-
 .../activemq/broker/store/LoadTester.java       |    9 +-
 .../store/RecoverExpiredMessagesTest.java       |    2 +-
 .../broker/util/DestinationsPluginTest.java     |    4 +-
 .../activemq/broker/util/PluginBrokerTest.java  |   17 +-
 .../broker/util/RedeliveryPluginTest.java       |   11 +-
 .../util/TimeStampingBrokerPluginTest.java      |    2 +-
 .../broker/util/TraceBrokerPathPluginTest.java  |    3 +-
 .../command/ActiveMQBytesMessageTest.java       |  152 +-
 .../command/ActiveMQDestinationTest.java        |   25 +-
 .../command/ActiveMQMapMessageTest.java         |   80 +-
 .../activemq/command/ActiveMQMessageTest.java   |  207 +--
 .../command/ActiveMQObjectMessageTest.java      |   23 +-
 .../command/ActiveMQStreamMessageTest.java      |  341 ++---
 .../command/ActiveMQTextMessageTest.java        |   32 +-
 .../command/DataStructureTestSupport.java       |   26 +-
 .../command/MessageCompressionTest.java         |   11 +-
 .../activemq/command/MessageSendTest.java       |    2 +-
 .../apache/activemq/command/MessageTest.java    |    2 +-
 .../activemq/config/BrokerPropertiesTest.java   |    2 +-
 .../config/BrokerXmlConfigFromJNDITest.java     |    7 +-
 .../activemq/config/BrokerXmlConfigTest.java    |    2 +-
 .../org/apache/activemq/config/ConfigTest.java  |   50 +-
 .../config/ConfigUsingDestinationOptions.java   |    8 +-
 .../apache/activemq/config/JDBCConfigTest.java  |   11 +-
 .../activemq/console/command/AMQ3410Test.java   |   11 +-
 .../activemq/console/command/AMQ3411Test.java   |    8 +-
 .../console/command/DummyConnectionFactory.java |    6 +-
 .../command/InvalidConnectionFactory.java       |    2 +-
 .../command/LowercasingPasswordFactory.java     |    2 +-
 .../console/command/PurgeCommandTest.java       |   39 +-
 .../activemq/demo/DefaultQueueSender.java       |   19 +-
 .../apache/activemq/demo/SimpleConsumer.java    |   26 +-
 .../apache/activemq/demo/SimpleProducer.java    |   28 +-
 .../activemq/demo/SimpleQueueReceiver.java      |   26 +-
 .../apache/activemq/demo/SimpleQueueSender.java |   28 +-
 .../activemq/filter/DestinationFilterTest.java  |    6 +-
 .../filter/DestinationMapMemoryTest.java        |    5 +-
 .../DestinationMapTempDestinationTest.java      |    4 +-
 .../activemq/filter/DestinationMapTest.java     |   12 +-
 .../activemq/filter/DestinationPathTest.java    |    2 +-
 .../org/apache/activemq/filter/DummyPolicy.java |    2 +-
 .../activemq/filter/DummyPolicyEntry.java       |    2 +-
 .../apache/activemq/filter/DummyPolicyTest.java |    2 +-
 .../apache/activemq/jmx/JmxCreateNCTest.java    |    4 +-
 .../activemq/jmx/OpenTypeSupportTest.java       |    5 +-
 .../jndi/ActiveMQInitialContextFactoryTest.java |    2 +-
 .../ActiveMQWASInitialContextFactoryTest.java   |    5 +-
 .../jndi/CustomConnectionFactoryNameTest.java   |    2 +-
 .../jndi/DestinationNameWithSlashTest.java      |    2 +-
 .../activemq/jndi/InitialContextTest.java       |    5 +-
 .../apache/activemq/jndi/JNDITestSupport.java   |    5 +-
 .../apache/activemq/jndi/ObjectFactoryTest.java |    2 +-
 .../activemq/jndi/XAConnectionFactoryTest.java  |    2 +-
 .../activemq/joramtests/ActiveMQAdmin.java      |   30 +-
 .../activemq/joramtests/JoramJmsTest.java       |    2 +-
 .../leveldb/LevelDBStoreBrokerTest.java         |    8 +-
 .../leveldb/LevelDBXARecoveryBrokerTest.java    |    5 +-
 .../org/apache/activemq/load/LoadClient.java    |    8 +-
 .../apache/activemq/load/LoadController.java    |   13 +-
 .../java/org/apache/activemq/load/LoadTest.java |    8 +-
 .../management/BoundaryStatisticTest.java       |    2 +-
 .../management/BoundedRangeStatisticTest.java   |    2 +-
 .../activemq/management/CountStatisticTest.java |    2 +-
 .../activemq/management/RangeStatisticTest.java |    2 +-
 .../management/StatisticTestSupport.java        |    2 +-
 .../activemq/management/TimeStatisticTest.java  |    2 +-
 .../activemq/memory/MemoryPropertyTest.java     |    2 +-
 .../activemq/memory/buffer/DummyMessage.java    |    2 +-
 .../memory/buffer/MemoryBufferTestSupport.java  |    4 +-
 .../buffer/OrderBasedMemoryBufferTest.java      |    5 +-
 .../buffer/SizeBasedMessageBufferTest.java      |    5 +-
 .../BrokerNetworkWithStuckMessagesTest.java     |   39 +-
 .../CheckDuplicateMessagesOnDuplexTest.java     |   27 +-
 .../network/CompressionOverNetworkTest.java     |   21 +-
 .../DemandForwardingBridgeFilterTest.java       |    8 +-
 .../network/DemandForwardingBridgeTest.java     |    5 +-
 .../network/DuplexNetworkMBeanTest.java         |   29 +-
 .../activemq/network/DuplexNetworkTest.java     |    8 +-
 ...lyIncludedDestinationsDuplexNetworkTest.java |   13 +-
 .../network/FailoverStaticNetworkTest.java      |   42 +-
 .../activemq/network/ForwardingBridgeTest.java  |    8 +-
 .../MQTTNetworkOfBrokersFailoverTest.java       |   12 +-
 .../activemq/network/MulticastNetworkTest.java  |    2 +-
 .../network/NetworkBrokerDetachTest.java        |   21 +-
 .../network/NetworkConnectionsTest.java         |   12 +-
 .../network/NetworkDestinationFilterTest.java   |    8 +-
 .../activemq/network/NetworkFailoverTest.java   |   28 +-
 .../activemq/network/NetworkLoadTest.java       |   23 +-
 .../activemq/network/NetworkLoopBackTest.java   |   16 +-
 .../activemq/network/NetworkReconnectTest.java  |   26 +-
 .../NetworkRemovesSubscriptionsTest.java        |    2 +-
 .../network/NetworkRestartPlainTest.java        |    2 +-
 .../activemq/network/NetworkRestartTest.java    |   11 +-
 .../activemq/network/NetworkRouteTest.java      |    4 +-
 .../activemq/network/NetworkTestSupport.java    |    2 +-
 .../network/SSHTunnelNetworkReconnectTest.java  |    8 +-
 .../activemq/network/SimpleNetworkTest.java     |   22 +-
 .../jms/QueueBridgeStandaloneReconnectTest.java |   35 +-
 .../activemq/network/jms/QueueBridgeTest.java   |    5 +-
 .../network/jms/QueueBridgeXBeanTest.java       |    2 +-
 .../jms/QueueOutboundBridgeReconnectTest.java   |   34 +-
 .../network/jms/TopicBridgeSpringTest.java      |    5 +-
 .../jms/TopicBridgeStandaloneReconnectTest.java |   35 +-
 .../network/jms/TopicBridgeXBeanTest.java       |    2 +-
 .../jms/TopicOutboundBridgeReconnectTest.java   |   34 +-
 .../activemq/openwire/BooleanStreamTest.java    |   14 +-
 .../activemq/openwire/BrokerInfoData.java       |    2 +-
 .../activemq/openwire/DataFileGenerator.java    |    8 +-
 .../openwire/DataFileGeneratorTestSupport.java  |   32 +-
 .../openwire/ItStillMarshallsTheSameTest.java   |    2 +-
 .../NumberRangesWhileMarshallingTest.java       |    8 +-
 .../activemq/openwire/WireFormatInfoData.java   |    2 +-
 .../openwire/v1/ActiveMQBytesMessageTest.java   |    2 +-
 .../v1/ActiveMQDestinationTestSupport.java      |    2 +-
 .../openwire/v1/ActiveMQMapMessageTest.java     |    2 +-
 .../openwire/v1/ActiveMQMessageTest.java        |    2 +-
 .../openwire/v1/ActiveMQObjectMessageTest.java  |    2 +-
 .../activemq/openwire/v1/ActiveMQQueueTest.java |    2 +-
 .../openwire/v1/ActiveMQStreamMessageTest.java  |    2 +-
 .../v1/ActiveMQTempDestinationTestSupport.java  |    2 +-
 .../openwire/v1/ActiveMQTempQueueTest.java      |    2 +-
 .../openwire/v1/ActiveMQTempTopicTest.java      |    2 +-
 .../openwire/v1/ActiveMQTextMessageTest.java    |    2 +-
 .../activemq/openwire/v1/ActiveMQTopicTest.java |    2 +-
 .../openwire/v1/BaseCommandTestSupport.java     |    2 +-
 .../activemq/openwire/v1/BrokerIdTest.java      |    2 +-
 .../activemq/openwire/v1/BrokerInfoTest.java    |    2 +-
 .../openwire/v1/ConnectionControlTest.java      |    2 +-
 .../openwire/v1/ConnectionErrorTest.java        |    2 +-
 .../activemq/openwire/v1/ConnectionIdTest.java  |    2 +-
 .../openwire/v1/ConnectionInfoTest.java         |    2 +-
 .../openwire/v1/ConsumerControlTest.java        |    2 +-
 .../activemq/openwire/v1/ConsumerIdTest.java    |    2 +-
 .../activemq/openwire/v1/ConsumerInfoTest.java  |    2 +-
 .../openwire/v1/ControlCommandTest.java         |    2 +-
 .../openwire/v1/DataArrayResponseTest.java      |    2 +-
 .../activemq/openwire/v1/DataResponseTest.java  |    2 +-
 .../openwire/v1/DestinationInfoTest.java        |    2 +-
 .../openwire/v1/DiscoveryEventTest.java         |    2 +-
 .../openwire/v1/ExceptionResponseTest.java      |    2 +-
 .../activemq/openwire/v1/FlushCommandTest.java  |    2 +-
 .../openwire/v1/IntegerResponseTest.java        |    2 +-
 .../openwire/v1/JournalQueueAckTest.java        |    2 +-
 .../openwire/v1/JournalTopicAckTest.java        |    2 +-
 .../activemq/openwire/v1/JournalTraceTest.java  |    2 +-
 .../openwire/v1/JournalTransactionTest.java     |    2 +-
 .../activemq/openwire/v1/KeepAliveInfoTest.java |    2 +-
 .../openwire/v1/LastPartialCommandTest.java     |    2 +-
 .../openwire/v1/LocalTransactionIdTest.java     |    2 +-
 .../activemq/openwire/v1/MessageAckTest.java    |    2 +-
 .../v1/MessageDispatchNotificationTest.java     |    2 +-
 .../openwire/v1/MessageDispatchTest.java        |    2 +-
 .../activemq/openwire/v1/MessageIdTest.java     |    2 +-
 .../openwire/v1/MessageTestSupport.java         |    2 +-
 .../openwire/v1/NetworkBridgeFilterTest.java    |    2 +-
 .../openwire/v1/PartialCommandTest.java         |    2 +-
 .../activemq/openwire/v1/ProducerIdTest.java    |    2 +-
 .../activemq/openwire/v1/ProducerInfoTest.java  |    2 +-
 .../activemq/openwire/v1/RemoveInfoTest.java    |    2 +-
 .../openwire/v1/RemoveSubscriptionInfoTest.java |    2 +-
 .../activemq/openwire/v1/ReplayCommandTest.java |    2 +-
 .../activemq/openwire/v1/ResponseTest.java      |    2 +-
 .../activemq/openwire/v1/SessionIdTest.java     |    2 +-
 .../activemq/openwire/v1/SessionInfoTest.java   |    2 +-
 .../activemq/openwire/v1/ShutdownInfoTest.java  |    2 +-
 .../openwire/v1/SubscriptionInfoTest.java       |    2 +-
 .../openwire/v1/TransactionIdTestSupport.java   |    2 +-
 .../openwire/v1/TransactionInfoTest.java        |    2 +-
 .../openwire/v1/WireFormatInfoTest.java         |    2 +-
 .../openwire/v1/XATransactionIdTest.java        |    2 +-
 .../openwire/v2/ActiveMQBytesMessageTest.java   |    2 +-
 .../v2/ActiveMQDestinationTestSupport.java      |    2 +-
 .../openwire/v2/ActiveMQMapMessageTest.java     |    2 +-
 .../openwire/v2/ActiveMQMessageTest.java        |    2 +-
 .../openwire/v2/ActiveMQObjectMessageTest.java  |    2 +-
 .../activemq/openwire/v2/ActiveMQQueueTest.java |    2 +-
 .../openwire/v2/ActiveMQStreamMessageTest.java  |    2 +-
 .../v2/ActiveMQTempDestinationTestSupport.java  |    2 +-
 .../openwire/v2/ActiveMQTempQueueTest.java      |    2 +-
 .../openwire/v2/ActiveMQTempTopicTest.java      |    2 +-
 .../openwire/v2/ActiveMQTextMessageTest.java    |    2 +-
 .../activemq/openwire/v2/ActiveMQTopicTest.java |    2 +-
 .../openwire/v2/BaseCommandTestSupport.java     |    2 +-
 .../activemq/openwire/v2/BrokerIdTest.java      |    2 +-
 .../activemq/openwire/v2/BrokerInfoTest.java    |    2 +-
 .../openwire/v2/ConnectionControlTest.java      |    2 +-
 .../openwire/v2/ConnectionErrorTest.java        |    2 +-
 .../activemq/openwire/v2/ConnectionIdTest.java  |    2 +-
 .../openwire/v2/ConnectionInfoTest.java         |    2 +-
 .../openwire/v2/ConsumerControlTest.java        |    2 +-
 .../activemq/openwire/v2/ConsumerIdTest.java    |    2 +-
 .../activemq/openwire/v2/ConsumerInfoTest.java  |    2 +-
 .../openwire/v2/ControlCommandTest.java         |    2 +-
 .../openwire/v2/DataArrayResponseTest.java      |    2 +-
 .../activemq/openwire/v2/DataResponseTest.java  |    2 +-
 .../openwire/v2/DestinationInfoTest.java        |    2 +-
 .../openwire/v2/DiscoveryEventTest.java         |    2 +-
 .../openwire/v2/ExceptionResponseTest.java      |    2 +-
 .../activemq/openwire/v2/FlushCommandTest.java  |    2 +-
 .../openwire/v2/IntegerResponseTest.java        |    2 +-
 .../openwire/v2/JournalQueueAckTest.java        |    2 +-
 .../openwire/v2/JournalTopicAckTest.java        |    2 +-
 .../activemq/openwire/v2/JournalTraceTest.java  |    2 +-
 .../openwire/v2/JournalTransactionTest.java     |    2 +-
 .../activemq/openwire/v2/KeepAliveInfoTest.java |    2 +-
 .../openwire/v2/LastPartialCommandTest.java     |    2 +-
 .../openwire/v2/LocalTransactionIdTest.java     |    2 +-
 .../activemq/openwire/v2/MessageAckTest.java    |    2 +-
 .../v2/MessageDispatchNotificationTest.java     |    2 +-
 .../openwire/v2/MessageDispatchTest.java        |    2 +-
 .../activemq/openwire/v2/MessageIdTest.java     |    2 +-
 .../activemq/openwire/v2/MessagePullTest.java   |    2 +-
 .../openwire/v2/MessageTestSupport.java         |    2 +-
 .../openwire/v2/NetworkBridgeFilterTest.java    |    2 +-
 .../openwire/v2/PartialCommandTest.java         |    2 +-
 .../activemq/openwire/v2/ProducerIdTest.java    |    2 +-
 .../activemq/openwire/v2/ProducerInfoTest.java  |    2 +-
 .../activemq/openwire/v2/RemoveInfoTest.java    |    2 +-
 .../openwire/v2/RemoveSubscriptionInfoTest.java |    2 +-
 .../activemq/openwire/v2/ReplayCommandTest.java |    2 +-
 .../activemq/openwire/v2/ResponseTest.java      |    2 +-
 .../activemq/openwire/v2/SessionIdTest.java     |    2 +-
 .../activemq/openwire/v2/SessionInfoTest.java   |    2 +-
 .../activemq/openwire/v2/ShutdownInfoTest.java  |    2 +-
 .../openwire/v2/SubscriptionInfoTest.java       |    2 +-
 .../openwire/v2/TransactionIdTestSupport.java   |    2 +-
 .../openwire/v2/TransactionInfoTest.java        |    2 +-
 .../openwire/v2/WireFormatInfoTest.java         |    2 +-
 .../openwire/v2/XATransactionIdTest.java        |    2 +-
 .../openwire/v3/BaseCommandTestSupport.java     |    2 +-
 .../activemq/openwire/v3/BrokerIdTest.java      |    2 +-
 .../activemq/openwire/v3/BrokerInfoTest.java    |    2 +-
 .../openwire/v3/ConnectionControlTest.java      |    2 +-
 .../openwire/v3/ConnectionErrorTest.java        |    2 +-
 .../activemq/openwire/v3/ConnectionIdTest.java  |    2 +-
 .../openwire/v3/ConnectionInfoTest.java         |    2 +-
 .../openwire/v3/ConsumerControlTest.java        |    2 +-
 .../activemq/openwire/v3/ConsumerIdTest.java    |    2 +-
 .../activemq/openwire/v3/ConsumerInfoTest.java  |    2 +-
 .../openwire/v3/ControlCommandTest.java         |    2 +-
 .../openwire/v3/DataArrayResponseTest.java      |    2 +-
 .../activemq/openwire/v3/DataResponseTest.java  |    2 +-
 .../openwire/v3/DestinationInfoTest.java        |    2 +-
 .../openwire/v3/DiscoveryEventTest.java         |    2 +-
 .../openwire/v3/ExceptionResponseTest.java      |    2 +-
 .../activemq/openwire/v3/FlushCommandTest.java  |    2 +-
 .../openwire/v3/IntegerResponseTest.java        |    2 +-
 .../openwire/v3/JournalQueueAckTest.java        |    2 +-
 .../openwire/v3/JournalTopicAckTest.java        |    2 +-
 .../activemq/openwire/v3/JournalTraceTest.java  |    2 +-
 .../openwire/v3/JournalTransactionTest.java     |    2 +-
 .../activemq/openwire/v3/KeepAliveInfoTest.java |    2 +-
 .../openwire/v3/LastPartialCommandTest.java     |    2 +-
 .../openwire/v3/LocalTransactionIdTest.java     |    2 +-
 .../activemq/openwire/v3/MessageAckTest.java    |    2 +-
 .../v3/MessageDispatchNotificationTest.java     |    2 +-
 .../openwire/v3/MessageDispatchTest.java        |    2 +-
 .../activemq/openwire/v3/MessageIdTest.java     |    2 +-
 .../activemq/openwire/v3/MessagePullTest.java   |    2 +-
 .../openwire/v3/MessageTestSupport.java         |    2 +-
 .../openwire/v3/NetworkBridgeFilterTest.java    |    2 +-
 .../openwire/v3/PartialCommandTest.java         |    2 +-
 .../activemq/openwire/v3/ProducerAckTest.java   |    2 +-
 .../activemq/openwire/v3/ProducerIdTest.java    |    2 +-
 .../activemq/openwire/v3/ProducerInfoTest.java  |    2 +-
 .../activemq/openwire/v3/RemoveInfoTest.java    |    2 +-
 .../openwire/v3/RemoveSubscriptionInfoTest.java |    2 +-
 .../activemq/openwire/v3/ReplayCommandTest.java |    2 +-
 .../activemq/openwire/v3/ResponseTest.java      |    2 +-
 .../activemq/openwire/v3/SessionIdTest.java     |    2 +-
 .../activemq/openwire/v3/SessionInfoTest.java   |    2 +-
 .../activemq/openwire/v3/ShutdownInfoTest.java  |    2 +-
 .../openwire/v3/SubscriptionInfoTest.java       |    2 +-
 .../openwire/v3/TransactionIdTestSupport.java   |    2 +-
 .../openwire/v3/TransactionInfoTest.java        |    2 +-
 .../openwire/v3/XATransactionIdTest.java        |    2 +-
 .../openwire/v4/BaseCommandTestSupport.java     |    2 +-
 .../activemq/openwire/v4/BrokerIdTest.java      |    5 +-
 .../activemq/openwire/v4/BrokerInfoTest.java    |    3 +-
 .../openwire/v4/ConnectionControlTest.java      |    3 +-
 .../openwire/v4/ConnectionErrorTest.java        |    3 +-
 .../activemq/openwire/v4/ConnectionIdTest.java  |    5 +-
 .../openwire/v4/ConnectionInfoTest.java         |    4 +-
 .../openwire/v4/ConsumerControlTest.java        |    3 +-
 .../activemq/openwire/v4/ConsumerIdTest.java    |    5 +-
 .../activemq/openwire/v4/ConsumerInfoTest.java  |    5 +-
 .../openwire/v4/ControlCommandTest.java         |    3 +-
 .../openwire/v4/DataArrayResponseTest.java      |    4 +-
 .../activemq/openwire/v4/DataResponseTest.java  |    3 +-
 .../openwire/v4/DestinationInfoTest.java        |    4 +-
 .../openwire/v4/DiscoveryEventTest.java         |    5 +-
 .../openwire/v4/ExceptionResponseTest.java      |    3 +-
 .../activemq/openwire/v4/FlushCommandTest.java  |    3 +-
 .../openwire/v4/IntegerResponseTest.java        |    3 +-
 .../openwire/v4/JournalQueueAckTest.java        |    5 +-
 .../openwire/v4/JournalTopicAckTest.java        |    5 +-
 .../activemq/openwire/v4/JournalTraceTest.java  |    5 +-
 .../openwire/v4/JournalTransactionTest.java     |    5 +-
 .../activemq/openwire/v4/KeepAliveInfoTest.java |    3 +-
 .../openwire/v4/LastPartialCommandTest.java     |    3 +-
 .../openwire/v4/LocalTransactionIdTest.java     |    3 +-
 .../activemq/openwire/v4/MessageAckTest.java    |    3 +-
 .../v4/MessageDispatchNotificationTest.java     |    3 +-
 .../openwire/v4/MessageDispatchTest.java        |    3 +-
 .../activemq/openwire/v4/MessageIdTest.java     |    5 +-
 .../activemq/openwire/v4/MessagePullTest.java   |    3 +-
 .../openwire/v4/MessageTestSupport.java         |    4 +-
 .../openwire/v4/NetworkBridgeFilterTest.java    |    5 +-
 .../openwire/v4/PartialCommandTest.java         |    5 +-
 .../activemq/openwire/v4/ProducerAckTest.java   |    3 +-
 .../activemq/openwire/v4/ProducerIdTest.java    |    5 +-
 .../activemq/openwire/v4/ProducerInfoTest.java  |    4 +-
 .../activemq/openwire/v4/RemoveInfoTest.java    |    3 +-
 .../openwire/v4/RemoveSubscriptionInfoTest.java |    3 +-
 .../activemq/openwire/v4/ReplayCommandTest.java |    3 +-
 .../activemq/openwire/v4/ResponseTest.java      |    3 +-
 .../activemq/openwire/v4/SessionIdTest.java     |    5 +-
 .../activemq/openwire/v4/SessionInfoTest.java   |    3 +-
 .../activemq/openwire/v4/ShutdownInfoTest.java  |    3 +-
 .../openwire/v4/SubscriptionInfoTest.java       |    5 +-
 .../openwire/v4/TransactionIdTestSupport.java   |    5 +-
 .../openwire/v4/TransactionInfoTest.java        |    3 +-
 .../openwire/v4/XATransactionIdTest.java        |    3 +-
 .../openwire/v5/BaseCommandTestSupport.java     |    2 +-
 .../activemq/openwire/v5/BrokerIdTest.java      |    5 +-
 .../activemq/openwire/v5/BrokerInfoTest.java    |    3 +-
 .../openwire/v5/ConnectionControlTest.java      |    3 +-
 .../openwire/v5/ConnectionErrorTest.java        |    3 +-
 .../activemq/openwire/v5/ConnectionIdTest.java  |    5 +-
 .../openwire/v5/ConnectionInfoTest.java         |    4 +-
 .../openwire/v5/ConsumerControlTest.java        |    3 +-
 .../activemq/openwire/v5/ConsumerIdTest.java    |    5 +-
 .../activemq/openwire/v5/ConsumerInfoTest.java  |    5 +-
 .../openwire/v5/ControlCommandTest.java         |    3 +-
 .../openwire/v5/DataArrayResponseTest.java      |    4 +-
 .../activemq/openwire/v5/DataResponseTest.java  |    3 +-
 .../openwire/v5/DestinationInfoTest.java        |    4 +-
 .../openwire/v5/DiscoveryEventTest.java         |    5 +-
 .../openwire/v5/ExceptionResponseTest.java      |    3 +-
 .../activemq/openwire/v5/FlushCommandTest.java  |    3 +-
 .../openwire/v5/IntegerResponseTest.java        |    3 +-
 .../openwire/v5/JournalQueueAckTest.java        |    5 +-
 .../openwire/v5/JournalTopicAckTest.java        |    5 +-
 .../activemq/openwire/v5/JournalTraceTest.java  |    5 +-
 .../openwire/v5/JournalTransactionTest.java     |    5 +-
 .../activemq/openwire/v5/KeepAliveInfoTest.java |    3 +-
 .../openwire/v5/LastPartialCommandTest.java     |    3 +-
 .../openwire/v5/LocalTransactionIdTest.java     |    3 +-
 .../activemq/openwire/v5/MessageAckTest.java    |    3 +-
 .../v5/MessageDispatchNotificationTest.java     |    3 +-
 .../openwire/v5/MessageDispatchTest.java        |    3 +-
 .../activemq/openwire/v5/MessageIdTest.java     |    5 +-
 .../activemq/openwire/v5/MessagePullTest.java   |    3 +-
 .../openwire/v5/MessageTestSupport.java         |    4 +-
 .../openwire/v5/NetworkBridgeFilterTest.java    |    5 +-
 .../openwire/v5/PartialCommandTest.java         |    5 +-
 .../activemq/openwire/v5/ProducerAckTest.java   |    3 +-
 .../activemq/openwire/v5/ProducerIdTest.java    |    5 +-
 .../activemq/openwire/v5/ProducerInfoTest.java  |    4 +-
 .../activemq/openwire/v5/RemoveInfoTest.java    |    3 +-
 .../openwire/v5/RemoveSubscriptionInfoTest.java |    3 +-
 .../activemq/openwire/v5/ReplayCommandTest.java |    3 +-
 .../activemq/openwire/v5/ResponseTest.java      |    3 +-
 .../activemq/openwire/v5/SessionIdTest.java     |    5 +-
 .../activemq/openwire/v5/SessionInfoTest.java   |    3 +-
 .../activemq/openwire/v5/ShutdownInfoTest.java  |    3 +-
 .../openwire/v5/SubscriptionInfoTest.java       |    5 +-
 .../openwire/v5/TransactionIdTestSupport.java   |    5 +-
 .../openwire/v5/TransactionInfoTest.java        |    3 +-
 .../openwire/v5/XATransactionIdTest.java        |    3 +-
 .../openwire/v6/BaseCommandTestSupport.java     |    2 +-
 .../activemq/openwire/v6/BrokerIdTest.java      |    5 +-
 .../activemq/openwire/v6/BrokerInfoTest.java    |    3 +-
 .../openwire/v6/ConnectionControlTest.java      |    3 +-
 .../openwire/v6/ConnectionErrorTest.java        |    3 +-
 .../activemq/openwire/v6/ConnectionIdTest.java  |    5 +-
 .../openwire/v6/ConnectionInfoTest.java         |    4 +-
 .../openwire/v6/ConsumerControlTest.java        |    3 +-
 .../activemq/openwire/v6/ConsumerIdTest.java    |    5 +-
 .../activemq/openwire/v6/ConsumerInfoTest.java  |    5 +-
 .../openwire/v6/ControlCommandTest.java         |    3 +-
 .../openwire/v6/DataArrayResponseTest.java      |    4 +-
 .../activemq/openwire/v6/DataResponseTest.java  |    3 +-
 .../openwire/v6/DestinationInfoTest.java        |    4 +-
 .../openwire/v6/DiscoveryEventTest.java         |    5 +-
 .../openwire/v6/ExceptionResponseTest.java      |    3 +-
 .../activemq/openwire/v6/FlushCommandTest.java  |    3 +-
 .../openwire/v6/IntegerResponseTest.java        |    3 +-
 .../openwire/v6/JournalQueueAckTest.java        |    5 +-
 .../openwire/v6/JournalTopicAckTest.java        |    5 +-
 .../activemq/openwire/v6/JournalTraceTest.java  |    5 +-
 .../openwire/v6/JournalTransactionTest.java     |    5 +-
 .../activemq/openwire/v6/KeepAliveInfoTest.java |    3 +-
 .../openwire/v6/LastPartialCommandTest.java     |    3 +-
 .../openwire/v6/LocalTransactionIdTest.java     |    3 +-
 .../activemq/openwire/v6/MessageAckTest.java    |    3 +-
 .../v6/MessageDispatchNotificationTest.java     |    3 +-
 .../openwire/v6/MessageDispatchTest.java        |    3 +-
 .../activemq/openwire/v6/MessageIdTest.java     |    5 +-
 .../activemq/openwire/v6/MessagePullTest.java   |    3 +-
 .../openwire/v6/MessageTestSupport.java         |    4 +-
 .../openwire/v6/NetworkBridgeFilterTest.java    |    5 +-
 .../openwire/v6/PartialCommandTest.java         |    5 +-
 .../activemq/openwire/v6/ProducerAckTest.java   |    3 +-
 .../activemq/openwire/v6/ProducerIdTest.java    |    5 +-
 .../activemq/openwire/v6/ProducerInfoTest.java  |    4 +-
 .../activemq/openwire/v6/RemoveInfoTest.java    |    3 +-
 .../openwire/v6/RemoveSubscriptionInfoTest.java |    3 +-
 .../activemq/openwire/v6/ReplayCommandTest.java |    3 +-
 .../activemq/openwire/v6/ResponseTest.java      |    3 +-
 .../activemq/openwire/v6/SessionIdTest.java     |    5 +-
 .../activemq/openwire/v6/SessionInfoTest.java   |    3 +-
 .../activemq/openwire/v6/ShutdownInfoTest.java  |    3 +-
 .../openwire/v6/SubscriptionInfoTest.java       |    5 +-
 .../openwire/v6/TransactionIdTestSupport.java   |    5 +-
 .../openwire/v6/TransactionInfoTest.java        |    3 +-
 .../openwire/v6/XATransactionIdTest.java        |    3 +-
 .../openwire/v7/BaseCommandTestSupport.java     |    2 +-
 .../activemq/openwire/v7/BrokerIdTest.java      |    5 +-
 .../activemq/openwire/v7/BrokerInfoTest.java    |    3 +-
 .../openwire/v7/ConnectionControlTest.java      |    3 +-
 .../openwire/v7/ConnectionErrorTest.java        |    3 +-
 .../activemq/openwire/v7/ConnectionIdTest.java  |    5 +-
 .../openwire/v7/ConnectionInfoTest.java         |    4 +-
 .../openwire/v7/ConsumerControlTest.java        |    3 +-
 .../activemq/openwire/v7/ConsumerIdTest.java    |    5 +-
 .../activemq/openwire/v7/ConsumerInfoTest.java  |    5 +-
 .../openwire/v7/ControlCommandTest.java         |    3 +-
 .../openwire/v7/DataArrayResponseTest.java      |    4 +-
 .../activemq/openwire/v7/DataResponseTest.java  |    3 +-
 .../openwire/v7/DestinationInfoTest.java        |    4 +-
 .../openwire/v7/DiscoveryEventTest.java         |    5 +-
 .../openwire/v7/ExceptionResponseTest.java      |    3 +-
 .../activemq/openwire/v7/FlushCommandTest.java  |    3 +-
 .../openwire/v7/IntegerResponseTest.java        |    3 +-
 .../openwire/v7/JournalQueueAckTest.java        |    5 +-
 .../openwire/v7/JournalTopicAckTest.java        |    5 +-
 .../activemq/openwire/v7/JournalTraceTest.java  |    5 +-
 .../openwire/v7/JournalTransactionTest.java     |    5 +-
 .../activemq/openwire/v7/KeepAliveInfoTest.java |    3 +-
 .../openwire/v7/LastPartialCommandTest.java     |    3 +-
 .../openwire/v7/LocalTransactionIdTest.java     |    3 +-
 .../activemq/openwire/v7/MessageAckTest.java    |    3 +-
 .../v7/MessageDispatchNotificationTest.java     |    3 +-
 .../openwire/v7/MessageDispatchTest.java        |    3 +-
 .../activemq/openwire/v7/MessageIdTest.java     |    5 +-
 .../activemq/openwire/v7/MessagePullTest.java   |    3 +-
 .../openwire/v7/MessageTestSupport.java         |    4 +-
 .../openwire/v7/NetworkBridgeFilterTest.java    |    5 +-
 .../openwire/v7/PartialCommandTest.java         |    5 +-
 .../activemq/openwire/v7/ProducerAckTest.java   |    3 +-
 .../activemq/openwire/v7/ProducerIdTest.java    |    5 +-
 .../activemq/openwire/v7/ProducerInfoTest.java  |    4 +-
 .../activemq/openwire/v7/RemoveInfoTest.java    |    3 +-
 .../openwire/v7/RemoveSubscriptionInfoTest.java |    3 +-
 .../activemq/openwire/v7/ReplayCommandTest.java |    3 +-
 .../activemq/openwire/v7/ResponseTest.java      |    3 +-
 .../activemq/openwire/v7/SessionIdTest.java     |    5 +-
 .../activemq/openwire/v7/SessionInfoTest.java   |    3 +-
 .../activemq/openwire/v7/ShutdownInfoTest.java  |    3 +-
 .../openwire/v7/SubscriptionInfoTest.java       |    5 +-
 .../openwire/v7/TransactionIdTestSupport.java   |    5 +-
 .../openwire/v7/TransactionInfoTest.java        |    3 +-
 .../openwire/v7/XATransactionIdTest.java        |    3 +-
 .../openwire/v8/BaseCommandTestSupport.java     |    2 +-
 .../activemq/openwire/v8/BrokerIdTest.java      |    5 +-
 .../activemq/openwire/v8/BrokerInfoTest.java    |    3 +-
 .../openwire/v8/ConnectionControlTest.java      |    3 +-
 .../openwire/v8/ConnectionErrorTest.java        |    3 +-
 .../activemq/openwire/v8/ConnectionIdTest.java  |    5 +-
 .../openwire/v8/ConnectionInfoTest.java         |    4 +-
 .../openwire/v8/ConsumerControlTest.java        |    3 +-
 .../activemq/openwire/v8/ConsumerIdTest.java    |    5 +-
 .../activemq/openwire/v8/ConsumerInfoTest.java  |    5 +-
 .../openwire/v8/ControlCommandTest.java         |    3 +-
 .../openwire/v8/DataArrayResponseTest.java      |    4 +-
 .../activemq/openwire/v8/DataResponseTest.java  |    3 +-
 .../openwire/v8/DestinationInfoTest.java        |    4 +-
 .../openwire/v8/DiscoveryEventTest.java         |    5 +-
 .../openwire/v8/ExceptionResponseTest.java      |    3 +-
 .../activemq/openwire/v8/FlushCommandTest.java  |    3 +-
 .../openwire/v8/IntegerResponseTest.java        |    3 +-
 .../openwire/v8/JournalQueueAckTest.java        |    5 +-
 .../openwire/v8/JournalTopicAckTest.java        |    5 +-
 .../activemq/openwire/v8/JournalTraceTest.java  |    5 +-
 .../openwire/v8/JournalTransactionTest.java     |    5 +-
 .../activemq/openwire/v8/KeepAliveInfoTest.java |    3 +-
 .../openwire/v8/LastPartialCommandTest.java     |    3 +-
 .../openwire/v8/LocalTransactionIdTest.java     |    3 +-
 .../activemq/openwire/v8/MessageAckTest.java    |    3 +-
 .../v8/MessageDispatchNotificationTest.java     |    3 +-
 .../openwire/v8/MessageDispatchTest.java        |    3 +-
 .../activemq/openwire/v8/MessageIdTest.java     |    5 +-
 .../activemq/openwire/v8/MessagePullTest.java   |    3 +-
 .../openwire/v8/MessageTestSupport.java         |    4 +-
 .../openwire/v8/NetworkBridgeFilterTest.java    |    5 +-
 .../openwire/v8/PartialCommandTest.java         |    5 +-
 .../activemq/openwire/v8/ProducerAckTest.java   |    3 +-
 .../activemq/openwire/v8/ProducerIdTest.java    |    5 +-
 .../activemq/openwire/v8/ProducerInfoTest.java  |    4 +-
 .../activemq/openwire/v8/RemoveInfoTest.java    |    3 +-
 .../openwire/v8/RemoveSubscriptionInfoTest.java |    3 +-
 .../activemq/openwire/v8/ReplayCommandTest.java |    3 +-
 .../activemq/openwire/v8/ResponseTest.java      |    3 +-
 .../activemq/openwire/v8/SessionIdTest.java     |    5 +-
 .../activemq/openwire/v8/SessionInfoTest.java   |    3 +-
 .../activemq/openwire/v8/ShutdownInfoTest.java  |    3 +-
 .../openwire/v8/SubscriptionInfoTest.java       |    5 +-
 .../openwire/v8/TransactionIdTestSupport.java   |    5 +-
 .../openwire/v8/TransactionInfoTest.java        |    3 +-
 .../openwire/v8/XATransactionIdTest.java        |    3 +-
 .../openwire/v9/BaseCommandTestSupport.java     |    2 +-
 .../activemq/openwire/v9/BrokerIdTest.java      |    5 +-
 .../activemq/openwire/v9/BrokerInfoTest.java    |    3 +-
 .../openwire/v9/ConnectionControlTest.java      |    3 +-
 .../openwire/v9/ConnectionErrorTest.java        |    3 +-
 .../activemq/openwire/v9/ConnectionIdTest.java  |    5 +-
 .../openwire/v9/ConnectionInfoTest.java         |    4 +-
 .../openwire/v9/ConsumerControlTest.java        |    3 +-
 .../activemq/openwire/v9/ConsumerIdTest.java    |    5 +-
 .../activemq/openwire/v9/ConsumerInfoTest.java  |    5 +-
 .../openwire/v9/ControlCommandTest.java         |    3 +-
 .../openwire/v9/DataArrayResponseTest.java      |    4 +-
 .../activemq/openwire/v9/DataResponseTest.java  |    3 +-
 .../openwire/v9/DestinationInfoTest.java        |    4 +-
 .../openwire/v9/DiscoveryEventTest.java         |    5 +-
 .../openwire/v9/ExceptionResponseTest.java      |    3 +-
 .../activemq/openwire/v9/FlushCommandTest.java  |    3 +-
 .../openwire/v9/IntegerResponseTest.java        |    3 +-
 .../openwire/v9/JournalQueueAckTest.java        |    5 +-
 .../openwire/v9/JournalTopicAckTest.java        |    5 +-
 .../activemq/openwire/v9/JournalTraceTest.java  |    5 +-
 .../openwire/v9/JournalTransactionTest.java     |    5 +-
 .../activemq/openwire/v9/KeepAliveInfoTest.java |    3 +-
 .../openwire/v9/LastPartialCommandTest.java     |    3 +-
 .../openwire/v9/LocalTransactionIdTest.java     |    3 +-
 .../activemq/openwire/v9/MessageAckTest.java    |    3 +-
 .../v9/MessageDispatchNotificationTest.java     |    3 +-
 .../openwire/v9/MessageDispatchTest.java        |    3 +-
 .../activemq/openwire/v9/MessageIdTest.java     |    5 +-
 .../activemq/openwire/v9/MessagePullTest.java   |    3 +-
 .../openwire/v9/MessageTestSupport.java         |    4 +-
 .../openwire/v9/NetworkBridgeFilterTest.java    |    5 +-
 .../openwire/v9/PartialCommandTest.java         |    5 +-
 .../activemq/openwire/v9/ProducerAckTest.java   |    3 +-
 .../activemq/openwire/v9/ProducerIdTest.java    |    5 +-
 .../activemq/openwire/v9/ProducerInfoTest.java  |    4 +-
 .../activemq/openwire/v9/RemoveInfoTest.java    |    3 +-
 .../openwire/v9/RemoveSubscriptionInfoTest.java |    3 +-
 .../activemq/openwire/v9/ReplayCommandTest.java |    3 +-
 .../activemq/openwire/v9/ResponseTest.java      |    3 +-
 .../activemq/openwire/v9/SessionIdTest.java     |    5 +-
 .../activemq/openwire/v9/SessionInfoTest.java   |    3 +-
 .../activemq/openwire/v9/ShutdownInfoTest.java  |    3 +-
 .../openwire/v9/SubscriptionInfoTest.java       |    5 +-
 .../openwire/v9/TransactionIdTestSupport.java   |    5 +-
 .../openwire/v9/TransactionInfoTest.java        |    3 +-
 .../openwire/v9/XATransactionIdTest.java        |    3 +-
 .../activemq/perf/ConnectionChurnTest.java      |    7 +-
 .../activemq/perf/InactiveDurableTopicTest.java |   20 +-
 .../apache/activemq/perf/InactiveQueueTest.java |    2 +-
 .../activemq/perf/KahaDBDurableTopicTest.java   |    2 +-
 .../perf/KahaDBDurableTransactedTopicTest.java  |    2 +-
 .../apache/activemq/perf/KahaDBQueueTest.java   |    2 +-
 .../org/apache/activemq/perf/KahaQueueTest.java |    2 +-
 .../activemq/perf/LevelDBDurableTopicTest.java  |    4 +-
 .../activemq/perf/LevelDBStoreQueueTest.java    |    2 +-
 .../activemq/perf/MemoryAllocationTest.java     |    5 +-
 .../apache/activemq/perf/NetworkedSyncTest.java |   42 +-
 .../activemq/perf/NumberOfDestinationsTest.java |    4 +-
 .../org/apache/activemq/perf/PerfConsumer.java  |   14 +-
 .../org/apache/activemq/perf/PerfProducer.java  |   15 +-
 .../java/org/apache/activemq/perf/PerfRate.java |    2 +-
 .../perf/QueueConnectionMemoryTest.java         |    2 +-
 .../org/apache/activemq/perf/RunBroker.java     |    5 +-
 .../perf/SimpleDurableTopicNetworkTest.java     |    2 +-
 .../activemq/perf/SimpleDurableTopicTest.java   |   10 +-
 .../apache/activemq/perf/SimpleNetworkTest.java |    2 +-
 .../SimpleNonPersistentQueueNetworkTest.java    |    7 +-
 .../perf/SimpleNonPersistentQueueTest.java      |    6 +-
 .../perf/SimpleNonPersistentTopicTest.java      |    2 +-
 .../apache/activemq/perf/SimpleQueueTest.java   |    2 +-
 .../apache/activemq/perf/SimpleTopicTest.java   |    2 +-
 .../org/apache/activemq/perf/SlowConsumer.java  |    5 +-
 .../activemq/perf/SlowConsumerTopicTest.java    |    2 +-
 .../perf/SlowDurableConsumerTopicTest.java      |    2 +-
 .../TemporaryTopicMemoryAllocationTest.java     |    2 +-
 .../plugin/BrokerStatisticsPluginTest.java      |    5 +-
 ...veTwoConnectionsWithSenderUsingPoolTest.java |    2 +-
 .../org/apache/activemq/proxy/AMQ4889Test.java  |   24 +-
 .../activemq/proxy/ProxyConnectorTest.java      |    5 +-
 .../activemq/proxy/ProxyFailoverTest.java       |   13 +-
 .../apache/activemq/proxy/ProxyTestSupport.java |    2 +-
 ...actCachedLDAPAuthorizationMapLegacyTest.java |   31 +-
 ...stractCachedLDAPAuthorizationModuleTest.java |    6 +-
 .../activemq/security/AuthorizationMapTest.java |   23 +-
 ...APAuthorizationModuleLegacyOpenLDAPTest.java |    2 +-
 ...CachedLDAPAuthorizationModuleLegacyTest.java |    8 +-
 ...chedLDAPAuthorizationModuleOpenLDAPTest.java |    8 +-
 .../CachedLDAPAuthorizationModuleTest.java      |    6 +-
 .../security/CachedLDAPSecurityLegacyTest.java  |   18 +-
 .../security/CachedLDAPSecurityTest.java        |    2 +-
 .../org/apache/activemq/security/DoSTest.java   |   10 +-
 ...JaasCertificateAuthenticationBrokerTest.java |   28 +-
 .../JaasDualAuthenticationBrokerTest.java       |   39 +-
 .../activemq/security/JaasNetworkTest.java      |    5 +-
 .../security/LDAPAuthenticationTest.java        |   11 +-
 .../security/LDAPAuthorizationMapTest.java      |   15 +-
 .../activemq/security/LDAPSecurityTest.java     |   14 +-
 .../activemq/security/SecurityJMXTest.java      |    9 +-
 .../activemq/security/SecurityTestSupport.java  |   20 +-
 .../security/SimpleAnonymousPluginTest.java     |    8 +-
 ...SimpleAuthenticationPluginSeparatorTest.java |    2 +-
 .../SimpleAuthenticationPluginTest.java         |   17 +-
 .../security/SimpleAuthorizationMapTest.java    |    2 +-
 .../SimpleSecurityBrokerSystemTest.java         |   17 +-
 .../security/StubDoNothingCallbackHandler.java  |    5 +-
 .../security/StubDualJaasConfiguration.java     |    5 +-
 .../security/StubJaasConfiguration.java         |    2 +-
 .../activemq/security/StubLoginModule.java      |    5 +-
 .../activemq/security/StubSecurityContext.java  |    2 +-
 .../activemq/security/XBeanSecurityTest.java    |    2 +-
 ...nSecurityWithGuestNoCredentialsOnlyTest.java |   13 +-
 .../security/XBeanSecurityWithGuestTest.java    |   10 +-
 .../activemq/security/XBeanSslContextTest.java  |    2 +-
 .../activemq/selector/SelectorParserTest.java   |    5 +-
 .../apache/activemq/selector/SelectorTest.java  |    5 +-
 .../selector/UnknownHandlingSelectorTest.java   |   10 +-
 ...ctiveMQConnectionFactoryFactoryBeanTest.java |    1 -
 .../apache/activemq/spring/ConsumerBean.java    |   13 +-
 .../spring/Spring2XmlNamespacesTest.java        |    4 +-
 ...ng2XmlNamespacesWithoutRemoteSchemaTest.java |    4 +-
 .../apache/activemq/spring/SpringConsumer.java  |    8 +-
 .../apache/activemq/spring/SpringProducer.java  |    2 +-
 .../org/apache/activemq/spring/SpringTest.java  |    2 +-
 .../activemq/spring/SpringTestSupport.java      |    5 +-
 .../activemq/test/JmsResourceProvider.java      |  400 +++---
 .../test/JmsSendReceiveTestSupport.java         |   24 +-
 .../activemq/test/JmsTopicSendReceiveTest.java  |    8 +-
 ...dReceiveWithEmbeddedBrokerAndUserIDTest.java |    5 +-
 ...veWithTwoConnectionsAndByteSelectorTest.java |    2 +-
 ...WithTwoConnectionsAndEmbeddedBrokerTest.java |    2 +-
 ...sTopicSendReceiveWithTwoConnectionsTest.java |    5 +-
 .../TemporaryDestinationToFromNameTest.java     |    2 +-
 .../org/apache/activemq/test/TestSupport.java   |  433 +++---
 .../message/NestedMapAndListPropertyTest.java   |    7 +-
 .../test/message/NestedMapMessageTest.java      |    9 +-
 .../test/retroactive/DummyMessageQuery.java     |    2 +-
 ...sumerTestWithDestinationBasedBufferTest.java |    2 +-
 ...TestWithLastImagePolicyWithWildcardTest.java |    2 +-
 ...veConsumerTestWithSimpleMessageListTest.java |    7 +-
 ...troactiveConsumerTestWithTimePolicyTest.java |    2 +-
 ...RetroactiveConsumerWithMessageQueryTest.java |    7 +-
 .../CloseRollbackRedeliveryQueueTest.java       |    2 +-
 .../DelegatingTransactionalMessageListener.java |   11 +-
 .../RollbacksWhileConsumingLargeQueueTest.java  |   18 +-
 .../activemq/transport/QueueClusterTest.java    |    2 +-
 .../transport/SoWriteTimeoutClientTest.java     |   19 +-
 .../activemq/transport/SoWriteTimeoutTest.java  |   17 +-
 .../transport/StubCompositeTransport.java       |    2 +-
 .../activemq/transport/StubTransport.java       |    2 +-
 .../transport/StubTransportListener.java        |    2 +-
 .../activemq/transport/TopicClusterTest.java    |   11 +-
 .../transport/TransportBrokerTestSupport.java   |    2 +-
 .../DiscoveryNetworkReconnectTest.java          |   11 +-
 .../discovery/DiscoveryTransportBrokerTest.java |    8 +-
 .../DiscoveryTransportNoBrokerTest.java         |   13 +-
 .../transport/discovery/DiscoveryUriTest.java   |   15 +-
 .../ZeroconfDiscoverTransportTest.java          |    2 +-
 .../transport/failover/AMQ1925Test.java         |   30 +-
 .../failover/ConnectionHangOnStartupTest.java   |    8 +-
 .../failover/FailoverBackupLeakTest.java        |   16 +-
 .../transport/failover/FailoverClusterTest.java |    3 +-
 .../failover/FailoverClusterTestSupport.java    |   22 +-
 .../failover/FailoverComplexClusterTest.java    |   10 +-
 .../FailoverConsumerOutstandingCommitTest.java  |   66 +-
 .../FailoverConsumerUnconsumedTest.java         |   85 +-
 .../failover/FailoverDuplicateTest.java         |   32 +-
 .../failover/FailoverPrefetchZeroTest.java      |    9 +-
 .../failover/FailoverPriorityTest.java          |   16 +-
 .../transport/failover/FailoverRandomTest.java  |   10 +-
 .../FailoverRedeliveryTransactionTest.java      |    2 +-
 .../transport/failover/FailoverTimeoutTest.java |   25 +-
 .../failover/FailoverTransactionTest.java       |  226 ++-
 .../failover/FailoverTransportBackupsTest.java  |   10 +-
 .../failover/FailoverTransportBrokerTest.java   |   33 +-
 .../failover/FailoverTransportTest.java         |   16 +-
 .../FailoverTransportUriHandlingTest.java       |    7 +-
 .../failover/FailoverUpdateURIsTest.java        |   13 +-
 .../transport/failover/FailoverUriTest.java     |    2 +-
 .../failover/InitalReconnectDelayTest.java      |   17 +-
 .../transport/failover/ReconnectTest.java       |   26 +-
 .../transport/failover/SlowConnectionTest.java  |   32 +-
 .../failover/TwoBrokerFailoverClusterTest.java  |   28 +-
 .../activemq/transport/fanout/FanoutTest.java   |    2 +-
 .../fanout/FanoutTransportBrokerTest.java       |   38 +-
 .../multicast/MulticastTransportTest.java       |    2 +-
 .../nio/NIOJmsDurableTopicSendReceiveTest.java  |    2 +-
 .../transport/nio/NIOJmsSendAndReceiveTest.java |    2 +-
 .../nio/NIOPersistentSendAndReceiveTest.java    |    2 +-
 .../activemq/transport/nio/NIOSSLBasicTest.java |    2 +-
 .../transport/nio/NIOSSLConcurrencyTest.java    |   23 +-
 .../activemq/transport/nio/NIOSSLLoadTest.java  |   10 +-
 .../nio/NIOSSLTransportBrokerTest.java          |    2 +-
 .../transport/nio/NIOSSLWindowSizeTest.java     |   20 +-
 .../transport/nio/NIOTransportBrokerTest.java   |    2 +-
 .../transport/peer/PeerTransportTest.java       |    5 +-
 .../transport/reliable/DropCommandStrategy.java |    2 +-
 .../reliable/ReliableTransportTest.java         |    5 +-
 .../UnreliableCommandDatagramChannel.java       |    5 +-
 .../UnreliableCommandDatagramSocket.java        |    5 +-
 .../reliable/UnreliableUdpTransport.java        |    2 +-
 .../reliable/UnreliableUdpTransportTest.java    |    2 +-
 .../transport/tcp/InactivityMonitorTest.java    |   17 +-
 .../tcp/QualityOfServiceUtilsTest.java          |   20 +-
 .../transport/tcp/ServerSocketTstFactory.java   |    4 +-
 .../transport/tcp/SocketTstFactory.java         |   17 +-
 .../transport/tcp/SslBrokerServiceTest.java     |   36 +-
 .../tcp/SslContextBrokerServiceTest.java        |    2 +-
 .../tcp/SslContextNBrokerServiceTest.java       |   24 +-
 .../activemq/transport/tcp/SslSocketHelper.java |    7 +-
 .../transport/tcp/SslTransportBrokerTest.java   |    2 +-
 .../transport/tcp/SslTransportFactoryTest.java  |   14 +-
 .../transport/tcp/SslTransportServerTest.java   |    5 +-
 .../transport/tcp/SslTransportTest.java         |   10 +-
 .../transport/tcp/StubSSLServerSocket.java      |    5 +-
 .../activemq/transport/tcp/StubSSLSession.java  |   15 +-
 .../activemq/transport/tcp/StubSSLSocket.java   |    5 +-
 .../transport/tcp/StubSSLSocketFactory.java     |    5 +-
 .../transport/tcp/StubSslTransport.java         |    2 +-
 .../transport/tcp/StubX509Certificate.java      |    2 +-
 .../transport/tcp/TcpFaultyTransport.java       |    6 +-
 .../tcp/TcpFaultyTransportFactory.java          |   13 +-
 .../transport/tcp/TcpFaultyTransportServer.java |    5 +-
 .../transport/tcp/TcpTransportBindTest.java     |   13 +-
 .../transport/tcp/TcpTransportBrokerTest.java   |    2 +-
 .../transport/tcp/TcpTransportServerTest.java   |   15 +-
 ...nsportConnectorInvalidSocketOptionsTest.java |   11 +-
 .../transport/tcp/TransportUriTest.java         |   11 +-
 .../tcp/WireformatNegociationTest.java          |    8 +-
 ...eWithTwoConnectionsAndLargeMessagesTest.java |    2 +-
 .../UdpSendReceiveWithTwoConnectionsTest.java   |    2 +-
 .../activemq/transport/udp/UdpTestSupport.java  |   29 +-
 .../transport/udp/UdpTransportTest.java         |    2 +-
 .../udp/UdpTransportUsingServerTest.java        |    2 +-
 .../transport/udp/UpdTransportBindTest.java     |   11 +-
 .../usage/CompositeMessageCursorUsageTest.java  |    2 +-
 .../usage/JobSchedulerStoreUsageTest.java       |    7 +-
 .../activemq/usage/StoreUsageLimitsTest.java    |    8 +-
 .../apache/activemq/usage/StoreUsageTest.java   |   10 +-
 .../apache/activemq/usecases/AMQ2927Test.java   |    8 +-
 .../activemq/usecases/AMQStackOverFlowTest.java |   12 +-
 ...rWildcardIncludedDestinationTestSupport.java |    5 +-
 .../usecases/AdvisoryTopicCleanUpTest.java      |   12 +-
 .../usecases/AdvisoryTopicDeletionTest.java     |    5 +-
 .../AuthorizationFromAdminViewTest.java         |    2 +-
 .../usecases/BacklogNetworkCrossTalkTest.java   |    4 +-
 .../BatchedMessagePriorityConsumerTest.java     |    4 +-
 .../BrokerQueueNetworkWithDisconnectTest.java   |   30 +-
 .../apache/activemq/usecases/BrowseDLQTest.java |   24 +-
 .../usecases/BrowseOverNetworkTest.java         |   21 +-
 .../usecases/ChangeSentMessageTest.java         |    5 +-
 .../usecases/ChangeSessionDeliveryModeTest.java |    5 +-
 .../activemq/usecases/ClientRebalanceTest.java  |    2 +-
 .../activemq/usecases/CompositeConsumeTest.java |    2 +-
 .../activemq/usecases/CompositePublishTest.java |    8 +-
 .../ConcurrentDestinationCreationTest.java      |   21 +-
 .../ConcurrentProducerDurableConsumerTest.java  |   48 +-
 .../ConcurrentProducerQueueConsumerTest.java    |   44 +-
 .../usecases/ConsumeQueuePrefetchTest.java      |    2 +-
 .../usecases/ConsumeTopicPrefetchTest.java      |   13 +-
 ...onsumeUncompressedCompressedMessageTest.java |   18 +-
 .../CreateLotsOfTemporaryQueuesTest.java        |    2 +-
 .../CreateTemporaryQueueBeforeStartTest.java    |   11 +-
 .../DiscriminatingConsumerLoadTest.java         |   29 +-
 .../usecases/DispatchMultipleConsumersTest.java |   39 +-
 ...DurableConsumerCloseAndReconnectTcpTest.java |   18 +-
 .../DurableConsumerCloseAndReconnectTest.java   |    8 +-
 .../DurableSubDelayedUnsubscribeTest.java       |   99 +-
 .../usecases/DurableSubInBrokerNetworkTest.java |    6 +-
 ...ConcurrentCommitActivateNoDuplicateTest.java |   87 +-
 .../DurableSubProcessMultiRestartTest.java      |   59 +-
 .../usecases/DurableSubProcessTest.java         |   64 +-
 .../DurableSubProcessWithRestartTest.java       |   74 +-
 .../usecases/DurableSubSelectorDelayTest.java   |   17 +-
 .../DurableSubSelectorDelayWithRestartTest.java |   20 +-
 ...neSelectorConcurrentConsumeIndexUseTest.java |   17 +-
 .../DurableSubsOfflineSelectorIndexUseTest.java |   14 +-
 ...rableSubscriberNonPersistentMessageTest.java |   27 +-
 ...ableSubscriberWithNetworkDisconnectTest.java |   33 +-
 ...DurableSubscriberWithNetworkRestartTest.java |   17 +-
 .../DurableSubscriptionActivationTest.java      |    5 +-
 .../DurableSubscriptionHangTestCase.java        |    4 +-
 .../DurableSubscriptionOffline1Test.java        |   16 +-
 .../DurableSubscriptionOffline2Test.java        |   24 +-
 .../DurableSubscriptionOffline3Test.java        |   22 +-
 .../DurableSubscriptionOffline4Test.java        |   18 +-
 .../DurableSubscriptionOfflineTest.java         |   37 +-
 .../DurableSubscriptionOfflineTestBase.java     |   29 +-
 .../DurableSubscriptionReactivationTest.java    |    2 +-
 .../DurableSubscriptionRemoveOfflineTest.java   |    2 +-
 .../DurableSubscriptionSelectorTest.java        |    5 +-
 .../DurableSubscriptionTestSupport.java         |    2 +-
 .../DurableSubscriptionUnsubscribeTest.java     |   20 +-
 .../usecases/DurableUnsubscribeTest.java        |    5 +-
 .../usecases/ExceptionListenerTest.java         |   14 +-
 .../activemq/usecases/ExpiredMessagesTest.java  |   24 +-
 .../ExpiredMessagesWithNoConsumerTest.java      |   33 +-
 .../usecases/JDBCDurableSubscriptionTest.java   |    2 +-
 .../JMXRemoveQueueThenSendIgnoredTest.java      |    6 +-
 .../usecases/JdbcDurableSubDupTest.java         |   44 +-
 .../JournalDurableSubscriptionTest.java         |    2 +-
 .../usecases/KahaDBDurableSubscriptionTest.java |    2 +-
 .../usecases/LargeQueueSparseDeleteTest.java    |   11 +-
 .../LevelDBDurableSubscriptionTest.java         |    2 +-
 .../ManagedDurableSubscriptionTest.java         |    5 +-
 .../activemq/usecases/MemoryLimitTest.java      |    4 +-
 .../usecases/MessageGroupCloseTest.java         |   36 +-
 .../usecases/MessageGroupDelayedTest.java       |   23 +-
 .../usecases/MessageGroupLateArrivalsTest.java  |   29 +-
 .../usecases/MessageGroupNewConsumerTest.java   |   21 +-
 .../MessageGroupReconnectDistributionTest.java  |   22 +-
 .../activemq/usecases/MessageReroutingTest.java |    2 +-
 .../usecases/MultiBrokersMultiClientsTest.java  |    7 +-
 .../MultiBrokersMultiClientsUsingTcpTest.java   |    8 +-
 .../MulticastDiscoveryOnFaultyNetworkTest.java  |   10 +-
 .../org/apache/activemq/usecases/MyObject.java  |    2 +-
 .../usecases/NetworkAsyncStartTest.java         |    5 +-
 .../NetworkBridgeProducerFlowControlTest.java   |   21 +-
 .../usecases/NetworkOfTwentyBrokersTest.java    |   11 +-
 .../NewConsumerCreatesDestinationTest.java      |    5 +-
 .../usecases/NoDuplicateOnTopicNetworkTest.java |   36 +-
 .../NonBlockingConsumerRedeliveryTest.java      |  171 ++-
 .../ObjectMessageNotSerializableTest.java       |   28 +-
 .../usecases/ProducerConsumerTestSupport.java   |    2 +-
 ...ublishOnDurableTopicConsumedMessageTest.java |    2 +-
 ...OnQueueConsumedMessageInTransactionTest.java |   26 +-
 .../PublishOnQueueConsumedMessageTest.java      |    2 +-
 ...ueueConsumedMessageUsingActivemqXMLTest.java |    2 +-
 ...lishOnTemporaryQueueConsumedMessageTest.java |    2 +-
 .../PublishOnTopicConsumedMessageTest.java      |    8 +-
 ...opicConsumerMessageUsingActivemqXMLTest.java |    2 +-
 .../usecases/QueueBrowsingLevelDBTest.java      |    8 +-
 .../usecases/QueueBrowsingLimitTest.java        |    8 +-
 .../activemq/usecases/QueueBrowsingTest.java    |   21 +-
 .../QueueConsumerCloseAndReconnectTest.java     |    2 +-
 .../activemq/usecases/QueueDuplicatesTest.java  |   22 +-
 .../QueueMemoryFullMultiBrokersTest.java        |    5 +-
 .../activemq/usecases/QueueRedeliverTest.java   |    2 +-
 .../activemq/usecases/QueueRepeaterTest.java    |   18 +-
 .../usecases/ReliableReconnectTest.java         |   15 +-
 .../RequestReplyNoAdvisoryNetworkTest.java      |   11 +-
 ...estReplyTempDestRemovalAdvisoryRaceTest.java |   52 +-
 ...uestReplyToTopicViaThreeNetworkHopsTest.java |   91 +-
 ...tualDestinationsWithWildcardLevelDBTest.java |    9 +-
 ...okerVirtualDestinationsWithWildcardTest.java |    7 +-
 .../usecases/StartAndStopBrokerTest.java        |    8 +-
 ...AndBrokerDoesNotLeaveThreadsRunningTest.java |    2 +-
 .../activemq/usecases/StaticNetworkTest.java    |    8 +-
 .../SubscribeClosePublishThenConsumeTest.java   |    2 +-
 .../TempTopicProducerFlowControlTest.java       |    2 +-
 ...kerConnectionDuplexExcludedDestinations.java |    5 +-
 .../apache/activemq/usecases/TestSupport.java   |    8 +-
 .../usecases/ThreeBrokerQueueNetworkTest.java   |    9 +-
 .../ThreeBrokerQueueNetworkUsingTcpTest.java    |    8 +-
 .../ThreeBrokerStompTemporaryQueueTest.java     |    5 +-
 ...erTempDestDemandSubscriptionCleanupTest.java |   18 +-
 .../ThreeBrokerTempQueueNetworkTest.java        |   10 +-
 .../usecases/ThreeBrokerTopicNetworkTest.java   |    9 +-
 .../ThreeBrokerTopicNetworkUsingTcpTest.java    |    8 +-
 ...reeBrokerVirtualTopicNetworkLevelDBTest.java |    4 +-
 .../ThreeBrokerVirtualTopicNetworkTest.java     |    7 +-
 .../usecases/TopicDurableConnectStatsTest.java  |   26 +-
 .../usecases/TopicProducerFlowControlTest.java  |   21 +-
 .../activemq/usecases/TopicRedeliverTest.java   |   21 +-
 .../activemq/usecases/TopicReplicationTest.java |    8 +-
 .../TopicSubscriptionSlowConsumerTest.java      |   14 +-
 .../TopicSubscriptionZeroPrefetchTest.java      |    2 +-
 .../usecases/TransactionRollbackOrderTest.java  |   21 +-
 .../activemq/usecases/TransactionTest.java      |   18 +-
 .../usecases/TransientQueueRedeliverTest.java   |    2 +-
 ...essageNotSentToRemoteWhenNoConsumerTest.java |    5 +-
 .../usecases/TwoBrokerMulticastQueueTest.java   |   13 +-
 ...dcardDynamicallyIncludedDestinationTest.java |    2 +-
 ...ldcardStaticallyIncludedDestinationTest.java |    2 +-
 .../TwoBrokerNetworkLoadBalanceTest.java        |    5 +-
 .../TwoBrokerQueueClientsReconnectTest.java     |   19 +-
 .../usecases/TwoBrokerQueueSendReceiveTest.java |    2 +-
 .../TwoBrokerTempQueueAdvisoryTest.java         |   26 +-
 ...icSendReceiveLotsOfMessagesUsingTcpTest.java |    2 +-
 .../usecases/TwoBrokerTopicSendReceiveTest.java |   10 +-
 ...icSendReceiveUsingJavaConfigurationTest.java |    8 +-
 .../TwoBrokerTopicSendReceiveUsingTcpTest.java  |    8 +-
 ...rVirtualDestDinamicallyIncludedDestTest.java |   16 +-
 .../TwoBrokerVirtualTopicForwardingTest.java    |   14 +-
 ...castDiscoveryBrokerTopicSendReceiveTest.java |    2 +-
 .../TwoSecureBrokerRequestReplyTest.java        |   12 +-
 .../activemq/usecases/UnlimitedEnqueueTest.java |   19 +-
 .../VerifyNetworkConsumersDisconnectTest.java   |   14 +-
 ...tualTopicNetworkClusterReactivationTest.java |   20 +-
 .../apache/activemq/util/ConsumerThread.java    |   23 +-
 .../activemq/util/DefaultTestAppender.java      |    2 +-
 .../apache/activemq/util/LinkedNodeTest.java    |    2 +-
 .../org/apache/activemq/util/LockFileTest.java  |   52 +-
 .../org/apache/activemq/util/MessageIdList.java |   18 +-
 .../apache/activemq/util/ProducerThread.java    |   19 +-
 .../activemq/util/ReflectionSupportTest.java    |    2 +-
 .../org/apache/activemq/util/SimplePojo.java    |    2 +-
 .../org/apache/activemq/util/SocketProxy.java   |  687 +++++----
 .../java/org/apache/activemq/util/Wait.java     |   46 +-
 .../xbean/ConnectorXBeanConfigTest.java         |   30 +-
 .../JDBCPersistenceAdapterXBeanConfigTest.java  |    2 +-
 .../xbean/JDBCPersistenceXBeanConfigTest.java   |    2 +-
 .../xbean/ManagementContextXBeanConfigTest.java |   14 +-
 ...stsWithEmbeddedBrokerAndPersistenceTest.java |    2 +-
 .../MultipleTestsWithEmbeddedBrokerTest.java    |    2 +-
 .../MultipleTestsWithSpringFactoryBeanTest.java |    2 +-
 ...ipleTestsWithSpringXBeanFactoryBeanTest.java |    2 +-
 .../MultipleTestsWithXBeanFactoryBeanTest.java  |    2 +-
 .../apache/activemq/xbean/XBeanConfigTest.java  |   13 +-
 .../activemq/xbean/XBeanStartFalseTest.java     |    2 +-
 .../org/apache/activemq/xbean/XBeanXmlTest.java |    2 +-
 .../activemq/transport/amqp/AmqpSupport.java    |   15 +-
 .../amqp/client/AmqpAbstractResource.java       |   18 +-
 .../transport/amqp/client/AmqpConnection.java   |   54 +-
 .../transport/amqp/client/AmqpMessage.java      |   96 +-
 .../transport/amqp/client/AmqpReceiver.java     |   84 +-
 .../transport/amqp/client/AmqpSender.java       |   57 +-
 .../transport/amqp/client/AmqpSession.java      |    8 +-
 .../transport/amqp/client/AmqpSupport.java      |   32 +-
 .../amqp/client/AmqpTransactionContext.java     |   15 +-
 .../amqp/client/AmqpTransactionCoordinator.java |   18 +-
 .../amqp/client/AmqpTransactionId.java          |    3 +-
 .../amqp/client/AmqpTransferTagGenerator.java   |    9 +-
 .../amqp/client/sasl/AbstractMechanism.java     |    3 +-
 .../amqp/client/sasl/CramMD5Mechanism.java      |   12 +-
 .../transport/amqp/client/sasl/Mechanism.java   |    2 +-
 .../amqp/client/sasl/SaslAuthenticator.java     |   18 +-
 .../client/transport/NettyTcpTransport.java     |   27 +-
 .../client/transport/NettyTransportFactory.java |    3 +-
 .../client/transport/NettyTransportSupport.java |   15 +-
 .../amqp/client/transport/NettyWSTransport.java |   36 +-
 .../PartialPooledByteBufAllocator.java          |    1 -
 .../amqp/client/util/ClientFuture.java          |    6 +-
 .../transport/amqp/client/util/IdGenerator.java |   27 +-
 .../amqp/client/util/PropertyUtil.java          |   27 +-
 .../amqp/client/util/TypeConversionSupport.java |   18 +-
 .../amqp/client/util/UnmodifiableDelivery.java  |    6 +-
 .../amqp/client/util/UnmodifiableLink.java      |    3 +-
 .../journal/JournalImplLatencyBench.java        |   12 +-
 .../journal/gcfree/GcFreeJournal.java           |    5 +-
 .../gcfree/GcFreeJournalLatencyBench.java       |   11 +-
 .../SequentialFileLatencyBench.java             |   15 +-
 .../byteman/ActiveMQMessageHandlerTest.java     |   12 +-
 .../tests/extras/byteman/BMFailoverTest.java    |   35 +-
 .../BridgeServerLocatorConfigurationTest.java   |    6 +-
 .../extras/byteman/ClosingConnectionTest.java   |   25 +-
 .../byteman/ClusteredBridgeReconnectTest.java   |    6 +-
 .../extras/byteman/ClusteredGroupingTest.java   |   36 +-
 .../byteman/ConcurrentDeliveryCancelTest.java   |   15 +-
 .../tests/extras/byteman/FailureXATest.java     |   55 +-
 .../tests/extras/byteman/GroupingTest.java      |   27 +-
 .../HierarchicalObjectRepositoryTest.java       |   12 +-
 .../byteman/InterruptedMessageHandlerTest.java  |   15 +-
 .../byteman/JMSBridgeReconnectionTest.java      |   15 +-
 .../LargeMessageOverReplicationTest.java        |   31 +-
 .../tests/extras/byteman/MessageCopyTest.java   |   12 +-
 .../extras/byteman/OrphanedConsumerTest.java    |   11 +-
 .../tests/extras/byteman/PagingLeakTest.java    |    3 +-
 .../tests/extras/byteman/PagingOMETest.java     |    3 +-
 ...eOnSyncLargeMessageOverReplication2Test.java |   23 +-
 ...ceOnSyncLargeMessageOverReplicationTest.java |   12 +-
 .../extras/byteman/ReplicationBackupTest.java   |   14 +-
 .../extras/byteman/ScaleDownFailoverTest.java   |    3 +-
 .../extras/byteman/StartStopDeadlockTest.java   |   12 +-
 .../extras/byteman/StompInternalStateTest.java  |    6 +-
 .../tests/extras/byteman/TimeoutXATest.java     |   38 +-
 .../tests/extras/jms/bridge/BridgeTestBase.java |   21 +-
 .../jms/bridge/ClusteredBridgeTestBase.java     |    5 +-
 .../jms/bridge/JMSBridgeClusteredTest.java      |   12 +-
 .../jms/bridge/JMSBridgeReconnectionTest.java   |   22 +-
 .../tests/extras/jms/bridge/JMSBridgeTest.java  |  126 +-
 ...MDBMultipleHandlersServerDisconnectTest.java |   51 +-
 .../extras/jms/xa/JMSXDeliveryCountTest.java    |   37 +-
 .../artemis/tests/extras/jms/xa/XATest.java     |   96 +-
 .../hornetq/HornetQProtocolManagerTest.java     |   16 +-
 .../protocols/hornetq/HornetQProtocolTest.java  |    1 -
 .../integration/DuplicateDetectionTest.java     |   33 +-
 .../artemis/tests/integration/SimpleTest.java   |    4 +-
 .../integration/SingleServerSimpleTest.java     |    4 +-
 .../tests/integration/String64KLimitTest.java   |   15 +-
 .../aerogear/AeroGearBasicServerTest.java       |   22 +-
 .../integration/amqp/AmqpClientTestSupport.java |   20 +-
 .../amqp/ProtonMaxFrameSizeTest.java            |   12 +-
 .../integration/amqp/ProtonPubSubTest.java      |   22 +-
 .../tests/integration/amqp/ProtonTest.java      |  121 +-
 .../tests/integration/amqp/ProtonTestBase.java  |    9 +-
 .../integration/amqp/ProtonTestForHeader.java   |   14 +-
 .../amqp/SendingAndReceivingTest.java           |   12 +-
 .../broadcast/JGroupsBroadcastTest.java         |   16 +-
 .../integration/cli/DestinationCommandTest.java |   17 +-
 .../integration/client/AckBatchSizeTest.java    |    2 +-
 .../integration/client/AcknowledgeTest.java     |   22 +-
 .../integration/client/ActiveMQCrashTest.java   |    6 +-
 .../client/AutoCreateJmsDestinationTest.java    |    7 +-
 .../client/AutoDeleteJmsDestinationTest.java    |    2 +-
 .../integration/client/AutogroupIdTest.java     |    3 +-
 .../integration/client/CommitRollbackTest.java  |   14 +-
 .../ConcurrentCreateDeleteProduceTest.java      |    5 +-
 .../integration/client/ConsumerCloseTest.java   |    9 +-
 .../client/ConsumerRoundRobinTest.java          |    6 +-
 .../integration/client/ConsumerStuckTest.java   |   15 +-
 .../tests/integration/client/ConsumerTest.java  |   24 +-
 .../client/ConsumerWindowSizeTest.java          |   66 +-
 .../integration/client/CoreClientTest.java      |    7 +-
 .../client/CreateQueueIdempotentTest.java       |   22 +-
 .../client/DeadLetterAddressTest.java           |    5 +-
 .../integration/client/DeliveryOrderTest.java   |    5 +-
 .../integration/client/DurableQueueTest.java    |   11 +-
 .../client/ExpiryLargeMessageTest.java          |    7 +-
 .../integration/client/FailureDeadlockTest.java |   16 +-
 ...FlowControlOnIgnoreLargeMessageBodyTest.java |   45 +-
 .../integration/client/HangConsumerTest.java    |   27 +-
 .../integration/client/HeuristicXATest.java     |   37 +-
 .../InVMNonPersistentMessageBufferTest.java     |    6 +-
 .../client/IncompatibleVersionTest.java         |   24 +-
 .../client/InterruptedLargeMessageTest.java     |   15 +-
 .../client/JMSPagingFileDeleteTest.java         |   24 +-
 .../client/JmsNettyNioStressTest.java           |   49 +-
 .../integration/client/JournalCrashTest.java    |   10 +-
 .../LargeMessageAvoidLargeMessagesTest.java     |   10 +-
 .../client/LargeMessageCompressTest.java        |    5 +-
 .../integration/client/LargeMessageTest.java    |  113 +-
 .../client/LibaioDependencyCheckTest.java       |    3 +-
 .../integration/client/MessageBufferTest.java   |    2 +-
 .../client/MessageConcurrencyTest.java          |   13 +-
 .../client/MessageConsumerRollbackTest.java     |   11 +-
 .../integration/client/MessageCounterTest.java  |    9 +-
 .../client/MessageDurabilityTest.java           |    6 +-
 .../client/MessageExpirationTest.java           |    9 +-
 .../MessageGroupingConnectionFactoryTest.java   |   11 +-
 .../integration/client/MessageGroupingTest.java |   39 +-
 .../integration/client/MessageHandlerTest.java  |   21 +-
 .../integration/client/MessageRateTest.java     |    3 +-
 .../client/MultipleProducersTest.java           |   11 +-
 .../client/MultipleThreadFilterOneTest.java     |   33 +-
 .../tests/integration/client/NIOvsOIOTest.java  |   18 +-
 .../tests/integration/client/OrderTest.java     |    2 +-
 .../client/ProducerFlowControlTest.java         |   29 +-
 .../tests/integration/client/ProducerTest.java  |    3 +-
 .../integration/client/QueueBrowserTest.java    |   11 +-
 .../client/ReceiveImmediateTest.java            |    9 +-
 .../tests/integration/client/ReceiveTest.java   |   14 +-
 .../client/RedeliveryConsumerTest.java          |    8 +-
 .../tests/integration/client/RequestorTest.java |    3 +-
 .../tests/integration/client/RoutingTest.java   |    8 +-
 .../client/SelfExpandingBufferTest.java         |    3 +-
 .../client/ServerLocatorConnectTest.java        |    9 +-
 .../integration/client/SessionCloseTest.java    |    6 +-
 ...onClosedOnRemotingConnectionFailureTest.java |   12 +-
 .../client/SessionCreateAndDeleteQueueTest.java |    6 +-
 .../client/SessionCreateConsumerTest.java       |   12 +-
 .../client/SessionCreateProducerTest.java       |    8 +-
 .../integration/client/SessionFactoryTest.java  |   70 +-
 .../SessionSendAcknowledgementHandlerTest.java  |    3 +-
 .../client/SessionStopStartTest.java            |   24 +-
 .../tests/integration/client/SessionTest.java   |    7 +-
 .../integration/client/SlowConsumerTest.java    |   23 +-
 .../integration/client/TemporaryQueueTest.java  |   28 +-
 .../integration/client/TransientQueueTest.java  |   12 +-
 .../clientcrash/ClientCrashTest.java            |   10 +-
 .../integration/clientcrash/ClientTestBase.java |    8 +-
 .../integration/clientcrash/CrashClient.java    |    7 +-
 .../integration/clientcrash/CrashClient2.java   |    5 +-
 .../clientcrash/DummyInterceptorB.java          |    2 +-
 .../integration/clientcrash/GracefulClient.java |    5 +-
 .../clientcrash/PendingDeliveriesTest.java      |   26 +-
 .../cluster/ClusterControllerTest.java          |    3 +-
 .../integration/cluster/NodeManagerAction.java  |    3 +-
 .../integration/cluster/NodeManagerTest.java    |    6 +-
 .../cluster/RealNodeManagerTest.java            |    4 +-
 .../cluster/bridge/BridgeReconnectTest.java     |   10 +-
 .../cluster/bridge/BridgeStartTest.java         |   30 +-
 .../integration/cluster/bridge/BridgeTest.java  |   99 +-
 .../cluster/bridge/BridgeTestBase.java          |   14 +-
 .../BridgeWithDiscoveryGroupStartTest.java      |   11 +-
 .../distribution/ClusterHeadersRemovedTest.java |   11 +-
 .../cluster/distribution/ClusterTestBase.java   |   95 +-
 .../distribution/ClusterWithBackupTest.java     |    4 +-
 .../distribution/ClusteredGroupingTest.java     |   78 +-
 .../distribution/MessageRedistributionTest.java |    4 +-
 .../distribution/OneWayChainClusterTest.java    |   12 +-
 .../distribution/OnewayTwoNodeClusterTest.java  |    7 +-
 .../distribution/SymmetricClusterTest.java      |    3 +-
 .../SymmetricClusterWithBackupTest.java         |    3 +-
 .../distribution/TemporaryQueueClusterTest.java |   11 +-
 .../distribution/TwoWayTwoNodeClusterTest.java  |    3 +-
 .../failover/AsynchronousFailoverTest.java      |   72 +-
 .../AutomaticColocatedQuorumVoteTest.java       |   40 +-
 .../failover/BackupAuthenticationTest.java      |   11 +-
 .../cluster/failover/BackupSyncJournalTest.java |   12 +-
 .../failover/BackupSyncLargeMessageTest.java    |   22 +-
 .../cluster/failover/BackupSyncPagingTest.java  |    6 +-
 .../ClusterWithBackupFailoverTestBase.java      |    4 +-
 .../cluster/failover/DelayInterceptor.java      |    3 +-
 .../cluster/failover/DelayInterceptor2.java     |    3 +-
 .../cluster/failover/DelayInterceptor3.java     |    3 +-
 .../cluster/failover/FailBackManualTest.java    |    3 +-
 .../cluster/failover/FailoverListenerTest.java  |    3 +-
 .../failover/FailoverOnFlowControlTest.java     |   11 +-
 .../cluster/failover/FailoverTest.java          |  138 +-
 .../cluster/failover/FailoverTestBase.java      |   12 +-
 .../failover/LiveToLiveFailoverTest.java        |   17 +-
 .../MultipleBackupsFailoverTestBase.java        |   15 +-
 ...ultipleLivesMultipleBackupsFailoverTest.java |   12 +-
 .../MultipleServerFailoverTestBase.java         |   24 +-
 .../cluster/failover/NettyFailoverTest.java     |    8 +-
 .../failover/NettyReplicatedFailoverTest.java   |    3 +-
 .../cluster/failover/PagingFailoverTest.java    |    4 +-
 .../failover/QuorumVoteServerConnectTest.java   |   11 +-
 .../failover/ReplicatedDistributionTest.java    |    6 +-
 .../failover/ReplicatedFailoverTest.java        |   18 +-
 .../ReplicatedLargeMessageFailoverTest.java     |    6 +-
 ...dMultipleServerFailoverExtraBackupsTest.java |    2 +-
 .../ReplicatedMultipleServerFailoverTest.java   |    6 +-
 .../failover/ReplicatedPagedFailoverTest.java   |    3 +-
 .../ReplicatedWithDelayFailoverTest.java        |    3 +-
 .../SingleLiveMultipleBackupsFailoverTest.java  |    6 +-
 .../remote/FailoverWithSharedStoreTest.java     |    6 +-
 .../MultiThreadRandomReattachTestBase.java      |   19 +-
 .../MultiThreadReattachSupportTestBase.java     |   16 +-
 .../cluster/reattach/OrderReattachTest.java     |   31 +-
 .../cluster/reattach/RandomReattachTest.java    |    9 +-
 .../cluster/reattach/ReattachTest.java          |   46 +-
 .../cluster/restart/ClusterRestartTest.java     |    5 +-
 .../cluster/topology/IsolatedTopologyTest.java  |   10 +-
 .../cluster/topology/NonHATopologyTest.java     |   17 +-
 .../topology/TopologyClusterTestBase.java       |   21 +-
 .../cluster/util/BackupSyncDelay.java           |   11 +-
 .../cluster/util/MultiServerTestBase.java       |   24 +-
 .../cluster/util/SameProcessActiveMQServer.java |    8 +-
 .../crossprotocol/AMQPToOpenwireTest.java       |   29 +-
 .../crossprotocol/OpenWireToAMQPTest.java       |   23 +-
 .../discovery/DiscoveryBaseTest.java            |    6 +-
 .../discovery/DiscoveryStayAliveTest.java       |    6 +-
 .../integration/discovery/DiscoveryTest.java    |   15 +-
 .../tests/integration/divert/DivertTest.java    |   12 +-
 .../divert/ReplicationWithDivertTest.java       |   10 +-
 .../integration/embedded/ValidateAIOTest.java   |    3 +-
 .../http/CoreClientOverHttpTest.java            |   13 +-
 .../integration/interceptors/Incoming.java      |    2 +-
 .../interceptors/InterceptorTest.java           |   12 +-
 .../integration/interceptors/Outgoing.java      |    2 +-
 .../jdbc/store/journal/JDBCJournalTest.java     |    6 +-
 .../jms/ActiveMQConnectionFactoryTest.java      |  143 +-
 .../tests/integration/jms/FloodServerTest.java  |   28 +-
 .../tests/integration/jms/JMSSecurityTest.java  |    6 +-
 .../tests/integration/jms/JmsProducerTest.java  |   66 +-
 .../ManualReconnectionToSingleServerTest.java   |   47 +-
 .../tests/integration/jms/RedeployTest.java     |    7 +-
 .../integration/jms/SimpleJNDIClientTest.java   |    2 +-
 .../integration/jms/client/ConnectionTest.java  |   32 +-
 .../integration/jms/client/CreateQueueTest.java |    2 +-
 .../jms/client/ExpiryMessageTest.java           |    2 +-
 .../integration/jms/client/GroupIDTest.java     |    3 +-
 .../integration/jms/client/GroupingTest.java    |   28 +-
 .../jms/client/MessageProducerTest.java         |   15 +-
 .../integration/jms/client/MessageTest.java     |   54 +-
 .../jms/client/NewQueueRequestorTest.java       |    6 +-
 .../jms/client/NoLocalSubscriberTest.java       |    8 +-
 .../integration/jms/client/PreACKJMSTest.java   |   14 +-
 .../jms/client/ReSendMessageTest.java           |   32 +-
 .../jms/client/ReceiveNoWaitTest.java           |    8 +-
 .../jms/client/RemoteConnectionStressTest.java  |   16 +-
 ...onClosedOnRemotingConnectionFailureTest.java |   25 +-
 .../integration/jms/client/SessionTest.java     |   35 +-
 .../integration/jms/client/StoreConfigTest.java |   17 +-
 .../integration/jms/client/TextMessageTest.java |   14 +-
 .../jms/client/TopicCleanupTest.java            |   12 +-
 .../jms/cluster/AutoCreateQueueClusterTest.java |    3 +-
 .../jms/cluster/BindingsClusterTest.java        |   33 +-
 .../jms/cluster/JMSFailoverListenerTest.java    |   29 +-
 .../jms/cluster/JMSFailoverTest.java            |   50 +-
 .../jms/cluster/JMSReconnectTest.java           |   29 +-
 .../jms/cluster/LargeMessageOverBridgeTest.java |   22 +-
 .../jms/cluster/MultipleThreadsOpeningTest.java |   11 +-
 .../jms/cluster/TemporaryQueueClusterTest.java  |   12 +-
 .../jms/cluster/TopicClusterTest.java           |    9 +-
 .../CloseConnectionFactoryOnGCest.java          |    6 +-
 .../jms/connection/CloseConnectionOnGCTest.java |   14 +-
 .../CloseDestroyedConnectionTest.java           |   13 +-
 .../connection/ConcurrentSessionCloseTest.java  |   11 +-
 .../ConnectionFactorySerializationTest.java     |   16 +-
 ...tionFactoryWithJGroupsSerializationTest.java |    6 +-
 .../jms/connection/ExceptionListenerTest.java   |   14 +-
 .../jms/connection/InvalidConnectorTest.java    |   14 +-
 .../integration/jms/consumer/ConsumerTest.java  |   54 +-
 .../jms/divert/DivertAndACKClientTest.java      |   16 +-
 .../integration/jms/jms2client/BodyTest.java    |    3 +-
 .../jms/jms2client/InvalidDestinationTest.java  |  141 +-
 .../jms/jms2client/JmsContextTest.java          |   33 +-
 .../JmsProducerCompletionListenerTest.java      |   11 +-
 .../jms/jms2client/NonExistentQueueTest.java    |    8 +-
 .../jms/jms2client/SharedConsumerTest.java      |   72 +-
 .../jms/largemessage/JMSLargeMessageTest.java   |   23 +-
 .../jms/serializables/TestClass1.java           |    1 +
 .../jms/server/JMSServerDeployerTest.java       |   10 +-
 .../jms/server/JMSServerStartStopTest.java      |    3 +-
 .../jms/server/config/JMSConfigurationTest.java |   16 +-
 .../config/JMSServerConfigParserTest.java       |    7 +-
 .../ConnectionFactoryControlTest.java           |   17 +-
 .../server/management/JMSMessagingProxy.java    |   11 +-
 .../server/management/JMSQueueControlTest.java  |   64 +-
 .../management/JMSQueueControlUsingJMSTest.java |   24 +-
 .../management/JMSServerControl2Test.java       |   88 +-
 .../management/JMSServerControlRestartTest.java |   14 +-
 .../server/management/JMSServerControlTest.java |   87 +-
 .../JMSServerControlUsingJMSTest.java           |    9 +-
 .../jms/server/management/JMSUtil.java          |   26 +-
 .../management/TopicControlClusterTest.java     |   13 +-
 .../jms/server/management/TopicControlTest.java |   49 +-
 .../management/TopicControlUsingJMSTest.java    |   40 +-
 .../journal/AIOSequentialFileFactoryTest.java   |    2 +-
 .../journal/NIOBufferedJournalCompactTest.java  |    2 +-
 .../journal/NIOImportExportTest.java            |    2 +-
 .../journal/NIOJournalCompactTest.java          |   41 +-
 .../integration/journal/NIOJournalImplTest.java |    4 +-
 .../journal/NIONoBufferJournalImplTest.java     |    2 +-
 .../journal/NIOSequentialFileFactoryTest.java   |   18 +-
 .../journal/ValidateTransactionHealthTest.java  |   21 +-
 .../integration/karaf/ArtemisFeatureTest.java   |  119 +-
 .../largemessage/LargeMessageTestBase.java      |  101 +-
 .../largemessage/ServerLargeMessageTest.java    |    3 +-
 .../management/AcceptorControlTest.java         |   19 +-
 .../AcceptorControlUsingCoreTest.java           |    3 +-
 .../management/ActiveMQServerControlTest.java   |   45 +-
 .../ActiveMQServerControlUsingCoreTest.java     |    1 -
 .../management/AddressControlTest.java          |    6 +-
 .../management/AddressControlUsingCoreTest.java |    6 +-
 .../management/BridgeControlTest.java           |   16 +-
 .../management/BroadcastGroupControlTest.java   |   10 +-
 .../ClusterConnectionControl2Test.java          |   22 +-
 .../ClusterConnectionControlTest.java           |   20 +-
 .../management/CoreMessagingProxy.java          |   13 +-
 .../integration/management/JMXDomainTest.java   |    6 +-
 .../management/ManagementActivationTest.java    |   50 +-
 .../management/ManagementControlHelper.java     |    2 +-
 .../management/ManagementHelperTest.java        |    2 +-
 .../management/ManagementServiceImplTest.java   |   12 +-
 .../management/ManagementTestBase.java          |   15 +-
 .../ManagementWithPagingServerTest.java         |   27 +-
 .../management/ManagementWithStompTest.java     |   24 +-
 .../management/QueueControlTest.java            |   22 +-
 .../management/QueueControlUsingCoreTest.java   |   11 +-
 .../management/SecurityManagementTestBase.java  |   12 +-
 .../management/SecurityNotificationTest.java    |    6 +-
 .../mqtt/imported/FuseMQTTClientProvider.java   |    3 +-
 .../mqtt/imported/MQTTClientProvider.java       |    2 +-
 .../integration/mqtt/imported/MQTTTest.java     |   23 +-
 .../mqtt/imported/MQTTTestSupport.java          |   15 +-
 .../integration/mqtt/imported/PahoMQTTTest.java |    8 +-
 .../util/ResourceLoadingSslContext.java         |   17 +-
 .../integration/mqtt/imported/util/Wait.java    |    2 +-
 .../integration/openwire/BasicOpenWireTest.java |   18 +-
 .../integration/openwire/BasicSecurityTest.java |   44 +-
 .../integration/openwire/OpenWireTestBase.java  |    2 +-
 .../integration/openwire/OpenWireUtilTest.java  |    4 +-
 .../openwire/SimpleOpenWireTest.java            |   44 +-
 .../openwire/VerySimpleOenwireTest.java         |    6 +-
 .../openwire/amq/JMSConsumer10Test.java         |    7 +-
 .../openwire/amq/JMSConsumer11Test.java         |   10 +-
 .../openwire/amq/JMSConsumer12Test.java         |    7 +-
 .../openwire/amq/JMSConsumer13Test.java         |    7 +-
 .../openwire/amq/JMSConsumer1Test.java          |   11 +-
 .../openwire/amq/JMSConsumer2Test.java          |   14 +-
 .../openwire/amq/JMSConsumer3Test.java          |    7 +-
 .../openwire/amq/JMSConsumer4Test.java          |    7 +-
 .../openwire/amq/JMSConsumer5Test.java          |   13 +-
 .../openwire/amq/JMSConsumer7Test.java          |   19 +-
 .../openwire/amq/JMSConsumer8Test.java          |   19 +-
 .../openwire/amq/JMSConsumer9Test.java          |   13 +-
 .../openwire/amq/JMSIndividualAckTest.java      |    2 +-
 .../openwire/amq/JMSMessageTest.java            |   22 +-
 .../openwire/amq/JMSUsecase1Test.java           |    7 +-
 .../openwire/amq/JMSUsecaseTest.java            |    9 +-
 .../openwire/amq/JmsAutoAckListenerTest.java    |    5 +-
 .../amq/JmsConnectionStartStopTest.java         |   25 +-
 .../amq/JmsConsumerResetActiveListenerTest.java |   21 +-
 .../amq/JmsCreateConsumerInOnMessageTest.java   |    5 +-
 .../openwire/amq/JmsQueueBrowserTest.java       |    5 +-
 .../openwire/amq/JmsResourceProvider.java       |    3 +-
 .../openwire/amq/JmsSendReceiveTestSupport.java |   16 +-
 .../openwire/amq/JmsTopicRedeliverTest.java     |    5 +-
 .../openwire/amq/JmsTopicRequestReplyTest.java  |   28 +-
 .../openwire/amq/JmsTopicSelectorTest.java      |    5 +-
 .../openwire/amq/JmsTopicSendReceiveTest.java   |    6 +-
 ...sTopicSendReceiveWithTwoConnectionsTest.java |    3 +-
 .../openwire/amq/JmsTransactionTestSupport.java |   17 +-
 .../amq/MessageListenerRedeliveryTest.java      |   50 +-
 .../amq/ProducerFlowControlSendFailTest.java    |   13 +-
 .../openwire/amq/ProducerFlowControlTest.java   |   24 +-
 .../amq/ReconnectWithSameClientIDTest.java      |    9 +-
 .../openwire/amq/RedeliveryPolicyTest.java      |    2 +-
 .../openwire/amq/TransactionContextTest.java    |    8 +-
 .../openwire/interop/CompressedInteropTest.java |   23 +-
 .../openwire/interop/GeneralInteropTest.java    |   43 +-
 .../paging/AddressFullLoggingTest.java          |    7 +-
 .../integration/paging/GlobalPagingTest.java    |   17 +-
 .../paging/MultipleProducersPagingTest.java     |   14 +-
 .../paging/PageCountSyncOnNonTXTest.java        |   18 +-
 .../integration/paging/PageCountSyncServer.java |   13 +-
 .../integration/paging/PagingCounterTest.java   |   11 +-
 .../integration/paging/PagingOrderTest.java     |   28 +-
 .../integration/paging/PagingReceiveTest.java   |    2 +-
 .../integration/paging/PagingSendTest.java      |    5 +-
 .../integration/paging/PagingSyncTest.java      |    2 +-
 .../tests/integration/paging/PagingTest.java    |  183 +--
 .../PagingWithFailoverAndCountersTest.java      |   42 +-
 .../paging/PagingWithFailoverServer.java        |    8 +-
 .../paging/SpawnedServerSupport.java            |    6 +-
 .../DeleteMessagesOnStartupTest.java            |    2 +-
 .../persistence/DeleteQueueRestartTest.java     |    3 +-
 .../persistence/DuplicateCacheTest.java         |    1 -
 ...nnectionFactoryConfigurationStorageTest.java |   10 +-
 .../persistence/JMSDynamicConfigTest.java       |   14 +-
 .../persistence/JMSStorageManagerTest.java      |    9 +-
 .../integration/persistence/RestartSMTest.java  |   16 +-
 .../RolesConfigurationStorageTest.java          |    8 +-
 .../persistence/StorageManagerTestBase.java     |   13 +-
 ...ansportConfigurationEncodingSupportTest.java |   10 +-
 .../persistence/XmlImportExportTest.java        |    1 -
 .../integration/ra/ActiveMQActivationTest.java  |    5 +-
 .../integration/ra/ActiveMQClusteredTest.java   |    5 +-
 .../ra/ActiveMQMessageHandlerSecurityTest.java  |    2 +-
 .../ra/ActiveMQMessageHandlerTest.java          |   52 +-
 .../ra/ActiveMQMessageHandlerXATest.java        |   30 +-
 .../ra/ActiveMQRAClusteredTestBase.java         |    9 +-
 .../integration/ra/ActiveMQRATestBase.java      |   18 +-
 .../tests/integration/ra/JMSContextTest.java    |   18 +-
 .../integration/ra/OutgoingConnectionTest.java  |   27 +-
 .../ra/OutgoingConnectionTestJTA.java           |   18 +-
 .../integration/remoting/BatchDelayTest.java    |   12 +-
 .../integration/remoting/DirectDeliverTest.java |    6 +-
 .../remoting/NetworkAddressTestBase.java        |   16 +-
 .../tests/integration/remoting/PingTest.java    |   25 +-
 .../integration/remoting/ReconnectTest.java     |   35 +-
 .../remoting/SynchronousCloseTest.java          |    3 +-
 .../replication/ReplicationOrderTest.java       |   14 +-
 .../replication/ReplicationTest.java            |   19 +-
 .../artemis/tests/integration/rest/Order.java   |    1 +
 .../rest/RestDeserializationTest.java           |   12 +-
 .../tests/integration/rest/RestTestBase.java    |    6 +-
 .../rest/util/QueueRestMessageContext.java      |    7 +-
 .../integration/rest/util/ResponseUtil.java     |    5 +-
 .../rest/util/RestAMQConnection.java            |    4 +-
 .../rest/util/RestMessageContext.java           |   62 +-
 .../rest/util/TopicRestMessageContext.java      |   14 +-
 .../scheduling/ScheduledMessageTest.java        |   16 +-
 .../integration/security/LDAPSecurityTest.java  |   63 +-
 ...cyLDAPSecuritySettingPluginListenerTest.java |   35 +-
 .../LegacyLDAPSecuritySettingPluginTest.java    |   58 +-
 .../security/NettySecurityClientTest.java       |    6 +-
 .../integration/security/SecurityTest.java      |  465 +++---
 .../integration/security/SimpleClient.java      |    8 +-
 .../server/ActivationFailureListenerTest.java   |    3 +-
 .../integration/server/ConnectionLimitTest.java |   14 +-
 .../integration/server/ExpiryRunnerTest.java    |   13 +-
 .../integration/server/FileLockTimeoutTest.java |   20 +-
 .../server/GracefulShutdownTest.java            |   12 +-
 .../integration/server/LVQRecoveryTest.java     |    6 +-
 .../server/PotentialOOMELoggingTest.java        |    3 +-
 .../integration/server/PredefinedQueueTest.java |   24 +-
 .../integration/server/ResourceLimitTest.java   |   22 +-
 .../integration/server/ScaleDown3NodeTest.java  |   21 +-
 .../integration/server/ScaleDownDirectTest.java |    6 +-
 .../tests/integration/server/ScaleDownTest.java |   11 +-
 .../integration/server/SimpleStartStopTest.java |    3 +-
 .../server/SuppliedThreadPoolTest.java          |    4 +-
 .../integration/spring/ExampleListener.java     |    3 +-
 .../tests/integration/spring/MessageSender.java |    3 +-
 .../spring/SpringIntegrationTest.java           |   13 +-
 .../ssl/CoreClientOverOneWaySSLTest.java        |   88 +-
 .../ssl/CoreClientOverTwoWaySSLTest.java        |   24 +-
 .../integration/stomp/ConcurrentStompTest.java  |   12 +-
 .../tests/integration/stomp/ExtraStompTest.java |   80 +-
 .../stomp/StompConnectionCleanupTest.java       |    3 +-
 .../integration/stomp/StompOverHttpTest.java    |    3 +-
 .../stomp/StompOverWebsocketTest.java           |   16 +-
 .../tests/integration/stomp/StompTest.java      |   15 +-
 .../tests/integration/stomp/StompTestBase.java  |    9 +-
 .../integration/stomp/StompWebSocketTest.java   |    6 +-
 .../util/AbstractStompClientConnection.java     |   33 +-
 .../stomp/util/StompClientConnectionV10.java    |    6 +-
 .../stomp/util/StompClientConnectionV11.java    |    9 +-
 .../stomp/util/StompClientConnectionV12.java    |    6 +-
 .../stomp/util/StompFrameFactoryV11.java        |    9 +-
 .../stomp/util/StompFrameFactoryV12.java        |   12 +-
 .../integration/stomp/v11/ExtraStompTest.java   |    3 +-
 .../integration/stomp/v11/StompV11Test.java     |   66 +-
 .../integration/stomp/v11/StompV11TestBase.java |   26 +-
 .../integration/stomp/v12/StompV12Test.java     |   44 +-
 .../NettyConnectorWithHTTPUpgradeTest.java      |   13 +-
 .../vertx/ActiveMQVertxUnitTest.java            |    3 +-
 .../integration/xa/BasicXaRecoveryTest.java     |   82 +-
 .../tests/integration/xa/BasicXaTest.java       |   48 +-
 .../tests/integration/xa/XaTimeoutTest.java     |   44 +-
 .../tests/util/JMSClusteredTestBase.java        |   14 +-
 .../artemis/tests/util/JMSTestBase.java         |   17 +-
 .../artemis/jms/tests/AcknowledgementTest.java  |   21 +-
 .../jms/tests/ActiveMQServerTestCase.java       |   12 +-
 .../jms/tests/AutoAckMesageListenerTest.java    |   17 +-
 .../activemq/artemis/jms/tests/BrowserTest.java |   21 +-
 .../artemis/jms/tests/CTSMiscellaneousTest.java |   11 +-
 .../artemis/jms/tests/ConnectionClosedTest.java |   54 +-
 .../jms/tests/ConnectionFactoryTest.java        |   30 +-
 .../artemis/jms/tests/ConnectionTest.java       |   36 +-
 .../artemis/jms/tests/ConsumerClosedTest.java   |    3 +-
 .../artemis/jms/tests/DeliveryOrderTest.java    |    3 +-
 .../jms/tests/DurableSubscriptionTest.java      |   33 +-
 .../activemq/artemis/jms/tests/JMSTest.java     |    6 +-
 .../activemq/artemis/jms/tests/JMSTestCase.java |    3 +-
 .../artemis/jms/tests/MessageConsumerTest.java  |  322 ++---
 .../artemis/jms/tests/MessageProducerTest.java  |   93 +-
 .../jms/tests/MessageWithReadResolveTest.java   |    3 +-
 .../artemis/jms/tests/MiscellaneousTest.java    |   21 +-
 .../jms/tests/NonDurableSubscriberTest.java     |    9 +-
 .../artemis/jms/tests/PersistenceTest.java      |   18 +-
 .../artemis/jms/tests/QueueReceiverTest.java    |    3 +-
 .../activemq/artemis/jms/tests/QueueTest.java   |    6 +-
 .../artemis/jms/tests/SecurityTest.java         |   18 +-
 .../activemq/artemis/jms/tests/SessionTest.java |   27 +-
 .../jms/tests/TemporaryDestinationTest.java     |   57 +-
 .../activemq/artemis/jms/tests/TopicTest.java   |    3 +-
 .../jms/tests/TransactedSessionTest.java        |   72 +-
 .../tests/message/BodyIsAssignableFromTest.java |    9 +-
 .../message/JMSDeliveryModeHeaderTest.java      |    3 +-
 .../tests/message/JMSExpirationHeaderTest.java  |   32 +-
 .../tests/message/JMSMessageIDHeaderTest.java   |    6 +-
 .../jms/tests/message/JMSReplyToHeaderTest.java |    3 +-
 .../tests/message/JMSTimestampHeaderTest.java   |    3 +-
 .../jms/tests/message/JMSTypeHeaderTest.java    |    3 +-
 .../jms/tests/message/MessageBodyTest.java      |  354 ++---
 .../jms/tests/message/MessageHeaderTest.java    |  161 +--
 .../tests/message/MessageHeaderTestBase.java    |   59 +-
 .../message/MessagePropertyConversionTest.java  |  360 ++---
 .../message/ObjectMessageDeliveryTest.java      |    9 +-
 .../jms/tests/message/ObjectMessageTest.java    |    3 +-
 .../tests/message/SimpleJMSBytesMessage.java    |  151 +-
 .../jms/tests/message/SimpleJMSMapMessage.java  |  135 +-
 .../jms/tests/message/SimpleJMSMessage.java     |    9 +-
 .../tests/message/SimpleJMSObjectMessage.java   |    3 +-
 .../tests/message/SimpleJMSStreamMessage.java   |  200 +--
 .../jms/tests/message/TextMessageTest.java      |    8 +-
 .../foreign/ForeignObjectMessageTest.java       |    5 +-
 .../jms/tests/selector/SelectorTest.java        |   60 +-
 .../jms/tests/tools/ServerManagement.java       |    9 +-
 .../jms/tests/tools/container/InVMContext.java  |   26 +-
 .../container/InVMInitialContextFactory.java    |   10 +-
 .../InVMInitialContextFactoryBuilder.java       |   16 +-
 .../tests/tools/container/InVMNameParser.java   |    5 +-
 .../tests/tools/container/LocalTestServer.java  |    9 +-
 .../tools/container/NonSerializableFactory.java |   11 +-
 .../artemis/jms/tests/util/JNDIUtilTest.java    |   15 +-
 .../jms/tests/util/ProxyAssertSupport.java      |  102 +-
 .../artemis/amqpJMS/ActiveMQAMQPAdmin.java      |   24 +-
 .../amqpJMS/JoramAMQPAggregationTest.java       |    5 +-
 .../activemq/artemis/common/AbstractAdmin.java  |   27 +-
 .../artemis/common/SpawnedJMSServer.java        |    8 +-
 .../artemis/common/testjndi/TestContext.java    |   42 +-
 .../common/testjndi/TestContextFactory.java     |    3 +-
 .../activemq/artemis/jms/ActiveMQCoreAdmin.java |   11 +-
 .../jtests/jms/admin/AdminFactory.java          |    6 +-
 .../jms/conform/connection/ConnectionTest.java  |   39 +-
 .../conform/connection/TopicConnectionTest.java |   18 +-
 .../jms/conform/message/MessageBodyTest.java    |   12 +-
 .../jms/conform/message/MessageTypeTest.java    |   53 +-
 .../message/headers/MessageHeaderTest.java      |   31 +-
 .../message/properties/JMSXPropertyTest.java    |   15 +-
 .../MessagePropertyConversionTest.java          |  339 ++---
 .../message/properties/MessagePropertyTest.java |   71 +-
 .../jms/conform/queue/QueueBrowserTest.java     |   18 +-
 .../jms/conform/queue/TemporaryQueueTest.java   |    3 +-
 .../conform/selector/SelectorSyntaxTest.java    |   72 +-
 .../jms/conform/session/QueueSessionTest.java   |   27 +-
 .../jtests/jms/conform/session/SessionTest.java |   60 +-
 .../jms/conform/session/TopicSessionTest.java   |   33 +-
 .../jms/conform/session/UnifiedSessionTest.java |   57 +-
 .../jms/conform/topic/TemporaryTopicTest.java   |    3 +-
 .../jtests/jms/framework/JMSTestCase.java       |    6 +-
 .../jtests/jms/framework/PTPTestCase.java       |    9 +-
 .../jtests/jms/framework/PubSubTestCase.java    |    9 +-
 .../jtests/jms/framework/TestConfig.java        |    6 +-
 .../jtests/jms/framework/UnifiedTestCase.java   |    9 +-
 .../journal/JournalImplTestUnit.java            |    3 +-
 .../paging/MeasurePagingMultiThreadTest.java    |   12 +-
 .../sends/AbstractSendReceivePerfTest.java      |   22 +-
 .../tests/performance/sends/ClientACKPerf.java  |    1 -
 .../storage/PersistMultiThreadTest.java         |   28 +-
 .../storage/SendReceiveMultiThreadTest.java     |   18 +-
 .../tests/soak/client/ClientAbstract.java       |   12 +-
 .../tests/soak/client/ClientSoakTest.java       |    8 +-
 .../artemis/tests/soak/client/Receiver.java     |    6 +-
 .../artemis/tests/soak/client/Sender.java       |    3 +-
 .../soak/client/SimpleSendReceiveSoakTest.java  |    6 +-
 .../tests/stress/client/SendStressTest.java     |    6 +-
 .../stress/journal/AddAndRemoveStressTest.java  |    8 +-
 .../stress/journal/CompactingStressTest.java    |   39 +-
 .../JournalCleanupCompactStressTest.java        |   42 +-
 .../journal/JournalRestartStressTest.java       |    9 +-
 .../stress/journal/LargeJournalStressTest.java  |   33 +-
 .../stress/journal/MixupCompactorTestBase.java  |   13 +-
 .../journal/MultiThreadConsumerStressTest.java  |   27 +-
 .../NIOMultiThreadCompactorStressTest.java      |   29 +-
 .../paging/MultipleConsumersPageStressTest.java |   34 +-
 .../stress/paging/PageCursorStressTest.java     |   31 +-
 .../tests/stress/remote/PingStressTest.java     |   17 +-
 .../tests/stress/stomp/StompStressTest.java     |   21 +-
 .../core/journal/impl/AIOJournalImplTest.java   |    2 +-
 .../core/journal/impl/FakeJournalImplTest.java  |    2 +-
 .../core/server/impl/QueueConcurrentTest.java   |    3 +-
 .../timing/core/server/impl/QueueImplTest.java  |   15 +-
 .../jms/bridge/impl/JMSBridgeImplTest.java      |   71 +-
 .../tests/timing/util/ReusableLatchTest.java    |    6 +-
 .../timing/util/TokenBucketLimiterImplTest.java |    9 +-
 .../artemis/tests/timing/util/UTF8Test.java     |    9 +-
 .../MultiThreadAsynchronousFileTest.java        |   25 +-
 .../client/impl/LargeMessageBufferTest.java     |   74 +-
 .../impl/ConfigurationValidationTest.java       |    6 +-
 .../core/config/impl/ConnectorsServiceTest.java |    6 +-
 .../config/impl/TransportConfigurationTest.java |   13 +-
 .../journal/impl/AlignedJournalImplTest.java    |   40 +-
 .../unit/core/journal/impl/CleanBufferTest.java |    6 +-
 .../core/journal/impl/FakeJournalImplTest.java  |    2 +-
 .../impl/FakeSequentialFileFactoryTest.java     |    2 +-
 .../core/journal/impl/JournalAsyncTest.java     |   21 +-
 .../core/journal/impl/JournalImplTestBase.java  |   14 +-
 .../core/journal/impl/JournalImplTestUnit.java  |   74 +-
 .../unit/core/journal/impl/ReclaimerTest.java   |    4 +-
 .../impl/SequentialFileFactoryTestBase.java     |   12 +-
 .../unit/core/journal/impl/TimedBufferTest.java |   12 +-
 .../impl/fakes/FakeSequentialFileFactory.java   |   17 +-
 .../unit/core/message/impl/MessageImplTest.java |   16 +-
 .../core/paging/impl/PagingStoreImplTest.java   |   21 +-
 .../impl/BatchIDGeneratorUnitTest.java          |    7 +-
 .../impl/OperationContextUnitTest.java          |   11 +-
 .../core/postoffice/impl/AddressImplTest.java   |    8 +-
 .../core/postoffice/impl/BindingsImplTest.java  |   18 +-
 .../impl/DuplicateDetectionUnitTest.java        |   12 +-
 .../impl/WildcardAddressManagerUnitTest.java    |   10 +-
 .../core/remoting/ActiveMQBufferTestBase.java   |    9 +-
 .../remoting/impl/netty/NettyAcceptorTest.java  |    9 +-
 .../impl/netty/NettyConnectionTest.java         |    2 +-
 .../remoting/impl/netty/NettyConnectorTest.java |   20 +-
 .../core/remoting/impl/ssl/SSLSupportTest.java  |   20 +-
 .../impl/ActiveMQSecurityManagerImplTest.java   |   19 +-
 .../impl/ClusterConnectionBridgeTest.java       |    2 +-
 .../cluster/impl/RemoteQueueBindImplTest.java   |    7 +-
 .../group/impl/SystemPropertyOverrideTest.java  |    2 +-
 .../unit/core/server/impl/FileLockTest.java     |    3 +-
 .../unit/core/server/impl/QueueImplTest.java    |   18 +-
 .../core/server/impl/fakes/FakeConsumer.java    |   12 +-
 .../core/server/impl/fakes/FakePostOffice.java  |   23 +-
 .../core/util/RandomUtilDistributionTest.java   |   16 +-
 .../tests/unit/jms/ActiveMQDestinationTest.java |   13 +-
 .../unit/jms/client/ActiveMQMapMessageTest.java |   56 +-
 .../jms/client/ActiveMQStreamMessageTest.java   |   31 +-
 .../unit/jms/client/JMSExceptionHelperTest.java |   10 +-
 .../unit/jms/client/SelectorTranslatorTest.java |    4 +-
 .../tests/unit/jms/misc/ManifestTest.java       |   11 +-
 .../DestinationObjectFactoryTest.java           |   10 +-
 .../ra/ActiveMQResourceAdapterConfigTest.java   |   12 +-
 .../ra/ConnectionFactoryPropertiesTest.java     |    4 +-
 .../tests/unit/ra/ResourceAdapterTest.java      |   15 +-
 .../artemis/tests/unit/util/InVMContext.java    |   26 +-
 .../artemis/tests/unit/util/InVMNameParser.java |    5 +-
 .../tests/unit/util/InVMNamingContext.java      |   26 +-
 .../artemis/tests/unit/util/LinkedListTest.java |   30 +-
 .../artemis/tests/unit/util/MemorySizeTest.java |    6 +-
 .../ObjectInputStreamWithClassLoaderTest.java   |   78 +-
 .../tests/unit/util/ReusableLatchTest.java      |   12 +-
 .../artemis/tests/unit/util/UTF8Test.java       |   21 +-
 .../artemis/tests/unit/util/UUIDTest.java       |    8 +-
 .../tests/unit/util/VersionLoaderTest.java      |    2 +-
 .../deserialization/pkg1/EnclosingClass.java    |    1 +
 .../util/deserialization/pkg1/TestClass1.java   |    1 +
 .../util/deserialization/pkg1/TestClass2.java   |    1 +
 .../artemis/tests/util/SpawnedVMSupport.java    |   34 +-
 2824 files changed, 19654 insertions(+), 30241 deletions(-)
----------------------------------------------------------------------