You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@activemq.apache.org by ta...@apache.org on 2009/06/27 00:14:01 UTC

svn commit: r788887 [3/3] - in /activemq/activemq-cpp/trunk: activemq-c/ activemq-cpp-openwire-generator/ activemq-cpp/ activemq-cpp/src/main/ activemq-cpp/src/test-benchmarks/ activemq-cpp/src/test-integration/ activemq-cpp/src/test/ maven-cpptools-pl...

Modified: activemq/activemq-cpp/trunk/activemq-cpp/src/test-benchmarks/Makefile.am
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/activemq-cpp/src/test-benchmarks/Makefile.am?rev=788887&r1=788886&r2=788887&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/activemq-cpp/src/test-benchmarks/Makefile.am (original)
+++ activemq/activemq-cpp/trunk/activemq-cpp/src/test-benchmarks/Makefile.am Fri Jun 26 22:14:01 2009
@@ -16,32 +16,32 @@
 # ---------------------------------------------------------------------------
 
 cc_sources = \
+    activemq/util/PrimitiveMapBenchmark.cpp \
+    activemq/wireformat/openwire/utils/OpenWireStringSupportBenchmark.cpp \
+    benchmark/PerformanceTimer.cpp \
+    decaf/io/DataInputStreamBenchmark.cpp \
+    decaf/io/DataOutputStreamBenchmark.cpp \
     decaf/lang/BooleanBenchmark.cpp \
-    decaf/util/QueueBenchmark.cpp \
-    decaf/util/SetBenchmark.cpp \
     decaf/util/MapBenchmark.cpp \
     decaf/util/PropertiesBenchmark.cpp \
-    decaf/io/DataOutputStreamBenchmark.cpp \
-    decaf/io/DataInputStreamBenchmark.cpp \
+    decaf/util/QueueBenchmark.cpp \
+    decaf/util/SetBenchmark.cpp \
     main.cpp \
-    testRegistry.cpp \
-    benchmark/PerformanceTimer.cpp \
-    activemq/wireformat/openwire/utils/OpenWireStringSupportBenchmark.cpp \
-    activemq/util/PrimitiveMapBenchmark.cpp
+    testRegistry.cpp
 
 
 h_sources = \
+    activemq/util/PrimitiveMapBenchmark.h \
+    activemq/wireformat/openwire/utils/OpenWireStringSupportBenchmark.h \
+    benchmark/BenchmarkBase.h \
+    benchmark/PerformanceTimer.h \
+    decaf/io/DataInputStreamBenchmark.h \
+    decaf/io/DataOutputStreamBenchmark.h \
     decaf/lang/BooleanBenchmark.h \
-    decaf/util/QueueBenchmark.h \
     decaf/util/MapBenchmark.h \
-    decaf/util/SetBenchmark.h \
     decaf/util/PropertiesBenchmark.h \
-    decaf/io/DataInputStreamBenchmark.h \
-    decaf/io/DataOutputStreamBenchmark.h \
-    benchmark/PerformanceTimer.h \
-    benchmark/BenchmarkBase.h \
-    activemq/wireformat/openwire/utils/OpenWireStringSupportBenchmark.h \
-    activemq/util/PrimitiveMapBenchmark.h
+    decaf/util/QueueBenchmark.h \
+    decaf/util/SetBenchmark.h
 
 
 ## Compile this as part of make check

Modified: activemq/activemq-cpp/trunk/activemq-cpp/src/test-integration/Makefile.am
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/activemq-cpp/src/test-integration/Makefile.am?rev=788887&r1=788886&r2=788887&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/activemq-cpp/src/test-integration/Makefile.am (original)
+++ activemq/activemq-cpp/trunk/activemq-cpp/src/test-integration/Makefile.am Fri Jun 26 22:14:01 2009
@@ -16,80 +16,80 @@
 # ---------------------------------------------------------------------------
 
 cc_sources = \
-    main.cpp \
-    util/teamcity/TeamCityProgressListener.cpp \
     TestRegistry.cpp \
+    activemq/test/AsyncSenderTest.cpp \
+    activemq/test/CmsTemplateTest.cpp \
     activemq/test/DurableTest.cpp \
+    activemq/test/ExpirationTest.cpp \
+    activemq/test/JmsMessageGroupsTest.cpp \
+    activemq/test/SimpleRollbackTest.cpp \
+    activemq/test/SimpleTest.cpp \
+    activemq/test/SlowListenerTest.cpp \
+    activemq/test/TransactionTest.cpp \
+    activemq/test/VirtualTopicTest.cpp \
+    activemq/test/openwire/OpenwireAsyncSenderTest.cpp \
     activemq/test/openwire/OpenwireCmsTemplateTest.cpp \
-    activemq/test/openwire/OpenwireTempDestinationTest.cpp \
-    activemq/test/openwire/OpenwireTransactionTest.cpp \
-    activemq/test/openwire/OpenwireVirtualTopicTest.cpp \
-    activemq/test/openwire/OpenwireSimpleTest.cpp \
+    activemq/test/openwire/OpenwireDurableTest.cpp \
     activemq/test/openwire/OpenwireExpirationTest.cpp \
