You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@qpid.apache.org by ro...@apache.org on 2010/11/01 00:40:13 UTC

svn commit: r1029522 - in /qpid/trunk/qpid: cc/config/java/ java/test-profiles/

Author: robbie
Date: Sun Oct 31 23:40:12 2010
New Revision: 1029522

URL: http://svn.apache.org/viewvc?rev=1029522&view=rev
Log:
add ASF licence to Java .testprofile and exclude files

Modified:
    qpid/trunk/qpid/cc/config/java/cpp.noprefetch.testprofile
    qpid/trunk/qpid/cc/config/java/cpp.testprofile
    qpid/trunk/qpid/java/test-profiles/08StandaloneExcludes
    qpid/trunk/qpid/java/test-profiles/CPPExcludes
    qpid/trunk/qpid/java/test-profiles/CPPNoPrefetchExcludes
    qpid/trunk/qpid/java/test-profiles/CPPPrefetchExcludes
    qpid/trunk/qpid/java/test-profiles/CPPTransientExcludes
    qpid/trunk/qpid/java/test-profiles/Excludes
    qpid/trunk/qpid/java/test-profiles/Java010Excludes
    qpid/trunk/qpid/java/test-profiles/JavaExcludes
    qpid/trunk/qpid/java/test-profiles/JavaInVMExcludes
    qpid/trunk/qpid/java/test-profiles/JavaPersistentExcludes
    qpid/trunk/qpid/java/test-profiles/JavaStandaloneExcludes
    qpid/trunk/qpid/java/test-profiles/JavaTransientExcludes
    qpid/trunk/qpid/java/test-profiles/XAExcludes
    qpid/trunk/qpid/java/test-profiles/cpp.async.excludes
    qpid/trunk/qpid/java/test-profiles/cpp.async.testprofile
    qpid/trunk/qpid/java/test-profiles/cpp.cluster.testprofile
    qpid/trunk/qpid/java/test-profiles/cpp.excludes
    qpid/trunk/qpid/java/test-profiles/cpp.noprefetch.testprofile
    qpid/trunk/qpid/java/test-profiles/cpp.ssl.excludes
    qpid/trunk/qpid/java/test-profiles/cpp.ssl.testprofile
    qpid/trunk/qpid/java/test-profiles/cpp.testprofile
    qpid/trunk/qpid/java/test-profiles/default.testprofile
    qpid/trunk/qpid/java/test-profiles/java-derby.0.10.testprofile
    qpid/trunk/qpid/java/test-profiles/java-derby.testprofile
    qpid/trunk/qpid/java/test-profiles/java.0.10.testprofile
    qpid/trunk/qpid/java/test-profiles/java.testprofile

Modified: qpid/trunk/qpid/cc/config/java/cpp.noprefetch.testprofile
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/cc/config/java/cpp.noprefetch.testprofile?rev=1029522&r1=1029521&r2=1029522&view=diff
==============================================================================
--- qpid/trunk/qpid/cc/config/java/cpp.noprefetch.testprofile (original)
+++ qpid/trunk/qpid/cc/config/java/cpp.noprefetch.testprofile Sun Oct 31 23:40:12 2010
@@ -1,4 +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.
+#
 broker.version=0-10
 broker=${project.root}/../cpp/src/qpidd --data-dir ${build.data} -t --load-module store_home/lib/.libs/libbdbstore.so --auth no --no-module-dir
 max_prefetch=0
-test.excludesfile=${project.root}/010ExcludeList-noPrefetch
\ No newline at end of file
+test.excludesfile=${project.root}/010ExcludeList-noPrefetch

Modified: qpid/trunk/qpid/cc/config/java/cpp.testprofile
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/cc/config/java/cpp.testprofile?rev=1029522&r1=1029521&r2=1029522&view=diff
==============================================================================
--- qpid/trunk/qpid/cc/config/java/cpp.testprofile (original)
+++ qpid/trunk/qpid/cc/config/java/cpp.testprofile Sun Oct 31 23:40:12 2010
@@ -1,3 +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.
+#
 broker.version=0-10
 broker=${project.root}/../cpp/src/qpidd --data-dir ${build.data} -t --load-module store_home/lib/.libs/libbdbstore.so --auth no --no-module-dir
 test.excludesfile=${project.root}/010ExcludeList-store

Modified: qpid/trunk/qpid/java/test-profiles/08StandaloneExcludes
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/test-profiles/08StandaloneExcludes?rev=1029522&r1=1029521&r2=1029522&view=diff
==============================================================================
--- qpid/trunk/qpid/java/test-profiles/08StandaloneExcludes (original)
+++ qpid/trunk/qpid/java/test-profiles/08StandaloneExcludes Sun Oct 31 23:40:12 2010
@@ -1,3 +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.
+//
+
 //======================================================================
 //Exclude the following from brokers defaulting to the 0-8 protocol
 //======================================================================

