summaryrefslogtreecommitdiff
path: root/qpid/java/test-profiles
diff options
context:
space:
mode:
Diffstat (limited to 'qpid/java/test-profiles')
-rw-r--r--qpid/java/test-profiles/08StandaloneExcludes41
-rwxr-xr-xqpid/java/test-profiles/CPPExcludes175
-rw-r--r--qpid/java/test-profiles/CPPNoPrefetchExcludes31
-rw-r--r--qpid/java/test-profiles/CPPPrefetchExcludes23
-rw-r--r--qpid/java/test-profiles/CPPTransientExcludes29
-rw-r--r--qpid/java/test-profiles/Excludes53
-rwxr-xr-xqpid/java/test-profiles/Java010Excludes82
-rw-r--r--qpid/java/test-profiles/JavaExcludes54
-rw-r--r--qpid/java/test-profiles/JavaInVMExcludes45
-rw-r--r--qpid/java/test-profiles/JavaPersistentExcludes21
-rw-r--r--qpid/java/test-profiles/JavaStandaloneExcludes55
-rw-r--r--qpid/java/test-profiles/JavaTransientExcludes32
-rw-r--r--qpid/java/test-profiles/XAExcludes22
-rwxr-xr-xqpid/java/test-profiles/clean-dir25
-rw-r--r--qpid/java/test-profiles/cpp.async.excludes21
-rw-r--r--qpid/java/test-profiles/cpp.async.testprofile21
-rw-r--r--qpid/java/test-profiles/cpp.cluster.testprofile28
-rw-r--r--qpid/java/test-profiles/cpp.excludes29
-rw-r--r--qpid/java/test-profiles/cpp.noprefetch.testprofile21
-rw-r--r--qpid/java/test-profiles/cpp.ssl.excludes20
-rw-r--r--qpid/java/test-profiles/cpp.ssl.testprofile29
-rw-r--r--qpid/java/test-profiles/cpp.testprofile38
-rw-r--r--qpid/java/test-profiles/default.testprofile61
-rw-r--r--qpid/java/test-profiles/java-derby.0.10.testprofile29
-rw-r--r--qpid/java/test-profiles/java-derby.testprofile33
-rw-r--r--qpid/java/test-profiles/java.0.10.testprofile26
-rw-r--r--qpid/java/test-profiles/java.testprofile28
-rwxr-xr-xqpid/java/test-profiles/kill-broker26
-rw-r--r--qpid/java/test-profiles/log4j-test.xml70
-rwxr-xr-xqpid/java/test-profiles/start-broker37
-rw-r--r--qpid/java/test-profiles/test-provider.properties51
-rw-r--r--qpid/java/test-profiles/test_resources/ssl/CA_db/cert8.dbbin0 -> 65536 bytes
-rw-r--r--qpid/java/test-profiles/test_resources/ssl/CA_db/key3.dbbin0 -> 16384 bytes
-rw-r--r--qpid/java/test-profiles/test_resources/ssl/CA_db/rootca.crt13
-rw-r--r--qpid/java/test-profiles/test_resources/ssl/CA_db/secmod.dbbin0 -> 16384 bytes
-rw-r--r--qpid/java/test-profiles/test_resources/ssl/app1.crt15
-rw-r--r--qpid/java/test-profiles/test_resources/ssl/app1.req10
-rw-r--r--qpid/java/test-profiles/test_resources/ssl/app2.crt15
-rw-r--r--qpid/java/test-profiles/test_resources/ssl/app2.req10
-rw-r--r--qpid/java/test-profiles/test_resources/ssl/certstore.jksbin0 -> 591 bytes
-rw-r--r--qpid/java/test-profiles/test_resources/ssl/keystore.jksbin0 -> 4296 bytes
-rw-r--r--qpid/java/test-profiles/test_resources/ssl/pfile1
-rw-r--r--qpid/java/test-profiles/test_resources/ssl/server_db/cert8.dbbin0 -> 65536 bytes
-rw-r--r--qpid/java/test-profiles/test_resources/ssl/server_db/key3.dbbin0 -> 16384 bytes
-rw-r--r--qpid/java/test-profiles/test_resources/ssl/server_db/secmod.dbbin0 -> 16384 bytes
-rw-r--r--qpid/java/test-profiles/test_resources/ssl/server_db/server.crt14
-rw-r--r--qpid/java/test-profiles/test_resources/ssl/server_db/server.req21
47 files changed, 1355 insertions, 0 deletions
diff --git a/qpid/java/test-profiles/08StandaloneExcludes b/qpid/java/test-profiles/08StandaloneExcludes
new file mode 100644
index 0000000000..43eb1f8ee5
--- /dev/null
+++ b/qpid/java/test-profiles/08StandaloneExcludes
@@ -0,0 +1,41 @@
+//
+// Licensed to the Apache Software Foundation (ASF) under one
+// or more contributor license agreements. See the NOTICE file
+// distributed with this work for additional information
+// regarding copyright ownership. The ASF licenses this file
+// to you under the Apache License, Version 2.0 (the
+// "License"); you may not use this file except in compliance
+// with the License. You may obtain a copy of the License at
+//
+// http://www.apache.org/licenses/LICENSE-2.0
+//
+// Unless required by applicable law or agreed to in writing,
+// software distributed under the License is distributed on an
+// "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+// KIND, either express or implied. See the License for the
+// specific language governing permissions and limitations
+// under the License.
+//
+
+//======================================================================
+//Exclude the following from brokers defaulting to the 0-8 protocol
+//======================================================================
+
+// This test requires a broker capable of 0-8/9 and 0-10
+org.apache.qpid.test.client.message.JMSDestinationTest#testReceiveResend
+
+// QPID-2478 test fails when run against broker using 0-8/9
+org.apache.qpid.test.client.message.JMSDestinationTest#testGetDestinationWithCustomExchange
+
+// The new addressing based sytanx is not supported for AMQP 0-8/0-9 versions
+org.apache.qpid.test.client.destination.AddressBasedDestinationTest#*
+org.apache.qpid.test.client.queue.QueuePolicyTest#testRingPolicy
+org.apache.qpid.test.client.queue.QueuePolicyTest#testRejectPolicy
+
+// Those tests are written against the 0.10 path
+org.apache.qpid.test.unit.message.UTF8Test#*
+org.apache.qpid.client.MessageListenerTest#testSynchronousReceiveNoWait
+
+org.apache.qpid.test.unit.client.connection.ConnectionTest#testUnsupportedSASLMechanism
+
+org.apache.qpid.test.unit.message.JMSPropertiesTest#testGetPropertyNames
diff --git a/qpid/java/test-profiles/CPPExcludes b/qpid/java/test-profiles/CPPExcludes
new file mode 100755
index 0000000000..4127682208
--- /dev/null
+++ b/qpid/java/test-profiles/CPPExcludes
@@ -0,0 +1,175 @@
+//
+// Licensed to the Apache Software Foundation (ASF) under one
+// or more contributor license agreements. See the NOTICE file
+// distributed with this work for additional information
+// regarding copyright ownership. The ASF licenses this file
+// to you under the Apache License, Version 2.0 (the
+// "License"); you may not use this file except in compliance
+// with the License. You may obtain a copy of the License at
+//
+// http://www.apache.org/licenses/LICENSE-2.0
+//
+// Unless required by applicable law or agreed to in writing,
+// software distributed under the License is distributed on an
+// "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+// KIND, either express or implied. See the License for the
+// specific language governing permissions and limitations
+// under the License.
+//
+
+org.apache.qpid.test.unit.client.channelclose.ChannelCloseTest#*
+org.apache.qpid.client.ResetMessageListenerTest#*
+
+// This test is not finished
+org.apache.qpid.test.testcases.TTLTest#*
+org.apache.qpid.test.client.failover.FailoverTest#test4MinuteFailover
+
+// Those tests are testing 0.8 specific semantics
+org.apache.qpid.test.testcases.ImmediateMessageTest#test_QPID_517_ImmediateFailsConsumerDisconnectedNoTxP2P
+org.apache.qpid.test.testcases.ImmediateMessageTest#test_QPID_517_ImmediateFailsConsumerDisconnectedTxP2P
+org.apache.qpid.test.testcases.ImmediateMessageTest#test_QPID_517_ImmediateFailsNoRouteNoTxP2P
+org.apache.qpid.test.testcases.ImmediateMessageTest#test_QPID_517_ImmediateFailsNoRouteTxP2P
+org.apache.qpid.test.testcases.ImmediateMessageTest#test_QPID_517_ImmediateFailsConsumerDisconnectedNoTxPubSub
+org.apache.qpid.test.testcases.ImmediateMessageTest#test_QPID_517_ImmediateFailsConsumerDisconnectedTxPubSub
+org.apache.qpid.test.testcases.ImmediateMessageTest#test_QPID_517_ImmediateFailsNoRouteNoTxPubSub
+org.apache.qpid.test.testcases.ImmediateMessageTest#test_QPID_517_ImmediateFailsNoRouteTxPubSub
+org.apache.qpid.test.testcases.MandatoryMessageTest#test_QPID_508_MandatoryFailsNoRouteNoTxP2P
+org.apache.qpid.test.testcases.MandatoryMessageTest#test_QPID_508_MandatoryFailsNoRouteTxP2P
+org.apache.qpid.test.testcases.MandatoryMessageTest#test_QPID_508_MandatoryFailsNoRouteNoTxPubSub
+org.apache.qpid.test.testcases.MandatoryMessageTest#test_QPID_508_MandatoryFailsNoRouteTxPubSub
+
+// the 0.10 c++ broker does not implement forget
+org.apache.qpid.test.unit.xa.FaultTest#testForget
+
+// the 0-10 c++ broker does not implement priority / this test depends on a Java broker extension for queue creation
+org.apache.qpid.server.queue.PriorityTest#*
+org.apache.qpid.server.queue.AMQPriorityQueueTest#*
+
+// the 0-10 c++ broker does not implement the extended LVQ semantics which the Java Broker does
+org.apache.qpid.server.queue.ConflationQueueTest#*
+
+//this test checks explicitly for 0-8 flow control semantics
+org.apache.qpid.test.client.FlowControlTest#*
+
+// 0-10 c++ broker doesn't implement virtual hosts, or those wackhy exchanges
+org.apache.qpid.test.unit.client.connection.ConnectionTest#testUnresolvedVirtualHostFailure
+org.apache.qpid.test.unit.client.connection.ConnectionTest#testDefaultExchanges
+
+// 0-10 c++ broker in cpp.testprofile is started with no auth so won't pass this test
+org.apache.qpid.test.unit.client.connection.ConnectionTest#testPasswordFailureConnection
+
+// c++ broker doesn't do selectors, so this will fail
+org.apache.qpid.test.unit.topic.TopicSessionTest#testNonMatchingMessagesDoNotFillQueue
+
+// InVM Broker tests
+org.apache.qpid.test.client.timeouts.SyncWaitDelayTest#*
+
+// QPID-1262, QPID-1119 : This test fails occasionally due to potential protocol issue.
+org.apache.qpid.test.client.timeouts.SyncWaitTimeoutDelayTest#*
+
+// c++ broker doesn't support message bouncing
+org.apache.qpid.server.exchange.ReturnUnroutableMandatoryMessageTest#*
+
+// c++ broker expires messages on delivery or when the queue cleaner thread runs.
+org.apache.qpid.server.queue.TimeToLiveTest#testActiveTTL
+org.apache.qpid.server.queue.TimeToLiveTest#testActiveTTLwithDurableSubscription
+
+// QPID-1727 , QPID-1726 :c++ broker does not support flow to disk on transient queues. Also it requries a persistent store impl. for Apache
+org.apache.qpid.test.client.QueueBrowsingFlowToDiskTest#*
+
+// This test currently does not pick up the runtime location of the nonVm queueBacking store.
+org.apache.qpid.test.unit.close.FlowToDiskBackingQueueDeleteTest#*
+
+// This test may use QpidTestCase but it is not using the getConnection and is hardwired to InVM
+org.apache.qpid.test.unit.client.connection.CloseAfterConnectionFailureTest#*
+
+//QPID-1818 : 0-10 Client code path does not correctly restore a transacted session after failover.
+org.apache.qpid.server.persistent.NoLocalAfterRecoveryTest#*
+
+// QPID-1730: the C++ server has a totally different logging mechanism. We should split this file differently
+org.apache.qpid.server.AlertingTest#*
+
+// The C++ server has a totally different persistence mechanism
+org.apache.qpid.server.store.PersistentStoreTest#*
+
+// These tests are for the Java broker persistent store modules
+org.apache.qpid.server.store.MessageStoreTest#testMessagePersistence
+org.apache.qpid.server.store.MessageStoreTest#testMessageRemoval
+org.apache.qpid.server.store.MessageStoreTest#testBindingPersistence
+org.apache.qpid.server.store.MessageStoreTest#testDurableBindingRemoval
+org.apache.qpid.server.store.MessageStoreTest#testQueuePersistence
+org.apache.qpid.server.store.MessageStoreTest#testDurableQueueRemoval
+org.apache.qpid.server.store.MessageStoreTest#testExchangePersistence
+org.apache.qpid.server.store.MessageStoreTest#testDurableExchangeRemoval
+
+// CPP Broker does not follow the same Logging convention as the Java broker
+org.apache.qpid.server.BrokerStartupTest#*
+org.apache.qpid.server.logging.*
+org.apache.qpid.server.logging.messages.*
+org.apache.qpid.server.logging.subjects.*
+org.apache.qpid.server.logging.actors.*
+
+// CPP Broker does not have a JMX interface to test
+org.apache.qpid.management.jmx.*
+org.apache.qpid.server.queue.AMQQueueMBeanTest#*
+org.apache.qpid.server.exchange.ExchangeMBeanTest#*
+org.apache.qpid.server.AMQBrokerManagerMBeanTest#*
+org.apache.qpid.server.protocol.AMQProtocolSessionMBeanTest#*
+
+// JMX is used in this test for validation
+org.apache.qpid.server.queue.ModelTest#*
+
+// 0-10 is not supported by the MethodRegistry
+org.apache.qpid.test.unit.close.JavaServerCloseRaceConditionTest#*
+
+// QPID-2084 : this test needs more work for 0-10
+org.apache.qpid.test.unit.client.DynamicQueueExchangeCreateTest#*
+
+// QPID-2118 : 0-10 Java client has differrent error handling to 0-8 code path
+org.apache.qpid.test.client.message.SelectorTest#testRuntimeSelectorError
+
+//QPID-942 : Implemented Channel.Flow based Producer Side flow control to the Java Broker (not in CPP Broker)
+org.apache.qpid.server.queue.ProducerFlowControlTest#*
+
+//QPID-1950 : Commit to test this failure. This is a MINA only failure so it cannot be tested when using 010.
+org.apache.qpid.server.failover.MessageDisappearWithIOExceptionTest#*
+
+// These are recent test additions that are failing with the c++ broker
+// Temporarily disabling until properly investigated.
+org.apache.qpid.test.unit.publish.DirtyTransactedPublishTest#*
+org.apache.qpid.test.unit.ack.FailoverBeforeConsumingRecoverTest#*
+
+org.apache.qpid.test.client.RollbackOrderTest#testOrderingAfterRollbackOnMessage#*
+
+// Temporarily adding the following until the issues are sorted out.
+org.apache.qpid.test.unit.client.AMQConnectionTest#testHeartBeat
+
+//Excluded due to QPID-1447 : CPP broker does not have SlowConsumer Disconnection
+org.apache.qpid.systest.GlobalQueuesTest#*
+org.apache.qpid.systest.GlobalTopicsTest#*
+org.apache.qpid.systest.MergeConfigurationTest#*
+org.apache.qpid.systest.SubscriptionTest#*
+org.apache.qpid.systest.TopicTest#*
+
+// Excluded because Java plugins not used in CPP broker
+org.apache.qpid.server.virtualhost.plugin.*
+org.apache.qpid.server.virtualhost.plugin.policies.*
+org.apache.qpid.info.systest.InfoPluginTest#*
+org.apache.qpid.info.test.*
+org.apache.qpid.server.security.access.*
+org.apache.qpid.server.security.access.plugins.*
+org.apache.qpid.server.security.acl.*
+org.apache.qpid.server.configuration.*
+org.apache.qpid.server.configuration.plugins.*
+org.apache.qpid.server.security.firewall.FirewallConfigTest#*
+org.apache.qpid.server.security.firewall.FirewallConfigurationTest#*
+org.apache.qpid.server.plugins.PluginTest#*
+
+// Transacion timeouts not implemented in CPP broker
+org.apache.qpid.test.unit.transacted.TransactionTimeoutDisabledTest#*
+org.apache.qpid.test.unit.transacted.TransactionTimeoutConfigurationTest#*
+org.apache.qpid.test.unit.transacted.TransactionTimeoutTest#*
+
+// Java broker only
+org.apache.qpid.server.logging.management.LoggingManagementMBeanTest#*
+org.apache.qpid.server.management.AMQUserManagementMBeanTest#*
diff --git a/qpid/java/test-profiles/CPPNoPrefetchExcludes b/qpid/java/test-profiles/CPPNoPrefetchExcludes
new file mode 100644
index 0000000000..ebcd430161
--- /dev/null
+++ b/qpid/java/test-profiles/CPPNoPrefetchExcludes
@@ -0,0 +1,31 @@
+//
+// Licensed to the Apache Software Foundation (ASF) under one
+// or more contributor license agreements. See the NOTICE file
+// distributed with this work for additional information
+// regarding copyright ownership. The ASF licenses this file
+// to you under the Apache License, Version 2.0 (the
+// "License"); you may not use this file except in compliance
+// with the License. You may obtain a copy of the License at
+//
+// http://www.apache.org/licenses/LICENSE-2.0
+//
+// Unless required by applicable law or agreed to in writing,
+// software distributed under the License is distributed on an
+// "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+// KIND, either express or implied. See the License for the
+// specific language governing permissions and limitations
+// under the License.
+//
+
+org.apache.qpid.test.unit.transacted.TransactedTest#testRollback
+
+org.apache.qpid.test.client.QueueBrowserAutoAckTest#testFailoverWithQueueBrowser
+org.apache.qpid.test.client.QueueBrowserClientAckTest#testFailoverWithQueueBrowser
+org.apache.qpid.test.client.QueueBrowserDupsOkTest#testFailoverWithQueueBrowser
+org.apache.qpid.test.client.QueueBrowserNoAckTest#testFailoverWithQueueBrowser
+org.apache.qpid.test.client.QueueBrowserPreAckTest#testFailoverWithQueueBrowser
+org.apache.qpid.test.client.QueueBrowserTransactedTest#testFailoverWithQueueBrowser
+
+org.apache.qpid.test.unit.topic.DurableSubscriptionTest#testDurabilityNOACK
+org.apache.qpid.test.unit.topic.DurableSubscriptionTest#testDurabilityNOACKSessionPerConnection
+org.apache.qpid.test.unit.xa.TopicTest#testMigrateDurableSubscriber
diff --git a/qpid/java/test-profiles/CPPPrefetchExcludes b/qpid/java/test-profiles/CPPPrefetchExcludes
new file mode 100644
index 0000000000..7ef52f89c7
--- /dev/null
+++ b/qpid/java/test-profiles/CPPPrefetchExcludes
@@ -0,0 +1,23 @@
+//
+// Licensed to the Apache Software Foundation (ASF) under one
+// or more contributor license agreements. See the NOTICE file
+// distributed with this work for additional information
+// regarding copyright ownership. The ASF licenses this file
+// to you under the Apache License, Version 2.0 (the
+// "License"); you may not use this file except in compliance
+// with the License. You may obtain a copy of the License at
+//
+// http://www.apache.org/licenses/LICENSE-2.0
+//
+// Unless required by applicable law or agreed to in writing,
+// software distributed under the License is distributed on an
+// "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+// KIND, either express or implied. See the License for the
+// specific language governing permissions and limitations
+// under the License.
+//
+
+// those tests should be run with prefetch off
+org.apache.qpid.client.MessageListenerMultiConsumerTest#testRecieveC2Only
+org.apache.qpid.client.MessageListenerMultiConsumerTest#testRecieveBoth
+org.apache.qpid.test.unit.xa.TopicTest#testMigrateDurableSubscriber
diff --git a/qpid/java/test-profiles/CPPTransientExcludes b/qpid/java/test-profiles/CPPTransientExcludes
new file mode 100644
index 0000000000..47f24db19c
--- /dev/null
+++ b/qpid/java/test-profiles/CPPTransientExcludes
@@ -0,0 +1,29 @@
+//
+// Licensed to the Apache Software Foundation (ASF) under one
+// or more contributor license agreements. See the NOTICE file
+// distributed with this work for additional information
+// regarding copyright ownership. The ASF licenses this file
+// to you under the Apache License, Version 2.0 (the
+// "License"); you may not use this file except in compliance
+// with the License. You may obtain a copy of the License at
+//
+// http://www.apache.org/licenses/LICENSE-2.0
+//
+// Unless required by applicable law or agreed to in writing,
+// software distributed under the License is distributed on an
+// "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+// KIND, either express or implied. See the License for the
+// specific language governing permissions and limitations
+// under the License.
+//
+
+// those tests need durable subscribe states to be persisted
+org.apache.qpid.test.unit.topic.DurableSubscriptionTest#testDurSubRestoredAfterNonPersistentMessageSent
+
+// those tests require broker recovery
+org.apache.qpid.test.unit.ct.DurableSubscriberTest#*
+org.apache.qpid.test.unit.xa.TopicTest#testDurSubCrash
+org.apache.qpid.test.unit.xa.TopicTest#testMultiMessagesDurSubCrash
+org.apache.qpid.test.unit.xa.TopicTest#testRecover
+org.apache.qpid.test.unit.xa.QueueTest#testRecover
+org.apache.qpid.test.unit.xa.QueueTest#testSendAndRecover
diff --git a/qpid/java/test-profiles/Excludes b/qpid/java/test-profiles/Excludes
new file mode 100644
index 0000000000..ff6993fa0b
--- /dev/null
+++ b/qpid/java/test-profiles/Excludes
@@ -0,0 +1,53 @@
+//
+// Licensed to the Apache Software Foundation (ASF) under one
+// or more contributor license agreements. See the NOTICE file
+// distributed with this work for additional information
+// regarding copyright ownership. The ASF licenses this file
+// to you under the Apache License, Version 2.0 (the
+// "License"); you may not use this file except in compliance
+// with the License. You may obtain a copy of the License at
+//
+// http://www.apache.org/licenses/LICENSE-2.0
+//
+// Unless required by applicable law or agreed to in writing,
+// software distributed under the License is distributed on an
+// "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+// KIND, either express or implied. See the License for the
+// specific language governing permissions and limitations
+// under the License.
+//
+
+org.apache.qpid.client.MultipleJCAProviderRegistrationTest#test
+// QPID-1715, QPID-1715 : Client Error Handling on close is still broken
+org.apache.qpid.server.queue.QueueCreateTest#testCreatePriorityString
+org.apache.qpid.server.queue.QueueCreateTest#testCreateFlowToDiskValidNoSize
+org.apache.qpid.server.queue.QueueCreateTest#testCreateFlowToDiskInvalid
+org.apache.qpid.server.queue.QueueCreateTest#testCreateFlowToDiskInvalidSize
+
+//
+// QPID-2031 : Broker is not cleanly shutdown by QpidTestCase
+//
+org.apache.qpid.server.logging.BrokerLoggingTest#testBrokerShutdownListeningTCPDefault
+org.apache.qpid.server.logging.BrokerLoggingTest#testBrokerShutdownListeningTCPSSL
+org.apache.qpid.server.logging.BrokerLoggingTest#testBrokerShutdownStopped
+org.apache.qpid.server.logging.VirtualHostLoggingTest#testVirtualhostClosure
+org.apache.qpid.server.logging.MemoryMessageStoreLoggingTest#testMessageStoreClose
+
+// QPID-XXX : Test fails to start external broker due to Derby Exception.
+org.apache.qpid.server.logging.DerbyMessageStoreLoggingTest#*
+
+// QPID-1816 : Client Ack has not been addressed
+org.apache.qpid.test.unit.ack.AcknowledgeAfterFailoverOnMessageTest#testDirtyClientAck
+org.apache.qpid.test.unit.ack.AcknowledgeAfterFailoverOnMessageTest#testClientAck
+org.apache.qpid.test.unit.ack.AcknowledgeAfterFailoverTest#testDirtyClientAck
+org.apache.qpid.test.unit.ack.AcknowledgeAfterFailoverTest#testClientAck
+
+
+// QPID-143 : Failover can occur between receive and ack but we don't stop the ack.
+// Just fully disable both tests as they are highlighting to many Java Client race conditions
+org.apache.qpid.test.unit.ack.AcknowledgeAfterFailoverOnMessageTest#*
+org.apache.qpid.test.unit.ack.AcknowledgeAfterFailoverTest#*
+
+// QPID-2418 : The queue backing the dur sub is not currently deleted at subscription change, so the test will fail.
+org.apache.qpid.test.unit.ct.DurableSubscriberTest#testResubscribeWithChangedSelectorAndRestart
+
diff --git a/qpid/java/test-profiles/Java010Excludes b/qpid/java/test-profiles/Java010Excludes
new file mode 100755
index 0000000000..c05aad0cb1
--- /dev/null
+++ b/qpid/java/test-profiles/Java010Excludes
@@ -0,0 +1,82 @@
+//
+// Licensed to the Apache Software Foundation (ASF) under one
+// or more contributor license agreements. See the NOTICE file
+// distributed with this work for additional information
+// regarding copyright ownership. The ASF licenses this file
+// to you under the Apache License, Version 2.0 (the
+// "License"); you may not use this file except in compliance
+// with the License. You may obtain a copy of the License at
+//
+// http://www.apache.org/licenses/LICENSE-2.0
+//
+// Unless required by applicable law or agreed to in writing,
+// software distributed under the License is distributed on an
+// "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+// KIND, either express or implied. See the License for the
+// specific language governing permissions and limitations
+// under the License.
+//
+
+// Those tests are testing 0.8 specific semantics
+org.apache.qpid.test.testcases.ImmediateMessageTest#test_QPID_517_ImmediateFailsConsumerDisconnectedNoTxP2P
+org.apache.qpid.test.testcases.ImmediateMessageTest#test_QPID_517_ImmediateFailsConsumerDisconnectedTxP2P
+org.apache.qpid.test.testcases.ImmediateMessageTest#test_QPID_517_ImmediateFailsNoRouteNoTxP2P
+org.apache.qpid.test.testcases.ImmediateMessageTest#test_QPID_517_ImmediateFailsNoRouteTxP2P
+org.apache.qpid.test.testcases.ImmediateMessageTest#test_QPID_517_ImmediateFailsConsumerDisconnectedNoTxPubSub
+org.apache.qpid.test.testcases.ImmediateMessageTest#test_QPID_517_ImmediateFailsConsumerDisconnectedTxPubSub
+org.apache.qpid.test.testcases.ImmediateMessageTest#test_QPID_517_ImmediateFailsNoRouteNoTxPubSub
+org.apache.qpid.test.testcases.ImmediateMessageTest#test_QPID_517_ImmediateFailsNoRouteTxPubSub
+org.apache.qpid.test.testcases.MandatoryMessageTest#test_QPID_508_MandatoryFailsNoRouteNoTxP2P
+org.apache.qpid.test.testcases.MandatoryMessageTest#test_QPID_508_MandatoryFailsNoRouteTxP2P
+org.apache.qpid.test.testcases.MandatoryMessageTest#test_QPID_508_MandatoryFailsNoRouteNoTxPubSub
+org.apache.qpid.test.testcases.MandatoryMessageTest#test_QPID_508_MandatoryFailsNoRouteTxPubSub
+
+//this test checks explicitly for 0-8 flow control semantics
+org.apache.qpid.test.client.FlowControlTest#*
+
+// 0-10 protocol doesn't support message bouncing
+org.apache.qpid.server.exchange.ReturnUnroutableMandatoryMessageTest#*
+
+// QPID-1727 , QPID-1726 :c++ broker does not support flow to disk on transient queues. Also it requries a persistent store impl. for Apache
+org.apache.qpid.test.client.QueueBrowsingFlowToDiskTest#*
+
+// 0-10 and 0-9 connections dont generate the exact same logging due to protocol differences
+org.apache.qpid.server.logging.ChannelLoggingTest#testChannelStartsFlowStopped
+org.apache.qpid.server.logging.ChannelLoggingTest#testChannelStartConsumerFlowStarted
+org.apache.qpid.server.logging.SubscriptionLoggingTest#testSubscriptionSuspend
+
+// 0-10 Broker does not have a JMX connection MBean
+org.apache.qpid.management.jmx.ManagementActorLoggingTest#testConnectionCloseViaManagement
+org.apache.qpid.management.jmx.MessageConnectionStatisticsTest#*
+
+// 0-10 has different ideas about clientid and ownership of queues
+org.apache.qpid.server.queue.ModelTest#*
+
+// 0-10 is not supported by the MethodRegistry
+org.apache.qpid.test.unit.close.JavaServerCloseRaceConditionTest#*
+
+//QPID-942 : Implemented Channel.Flow based Producer Side flow control to the Java Broker (not in CPP Broker)
+org.apache.qpid.server.queue.ProducerFlowControlTest#*
+
+//QPID-1950 : Commit to test this failure. This is a MINA only failure so it cannot be tested when using 010.
+org.apache.qpid.server.failover.MessageDisappearWithIOExceptionTest#*
+
+//QPID-2471 : Issues with 0-10 recovery
+org.apache.qpid.test.unit.ack.RecoverTest#testRecoverInAutoAckListener
+org.apache.qpid.test.unit.ack.FailoverBeforeConsumingRecoverTest#testRecoverInAutoAckListener
+
+// Temporarily disabling until properly investigated.
+org.apache.qpid.test.unit.publish.DirtyTransactedPublishTest#*
+
+//rollback with subscriptions does not work in 0-10 yet
+org.apache.qpid.test.client.RollbackOrderTest#testOrderingAfterRollbackOnMessage
+org.apache.qpid.test.unit.ack.RecoverTest#testRecoverInAutoAckListener
+
+// This test uses 0-8 channel frames
+org.apache.qpid.test.unit.client.channelclose.ChannelCloseTest#*
+
+//Temporarily adding the following until the issues are sorted out.
+//Should probably raise JIRAs for them.
+org.apache.qpid.transport.network.mina.MINANetworkDriverTest#*
+org.apache.qpid.test.client.destination.AddressBasedDestinationTest#testCreateExchange
+org.apache.qpid.test.client.destination.AddressBasedDestinationTest#testBrowseMode
diff --git a/qpid/java/test-profiles/JavaExcludes b/qpid/java/test-profiles/JavaExcludes
new file mode 100644
index 0000000000..c38a250abc
--- /dev/null
+++ b/qpid/java/test-profiles/JavaExcludes
@@ -0,0 +1,54 @@
+//
+// Licensed to the Apache Software Foundation (ASF) under one
+// or more contributor license agreements. See the NOTICE file
+// distributed with this work for additional information
+// regarding copyright ownership. The ASF licenses this file
+// to you under the Apache License, Version 2.0 (the
+// "License"); you may not use this file except in compliance
+// with the License. You may obtain a copy of the License at
+//
+// http://www.apache.org/licenses/LICENSE-2.0
+//
+// Unless required by applicable law or agreed to in writing,
+// software distributed under the License is distributed on an
+// "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+// KIND, either express or implied. See the License for the
+// specific language governing permissions and limitations
+// under the License.
+//
+
+// Those tests are not finished
+org.apache.qpid.test.testcases.TTLTest#*
+org.apache.qpid.test.testcases.FailoverTest#*
+
+// This is a long running test so should exclude from normal runs
+org.apache.qpid.test.client.failover.FailoverTest#test4MinuteFailover
+
+//QPID-1818 : Client code path does not correctly restore a transacted session after failover.
+org.apache.qpid.server.persistent.NoLocalAfterRecoveryTest#*
+
+// QPID-1823: this takes ages to run
+org.apache.qpid.client.SessionCreateTest#*
+
+// related to QPID-2471. Temporarily disabling these tests until I figure out why they are failing with the Java broker.
+org.apache.qpid.test.unit.ack.RecoverTest#testRecoverResendsMsgs
+org.apache.qpid.test.unit.ack.RecoverTest#testRecoverResendsMsgsAckOnEarlier
+org.apache.qpid.test.unit.ack.RecoverTest#testAcknowledgePerConsumer
+org.apache.qpid.test.unit.ack.FailoverBeforeConsumingRecoverTest#testRecoverResendsMsgs
+org.apache.qpid.test.unit.ack.FailoverBeforeConsumingRecoverTest#testRecoverResendsMsgsAckOnEarlier
+org.apache.qpid.test.unit.ack.FailoverBeforeConsumingRecoverTest#testAcknowledgePerConsumer
+
+// related to QPID-2471. These are new test cases and fail with the Java broker.
+org.apache.qpid.test.unit.ack.RecoverTest#testOderingWithAsyncConsumer
+org.apache.qpid.test.unit.ack.RecoverTest#testOderingWithSyncConsumer
+org.apache.qpid.test.unit.ack.FailoverBeforeConsumingRecoverTest#testOderingWithAsyncConsumer
+org.apache.qpid.test.unit.ack.FailoverBeforeConsumingRecoverTest#testOderingWithSyncConsumer
+
+org.apache.qpid.test.client.queue.LVQTest#*
+
+// Session resume is not supported in the Java client
+org.apache.qpid.transport.ConnectionTest#testResumeNonemptyReplayBuffer
+
+//QPID-2845: The queue policy types used by the C++ broker are not currently supported by the Java broker
+org.apache.qpid.test.client.queue.QueuePolicyTest#testRingPolicy
+org.apache.qpid.test.client.queue.QueuePolicyTest#testRejectPolicy
diff --git a/qpid/java/test-profiles/JavaInVMExcludes b/qpid/java/test-profiles/JavaInVMExcludes
new file mode 100644
index 0000000000..7960b28d81
--- /dev/null
+++ b/qpid/java/test-profiles/JavaInVMExcludes
@@ -0,0 +1,45 @@
+//
+// Licensed to the Apache Software Foundation (ASF) under one
+// or more contributor license agreements. See the NOTICE file
+// distributed with this work for additional information
+// regarding copyright ownership. The ASF licenses this file
+// to you under the Apache License, Version 2.0 (the
+// "License"); you may not use this file except in compliance
+// with the License. You may obtain a copy of the License at
+//
+// http://www.apache.org/licenses/LICENSE-2.0
+//
+// Unless required by applicable law or agreed to in writing,
+// software distributed under the License is distributed on an
+// "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+// KIND, either express or implied. See the License for the
+// specific language governing permissions and limitations
+// under the License.
+//
+
+//======================================================================
+//Exclude the following tests when running the InVM default test profile
+//======================================================================
+
+// The FirewallPlugin only operates for TCP connections, the tests NO-OP when run InVM
+org.apache.qpid.server.security.firewall.FirewallConfigTest#*
+
+// This test requires a broker capable of 0-8/9 and 0-10
+org.apache.qpid.test.client.message.JMSDestinationTest#testReceiveResend
+
+// QPID-2478 test fails when run against broker using 0-8/9
+org.apache.qpid.test.client.message.JMSDestinationTest#testGetDestinationWithCustomExchange
+
+// related to QPID-2471. Temporarily disabling these tests until I figure out why they are failing with the Java broker.
+org.apache.qpid.test.unit.ack.RecoverTest#testRecoverResendsMsgs
+org.apache.qpid.test.unit.ack.RecoverTest#testRecoverResendsMsgsAckOnEarlier
+org.apache.qpid.test.unit.ack.RecoverTest#testAcknowledgePerConsumer
+
+// related to QPID-2471. These are new test cases and fail with the Java broker.
+org.apache.qpid.test.unit.ack.RecoverTest#testOderingWithAsyncConsumer
+org.apache.qpid.test.unit.ack.RecoverTest#testOderingWithSyncConsumer
+
+//The VM broker does not export the logging management JMX MBean
+org.apache.qpid.server.security.acl.ExternalAdminACLTest#*
+
+org.apache.qpid.test.unit.message.JMSPropertiesTest#testGetPropertyNames
diff --git a/qpid/java/test-profiles/JavaPersistentExcludes b/qpid/java/test-profiles/JavaPersistentExcludes
new file mode 100644
index 0000000000..240f6dc330
--- /dev/null
+++ b/qpid/java/test-profiles/JavaPersistentExcludes
@@ -0,0 +1,21 @@
+//
+// Licensed to the Apache Software Foundation (ASF) under one
+// or more contributor license agreements. See the NOTICE file
+// distributed with this work for additional information
+// regarding copyright ownership. The ASF licenses this file
+// to you under the Apache License, Version 2.0 (the
+// "License"); you may not use this file except in compliance
+// with the License. You may obtain a copy of the License at
+//
+// http://www.apache.org/licenses/LICENSE-2.0
+//
+// Unless required by applicable law or agreed to in writing,
+// software distributed under the License is distributed on an
+// "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+// KIND, either express or implied. See the License for the
+// specific language governing permissions and limitations
+// under the License.
+//
+
+//These tests require the MemoryMessageStore
+org.apache.qpid.server.logging.MemoryMessageStoreLoggingTest#*
diff --git a/qpid/java/test-profiles/JavaStandaloneExcludes b/qpid/java/test-profiles/JavaStandaloneExcludes
new file mode 100644
index 0000000000..d208a20d15
--- /dev/null
+++ b/qpid/java/test-profiles/JavaStandaloneExcludes
@@ -0,0 +1,55 @@
+//
+// Licensed to the Apache Software Foundation (ASF) under one
+// or more contributor license agreements. See the NOTICE file
+// distributed with this work for additional information
+// regarding copyright ownership. The ASF licenses this file
+// to you under the Apache License, Version 2.0 (the
+// "License"); you may not use this file except in compliance
+// with the License. You may obtain a copy of the License at
+//
+// http://www.apache.org/licenses/LICENSE-2.0
+//
+// Unless required by applicable law or agreed to in writing,
+// software distributed under the License is distributed on an
+// "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+// KIND, either express or implied. See the License for the
+// specific language governing permissions and limitations
+// under the License.
+//
+
+// This is a long running test so should exclude from normal runs
+org.apache.qpid.test.client.failover.FailoverTest#test4MinuteFailover
+
+// Those tests require failover support
+org.apache.qpid.test.client.QueueBrowserAutoAckTest#testFailoverAsQueueBrowserCreated
+org.apache.qpid.test.client.QueueBrowserAutoAckTest#testFailoverWithQueueBrowser
+org.apache.qpid.test.client.QueueBrowserClientAckTest#testFailoverAsQueueBrowserCreated
+org.apache.qpid.test.client.QueueBrowserClientAckTest#testFailoverWithQueueBrowser
+org.apache.qpid.test.client.QueueBrowserDupsOkTest#testFailoverAsQueueBrowserCreated
+org.apache.qpid.test.client.QueueBrowserDupsOkTest#testFailoverWithQueueBrowser
+org.apache.qpid.test.client.QueueBrowserNoAckTest#testFailoverAsQueueBrowserCreated
+org.apache.qpid.test.client.QueueBrowserNoAckTest#testFailoverWithQueueBrowser
+org.apache.qpid.test.client.QueueBrowserPreAckTest#testFailoverAsQueueBrowserCreated
+org.apache.qpid.test.client.QueueBrowserPreAckTest#testFailoverWithQueueBrowser
+org.apache.qpid.test.client.QueueBrowserTransactedTest#testFailoverAsQueueBrowserCreated
+org.apache.qpid.test.client.QueueBrowserTransactedTest#testFailoverWithQueueBrowser
+org.apache.qpid.test.testcases.FailoverTest#*
+org.apache.qpid.test.client.failover.FailoverTest#*
+
+// InVM Broker tests awaiting resolution of QPID-1103
+org.apache.qpid.test.client.timeouts.SyncWaitDelayTest#*
+org.apache.qpid.test.client.timeouts.SyncWaitTimeoutDelayTest#*
+
+// This test currently does not pick up the runtime location of the nonVm queueBacking store.
+org.apache.qpid.test.unit.close.FlowToDiskBackingQueueDeleteTest#*
+
+// This test may use QpidTestCase but it is not using the getConnection and is hardwired to InVM
+org.apache.qpid.test.unit.client.connection.CloseAfterConnectionFailureTest#*
+
+//QPID-1818 : Client code path does not correctly restore a transacted session after failover.
+org.apache.qpid.server.persistent.NoLocalAfterRecoveryTest#*
+
+// This test requires the standard configuration file for validation.
+// Excluding here does not reduce test coverage.
+org.apache.qpid.server.configuration.ServerConfigurationFileTest#*
+
diff --git a/qpid/java/test-profiles/JavaTransientExcludes b/qpid/java/test-profiles/JavaTransientExcludes
new file mode 100644
index 0000000000..2ea46795d9
--- /dev/null
+++ b/qpid/java/test-profiles/JavaTransientExcludes
@@ -0,0 +1,32 @@
+//
+// Licensed to the Apache Software Foundation (ASF) under one
+// or more contributor license agreements. See the NOTICE file
+// distributed with this work for additional information
+// regarding copyright ownership. The ASF licenses this file
+// to you under the Apache License, Version 2.0 (the
+// "License"); you may not use this file except in compliance
+// with the License. You may obtain a copy of the License at
+//
+// http://www.apache.org/licenses/LICENSE-2.0
+//
+// Unless required by applicable law or agreed to in writing,
+// software distributed under the License is distributed on an
+// "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+// KIND, either express or implied. See the License for the
+// specific language governing permissions and limitations
+// under the License.
+//
+
+//These tests require a persistent store
+org.apache.qpid.server.store.PersistentStoreTest#*
+
+org.apache.qpid.test.unit.ct.DurableSubscriberTest#*
+
+org.apache.qpid.server.store.MessageStoreTest#testMessagePersistence
+org.apache.qpid.server.store.MessageStoreTest#testMessageRemoval
+org.apache.qpid.server.store.MessageStoreTest#testBindingPersistence
+org.apache.qpid.server.store.MessageStoreTest#testDurableBindingRemoval
+org.apache.qpid.server.store.MessageStoreTest#testQueuePersistence
+org.apache.qpid.server.store.MessageStoreTest#testDurableQueueRemoval
+org.apache.qpid.server.store.MessageStoreTest#testExchangePersistence
+org.apache.qpid.server.store.MessageStoreTest#testDurableExchangeRemoval
diff --git a/qpid/java/test-profiles/XAExcludes b/qpid/java/test-profiles/XAExcludes
new file mode 100644
index 0000000000..907864a730
--- /dev/null
+++ b/qpid/java/test-profiles/XAExcludes
@@ -0,0 +1,22 @@
+//
+// Licensed to the Apache Software Foundation (ASF) under one
+// or more contributor license agreements. See the NOTICE file
+// distributed with this work for additional information
+// regarding copyright ownership. The ASF licenses this file
+// to you under the Apache License, Version 2.0 (the
+// "License"); you may not use this file except in compliance
+// with the License. You may obtain a copy of the License at
+//
+// http://www.apache.org/licenses/LICENSE-2.0
+//
+// Unless required by applicable law or agreed to in writing,
+// software distributed under the License is distributed on an
+// "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+// KIND, either express or implied. See the License for the
+// specific language governing permissions and limitations
+// under the License.
+//
+
+org.apache.qpid.test.unit.xa.QueueTest#*
+org.apache.qpid.test.unit.xa.TopicTest#*
+org.apache.qpid.test.unit.xa.FaultTest#*
diff --git a/qpid/java/test-profiles/clean-dir b/qpid/java/test-profiles/clean-dir
new file mode 100755
index 0000000000..4d6141b4ab
--- /dev/null
+++ b/qpid/java/test-profiles/clean-dir
@@ -0,0 +1,25 @@
+
+#!/bin/bash
+#
+#
+# Licensed to the Apache Software Foundation (ASF) under one
+# or more contributor license agreements. See the NOTICE file
+# distributed with this work for additional information
+# regarding copyright ownership. The ASF licenses this file
+# to you under the Apache License, Version 2.0 (the
+# "License"); you may not use this file except in compliance
+# with the License. You may obtain a copy of the License at
+#
+# http://www.apache.org/licenses/LICENSE-2.0
+#
+# Unless required by applicable law or agreed to in writing,
+# software distributed under the License is distributed on an
+# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+# KIND, either express or implied. See the License for the
+# specific language governing permissions and limitations
+# under the License.
+#
+#
+
+
+rm -rf $@; mkdir $@
diff --git a/qpid/java/test-profiles/cpp.async.excludes b/qpid/java/test-profiles/cpp.async.excludes
new file mode 100644
index 0000000000..d700538345
--- /dev/null
+++ b/qpid/java/test-profiles/cpp.async.excludes
@@ -0,0 +1,21 @@
+//
+// Licensed to the Apache Software Foundation (ASF) under one
+// or more contributor license agreements. See the NOTICE file
+// distributed with this work for additional information
+// regarding copyright ownership. The ASF licenses this file
+// to you under the Apache License, Version 2.0 (the
+// "License"); you may not use this file except in compliance
+// with the License. You may obtain a copy of the License at
+//
+// http://www.apache.org/licenses/LICENSE-2.0
+//
+// Unless required by applicable law or agreed to in writing,
+// software distributed under the License is distributed on an
+// "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+// KIND, either express or implied. See the License for the
+// specific language governing permissions and limitations
+// under the License.
+//
+
+// the C++ broker doesn't guarantee the order of messages on recovery
+org.apache.qpid.test.unit.xa.TopicTest#testMultiMessagesDurSubCrash
diff --git a/qpid/java/test-profiles/cpp.async.testprofile b/qpid/java/test-profiles/cpp.async.testprofile
new file mode 100644
index 0000000000..c3d47f0ce6
--- /dev/null
+++ b/qpid/java/test-profiles/cpp.async.testprofile
@@ -0,0 +1,21 @@
+#
+# Licensed to the Apache Software Foundation (ASF) under one
+# or more contributor license agreements. See the NOTICE file
+# distributed with this work for additional information
+# regarding copyright ownership. The ASF licenses this file
+# to you under the Apache License, Version 2.0 (the
+# "License"); you may not use this file except in compliance
+# with the License. You may obtain a copy of the License at
+#
+# http://www.apache.org/licenses/LICENSE-2.0
+#
+# Unless required by applicable law or agreed to in writing,
+# software distributed under the License is distributed on an
+# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+# KIND, either express or implied. See the License for the
+# specific language governing permissions and limitations
+# under the License.
+#
+include=cpp
+profile.excludes=CPPPrefetchExcludes
+broker.modules=--load-module ${broker.module.store}
diff --git a/qpid/java/test-profiles/cpp.cluster.testprofile b/qpid/java/test-profiles/cpp.cluster.testprofile
new file mode 100644
index 0000000000..22a082e85b
--- /dev/null
+++ b/qpid/java/test-profiles/cpp.cluster.testprofile
@@ -0,0 +1,28 @@
+#
+# Licensed to the Apache Software Foundation (ASF) under one
+# or more contributor license agreements. See the NOTICE file
+# distributed with this work for additional information
+# regarding copyright ownership. The ASF licenses this file
+# to you under the Apache License, Version 2.0 (the
+# "License"); you may not use this file except in compliance
+# with the License. You may obtain a copy of the License at
+#
+# http://www.apache.org/licenses/LICENSE-2.0
+#
+# Unless required by applicable law or agreed to in writing,
+# software distributed under the License is distributed on an
+# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+# KIND, either express or implied. See the License for the
+# specific language governing permissions and limitations
+# under the License.
+#
+include=cpp
+
+broker.modules=--load-module ${broker.module.cluster} --cluster-name cpp-java-test-cluster
+
+profile.excludes=XAExcludes CPPPrefetchExcludes CPPTransientExcludes
+
+profile.clustered=true
+profile.failoverMsgCount=10
+profile.failoverIterations=10
+profile.failoverRandomSeed=20080921
diff --git a/qpid/java/test-profiles/cpp.excludes b/qpid/java/test-profiles/cpp.excludes
new file mode 100644
index 0000000000..c8fae1797e
--- /dev/null
+++ b/qpid/java/test-profiles/cpp.excludes
@@ -0,0 +1,29 @@
+//
+// Licensed to the Apache Software Foundation (ASF) under one
+// or more contributor license agreements. See the NOTICE file
+// distributed with this work for additional information
+// regarding copyright ownership. The ASF licenses this file
+// to you under the Apache License, Version 2.0 (the
+// "License"); you may not use this file except in compliance
+// with the License. You may obtain a copy of the License at
+//
+// http://www.apache.org/licenses/LICENSE-2.0
+//
+// Unless required by applicable law or agreed to in writing,
+// software distributed under the License is distributed on an
+// "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+// KIND, either express or implied. See the License for the
+// specific language governing permissions and limitations
+// under the License.
+//
+
+//======================================================================
+//Exclude the following tests when running all cpp test profilies
+//======================================================================
+
+// This test requires JMX interface to move messages
+org.apache.qpid.test.client.message.JMSDestinationTest#testMovedToQueue
+
+// This test requires a broker capable of 0-8/9 and 0-10
+org.apache.qpid.test.client.message.JMSDestinationTest#testReceiveResend
+
diff --git a/qpid/java/test-profiles/cpp.noprefetch.testprofile b/qpid/java/test-profiles/cpp.noprefetch.testprofile
new file mode 100644
index 0000000000..4764cb576b
--- /dev/null
+++ b/qpid/java/test-profiles/cpp.noprefetch.testprofile
@@ -0,0 +1,21 @@
+#
+# Licensed to the Apache Software Foundation (ASF) under one
+# or more contributor license agreements. See the NOTICE file
+# distributed with this work for additional information
+# regarding copyright ownership. The ASF licenses this file
+# to you under the Apache License, Version 2.0 (the
+# "License"); you may not use this file except in compliance
+# with the License. You may obtain a copy of the License at
+#
+# http://www.apache.org/licenses/LICENSE-2.0
+#
+# Unless required by applicable law or agreed to in writing,
+# software distributed under the License is distributed on an
+# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+# KIND, either express or implied. See the License for the
+# specific language governing permissions and limitations
+# under the License.
+#
+include=cpp
+profile.excludes=CPPTransientExcludes CPPNoPrefetchExcludes
+max_prefetch=0
diff --git a/qpid/java/test-profiles/cpp.ssl.excludes b/qpid/java/test-profiles/cpp.ssl.excludes
new file mode 100644
index 0000000000..4d499c57b9
--- /dev/null
+++ b/qpid/java/test-profiles/cpp.ssl.excludes
@@ -0,0 +1,20 @@
+//
+// Licensed to the Apache Software Foundation (ASF) under one
+// or more contributor license agreements. See the NOTICE file
+// distributed with this work for additional information
+// regarding copyright ownership. The ASF licenses this file
+// to you under the Apache License, Version 2.0 (the
+// "License"); you may not use this file except in compliance
+// with the License. You may obtain a copy of the License at
+//
+// http://www.apache.org/licenses/LICENSE-2.0
+//
+// Unless required by applicable law or agreed to in writing,
+// software distributed under the License is distributed on an
+// "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+// KIND, either express or implied. See the License for the
+// specific language governing permissions and limitations
+// under the License.
+//
+
+#org.apache.qpid.test.client.failover.FailoverTest#*
diff --git a/qpid/java/test-profiles/cpp.ssl.testprofile b/qpid/java/test-profiles/cpp.ssl.testprofile
new file mode 100644
index 0000000000..bf71384835
--- /dev/null
+++ b/qpid/java/test-profiles/cpp.ssl.testprofile
@@ -0,0 +1,29 @@
+#
+# Licensed to the Apache Software Foundation (ASF) under one
+# or more contributor license agreements. See the NOTICE file
+# distributed with this work for additional information
+# regarding copyright ownership. The ASF licenses this file
+# to you under the Apache License, Version 2.0 (the
+# "License"); you may not use this file except in compliance
+# with the License. You may obtain a copy of the License at
+#
+# http://www.apache.org/licenses/LICENSE-2.0
+#
+# Unless required by applicable law or agreed to in writing,
+# software distributed under the License is distributed on an
+# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+# KIND, either express or implied. See the License for the
+# specific language governing permissions and limitations
+# under the License.
+#
+include=cpp
+
+broker.modules=--load-module ${broker.module.ssl} --ssl-cert-name localhost.localdomain --ssl-cert-password-file ${test.profiles}/test_resources/ssl/pfile --ssl-cert-db ${test.profiles}/test_resources/ssl/server_db/ --ssl-require-client-authentication --ssl-port @SSL_PORT
+
+profile.use_ssl=true
+broker.ready= Listening for SSL connections
+
+javax.net.ssl.keyStore=${test.profiles}/test_resources/ssl/keystore.jks
+javax.net.ssl.keyStorePassword=password
+javax.net.ssl.trustStore=${test.profiles}/test_resources/ssl/certstore.jks
+javax.net.ssl.trustStorePassword=password
diff --git a/qpid/java/test-profiles/cpp.testprofile b/qpid/java/test-profiles/cpp.testprofile
new file mode 100644
index 0000000000..694e22f48c
--- /dev/null
+++ b/qpid/java/test-profiles/cpp.testprofile
@@ -0,0 +1,38 @@
+#
+# Licensed to the Apache Software Foundation (ASF) under one
+# or more contributor license agreements. See the NOTICE file
+# distributed with this work for additional information
+# regarding copyright ownership. The ASF licenses this file
+# to you under the Apache License, Version 2.0 (the
+# "License"); you may not use this file except in compliance
+# with the License. You may obtain a copy of the License at
+#
+# http://www.apache.org/licenses/LICENSE-2.0
+#
+# Unless required by applicable law or agreed to in writing,
+# software distributed under the License is distributed on an
+# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+# KIND, either express or implied. See the License for the
+# specific language governing permissions and limitations
+# under the License.
+#
+broker.version=0-10
+broker.language=cpp
+
+broker.dir=${project.root}/../cpp/src
+module.dir=${broker.dir}/.libs
+store.module.dir=${project.root}/../../cppStore/cpp/lib/.libs
+
+broker.executable=${broker.dir}/qpidd
+broker.module.ssl=${module.dir}/ssl.so
+broker.module.cluster=${module.dir}/cluster.so
+broker.module.store=${store.module.dir}/msgstore.so
+broker.stopped=Exception constructed
+
+broker.modules=
+broker.args=
+
+broker=${broker.executable} -p @PORT --data-dir ${build.data}/@PORT -t --auth no --no-module-dir ${broker.modules} ${broker.args}
+
+profile.excludes=CPPPrefetchExcludes CPPTransientExcludes
+test.excludes=Excludes CPPExcludes ${profile}.excludes ${profile.excludes} cpp.excludes
diff --git a/qpid/java/test-profiles/default.testprofile b/qpid/java/test-profiles/default.testprofile
new file mode 100644
index 0000000000..df8148f787
--- /dev/null
+++ b/qpid/java/test-profiles/default.testprofile
@@ -0,0 +1,61 @@
+#
+# Licensed to the Apache Software Foundation (ASF) under one
+# or more contributor license agreements. See the NOTICE file
+# distributed with this work for additional information
+# regarding copyright ownership. The ASF licenses this file
+# to you under the Apache License, Version 2.0 (the
+# "License"); you may not use this file except in compliance
+# with the License. You may obtain a copy of the License at
+#
+# http://www.apache.org/licenses/LICENSE-2.0
+#
+# Unless required by applicable law or agreed to in writing,
+# software distributed under the License is distributed on an
+# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+# KIND, either express or implied. See the License for the
+# specific language governing permissions and limitations
+# under the License.
+#
+java.naming.factory.initial=org.apache.qpid.jndi.PropertiesFileInitialContextFactory
+java.naming.provider.url=${test.profiles}/test-provider.properties
+
+broker.version=0-8
+broker=vm
+broker.clean=${test.profiles}/clean-dir ${build.data} ${project.root}/build/work
+broker.ready=Listening on TCP port
+broker.start=${test.profiles}/start-broker
+broker.kill=${test.profiles}/kill-broker
+broker.config=${project.root}/build/etc/config-systests.xml
+messagestore.class.name=org.apache.qpid.server.store.MemoryMessageStore
+
+max_prefetch=1000
+qpid.dest_syntax=BURL
+
+log=debug
+amqj.logging.level=${log}
+amqj.server.logging.level=${log}
+amqj.protocol.logging.level=${log}
+root.logging.level=warn
+log4j.configuration=file:///${test.profiles}/log4j-test.xml
+log4j.debug=false
+
+# Note test-provider.properties also has variables of same name.
+# Keep in sync
+test.port=15672
+test.mport=18999
+#Note : Management will start open second port on: mport + 100 : 19099
+test.port.ssl=15671
+test.port.alt=25672
+test.port.alt.ssl=25671
+
+test.exclude=true
+profile.excludes=JavaTransientExcludes JavaInVMExcludes 08StandaloneExcludes
+test.excludes=Excludes XAExcludes JavaExcludes ${profile}.excludes ${profile.excludes}
+test.fork=no
+test.mem=512M
+test=*Test
+haltonfailure=no
+haltonerror=no
+exclude.modules=none
+
+profile.clustered=false
diff --git a/qpid/java/test-profiles/java-derby.0.10.testprofile b/qpid/java/test-profiles/java-derby.0.10.testprofile
new file mode 100644
index 0000000000..ca9115d30d
--- /dev/null
+++ b/qpid/java/test-profiles/java-derby.0.10.testprofile
@@ -0,0 +1,29 @@
+#
+# Licensed to the Apache Software Foundation (ASF) under one
+# or more contributor license agreements. See the NOTICE file
+# distributed with this work for additional information
+# regarding copyright ownership. The ASF licenses this file
+# to you under the Apache License, Version 2.0 (the
+# "License"); you may not use this file except in compliance
+# with the License. You may obtain a copy of the License at
+#
+# http://www.apache.org/licenses/LICENSE-2.0
+#
+# Unless required by applicable law or agreed to in writing,
+# software distributed under the License is distributed on an
+# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+# KIND, either express or implied. See the License for the
+# specific language governing permissions and limitations
+# under the License.
+#
+broker.language=java
+broker.version=0-10
+broker=${project.root}/build/bin/qpid-server -p @PORT -m @MPORT -c @CONFIG_FILE -l ${test.profiles}/log4j-test.xml
+broker.clean=${test.profiles}/clean-dir ${build.data} ${project.root}/build/work
+broker.ready=BRK-1004
+broker.stopped=Exception
+broker.config=${project.root}/build/etc/config-systests-derby.xml
+messagestore.class.name=org.apache.qpid.server.store.DerbyMessageStore
+profile.excludes=JavaStandaloneExcludes JavaPersistentExcludes Java010Excludes
+broker.clean.between.tests=true
+broker.persistent=true
diff --git a/qpid/java/test-profiles/java-derby.testprofile b/qpid/java/test-profiles/java-derby.testprofile
new file mode 100644
index 0000000000..d22e35f07e
--- /dev/null
+++ b/qpid/java/test-profiles/java-derby.testprofile
@@ -0,0 +1,33 @@
+#
+# Licensed to the Apache Software Foundation (ASF) under one
+# or more contributor license agreements. See the NOTICE file
+# distributed with this work for additional information
+# regarding copyright ownership. The ASF licenses this file
+# to you under the Apache License, Version 2.0 (the
+# "License"); you may not use this file except in compliance
+# with the License. You may obtain a copy of the License at
+#
+# http://www.apache.org/licenses/LICENSE-2.0
+#
+# Unless required by applicable law or agreed to in writing,
+# software distributed under the License is distributed on an
+# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+# KIND, either express or implied. See the License for the
+# specific language governing permissions and limitations
+# under the License.
+#
+broker.language=java
+broker=${project.root}/build/bin/qpid-server -p @PORT -m @MPORT --exclude-0-10 @PORT -c @CONFIG_FILE -l ${test.profiles}/log4j-test.xml
+broker.clean=${test.profiles}/clean-dir ${build.data} ${project.root}/build/work
+broker.ready=BRK-1004
+broker.stopped=Exception
+broker.config=${project.root}/build/etc/config-systests-derby.xml
+messagestore.class.name=org.apache.qpid.server.store.DerbyMessageStore
+profile.excludes=JavaStandaloneExcludes JavaPersistentExcludes 08StandaloneExcludes
+broker.clean.between.tests=true
+broker.persistent=true
+#
+# Do not enable. Allow client to attempt 0-10 and negotiate downwards
+#
+#qpid.amqp.version=0-91
+
diff --git a/qpid/java/test-profiles/java.0.10.testprofile b/qpid/java/test-profiles/java.0.10.testprofile
new file mode 100644
index 0000000000..fa87b22e92
--- /dev/null
+++ b/qpid/java/test-profiles/java.0.10.testprofile
@@ -0,0 +1,26 @@
+#
+# Licensed to the Apache Software Foundation (ASF) under one
+# or more contributor license agreements. See the NOTICE file
+# distributed with this work for additional information
+# regarding copyright ownership. The ASF licenses this file
+# to you under the Apache License, Version 2.0 (the
+# "License"); you may not use this file except in compliance
+# with the License. You may obtain a copy of the License at
+#
+# http://www.apache.org/licenses/LICENSE-2.0
+#
+# Unless required by applicable law or agreed to in writing,
+# software distributed under the License is distributed on an
+# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+# KIND, either express or implied. See the License for the
+# specific language governing permissions and limitations
+# under the License.
+#
+broker.language=java
+broker.version=0-10
+broker=${project.root}/build/bin/qpid-server -p @PORT -m @MPORT -c @CONFIG_FILE -l ${test.profiles}/log4j-test.xml
+broker.clean=${test.profiles}/clean-dir ${build.data} ${project.root}/build/work
+broker.ready=BRK-1004
+broker.stopped=Exception
+
+profile.excludes=JavaTransientExcludes JavaStandaloneExcludes Java010Excludes
diff --git a/qpid/java/test-profiles/java.testprofile b/qpid/java/test-profiles/java.testprofile
new file mode 100644
index 0000000000..c8c776d3e1
--- /dev/null
+++ b/qpid/java/test-profiles/java.testprofile
@@ -0,0 +1,28 @@
+#
+# Licensed to the Apache Software Foundation (ASF) under one
+# or more contributor license agreements. See the NOTICE file
+# distributed with this work for additional information
+# regarding copyright ownership. The ASF licenses this file
+# to you under the Apache License, Version 2.0 (the
+# "License"); you may not use this file except in compliance
+# with the License. You may obtain a copy of the License at
+#
+# http://www.apache.org/licenses/LICENSE-2.0
+#
+# Unless required by applicable law or agreed to in writing,
+# software distributed under the License is distributed on an
+# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+# KIND, either express or implied. See the License for the
+# specific language governing permissions and limitations
+# under the License.
+#
+broker.language=java
+broker=${project.root}/build/bin/qpid-server -p @PORT -m @MPORT --exclude-0-10 @PORT -c @CONFIG_FILE -l ${test.profiles}/log4j-test.xml
+broker.clean=${test.profiles}/clean-dir ${build.data} ${project.root}/build/work
+broker.ready=BRK-1004
+broker.stopped=Exception
+#
+# Do not enable. Allow client to attempt 0-10 and negotiate downwards
+#
+#qpid.amqp.version=0-91
+profile.excludes=JavaTransientExcludes JavaStandaloneExcludes 08StandaloneExcludes
diff --git a/qpid/java/test-profiles/kill-broker b/qpid/java/test-profiles/kill-broker
new file mode 100755
index 0000000000..8078fa755e
--- /dev/null
+++ b/qpid/java/test-profiles/kill-broker
@@ -0,0 +1,26 @@
+
+#!/bin/bash
+#
+#
+# Licensed to the Apache Software Foundation (ASF) under one
+# or more contributor license agreements. See the NOTICE file
+# distributed with this work for additional information
+# regarding copyright ownership. The ASF licenses this file
+# to you under the Apache License, Version 2.0 (the
+# "License"); you may not use this file except in compliance
+# with the License. You may obtain a copy of the License at
+#
+# http://www.apache.org/licenses/LICENSE-2.0
+#
+# Unless required by applicable law or agreed to in writing,
+# software distributed under the License is distributed on an
+# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+# KIND, either express or implied. See the License for the
+# specific language governing permissions and limitations
+# under the License.
+#
+#
+
+kill -CONT $1
+kill -9 $1
+rm /tmp/broker.log
diff --git a/qpid/java/test-profiles/log4j-test.xml b/qpid/java/test-profiles/log4j-test.xml
new file mode 100644
index 0000000000..9adfd68202
--- /dev/null
+++ b/qpid/java/test-profiles/log4j-test.xml
@@ -0,0 +1,70 @@
+<?xml version="1.0" encoding="UTF-8" ?>
+<!--
+ Licensed to the Apache Software Foundation (ASF) under one
+ or more contributor license agreements. See the NOTICE file
+ distributed with this work for additional information
+ regarding copyright ownership. The ASF licenses this file
+ to you under the Apache License, Version 2.0 (the
+ "License"); you may not use this file except in compliance
+ with the License. You may obtain a copy of the License at
+
+ http://www.apache.org/licenses/LICENSE-2.0
+
+ Unless required by applicable law or agreed to in writing,
+ software distributed under the License is distributed on an
+ "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ KIND, either express or implied. See the License for the
+ specific language governing permissions and limitations
+ under the License.
+-->
+
+<!DOCTYPE log4j:configuration SYSTEM "log4j.dtd">
+
+<!-- ===================================================================== -->
+<!-- -->
+<!-- Log4j configuration for unit tests -->
+<!-- -->
+<!-- ===================================================================== -->
+
+<log4j:configuration xmlns:log4j="http://jakarta.apache.org/log4j/">
+ <appender name="console" class="org.apache.log4j.ConsoleAppender">
+ <param name="Target" value="System.out"/>
+ <param name="ImmediateFlush" value="true"/>
+ <layout class="org.apache.log4j.PatternLayout">
+ <param name="ConversionPattern" value="%t %d %p [%c{4}] %m%n"/>
+ </layout>
+ </appender>
+
+ <logger name="org.apache.qpid">
+ <level value="${amqj.logging.level}"/>
+ </logger>
+
+ <logger name="qpid.message">
+ <level value="INFO"/>
+ </logger>
+
+ <logger name="qpid.protocol">
+ <level value="${amqj.protocol.logging.level}"/>
+ </logger>
+
+ <logger name="org.apache.qpid.test.utils.QpidTestCase">
+ <level value="ALL"/>
+ </logger>
+
+ <logger name="org.apache.commons">
+ <level value="WARN"/>
+ </logger>
+
+ <logger name="apache.commons.configuration.ConfigurationFactory">
+ <level value="ERROR"/>
+ </logger>
+
+ <logger name="org.apache.qpid.server.virtualhost.VirtualHostImpl$1HouseKeepingTask">
+ <level value="WARN"/>
+ </logger>
+
+ <root>
+ <level value="${root.logging.level}"/>
+ <appender-ref ref="console" />
+ </root>
+</log4j:configuration>
diff --git a/qpid/java/test-profiles/start-broker b/qpid/java/test-profiles/start-broker
new file mode 100755
index 0000000000..e0bbb89d87
--- /dev/null
+++ b/qpid/java/test-profiles/start-broker
@@ -0,0 +1,37 @@
+
+#!/bin/bash
+#
+#
+# Licensed to the Apache Software Foundation (ASF) under one
+# or more contributor license agreements. See the NOTICE file
+# distributed with this work for additional information
+# regarding copyright ownership. The ASF licenses this file
+# to you under the Apache License, Version 2.0 (the
+# "License"); you may not use this file except in compliance
+# with the License. You may obtain a copy of the License at
+#
+# http://www.apache.org/licenses/LICENSE-2.0
+#
+# Unless required by applicable law or agreed to in writing,
+# software distributed under the License is distributed on an
+# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+# KIND, either express or implied. See the License for the
+# specific language governing permissions and limitations
+# under the License.
+#
+#
+
+# The entire broker command is passed as an argument.
+
+waitfor() {
+ until grep -a -l "$2" $1 >/dev/null 2>&1
+ do
+ if [ $count == 10 ]; then return; fi;
+ sleep 1 ;
+ count=`expr $count + 1`;
+ done
+ }
+
+sh $BROKER_CMD --log-to-file /tmp/broker.log &
+waitfor /tmp/broker.log $BROKER_READY
+
diff --git a/qpid/java/test-profiles/test-provider.properties b/qpid/java/test-profiles/test-provider.properties
new file mode 100644
index 0000000000..8cea012c1d
--- /dev/null
+++ b/qpid/java/test-profiles/test-provider.properties
@@ -0,0 +1,51 @@
+#
+#
+# Licensed to the Apache Software Foundation (ASF) under one
+# or more contributor license agreements. See the NOTICE file
+# distributed with this work for additional information
+# regarding copyright ownership. The ASF licenses this file
+# to you under the Apache License, Version 2.0 (the
+# "License"); you may not use this file except in compliance
+# with the License. You may obtain a copy of the License at
+#
+# http://www.apache.org/licenses/LICENSE-2.0
+#
+# Unless required by applicable law or agreed to in writing,
+# software distributed under the License is distributed on an
+# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+# KIND, either express or implied. See the License for the
+# specific language governing permissions and limitations
+# under the License.
+#
+#
+
+# Copied from default.testprofile
+test.port=15672
+test.mport=18999
+#Note : Java Management will start open second port on: mport + 100 : 19099
+test.port.ssl=15671
+test.port.alt=25672
+test.port.alt.ssl=25671
+
+
+connectionfactory.default = amqp://username:password@clientid/test?brokerlist='tcp://localhost:${test.port}'
+connectionfactory.default.ssl = amqp://username:password@clientid/test?brokerlist='tcp://localhost:${test.port.ssl}?ssl='true''
+connectionfactory.default.vm = amqp://username:password@clientid/test?brokerlist='vm://:1'
+
+connectionfactory.failover = amqp://username:password@clientid/test?brokerlist='tcp://localhost:${test.port.alt};tcp://localhost:${test.port}'&sync_ack='true'&sync_publish='all'&failover='roundrobin?cyclecount='20''
+connectionfactory.failover.ssl = amqp://username:password@clientid/test?brokerlist='tcp://localhost:${test.port.alt.ssl}?ssl='true';tcp://localhost:${test.port.ssl}?ssl='true''&sync_ack='true'&sync_publish='all'&failover='roundrobin?cyclecount='20''
+connectionfactory.failover.vm = amqp://username:password@clientid/test?brokerlist='vm://:2;vm://:1'&failover='roundrobin?cyclecount='20''
+
+connectionfactory.connection1 = amqp://username:password@clientid/test?brokerlist='tcp://localhost:${test.port}'
+connectionfactory.connection2 = amqp://username:password@clientid/test?brokerlist='tcp://localhost:${test.port.alt}'
+connectionfactory.connection1.vm = amqp://username:password@clientid/test?brokerlist='vm://:1'
+connectionfactory.connection2.vm = amqp://username:password@clientid/test?brokerlist='vm://:2'
+
+
+queue.MyQueue = example.MyQueue
+queue.queue = example.queue
+queue.xaQueue = xaQueue
+
+topic.topic = topic
+topic.xaTopic = xaTopic
+topic.durableSubscriberTopic = durableSubscriberTopic
diff --git a/qpid/java/test-profiles/test_resources/ssl/CA_db/cert8.db b/qpid/java/test-profiles/test_resources/ssl/CA_db/cert8.db
new file mode 100644
index 0000000000..846e59e82d
--- /dev/null
+++ b/qpid/java/test-profiles/test_resources/ssl/CA_db/cert8.db
Binary files differ
diff --git a/qpid/java/test-profiles/test_resources/ssl/CA_db/key3.db b/qpid/java/test-profiles/test_resources/ssl/CA_db/key3.db
new file mode 100644
index 0000000000..dd60e1e05e
--- /dev/null
+++ b/qpid/java/test-profiles/test_resources/ssl/CA_db/key3.db
Binary files differ
diff --git a/qpid/java/test-profiles/test_resources/ssl/CA_db/rootca.crt b/qpid/java/test-profiles/test_resources/ssl/CA_db/rootca.crt
new file mode 100644
index 0000000000..d9cdd9891c
--- /dev/null
+++ b/qpid/java/test-profiles/test_resources/ssl/CA_db/rootca.crt
@@ -0,0 +1,13 @@
+-----BEGIN CERTIFICATE-----
+MIICDDCCAXWgAwIBAgIFAJBNP3QwDQYJKoZIhvcNAQEFBQAwQTELMAkGA1UEBhMC
+Q0ExEDAOBgNVBAgTB09udGFyaW8xDTALBgNVBAoTBEFDTUUxETAPBgNVBAMTCE15
+Um9vdENBMB4XDTEwMDMyMjIxMDAyMloXDTE1MDMyMjIxMDAyMlowQTELMAkGA1UE
+BhMCQ0ExEDAOBgNVBAgTB09udGFyaW8xDTALBgNVBAoTBEFDTUUxETAPBgNVBAMT
+CE15Um9vdENBMIGfMA0GCSqGSIb3DQEBAQUAA4GNADCBiQKBgQDICe+SkXU9NRCk
+s+Tmai/j+3uDfJ4mVEt4PRkRWTVVHvuMvbPfKhdBRYRM5wmQmSCOi25Xd9jnh3PF
+BwE+pfaSgVqQiilUYqYak56ZR1Ll0nGwyXZQnW3lTf9VboEl0p67qckcd8SmaJf2
+0lAlTu2W7kJ8whYYyYRqaw+3yA6dGQIDAQABoxAwDjAMBgNVHRMEBTADAQH/MA0G
+CSqGSIb3DQEBBQUAA4GBADUbCNoxvFbPv+vqfQJ59p8P0cArEPajHR51omE1BbLc
+TfouOIidiBORf1n8DzE7k2Pf//nUHWhJLBP7J7CMs18UYsDD+0aa9A3BZi4wcsYX
+AW9EiXAIhnCk2+yyZyI1gdOnRS/9aOBRFSa1ngCb9GLm4kFzakiDQ1iX7k9dk17p
+-----END CERTIFICATE-----
diff --git a/qpid/java/test-profiles/test_resources/ssl/CA_db/secmod.db b/qpid/java/test-profiles/test_resources/ssl/CA_db/secmod.db
new file mode 100644
index 0000000000..a13e3e602c
--- /dev/null
+++ b/qpid/java/test-profiles/test_resources/ssl/CA_db/secmod.db
Binary files differ
diff --git a/qpid/java/test-profiles/test_resources/ssl/app1.crt b/qpid/java/test-profiles/test_resources/ssl/app1.crt
new file mode 100644
index 0000000000..c04b07fce8
--- /dev/null
+++ b/qpid/java/test-profiles/test_resources/ssl/app1.crt
@@ -0,0 +1,15 @@
+-----BEGIN CERTIFICATE-----
+MIICPjCCAaegAwIBAgIFAJJRUVUwDQYJKoZIhvcNAQEFBQAwQTELMAkGA1UEBhMC
+Q0ExEDAOBgNVBAgTB09udGFyaW8xDTALBgNVBAoTBEFDTUUxETAPBgNVBAMTCE15
+Um9vdENBMB4XDTEwMTAxNDAyMzM1NloXDTE1MTAxNDAyMzM1NlowYTELMAkGA1UE
+BhMCQ0ExCzAJBgNVBAgTAk9OMRAwDgYDVQQHEwdUb3JvbnRvMQ0wCwYDVQQKEwRh
+Y21lMQwwCgYDVQQLEwNhcnQxFjAUBgNVBAMMDWFwcDFAYWNtZS5vcmcwgZ8wDQYJ
+KoZIhvcNAQEBBQADgY0AMIGJAoGBAIlYzFnmAsv/Ci4rgp3sWwkFGFYEBwiXx0Xz
+auZ10nrOUz6Ce2FGVQBYFA09zi79iUyn86oLuTY0Kc/1emCZEPkmOW+hw1uk/TxG
+5MqpEOZdsDv4xIqBHgtWv/d3kGubwSS5lia1l6EPvnzHvsQSM//xhkrJaF0fAHx5
+FMkilnvfAgMBAAGjIjAgMAkGA1UdEwQCMAAwEwYDVR0lBAwwCgYIKwYBBQUHAwIw
+DQYJKoZIhvcNAQEFBQADgYEAJ47Q/4/hJMwTTpfcojv9KbZUTrve/wkabUrytNf3
+ogqhaIzgUr+vA9EMBc91Jg1WJC/0VMmTrTEggqrgd/prg4xcyATQOwNR1TiaWC4E
+r3pWEpZZnEJSd4vtcciNFNsbuAt2m4Nc90gPNXKgNoe0+3nuxPLs/TIauwOSDF+I
+oiw=
+-----END CERTIFICATE-----
diff --git a/qpid/java/test-profiles/test_resources/ssl/app1.req b/qpid/java/test-profiles/test_resources/ssl/app1.req
new file mode 100644
index 0000000000..b4f1ff9a2c
--- /dev/null
+++ b/qpid/java/test-profiles/test_resources/ssl/app1.req
@@ -0,0 +1,10 @@
+-----BEGIN NEW CERTIFICATE REQUEST-----
+MIIBoTCCAQoCAQAwYTELMAkGA1UEBhMCQ0ExCzAJBgNVBAgTAk9OMRAwDgYDVQQHEwdUb3JvbnRv
+MQ0wCwYDVQQKEwRhY21lMQwwCgYDVQQLEwNhcnQxFjAUBgNVBAMMDWFwcDFAYWNtZS5vcmcwgZ8w
+DQYJKoZIhvcNAQEBBQADgY0AMIGJAoGBAIlYzFnmAsv/Ci4rgp3sWwkFGFYEBwiXx0XzauZ10nrO
+Uz6Ce2FGVQBYFA09zi79iUyn86oLuTY0Kc/1emCZEPkmOW+hw1uk/TxG5MqpEOZdsDv4xIqBHgtW
+v/d3kGubwSS5lia1l6EPvnzHvsQSM//xhkrJaF0fAHx5FMkilnvfAgMBAAGgADANBgkqhkiG9w0B
+AQQFAAOBgQADKx89mTCGIbrCE6lICLYDexGxexeaZaUDq7YgtyXVIs2wcVGcZJGolUARopMWgE+y
+ryHTC4nvNCaBULyXGrzwPfzTJaVBiY4V5BoTrmz6Ofd73ZO6ZYNhy9bVLrb5VtDyldCj0EWz2lBe
++OzVUeII5KPopRtzXpMH3sB2OredUg==
+-----END NEW CERTIFICATE REQUEST-----
diff --git a/qpid/java/test-profiles/test_resources/ssl/app2.crt b/qpid/java/test-profiles/test_resources/ssl/app2.crt
new file mode 100644
index 0000000000..5c889a4c31
--- /dev/null
+++ b/qpid/java/test-profiles/test_resources/ssl/app2.crt
@@ -0,0 +1,15 @@
+-----BEGIN CERTIFICATE-----
+MIICPjCCAaegAwIBAgIFAJJRUXgwDQYJKoZIhvcNAQEFBQAwQTELMAkGA1UEBhMC
+Q0ExEDAOBgNVBAgTB09udGFyaW8xDTALBgNVBAoTBEFDTUUxETAPBgNVBAMTCE15
+Um9vdENBMB4XDTEwMTAxNDAyMzQxNVoXDTE1MTAxNDAyMzQxNVowYTELMAkGA1UE
+BhMCQ0ExCzAJBgNVBAgTAk9OMRAwDgYDVQQHEwdUb3JvbnRvMQ0wCwYDVQQKEwRh
+Y21lMQwwCgYDVQQLEwNhcnQxFjAUBgNVBAMMDWFwcDJAYWNtZS5vcmcwgZ8wDQYJ
+KoZIhvcNAQEBBQADgY0AMIGJAoGBAJcIo3TSYxDa1OfmnDEP4qzLxmgyXC3n0Evu
+2nJz0s5zljjItnwJ9UpOkYh/PQcpUWoM+qKeZYadXbGhp8M8nMrJtUPOAKgDmF6A
+DKS9WL7u8kVCcEvBzLRD7bftEm2IPaRu72wOQai76hj11rYWHHkdAPem+C4ODqVn
+y2NN3zDnAgMBAAGjIjAgMAkGA1UdEwQCMAAwEwYDVR0lBAwwCgYIKwYBBQUHAwIw
+DQYJKoZIhvcNAQEFBQADgYEAc5FG8sDbK+i1703rJEwjJ9dCVXljN2jYL1sGXO2o
+9O5Da0zKcQ+OMhLJUoJf38pJw+maYhtT0fKFLItXP/rlyWlaGRBjkcZjOZ2D/Hg5
+/8pEVwiyTYRoEnGKRawnedIbEyBAcgtnlbkTFWXtQmnmgVApSzTpALRn5/jUC1PU
+Y3g=
+-----END CERTIFICATE-----
diff --git a/qpid/java/test-profiles/test_resources/ssl/app2.req b/qpid/java/test-profiles/test_resources/ssl/app2.req
new file mode 100644
index 0000000000..53f3494168
--- /dev/null
+++ b/qpid/java/test-profiles/test_resources/ssl/app2.req
@@ -0,0 +1,10 @@
+-----BEGIN NEW CERTIFICATE REQUEST-----
+MIIBoTCCAQoCAQAwYTELMAkGA1UEBhMCQ0ExCzAJBgNVBAgTAk9OMRAwDgYDVQQHEwdUb3JvbnRv
+MQ0wCwYDVQQKEwRhY21lMQwwCgYDVQQLEwNhcnQxFjAUBgNVBAMMDWFwcDJAYWNtZS5vcmcwgZ8w
+DQYJKoZIhvcNAQEBBQADgY0AMIGJAoGBAJcIo3TSYxDa1OfmnDEP4qzLxmgyXC3n0Evu2nJz0s5z
+ljjItnwJ9UpOkYh/PQcpUWoM+qKeZYadXbGhp8M8nMrJtUPOAKgDmF6ADKS9WL7u8kVCcEvBzLRD
+7bftEm2IPaRu72wOQai76hj11rYWHHkdAPem+C4ODqVny2NN3zDnAgMBAAGgADANBgkqhkiG9w0B
+AQQFAAOBgQAGNtSvXwdyujmMTaVQj2M2jZkgnVFtMBjDDmdz+wgzu8fKaej7e+fJi5owf31wJUUP
+0Zi/6mBNj+blmqHjNQ9U3w9Rns0z3+1DbO3Yj48d75IuxQJJd+lXXjCFi2qSBhaNUwyOpzaI1AQo
+JJTC1/WMaPENU9bgYYsOrmIhnbt5rQ==
+-----END NEW CERTIFICATE REQUEST-----
diff --git a/qpid/java/test-profiles/test_resources/ssl/certstore.jks b/qpid/java/test-profiles/test_resources/ssl/certstore.jks
new file mode 100644
index 0000000000..2af95f21f8
--- /dev/null
+++ b/qpid/java/test-profiles/test_resources/ssl/certstore.jks
Binary files differ
diff --git a/qpid/java/test-profiles/test_resources/ssl/keystore.jks b/qpid/java/test-profiles/test_resources/ssl/keystore.jks
new file mode 100644
index 0000000000..e3a850a248
--- /dev/null
+++ b/qpid/java/test-profiles/test_resources/ssl/keystore.jks
Binary files differ
diff --git a/qpid/java/test-profiles/test_resources/ssl/pfile b/qpid/java/test-profiles/test_resources/ssl/pfile
new file mode 100644
index 0000000000..f3097ab130
--- /dev/null
+++ b/qpid/java/test-profiles/test_resources/ssl/pfile
@@ -0,0 +1 @@
+password
diff --git a/qpid/java/test-profiles/test_resources/ssl/server_db/cert8.db b/qpid/java/test-profiles/test_resources/ssl/server_db/cert8.db
new file mode 100644
index 0000000000..d55f529c52
--- /dev/null
+++ b/qpid/java/test-profiles/test_resources/ssl/server_db/cert8.db
Binary files differ
diff --git a/qpid/java/test-profiles/test_resources/ssl/server_db/key3.db b/qpid/java/test-profiles/test_resources/ssl/server_db/key3.db
new file mode 100644
index 0000000000..12f3c394c5
--- /dev/null
+++ b/qpid/java/test-profiles/test_resources/ssl/server_db/key3.db
Binary files differ
diff --git a/qpid/java/test-profiles/test_resources/ssl/server_db/secmod.db b/qpid/java/test-profiles/test_resources/ssl/server_db/secmod.db
new file mode 100644
index 0000000000..97a5b9b2fe
--- /dev/null
+++ b/qpid/java/test-profiles/test_resources/ssl/server_db/secmod.db
Binary files differ
diff --git a/qpid/java/test-profiles/test_resources/ssl/server_db/server.crt b/qpid/java/test-profiles/test_resources/ssl/server_db/server.crt
new file mode 100644
index 0000000000..4f1c007d16
--- /dev/null
+++ b/qpid/java/test-profiles/test_resources/ssl/server_db/server.crt
@@ -0,0 +1,14 @@
+-----BEGIN CERTIFICATE-----
+MIICKzCCAZSgAwIBAgIFAJBNUhEwDQYJKoZIhvcNAQEFBQAwQTELMAkGA1UEBhMC
+Q0ExEDAOBgNVBAgTB09udGFyaW8xDTALBgNVBAoTBEFDTUUxETAPBgNVBAMTCE15
+Um9vdENBMB4XDTEwMDMyMjIxNDE0OVoXDTE1MDMyMjIxNDE0OVowTjELMAkGA1UE
+BhMCQ0ExEDAOBgNVBAgTB09udGFyaW8xDTALBgNVBAoTBEFDTUUxHjAcBgNVBAMT
+FWxvY2FsaG9zdC5sb2NhbGRvbWFpbjCBnzANBgkqhkiG9w0BAQEFAAOBjQAwgYkC
+gYEAtmFy+0IIn6otWu2TCJ3fN2UDA//EVDWpiozzvd/My31XpPQ8jhuvsZ2//xvG
+OKqDfgQ80OE6BiGmR2zxPKFfsgxhU+0g8132focOzd0MhmGpyhdQdogXQ2cCcvjB
+CvgaugIjTmk3MX9njD7np8TQQ7wW1Wuk/c99tuvlexjEoWkCAwEAAaMiMCAwCQYD
+VR0TBAIwADATBgNVHSUEDDAKBggrBgEFBQcDATANBgkqhkiG9w0BAQUFAAOBgQDH
+iOxUWKllSUgCcAij0Gb4qDo/YDoatWyzE8pNZR7OgSOJ8zEVJcB/7YW//frd2dMS
+lz6c38vqbGwyblw+b64SvBKI3WK0jyO4Ft9FGpNIEfc9Q5G0MFiGilv+GDIZ/asE
+KnsZNy4z4gs3KFSf96k1AV1YQ1tVpFcUrI+3QqdWfQ==
+-----END CERTIFICATE-----
diff --git a/qpid/java/test-profiles/test_resources/ssl/server_db/server.req b/qpid/java/test-profiles/test_resources/ssl/server_db/server.req
new file mode 100644
index 0000000000..5551516586
--- /dev/null
+++ b/qpid/java/test-profiles/test_resources/ssl/server_db/server.req
@@ -0,0 +1,21 @@
+
+Certificate request generated by Netscape certutil
+Phone: (not specified)
+
+Common Name: localhost.localdomain
+Email: (not specified)
+Organization: ACME
+State: Ontario
+Country: CA
+
+-----BEGIN NEW CERTIFICATE REQUEST-----
+MIIBjTCB9wIBADBOMQswCQYDVQQGEwJDQTEQMA4GA1UECBMHT250YXJpbzENMAsG
+A1UEChMEQUNNRTEeMBwGA1UEAxMVbG9jYWxob3N0LmxvY2FsZG9tYWluMIGfMA0G
+CSqGSIb3DQEBAQUAA4GNADCBiQKBgQC2YXL7Qgifqi1a7ZMInd83ZQMD/8RUNamK
+jPO938zLfVek9DyOG6+xnb//G8Y4qoN+BDzQ4ToGIaZHbPE8oV+yDGFT7SDzXfZ+
+hw7N3QyGYanKF1B2iBdDZwJy+MEK+Bq6AiNOaTcxf2eMPuenxNBDvBbVa6T9z322
+6+V7GMShaQIDAQABoAAwDQYJKoZIhvcNAQEFBQADgYEAJGqdJVTScR4rzusrf6dE
+Snz/PtKcl8ZqXfHMPhj5uqUACcj3AxvlerIrpIGG9YT5cX4cOa92plpearMAC1TW
+fksbpsJR174WnAbBETrNbOX55igS/KDkW+RJCn7GGOvcSza+nJ880/lZ0iC63bgY
+SmvSnp3ub1CBX0grWl4bzTw=
+-----END NEW CERTIFICATE REQUEST-----