-    activemq/test/openwire/OpenwireSlowListenerTest.cpp \
     activemq/test/openwire/OpenwireJmsMessageGroupsTest.cpp \
-    activemq/test/openwire/OpenwireAsyncSenderTest.cpp \
     activemq/test/openwire/OpenwireSimpleRollbackTest.cpp \
-    activemq/test/openwire/OpenwireDurableTest.cpp \
-    activemq/test/SimpleTest.cpp \
-    activemq/test/stomp/StompExpirationTest.cpp \
-    activemq/test/stomp/StompSlowListenerTest.cpp \
-    activemq/test/stomp/StompSimpleTest.cpp \
-    activemq/test/stomp/StompCmsTemplateTest.cpp \
-    activemq/test/stomp/StompTransactionTest.cpp \
+    activemq/test/openwire/OpenwireSimpleTest.cpp \
+    activemq/test/openwire/OpenwireSlowListenerTest.cpp \
+    activemq/test/openwire/OpenwireTempDestinationTest.cpp \
+    activemq/test/openwire/OpenwireTransactionTest.cpp \
+    activemq/test/openwire/OpenwireVirtualTopicTest.cpp \
     activemq/test/stomp/StompAsyncSenderTest.cpp \
-    activemq/test/stomp/StompJmsMessageGroupsTest.cpp \
+    activemq/test/stomp/StompCmsTemplateTest.cpp \
     activemq/test/stomp/StompDurableTest.cpp \
+    activemq/test/stomp/StompExpirationTest.cpp \
+    activemq/test/stomp/StompJmsMessageGroupsTest.cpp \
     activemq/test/stomp/StompSimpleRollbackTest.cpp \
-    activemq/test/VirtualTopicTest.cpp \
-    activemq/test/AsyncSenderTest.cpp \
-    activemq/test/TransactionTest.cpp \
-    activemq/test/ExpirationTest.cpp \
-    activemq/test/SimpleRollbackTest.cpp \
-    activemq/test/JmsMessageGroupsTest.cpp \
-    activemq/test/CmsTemplateTest.cpp \
-    activemq/test/SlowListenerTest.cpp \
+    activemq/test/stomp/StompSimpleTest.cpp \
+    activemq/test/stomp/StompSlowListenerTest.cpp \
+    activemq/test/stomp/StompTransactionTest.cpp \
+    activemq/util/CMSListener.cpp \
     activemq/util/CMSProvider.cpp \
     activemq/util/IntegrationCommon.cpp \
-    activemq/util/CMSListener.cpp
+    main.cpp \
+    util/teamcity/TeamCityProgressListener.cpp
 
 
 h_sources = \
-    util/teamcity/TeamCityProgressListener.h \
+    activemq/test/AsyncSenderTest.h \
+    activemq/test/CMSTestFixture.h \
+    activemq/test/CmsTemplateTest.h \
+    activemq/test/DurableTest.h \
+    activemq/test/ExpirationTest.h \
+    activemq/test/JmsMessageGroupsTest.h \
+    activemq/test/SimpleRollbackTest.h \
+    activemq/test/SimpleTest.h \
+    activemq/test/SlowListenerTest.h \
+    activemq/test/TransactionTest.h \
+    activemq/test/VirtualTopicTest.h \
     activemq/test/openwire/OpenwireAsyncSenderTest.h \
-    activemq/test/openwire/OpenwireTransactionTest.h \
-    activemq/test/openwire/OpenwireVirtualTopicTest.h \
-    activemq/test/openwire/OpenwireJmsMessageGroupsTest.h \
     activemq/test/openwire/OpenwireCmsTemplateTest.h \
-    activemq/test/openwire/OpenwireSimpleRollbackTest.h \
     activemq/test/openwire/OpenwireDurableTest.h \
+    activemq/test/openwire/OpenwireExpirationTest.h \
+    activemq/test/openwire/OpenwireJmsMessageGroupsTest.h \
+    activemq/test/openwire/OpenwireSimpleRollbackTest.h \
     activemq/test/openwire/OpenwireSimpleTest.h \
-    activemq/test/openwire/OpenwireTempDestinationTest.h \
     activemq/test/openwire/OpenwireSlowListenerTest.h \
-    activemq/test/openwire/OpenwireExpirationTest.h \
-    activemq/test/JmsMessageGroupsTest.h \
-    activemq/test/VirtualTopicTest.h \
-    activemq/test/AsyncSenderTest.h \
-    activemq/test/CMSTestFixture.h \
-    activemq/test/stomp/StompSlowListenerTest.h \
-    activemq/test/stomp/StompDurableTest.h \
-    activemq/test/stomp/StompSimpleRollbackTest.h \
-    activemq/test/stomp/StompCmsTemplateTest.h \
+    activemq/test/openwire/OpenwireTempDestinationTest.h \
+    activemq/test/openwire/OpenwireTransactionTest.h \
+    activemq/test/openwire/OpenwireVirtualTopicTest.h \
     activemq/test/stomp/StompAsyncSenderTest.h \