Modified: qpid/trunk/qpid/java/test-profiles/CPPExcludes
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/test-profiles/CPPExcludes?rev=1029522&r1=1029521&r2=1029522&view=diff
==============================================================================
--- qpid/trunk/qpid/java/test-profiles/CPPExcludes (original)
+++ qpid/trunk/qpid/java/test-profiles/CPPExcludes Sun Oct 31 23:40:12 2010
@@ -1,3 +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.client.channelclose.ChannelCloseTest#*
 org.apache.qpid.client.ResetMessageListenerTest#*
 

Modified: qpid/trunk/qpid/java/test-profiles/CPPNoPrefetchExcludes
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/test-profiles/CPPNoPrefetchExcludes?rev=1029522&r1=1029521&r2=1029522&view=diff
==============================================================================
--- qpid/trunk/qpid/java/test-profiles/CPPNoPrefetchExcludes (original)
+++ qpid/trunk/qpid/java/test-profiles/CPPNoPrefetchExcludes Sun Oct 31 23:40:12 2010
@@ -1,3 +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.transacted.TransactedTest#testRollback
 
 org.apache.qpid.test.client.QueueBrowserAutoAckTest#testFailoverWithQueueBrowser

Modified: qpid/trunk/qpid/java/test-profiles/CPPPrefetchExcludes
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/test-profiles/CPPPrefetchExcludes?rev=1029522&r1=1029521&r2=1029522&view=diff
==============================================================================
--- qpid/trunk/qpid/java/test-profiles/CPPPrefetchExcludes (original)
+++ qpid/trunk/qpid/java/test-profiles/CPPPrefetchExcludes Sun Oct 31 23:40:12 2010
@@ -1,3 +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.
+//
+
 // those tests should be run with prefetch off
 org.apache.qpid.client.MessageListenerMultiConsumerTest#testRecieveC2Only
 org.apache.qpid.client.MessageListenerMultiConsumerTest#testRecieveBoth

Modified: qpid/trunk/qpid/java/test-profiles/CPPTransientExcludes
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/test-profiles/CPPTransientExcludes?rev=1029522&r1=1029521&r2=1029522&view=diff
==============================================================================
--- qpid/trunk/qpid/java/test-profiles/CPPTransientExcludes (original)
+++ qpid/trunk/qpid/java/test-profiles/CPPTransientExcludes Sun Oct 31 23:40:12 2010
@@ -1,3 +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.
+//
+
 // those tests need durable subscribe states to be persisted
 org.apache.qpid.test.unit.topic.DurableSubscriptionTest#testDurSubRestoredAfterNonPersistentMessageSent
 

Modified: qpid/trunk/qpid/java/test-profiles/Excludes
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/test-profiles/Excludes?rev=1029522&r1=1029521&r2=1029522&view=diff
==============================================================================
--- qpid/trunk/qpid/java/test-profiles/Excludes (original)
+++ qpid/trunk/qpid/java/test-profiles/Excludes Sun Oct 31 23:40:12 2010
@@ -1,3 +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.client.MultipleJCAProviderRegistrationTest#test
 // QPID-1715, QPID-1715 : Client Error Handling on close is still broken
 org.apache.qpid.server.queue.QueueCreateTest#testCreatePriorityString

Modified: qpid/trunk/qpid/java/test-profiles/Java010Excludes
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/test-profiles/Java010Excludes?rev=1029522&r1=1029521&r2=1029522&view=diff
==============================================================================
--- qpid/trunk/qpid/java/test-profiles/Java010Excludes (original)
+++ qpid/trunk/qpid/java/test-profiles/Java010Excludes Sun Oct 31 23:40:12 2010
@@ -1,3 +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.
+//
+
 // 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

Modified: qpid/trunk/qpid/java/test-profiles/JavaExcludes
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/test-profiles/JavaExcludes?rev=1029522&r1=1029521&r2=1029522&view=diff
==============================================================================
--- qpid/trunk/qpid/java/test-profiles/JavaExcludes (original)
+++ qpid/trunk/qpid/java/test-profiles/JavaExcludes Sun Oct 31 23:40:12 2010
@@ -1,3 +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.
+//
+
 // Those tests are not finished
 org.apache.qpid.test.testcases.TTLTest#*
 org.apache.qpid.test.testcases.FailoverTest#*