-    activemq/test/stomp/StompTransactionTest.h \
+    activemq/test/stomp/StompCmsTemplateTest.h \
+    activemq/test/stomp/StompDurableTest.h \
+    activemq/test/stomp/StompExpirationTest.h \
     activemq/test/stomp/StompJmsMessageGroupsTest.h \
+    activemq/test/stomp/StompSimpleRollbackTest.h \
     activemq/test/stomp/StompSimpleTest.h \
-    activemq/test/stomp/StompExpirationTest.h \
-    activemq/test/DurableTest.h \
-    activemq/test/TransactionTest.h \
-    activemq/test/ExpirationTest.h \
-    activemq/test/CmsTemplateTest.h \
-    activemq/test/SlowListenerTest.h \
-    activemq/test/SimpleRollbackTest.h \
-    activemq/test/SimpleTest.h \
+    activemq/test/stomp/StompSlowListenerTest.h \
+    activemq/test/stomp/StompTransactionTest.h \
+    activemq/util/CMSListener.h \
     activemq/util/CMSProvider.h \
     activemq/util/IntegrationCommon.h \
-    activemq/util/CMSListener.h
+    util/teamcity/TeamCityProgressListener.h
 
 
 ## Compile this as part of make check

Modified: activemq/activemq-cpp/trunk/activemq-cpp/src/test/Makefile.am
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/activemq-cpp/src/test/Makefile.am?rev=788887&r1=788886&r2=788887&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/activemq-cpp/src/test/Makefile.am (original)
+++ activemq/activemq-cpp/trunk/activemq-cpp/src/test/Makefile.am Fri Jun 26 22:14:01 2009
@@ -16,237 +16,237 @@
 # ---------------------------------------------------------------------------
 
 cc_sources = \
-    decaf/lang/PointerTest.cpp \
-    decaf/lang/DoubleTest.cpp \
-    decaf/lang/ByteTest.cpp \
+    activemq/cmsutil/CmsAccessorTest.cpp \
+    activemq/cmsutil/CmsDestinationAccessorTest.cpp \
+    activemq/cmsutil/CmsTemplateTest.cpp \
+    activemq/cmsutil/DynamicDestinationResolverTest.cpp \
+    activemq/cmsutil/SessionPoolTest.cpp \
+    activemq/commands/ActiveMQBytesMessageTest.cpp \
+    activemq/commands/ActiveMQDestinationTest2.cpp \
+    activemq/commands/ActiveMQMapMessageTest.cpp \
+    activemq/commands/ActiveMQMessageTest.cpp \
+    activemq/commands/ActiveMQQueueTest.cpp \
+    activemq/commands/ActiveMQStreamMessageTest.cpp \
+    activemq/commands/ActiveMQTempQueueTest.cpp \
+    activemq/commands/ActiveMQTempTopicTest.cpp \
+    activemq/commands/ActiveMQTextMessageTest.cpp \
+    activemq/commands/ActiveMQTopicTest.cpp \
+    activemq/commands/BrokerIdTest.cpp \
+    activemq/commands/BrokerInfoTest.cpp \
+    activemq/core/ActiveMQConnectionFactoryTest.cpp \
+    activemq/core/ActiveMQConnectionTest.cpp \
+    activemq/core/ActiveMQSessionTest.cpp \
+    activemq/core/MessageDispatchChannelTest.cpp \
+    activemq/exceptions/ActiveMQExceptionTest.cpp \
+    activemq/state/ConnectionStateTest.cpp \
+    activemq/state/ConnectionStateTrackerTest.cpp \
+    activemq/state/ConsumerStateTest.cpp \
+    activemq/state/ProducerStateTest.cpp \
+    activemq/state/SessionStateTest.cpp \
+    activemq/state/TransactionStateTest.cpp \
+    activemq/threads/CompositeTaskRunnerTest.cpp \
+    activemq/threads/DedicatedTaskRunnerTest.cpp \
+    activemq/transport/IOTransportTest.cpp \
+    activemq/transport/TransportRegistryTest.cpp \
+    activemq/transport/correlator/ResponseCorrelatorTest.cpp \
+    activemq/transport/failover/FailoverTransportTest.cpp \
+    activemq/transport/mock/MockTransportFactoryTest.cpp \
+    activemq/util/LongSequenceGeneratorTest.cpp \
+    activemq/util/MemoryUsageTest.cpp \
+    activemq/util/PrimitiveListTest.cpp \
+    activemq/util/PrimitiveMapTest.cpp \
+    activemq/util/PrimitiveValueConverterTest.cpp \
+    activemq/util/PrimitiveValueNodeTest.cpp \
+    activemq/util/URISupportTest.cpp \
+    activemq/wireformat/WireFormatRegistryTest.cpp \
+    activemq/wireformat/openwire/OpenWireFormatTest.cpp \
+    activemq/wireformat/openwire/marshal/BaseDataStreamMarshallerTest.cpp \
+    activemq/wireformat/openwire/marshal/PrimitiveTypesMarshallerTest.cpp \
+    activemq/wireformat/openwire/utils/BooleanStreamTest.cpp \
+    activemq/wireformat/openwire/utils/HexTableTest.cpp \
+    activemq/wireformat/openwire/utils/MessagePropertyInterceptorTest.cpp \
+    activemq/wireformat/openwire/utils/OpenwireStringSupportTest.cpp \
+    decaf/internal/net/URIEncoderDecoderTest.cpp \
+    decaf/internal/net/URIHelperTest.cpp \
+    decaf/internal/nio/BufferFactoryTest.cpp \
+    decaf/internal/nio/ByteArrayBufferTest.cpp \
+    decaf/internal/nio/ByteArrayPerspectiveTest.cpp \
+    decaf/internal/nio/CharArrayBufferTest.cpp \
+    decaf/internal/nio/DoubleArrayBufferTest.cpp \
+    decaf/internal/nio/FloatArrayBufferTest.cpp \
+    decaf/internal/nio/IntArrayBufferTest.cpp \
+    decaf/internal/nio/LongArrayBufferTest.cpp \
+    decaf/internal/nio/ShortArrayBufferTest.cpp \
+    decaf/internal/util/ByteArrayAdapterTest.cpp \
+    decaf/io/BufferedInputStreamTest.cpp \
+    decaf/io/BufferedOutputStreamTest.cpp \
+    decaf/io/ByteArrayInputStreamTest.cpp \
+    decaf/io/ByteArrayOutputStreamTest.cpp \
+    decaf/io/DataInputStreamTest.cpp \
+    decaf/io/DataOutputStreamTest.cpp \
+    decaf/io/FilterInputStreamTest.cpp \
+    decaf/io/FilterOutputStreamTest.cpp \
     decaf/lang/BooleanTest.cpp \
-    decaf/lang/ShortTest.cpp \
-    decaf/lang/FloatTest.cpp \
-    decaf/lang/LongTest.cpp \
-    decaf/lang/SystemTest.cpp \
+    decaf/lang/ByteTest.cpp \
+    decaf/lang/CharacterTest.cpp \
+    decaf/lang/DoubleTest.cpp \
     decaf/lang/ExceptionTest.cpp \
+    decaf/lang/FloatTest.cpp \
     decaf/lang/IntegerTest.cpp \
+    decaf/lang/LongTest.cpp \
     decaf/lang/MathTest.cpp \
-    decaf/lang/CharacterTest.cpp \
+    decaf/lang/PointerTest.cpp \
+    decaf/lang/ShortTest.cpp \
+    decaf/lang/SystemTest.cpp \
     decaf/lang/ThreadTest.cpp \
+    decaf/net/SocketFactoryTest.cpp \
+    decaf/net/SocketTest.cpp \
+    decaf/net/URISyntaxExceptionTest.cpp \
+    decaf/net/URITest.cpp \
+    decaf/net/URLDecoderTest.cpp \
+    decaf/net/URLEncoderTest.cpp \
+    decaf/nio/BufferTest.cpp \
+    decaf/util/DateTest.cpp \
+    decaf/util/Endian.cpp \
+    decaf/util/ListTest.cpp \
+    decaf/util/PropertiesTest.cpp \
     decaf/util/QueueTest.cpp \
     decaf/util/RandomTest.cpp \
+    decaf/util/SetTest.cpp \
+    decaf/util/StlMapTest.cpp \
     decaf/util/StringTokenizerTest.cpp \
-    decaf/util/Endian.cpp \
-    decaf/util/DateTest.cpp \
+    decaf/util/UUIDTest.cpp \
+    decaf/util/concurrent/ConcurrentStlMapTest.cpp \
     decaf/util/concurrent/CountDownLatchTest.cpp \
+    decaf/util/concurrent/MutexTest.cpp \
     decaf/util/concurrent/ThreadPoolTest.cpp \
-    decaf/util/concurrent/ConcurrentStlMapTest.cpp \
     decaf/util/concurrent/TimeUnitTest.cpp \
-    decaf/util/concurrent/MutexTest.cpp \
     decaf/util/concurrent/atomic/AtomicBooleanTest.cpp \
-    decaf/util/concurrent/atomic/AtomicReferenceTest.cpp \
     decaf/util/concurrent/atomic/AtomicIntegerTest.cpp \