Modified: qpid/trunk/qpid/java/test-profiles/JavaInVMExcludes
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/test-profiles/JavaInVMExcludes?rev=1029522&r1=1029521&r2=1029522&view=diff
==============================================================================
--- qpid/trunk/qpid/java/test-profiles/JavaInVMExcludes (original)
+++ qpid/trunk/qpid/java/test-profiles/JavaInVMExcludes Sun Oct 31 23:40:12 2010
@@ -1,3 +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.
+//
+
 //======================================================================
 //Exclude the following tests when running the InVM default test profile
 //======================================================================

Modified: qpid/trunk/qpid/java/test-profiles/JavaPersistentExcludes
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/test-profiles/JavaPersistentExcludes?rev=1029522&r1=1029521&r2=1029522&view=diff
==============================================================================
--- qpid/trunk/qpid/java/test-profiles/JavaPersistentExcludes (original)
+++ qpid/trunk/qpid/java/test-profiles/JavaPersistentExcludes Sun Oct 31 23:40:12 2010
@@ -1,2 +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#*

Modified: qpid/trunk/qpid/java/test-profiles/JavaStandaloneExcludes
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/test-profiles/JavaStandaloneExcludes?rev=1029522&r1=1029521&r2=1029522&view=diff
==============================================================================
--- qpid/trunk/qpid/java/test-profiles/JavaStandaloneExcludes (original)
+++ qpid/trunk/qpid/java/test-profiles/JavaStandaloneExcludes Sun Oct 31 23:40:12 2010
@@ -1,3 +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.
+//
 
 // This is a long running test so should exclude from normal runs
 org.apache.qpid.test.client.failover.FailoverTest#test4MinuteFailover

Modified: qpid/trunk/qpid/java/test-profiles/JavaTransientExcludes
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/test-profiles/JavaTransientExcludes?rev=1029522&r1=1029521&r2=1029522&view=diff
==============================================================================
--- qpid/trunk/qpid/java/test-profiles/JavaTransientExcludes (original)
+++ qpid/trunk/qpid/java/test-profiles/JavaTransientExcludes Sun Oct 31 23:40:12 2010
@@ -1,3 +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.
+//
+
 //These tests require a persistent store
 org.apache.qpid.server.store.PersistentStoreTest#*
 

Modified: qpid/trunk/qpid/java/test-profiles/XAExcludes
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/test-profiles/XAExcludes?rev=1029522&r1=1029521&r2=1029522&view=diff
==============================================================================
--- qpid/trunk/qpid/java/test-profiles/XAExcludes (original)
+++ qpid/trunk/qpid/java/test-profiles/XAExcludes Sun Oct 31 23:40:12 2010
@@ -1,3 +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#*

Modified: qpid/trunk/qpid/java/test-profiles/cpp.async.excludes
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/test-profiles/cpp.async.excludes?rev=1029522&r1=1029521&r2=1029522&view=diff
==============================================================================
--- qpid/trunk/qpid/java/test-profiles/cpp.async.excludes (original)
+++ qpid/trunk/qpid/java/test-profiles/cpp.async.excludes Sun Oct 31 23:40:12 2010
@@ -1,2 +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

Modified: qpid/trunk/qpid/java/test-profiles/cpp.async.testprofile
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/test-profiles/cpp.async.testprofile?rev=1029522&r1=1029521&r2=1029522&view=diff
==============================================================================
--- qpid/trunk/qpid/java/test-profiles/cpp.async.testprofile (original)
+++ qpid/trunk/qpid/java/test-profiles/cpp.async.testprofile Sun Oct 31 23:40:12 2010
@@ -1,3 +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}

Modified: qpid/trunk/qpid/java/test-profiles/cpp.cluster.testprofile
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/test-profiles/cpp.cluster.testprofile?rev=1029522&r1=1029521&r2=1029522&view=diff
==============================================================================
--- qpid/trunk/qpid/java/test-profiles/cpp.cluster.testprofile (original)
+++ qpid/trunk/qpid/java/test-profiles/cpp.cluster.testprofile Sun Oct 31 23:40:12 2010
@@ -1,3 +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
 
 broker.modules=--load-module ${broker.module.cluster} --cluster-name cpp-java-test-cluster

Modified: qpid/trunk/qpid/java/test-profiles/cpp.excludes
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/test-profiles/cpp.excludes?rev=1029522&r1=1029521&r2=1029522&view=diff
==============================================================================
--- qpid/trunk/qpid/java/test-profiles/cpp.excludes (original)
+++ qpid/trunk/qpid/java/test-profiles/cpp.excludes Sun Oct 31 23:40:12 2010
@@ -1,3 +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.
+//
+
 //======================================================================
 //Exclude the following tests when running all cpp test profilies
 //======================================================================