-    decaf/util/ListTest.cpp \
-    decaf/util/StlMapTest.cpp \
-    decaf/util/SetTest.cpp \
-    decaf/util/PropertiesTest.cpp \
-    decaf/util/UUIDTest.cpp \
-    decaf/internal/util/ByteArrayAdapterTest.cpp \
-    decaf/internal/nio/ShortArrayBufferTest.cpp \
-    decaf/internal/nio/CharArrayBufferTest.cpp \
-    decaf/internal/nio/ByteArrayBufferTest.cpp \
-    decaf/internal/nio/LongArrayBufferTest.cpp \
-    decaf/internal/nio/FloatArrayBufferTest.cpp \
-    decaf/internal/nio/DoubleArrayBufferTest.cpp \
-    decaf/internal/nio/ByteArrayPerspectiveTest.cpp \
-    decaf/internal/nio/BufferFactoryTest.cpp \
-    decaf/internal/nio/IntArrayBufferTest.cpp \
-    decaf/internal/net/URIHelperTest.cpp \
-    decaf/internal/net/URIEncoderDecoderTest.cpp \
-    decaf/nio/BufferTest.cpp \
-    decaf/net/URITest.cpp \
-    decaf/net/URISyntaxExceptionTest.cpp \
-    decaf/net/URLDecoderTest.cpp \
-    decaf/net/SocketTest.cpp \
-    decaf/net/URLEncoderTest.cpp \
-    decaf/net/SocketFactoryTest.cpp \
-    decaf/io/DataOutputStreamTest.cpp \
-    decaf/io/BufferedOutputStreamTest.cpp \
-    decaf/io/BufferedInputStreamTest.cpp \
-    decaf/io/FilterInputStreamTest.cpp \
-    decaf/io/ByteArrayOutputStreamTest.cpp \
-    decaf/io/DataInputStreamTest.cpp \
-    decaf/io/FilterOutputStreamTest.cpp \
-    decaf/io/ByteArrayInputStreamTest.cpp \
+    decaf/util/concurrent/atomic/AtomicReferenceTest.cpp \
     main.cpp \
-    util/teamcity/TeamCityProgressListener.cpp \
     testRegistry.cpp \
-    activemq/transport/TransportRegistryTest.cpp \
-    activemq/transport/mock/MockTransportFactoryTest.cpp \
-    activemq/transport/failover/FailoverTransportTest.cpp \
-    activemq/transport/correlator/ResponseCorrelatorTest.cpp \
-    activemq/transport/IOTransportTest.cpp \
-    activemq/wireformat/openwire/OpenWireFormatTest.cpp \
-    activemq/wireformat/openwire/marshal/PrimitiveTypesMarshallerTest.cpp \
-    activemq/wireformat/openwire/marshal/BaseDataStreamMarshallerTest.cpp \
-    activemq/wireformat/openwire/utils/HexTableTest.cpp \
-    activemq/wireformat/openwire/utils/OpenwireStringSupportTest.cpp \
-    activemq/wireformat/openwire/utils/MessagePropertyInterceptorTest.cpp \
-    activemq/wireformat/openwire/utils/BooleanStreamTest.cpp \
-    activemq/wireformat/WireFormatRegistryTest.cpp \
-    activemq/cmsutil/SessionPoolTest.cpp \
-    activemq/cmsutil/CmsAccessorTest.cpp \
-    activemq/cmsutil/CmsDestinationAccessorTest.cpp \
-    activemq/cmsutil/DynamicDestinationResolverTest.cpp \
-    activemq/cmsutil/CmsTemplateTest.cpp \
-    activemq/util/PrimitiveValueNodeTest.cpp \
-    activemq/util/LongSequenceGeneratorTest.cpp \
-    activemq/util/PrimitiveValueConverterTest.cpp \
-    activemq/util/PrimitiveMapTest.cpp \
-    activemq/util/MemoryUsageTest.cpp \
-    activemq/util/URISupportTest.cpp \
-    activemq/util/PrimitiveListTest.cpp \
-    activemq/state/ConsumerStateTest.cpp \
-    activemq/state/ProducerStateTest.cpp \
-    activemq/state/ConnectionStateTrackerTest.cpp \
-    activemq/state/TransactionStateTest.cpp \
-    activemq/state/SessionStateTest.cpp \
-    activemq/state/ConnectionStateTest.cpp \
-    activemq/exceptions/ActiveMQExceptionTest.cpp \
-    activemq/threads/DedicatedTaskRunnerTest.cpp \
-    activemq/threads/CompositeTaskRunnerTest.cpp \
-    activemq/core/ActiveMQSessionTest.cpp \
-    activemq/core/ActiveMQConnectionFactoryTest.cpp \
-    activemq/core/ActiveMQConnectionTest.cpp \
-    activemq/core/MessageDispatchChannelTest.cpp \
-    activemq/commands/ActiveMQTextMessageTest.cpp \
-    activemq/commands/BrokerIdTest.cpp \
-    activemq/commands/BrokerInfoTest.cpp \
-    activemq/commands/ActiveMQMapMessageTest.cpp \
-    activemq/commands/ActiveMQDestinationTest2.cpp \
-    activemq/commands/ActiveMQTempTopicTest.cpp \
-    activemq/commands/ActiveMQTopicTest.cpp \
-    activemq/commands/ActiveMQStreamMessageTest.cpp \
-    activemq/commands/ActiveMQMessageTest.cpp \
-    activemq/commands/ActiveMQTempQueueTest.cpp \
-    activemq/commands/ActiveMQBytesMessageTest.cpp \
-    activemq/commands/ActiveMQQueueTest.cpp
+    util/teamcity/TeamCityProgressListener.cpp
 
 
 h_sources = \
-    decaf/lang/LongTest.h \
+    activemq/cmsutil/CmsAccessorTest.h \
+    activemq/cmsutil/CmsDestinationAccessorTest.h \
+    activemq/cmsutil/CmsTemplateTest.h \
+    activemq/cmsutil/DummyConnection.h \
+    activemq/cmsutil/DummyConnectionFactory.h \
+    activemq/cmsutil/DummyConsumer.h \
+    activemq/cmsutil/DummyMessage.h \
+    activemq/cmsutil/DummyMessageCreator.h \
+    activemq/cmsutil/DummyProducer.h \
+    activemq/cmsutil/DummySession.h \
+    activemq/cmsutil/DynamicDestinationResolverTest.h \
+    activemq/cmsutil/MessageContext.h \
+    activemq/cmsutil/SessionPoolTest.h \
+    activemq/commands/ActiveMQBytesMessageTest.h \
+    activemq/commands/ActiveMQDestinationTest2.h \
+    activemq/commands/ActiveMQMapMessageTest.h \
+    activemq/commands/ActiveMQMessageTest.h \
+    activemq/commands/ActiveMQQueueTest.h \
+    activemq/commands/ActiveMQStreamMessageTest.h \
+    activemq/commands/ActiveMQTempQueueTest.h \
+    activemq/commands/ActiveMQTempTopicTest.h \
+    activemq/commands/ActiveMQTextMessageTest.h \
+    activemq/commands/ActiveMQTopicTest.h \
+    activemq/commands/BrokerIdTest.h \
+    activemq/commands/BrokerInfoTest.h \
+    activemq/core/ActiveMQConnectionFactoryTest.h \
+    activemq/core/ActiveMQConnectionTest.h \
+    activemq/core/ActiveMQSessionTest.h \
+    activemq/core/MessageDispatchChannelTest.h \
+    activemq/exceptions/ActiveMQExceptionTest.h \
+    activemq/state/ConnectionStateTest.h \
+    activemq/state/ConnectionStateTrackerTest.h \
+    activemq/state/ConsumerStateTest.h \
+    activemq/state/ProducerStateTest.h \
+    activemq/state/SessionStateTest.h \
+    activemq/state/TransactionStateTest.h \
+    activemq/threads/CompositeTaskRunnerTest.h \
+    activemq/threads/DedicatedTaskRunnerTest.h \
+    activemq/transport/IOTransportTest.h \
+    activemq/transport/TransportRegistryTest.h \
+    activemq/transport/correlator/ResponseCorrelatorTest.h \
+    activemq/transport/failover/FailoverTransportTest.h \
+    activemq/transport/mock/MockTransportFactoryTest.h \
+    activemq/util/LongSequenceGeneratorTest.h \
+    activemq/util/MemoryUsageTest.h \
+    activemq/util/PrimitiveListTest.h \
+    activemq/util/PrimitiveMapTest.h \
+    activemq/util/PrimitiveValueConverterTest.h \
+    activemq/util/PrimitiveValueNodeTest.h \
+    activemq/util/URISupportTest.h \
+    activemq/wireformat/WireFormatRegistryTest.h \
+    activemq/wireformat/openwire/OpenWireFormatTest.h \
+    activemq/wireformat/openwire/marshal/BaseDataStreamMarshallerTest.h \
+    activemq/wireformat/openwire/marshal/PrimitiveTypesMarshallerTest.h \
+    activemq/wireformat/openwire/utils/BooleanStreamTest.h \
+    activemq/wireformat/openwire/utils/HexTableTest.h \
+    activemq/wireformat/openwire/utils/MessagePropertyInterceptorTest.h \
+    activemq/wireformat/openwire/utils/OpenwireStringSupportTest.h \
+    decaf/internal/net/URIEncoderDecoderTest.h \
+    decaf/internal/net/URIHelperTest.h \
+    decaf/internal/nio/BufferFactoryTest.h \
+    decaf/internal/nio/ByteArrayBufferTest.h \
+    decaf/internal/nio/ByteArrayPerspectiveTest.h \
+    decaf/internal/nio/CharArrayBufferTest.h \
+    decaf/internal/nio/DoubleArrayBufferTest.h \
+    decaf/internal/nio/FloatArrayBufferTest.h \
+    decaf/internal/nio/IntArrayBufferTest.h \
+    decaf/internal/nio/LongArrayBufferTest.h \
+    decaf/internal/nio/ShortArrayBufferTest.h \
+    decaf/internal/util/ByteArrayAdapterTest.h \
+    decaf/io/BufferedInputStreamTest.h \
+    decaf/io/BufferedOutputStreamTest.h \
+    decaf/io/ByteArrayInputStreamTest.h \
+    decaf/io/ByteArrayOutputStreamTest.h \
+    decaf/io/DataInputStreamTest.h \
+    decaf/io/DataOutputStreamTest.h \
+    decaf/io/FilterInputStreamTest.h \
+    decaf/io/FilterOutputStreamTest.h \
+    decaf/lang/BooleanTest.h \
+    decaf/lang/ByteTest.h \
     decaf/lang/CharacterTest.h \
     decaf/lang/DoubleTest.h \