Modified: qpid/trunk/qpid/java/test-profiles/cpp.noprefetch.testprofile
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/test-profiles/cpp.noprefetch.testprofile?rev=1029522&r1=1029521&r2=1029522&view=diff
==============================================================================
--- qpid/trunk/qpid/java/test-profiles/cpp.noprefetch.testprofile (original)
+++ qpid/trunk/qpid/java/test-profiles/cpp.noprefetch.testprofile Sun Oct 31 23:40:12 2010
@@ -1,3 +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

Modified: qpid/trunk/qpid/java/test-profiles/cpp.ssl.excludes
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/test-profiles/cpp.ssl.excludes?rev=1029522&r1=1029521&r2=1029522&view=diff
==============================================================================
--- qpid/trunk/qpid/java/test-profiles/cpp.ssl.excludes (original)
+++ qpid/trunk/qpid/java/test-profiles/cpp.ssl.excludes Sun Oct 31 23:40:12 2010
@@ -1 +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#*

Modified: qpid/trunk/qpid/java/test-profiles/cpp.ssl.testprofile
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/test-profiles/cpp.ssl.testprofile?rev=1029522&r1=1029521&r2=1029522&view=diff
==============================================================================
--- qpid/trunk/qpid/java/test-profiles/cpp.ssl.testprofile (original)
+++ qpid/trunk/qpid/java/test-profiles/cpp.ssl.testprofile Sun Oct 31 23:40:12 2010
@@ -1,3 +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
 
 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

Modified: qpid/trunk/qpid/java/test-profiles/cpp.testprofile
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/test-profiles/cpp.testprofile?rev=1029522&r1=1029521&r2=1029522&view=diff
==============================================================================
--- qpid/trunk/qpid/java/test-profiles/cpp.testprofile (original)
+++ qpid/trunk/qpid/java/test-profiles/cpp.testprofile Sun Oct 31 23:40:12 2010
@@ -1,3 +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.
+#
 broker.version=0-10
 broker.language=cpp
 

Modified: qpid/trunk/qpid/java/test-profiles/default.testprofile
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/test-profiles/default.testprofile?rev=1029522&r1=1029521&r2=1029522&view=diff
==============================================================================
--- qpid/trunk/qpid/java/test-profiles/default.testprofile (original)
+++ qpid/trunk/qpid/java/test-profiles/default.testprofile Sun Oct 31 23:40:12 2010
@@ -1,3 +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.
+#
 java.naming.factory.initial=org.apache.qpid.jndi.PropertiesFileInitialContextFactory
 java.naming.provider.url=${test.profiles}/test-provider.properties
 

Modified: qpid/trunk/qpid/java/test-profiles/java-derby.0.10.testprofile
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/test-profiles/java-derby.0.10.testprofile?rev=1029522&r1=1029521&r2=1029522&view=diff
==============================================================================
--- qpid/trunk/qpid/java/test-profiles/java-derby.0.10.testprofile (original)
+++ qpid/trunk/qpid/java/test-profiles/java-derby.0.10.testprofile Sun Oct 31 23:40:12 2010
@@ -1,3 +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.
+#
 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

Modified: qpid/trunk/qpid/java/test-profiles/java-derby.testprofile
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/test-profiles/java-derby.testprofile?rev=1029522&r1=1029521&r2=1029522&view=diff
==============================================================================
--- qpid/trunk/qpid/java/test-profiles/java-derby.testprofile (original)
+++ qpid/trunk/qpid/java/test-profiles/java-derby.testprofile Sun Oct 31 23:40:12 2010
@@ -1,3 +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.
+#
 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

Modified: qpid/trunk/qpid/java/test-profiles/java.0.10.testprofile
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/test-profiles/java.0.10.testprofile?rev=1029522&r1=1029521&r2=1029522&view=diff
==============================================================================
--- qpid/trunk/qpid/java/test-profiles/java.0.10.testprofile (original)
+++ qpid/trunk/qpid/java/test-profiles/java.0.10.testprofile Sun Oct 31 23:40:12 2010
@@ -1,3 +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.
+#
 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

Modified: qpid/trunk/qpid/java/test-profiles/java.testprofile
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/test-profiles/java.testprofile?rev=1029522&r1=1029521&r2=1029522&view=diff
==============================================================================
--- qpid/trunk/qpid/java/test-profiles/java.testprofile (original)
+++ qpid/trunk/qpid/java/test-profiles/java.testprofile Sun Oct 31 23:40:12 2010
@@ -1,3 +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.
+#
 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



---------------------------------------------------------------------
Apache Qpid - AMQP Messaging Implementation
Project:      http://qpid.apache.org
Use/Interact: mailto:commits-subscribe@qpid.apache.org