-    decaf/lang/BooleanTest.h \
-    decaf/lang/ThreadTest.h \
-    decaf/lang/ShortTest.h \
     decaf/lang/ExceptionTest.h \
-    decaf/lang/MathTest.h \
     decaf/lang/FloatTest.h \
-    decaf/lang/PointerTest.h \
     decaf/lang/IntegerTest.h \
+    decaf/lang/LongTest.h \
+    decaf/lang/MathTest.h \
+    decaf/lang/PointerTest.h \
+    decaf/lang/ShortTest.h \
     decaf/lang/SystemTest.h \
-    decaf/lang/ByteTest.h \
-    decaf/util/StlMapTest.h \
+    decaf/lang/ThreadTest.h \
+    decaf/net/SocketFactoryTest.h \
+    decaf/net/SocketTest.h \
+    decaf/net/URISyntaxExceptionTest.h \
+    decaf/net/URITest.h \
+    decaf/net/URLDecoderTest.h \
+    decaf/net/URLEncoderTest.h \
+    decaf/nio/BufferTest.h \
+    decaf/util/DateTest.h \
+    decaf/util/Endian.h \
     decaf/util/ListTest.h \
-    decaf/util/UUIDTest.h \
-    decaf/util/StringTokenizerTest.h \
+    decaf/util/PropertiesTest.h \
     decaf/util/QueueTest.h \
-    decaf/util/concurrent/MutexTest.h \
+    decaf/util/RandomTest.h \
+    decaf/util/SetTest.h \
+    decaf/util/StlMapTest.h \
+    decaf/util/StringTokenizerTest.h \
+    decaf/util/UUIDTest.h \
     decaf/util/concurrent/ConcurrentStlMapTest.h \
-    decaf/util/concurrent/ThreadPoolTest.h \
     decaf/util/concurrent/CountDownLatchTest.h \
-    decaf/util/concurrent/atomic/AtomicReferenceTest.h \
+    decaf/util/concurrent/MutexTest.h \
+    decaf/util/concurrent/ThreadPoolTest.h \
+    decaf/util/concurrent/TimeUnitTest.h \
     decaf/util/concurrent/atomic/AtomicBooleanTest.h \
     decaf/util/concurrent/atomic/AtomicIntegerTest.h \
-    decaf/util/concurrent/TimeUnitTest.h \
-    decaf/util/DateTest.h \
-    decaf/util/PropertiesTest.h \
-    decaf/util/Endian.h \
-    decaf/util/SetTest.h \
-    decaf/util/RandomTest.h \
-    decaf/internal/util/ByteArrayAdapterTest.h \
-    decaf/internal/nio/ByteArrayPerspectiveTest.h \
-    decaf/internal/nio/ByteArrayBufferTest.h \
-    decaf/internal/nio/IntArrayBufferTest.h \
-    decaf/internal/nio/BufferFactoryTest.h \
-    decaf/internal/nio/ShortArrayBufferTest.h \
-    decaf/internal/nio/LongArrayBufferTest.h \
-    decaf/internal/nio/DoubleArrayBufferTest.h \
-    decaf/internal/nio/CharArrayBufferTest.h \
-    decaf/internal/nio/FloatArrayBufferTest.h \
-    decaf/internal/net/URIHelperTest.h \
-    decaf/internal/net/URIEncoderDecoderTest.h \
-    decaf/nio/BufferTest.h \
-    decaf/net/SocketTest.h \
-    decaf/net/URLEncoderTest.h \
-    decaf/net/URISyntaxExceptionTest.h \
-    decaf/net/URLDecoderTest.h \
-    decaf/net/SocketFactoryTest.h \
-    decaf/net/URITest.h \
-    decaf/io/FilterInputStreamTest.h \
-    decaf/io/BufferedOutputStreamTest.h \
-    decaf/io/ByteArrayInputStreamTest.h \
-    decaf/io/ByteArrayOutputStreamTest.h \
-    decaf/io/DataOutputStreamTest.h \
-    decaf/io/FilterOutputStreamTest.h \
-    decaf/io/DataInputStreamTest.h \
-    decaf/io/BufferedInputStreamTest.h \
-    util/teamcity/TeamCityProgressListener.h \
-    activemq/transport/IOTransportTest.h \
-    activemq/transport/mock/MockTransportFactoryTest.h \
-    activemq/transport/failover/FailoverTransportTest.h \
-    activemq/transport/correlator/ResponseCorrelatorTest.h \
-    activemq/transport/TransportRegistryTest.h \
-    activemq/wireformat/openwire/OpenWireFormatTest.h \
-    activemq/wireformat/openwire/marshal/BaseDataStreamMarshallerTest.h \
-    activemq/wireformat/openwire/marshal/PrimitiveTypesMarshallerTest.h \
-    activemq/wireformat/openwire/utils/MessagePropertyInterceptorTest.h \
-    activemq/wireformat/openwire/utils/OpenwireStringSupportTest.h \
-    activemq/wireformat/openwire/utils/HexTableTest.h \
-    activemq/wireformat/openwire/utils/BooleanStreamTest.h \
-    activemq/wireformat/WireFormatRegistryTest.h \
-    activemq/cmsutil/DynamicDestinationResolverTest.h \
-    activemq/cmsutil/SessionPoolTest.h \
-    activemq/cmsutil/DummySession.h \
-    activemq/cmsutil/MessageContext.h \
-    activemq/cmsutil/DummyConsumer.h \
-    activemq/cmsutil/DummyMessage.h \
-    activemq/cmsutil/DummyConnection.h \
-    activemq/cmsutil/CmsDestinationAccessorTest.h \
-    activemq/cmsutil/DummyProducer.h \
-    activemq/cmsutil/CmsTemplateTest.h \
-    activemq/cmsutil/DummyConnectionFactory.h \
-    activemq/cmsutil/CmsAccessorTest.h \
-    activemq/cmsutil/DummyMessageCreator.h \
-    activemq/util/PrimitiveValueNodeTest.h \
-    activemq/util/PrimitiveMapTest.h \
-    activemq/util/PrimitiveListTest.h \
-    activemq/util/PrimitiveValueConverterTest.h \
-    activemq/util/URISupportTest.h \
-    activemq/util/LongSequenceGeneratorTest.h \
-    activemq/util/MemoryUsageTest.h \
-    activemq/state/ConnectionStateTrackerTest.h \
-    activemq/state/ConnectionStateTest.h \
-    activemq/state/ProducerStateTest.h \
-    activemq/state/TransactionStateTest.h \
-    activemq/state/ConsumerStateTest.h \
-    activemq/state/SessionStateTest.h \
-    activemq/exceptions/ActiveMQExceptionTest.h \
-    activemq/threads/CompositeTaskRunnerTest.h \
-    activemq/threads/DedicatedTaskRunnerTest.h \
-    activemq/core/ActiveMQConnectionFactoryTest.h \
-    activemq/core/ActiveMQConnectionTest.h \
-    activemq/core/ActiveMQSessionTest.h \
-    activemq/core/MessageDispatchChannelTest.h \
-    activemq/commands/ActiveMQStreamMessageTest.h \
-    activemq/commands/ActiveMQTempTopicTest.h \
-    activemq/commands/ActiveMQQueueTest.h \
-    activemq/commands/ActiveMQBytesMessageTest.h \
-    activemq/commands/ActiveMQMessageTest.h \
-    activemq/commands/ActiveMQMapMessageTest.h \
-    activemq/commands/BrokerIdTest.h \
-    activemq/commands/ActiveMQTempQueueTest.h \
-    activemq/commands/BrokerInfoTest.h \
-    activemq/commands/ActiveMQDestinationTest2.h \
-    activemq/commands/ActiveMQTextMessageTest.h \
-    activemq/commands/ActiveMQTopicTest.h
+    decaf/util/concurrent/atomic/AtomicReferenceTest.h \
+    util/teamcity/TeamCityProgressListener.h
 
 
 ## include activemq/wireformat/openwire/marshal/v1/srcmakefile.mk

Modified: activemq/activemq-cpp/trunk/maven-cpptools-plugin/pom.xml
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/maven-cpptools-plugin/pom.xml?rev=788887&r1=788886&r2=788887&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/maven-cpptools-plugin/pom.xml (original)
+++ activemq/activemq-cpp/trunk/maven-cpptools-plugin/pom.xml Fri Jun 26 22:14:01 2009
@@ -23,13 +23,11 @@
   <modelVersion>4.0.0</modelVersion>
 
   <parent>
-    <groupId>org.apache.activemq</groupId>
+    <groupId>org.apache.activemq-cpp</groupId>
     <artifactId>activemq-cpp-parent</artifactId>
     <version>3.0.1-SNAPSHOT</version>
-    <relativePath>../pom.xml</relativePath>
   </parent>
 
-  <groupId>org.apache.activemq</groupId>
   <artifactId>maven-cpptools-plugin</artifactId>
   <packaging>maven-plugin</packaging>
   <name>CPP Maven Project Tools Plugin</name>

Modified: activemq/activemq-cpp/trunk/maven-cpptools-plugin/src/main/java/org/apache/activemq/maven/MakefileMojo.java
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/maven-cpptools-plugin/src/main/java/org/apache/activemq/maven/MakefileMojo.java?rev=788887&r1=788886&r2=788887&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/maven-cpptools-plugin/src/main/java/org/apache/activemq/maven/MakefileMojo.java (original)
+++ activemq/activemq-cpp/trunk/maven-cpptools-plugin/src/main/java/org/apache/activemq/maven/MakefileMojo.java Fri Jun 26 22:14:01 2009
@@ -24,6 +24,7 @@
 import java.io.File;
 import java.io.FileReader;
 import java.io.FileWriter;
+import java.util.Collections;
 import java.util.List;
 
 /**
@@ -110,6 +111,8 @@
 
         List<File> files = sources.getFiles();
 
+        Collections.sort( files );
+
         int pos = 0;
 
         if( ( pos = line.indexOf( marker ) ) != -1 ) {