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 2012/04/08 19:26:34 UTC

svn commit: r1311058 - in /activemq/activemq-cpp/trunk/activemq-cpp: src/main/decaf/internal/util/concurrent/windows/ src/test/decaf/util/concurrent/locks/ vs2008-build/

Author: tabish
Date: Sun Apr  8 17:26:34 2012
New Revision: 1311058

URL: http://svn.apache.org/viewvc?rev=1311058&view=rev
Log:
Update project files to include new files added and fix some windows build issues.

Modified:
    activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/internal/util/concurrent/windows/Atomics.cpp
    activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/internal/util/concurrent/windows/PlatformDefs.h
    activemq/activemq-cpp/trunk/activemq-cpp/src/test/decaf/util/concurrent/locks/AbstractQueuedSynchronizerTest.cpp
    activemq/activemq-cpp/trunk/activemq-cpp/vs2008-build/activemq-cpp-integration-tests.vcproj
    activemq/activemq-cpp/trunk/activemq-cpp/vs2008-build/activemq-cpp-unittests.vcproj
    activemq/activemq-cpp/trunk/activemq-cpp/vs2008-build/activemq-cpp.vcproj

Modified: activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/internal/util/concurrent/windows/Atomics.cpp
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/internal/util/concurrent/windows/Atomics.cpp?rev=1311058&r1=1311057&r2=1311058&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/internal/util/concurrent/windows/Atomics.cpp (original)
+++ activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/internal/util/concurrent/windows/Atomics.cpp Sun Apr  8 17:26:34 2012
@@ -31,51 +31,51 @@ void Atomics::shutdown() {
 
 ////////////////////////////////////////////////////////////////////////////////
 bool Atomics::compareAndSet32(volatile int* target, int expect, int update ) {
-    return InterlockedCompareExchange((volatile apr_uint32_t*)target, update, expect) == (unsigned int)expect;
+	return ::InterlockedCompareExchange((volatile LONG*)target, update, expect) == (unsigned int)expect;
 }
 
 ////////////////////////////////////////////////////////////////////////////////
 bool Atomics::compareAndSet(volatile void** target, void* expect, void* update) {
-    return InterlockedCompareExchangePointer( target, (void*)update, (void*)expect ) == (void*)expect;
+	return ::InterlockedCompareExchangePointer((volatile PVOID*)target, (void*)update, (void*)expect ) == (void*)expect;
 }
 
 ////////////////////////////////////////////////////////////////////////////////
 int Atomics::getAndSet(volatile int* target, int newValue) {
-    return InterlockedExchange((volatile apr_uint32_t*)target, newValue);
+	return ::InterlockedExchange((volatile LONG*)target, newValue);
 }
 
 ////////////////////////////////////////////////////////////////////////////////
 void* Atomics::getAndSet(volatile void** target, void* newValue) {
-    return InterlockedExchangePointer(target, newValue);
+	return InterlockedExchangePointer((volatile PVOID*)target, newValue);
 }
 
 ////////////////////////////////////////////////////////////////////////////////
 int Atomics::getAndIncrement(volatile int* target) {
-    return InterlockedIncrement((volatile apr_uint32_t*)target);
+	return ::InterlockedIncrement((volatile LONG*)target);
 }
 
 ////////////////////////////////////////////////////////////////////////////////
 int Atomics::getAndDecrement(volatile int* target) {
-    return InterlockedExchangeAdd((volatile apr_uint32_t*)target, 0xFFFFFFFF);
+	return ::InterlockedExchangeAdd((volatile LONG*)target, 0xFFFFFFFF);
 }
 
 ////////////////////////////////////////////////////////////////////////////////
 int Atomics::getAndAdd(volatile int* target, int delta) {
-    return InterlockedExchangeAdd((volatile apr_uint32_t*)target, delta);
+	return ::InterlockedExchangeAdd((volatile LONG*)target, delta);
 }
 
 ////////////////////////////////////////////////////////////////////////////////
 int Atomics::addAndGet(volatile int* target, int delta) {
-    return InterlockedExchangeAdd((volatile apr_uint32_t*)target, delta) + delta;
+	return ::InterlockedExchangeAdd((volatile LONG*)target, delta) + delta;
 }
 
 ////////////////////////////////////////////////////////////////////////////////
 int Atomics::incrementAndGet(volatile int* target) {
-    return InterlockedIncrement((volatile apr_uint32_t*)target) + 1;
+	return ::InterlockedIncrement((volatile LONG*)target) + 1;
 }
 
 ////////////////////////////////////////////////////////////////////////////////
 int Atomics::decrementAndGet(volatile int* target) {
-    return InterlockedExchangeAdd((volatile apr_uint32_t*)target, 0xFFFFFFFF) - 1;
+	return ::InterlockedExchangeAdd((volatile LONG*)target, 0xFFFFFFFF) - 1;
 }
 

Modified: activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/internal/util/concurrent/windows/PlatformDefs.h
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/internal/util/concurrent/windows/PlatformDefs.h?rev=1311058&r1=1311057&r2=1311058&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/internal/util/concurrent/windows/PlatformDefs.h (original)
+++ activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/internal/util/concurrent/windows/PlatformDefs.h Sun Apr  8 17:26:34 2012
@@ -50,7 +50,7 @@ namespace concurrent{
     struct RWLOCK {
         HANDLE writeMutex;
         HANDLE readEvent;
-        LONG readers;
+        volatile LONG readers;
     };
 
     typedef void* PLATFORM_THREAD_ENTRY_ARG;

Modified: activemq/activemq-cpp/trunk/activemq-cpp/src/test/decaf/util/concurrent/locks/AbstractQueuedSynchronizerTest.cpp
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/activemq-cpp/src/test/decaf/util/concurrent/locks/AbstractQueuedSynchronizerTest.cpp?rev=1311058&r1=1311057&r2=1311058&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/activemq-cpp/src/test/decaf/util/concurrent/locks/AbstractQueuedSynchronizerTest.cpp (original)
+++ activemq/activemq-cpp/trunk/activemq-cpp/src/test/decaf/util/concurrent/locks/AbstractQueuedSynchronizerTest.cpp Sun Apr  8 17:26:34 2012
@@ -669,7 +669,7 @@ void AbstractQueuedSynchronizerTest::tes
     AbstractQueuedSynchronizer::ConditionObject* c = mutex.newCondition();
     try {
         mutex.acquire(1);
-        long t = c->awaitNanos(100);
+        long long t = c->awaitNanos(100);
         CPPUNIT_ASSERT(t <= 0);
         mutex.release(1);
     } catch(Exception& ex) {

Modified: activemq/activemq-cpp/trunk/activemq-cpp/vs2008-build/activemq-cpp-integration-tests.vcproj
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/activemq-cpp/vs2008-build/activemq-cpp-integration-tests.vcproj?rev=1311058&r1=1311057&r2=1311058&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/activemq-cpp/vs2008-build/activemq-cpp-integration-tests.vcproj (original)
+++ activemq/activemq-cpp/trunk/activemq-cpp/vs2008-build/activemq-cpp-integration-tests.vcproj Sun Apr  8 17:26:34 2012
@@ -916,6 +916,14 @@
 							>
 						</File>
 						<File
+							RelativePath="..\src\test-integration\activemq\test\openwire\OpenwireJmsRecoverTest.cpp"
+							>
+						</File>
+						<File
+							RelativePath="..\src\test-integration\activemq\test\openwire\OpenwireJmsRecoverTest.h"
+							>
+						</File>
+						<File
 							RelativePath="..\src\test-integration\activemq\test\openwire\OpenwireMapMessageTest.cpp"
 							>
 						</File>

Modified: activemq/activemq-cpp/trunk/activemq-cpp/vs2008-build/activemq-cpp-unittests.vcproj
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/activemq-cpp/vs2008-build/activemq-cpp-unittests.vcproj?rev=1311058&r1=1311057&r2=1311058&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/activemq-cpp/vs2008-build/activemq-cpp-unittests.vcproj (original)
+++ activemq/activemq-cpp/trunk/activemq-cpp/vs2008-build/activemq-cpp-unittests.vcproj Sun Apr  8 17:26:34 2012
@@ -2354,6 +2354,14 @@
 					Name="concurrent"
 					>
 					<File
+						RelativePath="..\src\test\decaf\util\concurrent\AbstractExecutorServiceTest.cpp"
+						>
+					</File>
+					<File
+						RelativePath="..\src\test\decaf\util\concurrent\AbstractExecutorServiceTest.h"
+						>
+					</File>
+					<File
 						RelativePath="..\src\test\decaf\util\concurrent\ConcurrentStlMapTest.cpp"
 						>
 					</File>
@@ -2402,6 +2410,14 @@
 						>
 					</File>
 					<File
+						RelativePath="..\src\test\decaf\util\concurrent\FutureTaskTest.cpp"
+						>
+					</File>
+					<File
+						RelativePath="..\src\test\decaf\util\concurrent\FutureTaskTest.h"
+						>
+					</File>
+					<File
 						RelativePath="..\src\test\decaf\util\concurrent\LinkedBlockingQueueTest.cpp"
 						>
 					</File>
@@ -2418,6 +2434,22 @@
 						>
 					</File>
 					<File
+						RelativePath="..\src\test\decaf\util\concurrent\SemaphoreTest.cpp"
+						>
+					</File>
+					<File
+						RelativePath="..\src\test\decaf\util\concurrent\SemaphoreTest.h"
+						>
+					</File>
+					<File
+						RelativePath="..\src\test\decaf\util\concurrent\SynchronousQueueTest.cpp"
+						>
+					</File>
+					<File
+						RelativePath="..\src\test\decaf\util\concurrent\SynchronousQueueTest.h"
+						>
+					</File>
+					<File
 						RelativePath="..\src\test\decaf\util\concurrent\ThreadPoolExecutorTest.cpp"
 						>
 					</File>
@@ -2465,6 +2497,14 @@
 						Name="locks"
 						>
 						<File
+							RelativePath="..\src\test\decaf\util\concurrent\locks\AbstractQueuedSynchronizerTest.cpp"
+							>
+						</File>
+						<File
+							RelativePath="..\src\test\decaf\util\concurrent\locks\AbstractQueuedSynchronizerTest.h"
+							>
+						</File>
+						<File
 							RelativePath="..\src\test\decaf\util\concurrent\locks\LockSupportTest.cpp"
 							>
 						</File>
@@ -2472,6 +2512,14 @@
 							RelativePath="..\src\test\decaf\util\concurrent\locks\LockSupportTest.h"
 							>
 						</File>
+						<File
+							RelativePath="..\src\test\decaf\util\concurrent\locks\ReentrantLockTest.cpp"
+							>
+						</File>
+						<File
+							RelativePath="..\src\test\decaf\util\concurrent\locks\ReentrantLockTest.h"
+							>
+						</File>
 					</Filter>
 				</Filter>
 				<Filter

Modified: activemq/activemq-cpp/trunk/activemq-cpp/vs2008-build/activemq-cpp.vcproj
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/activemq-cpp/vs2008-build/activemq-cpp.vcproj?rev=1311058&r1=1311057&r2=1311058&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/activemq-cpp/vs2008-build/activemq-cpp.vcproj (original)
+++ activemq/activemq-cpp/trunk/activemq-cpp/vs2008-build/activemq-cpp.vcproj Sun Apr  8 17:26:34 2012
@@ -2748,6 +2748,42 @@
 						>
 					</File>
 				</Filter>
+				<Filter
+					Name="kernels"
+					>
+					<File
+						RelativePath="..\src\main\activemq\core\kernels\ActiveMQConsumerKernel.cpp"
+						>
+					</File>
+					<File
+						RelativePath="..\src\main\activemq\core\kernels\ActiveMQConsumerKernel.h"
+						>
+					</File>
+					<File
+						RelativePath="..\src\main\activemq\core\kernels\ActiveMQProducerKernel.cpp"
+						>
+					</File>
+					<File
+						RelativePath="..\src\main\activemq\core\kernels\ActiveMQProducerKernel.h"
+						>
+					</File>
+					<File
+						RelativePath="..\src\main\activemq\core\kernels\ActiveMQSessionKernel.cpp"
+						>
+					</File>
+					<File
+						RelativePath="..\src\main\activemq\core\kernels\ActiveMQSessionKernel.h"
+						>
+					</File>
+					<File
+						RelativePath="..\src\main\activemq\core\kernels\ActiveMQXASessionKernel.cpp"
+						>
+					</File>
+					<File
+						RelativePath="..\src\main\activemq\core\kernels\ActiveMQXASessionKernel.h"
+						>
+					</File>
+				</Filter>
 			</Filter>
 			<Filter
 				Name="exceptions"
@@ -4375,6 +4411,18 @@
 						Name="concurrent"
 						>
 						<File
+							RelativePath="..\src\main\decaf\internal\util\concurrent\Atomics.h"
+							>
+						</File>
+						<File
+							RelativePath="..\src\main\decaf\internal\util\concurrent\ExecutorsSupport.cpp"
+							>
+						</File>
+						<File
+							RelativePath="..\src\main\decaf\internal\util\concurrent\ExecutorsSupport.h"
+							>
+						</File>
+						<File
 							RelativePath="..\src\main\decaf\internal\util\concurrent\PlatformThread.h"
 							>
 						</File>
@@ -4414,6 +4462,10 @@
 							Name="windows"
 							>
 							<File
+								RelativePath="..\src\main\decaf\internal\util\concurrent\windows\Atomics.cpp"
+								>
+							</File>
+							<File
 								RelativePath="..\src\main\decaf\internal\util\concurrent\windows\PlatformDefs.h"
 								>
 							</File>
@@ -5768,6 +5820,14 @@
 						>
 					</File>
 					<File
+						RelativePath="..\src\main\decaf\util\concurrent\FutureTask.cpp"
+						>
+					</File>
+					<File
+						RelativePath="..\src\main\decaf\util\concurrent\FutureTask.h"
+						>
+					</File>
+					<File
 						RelativePath="..\src\main\decaf\util\concurrent\LinkedBlockingQueue.cpp"
 						>
 					</File>
@@ -5804,6 +5864,14 @@
 						>
 					</File>
 					<File
+						RelativePath="..\src\main\decaf\util\concurrent\RunnableFuture.cpp"
+						>
+					</File>
+					<File
+						RelativePath="..\src\main\decaf\util\concurrent\RunnableFuture.h"
+						>
+					</File>
+					<File
 						RelativePath="..\src\main\decaf\util\concurrent\Semaphore.cpp"
 						>
 					</File>
@@ -5899,6 +5967,14 @@
 							>
 						</File>
 						<File
+							RelativePath="..\src\main\decaf\util\concurrent\locks\AbstractQueuedSynchronizer.cpp"
+							>
+						</File>
+						<File
+							RelativePath="..\src\main\decaf\util\concurrent\locks\AbstractQueuedSynchronizer.h"
+							>
+						</File>
+						<File
 							RelativePath="..\src\main\decaf\util\concurrent\locks\Condition.h"
 							>
 						</File>
@@ -5919,6 +5995,10 @@
 							>
 						</File>
 						<File
+							RelativePath="..\src\main\decaf\util\concurrent\locks\ReentrantLock.cpp"
+							>
+						</File>
+						<File
 							RelativePath="..\src\main\decaf\util\concurrent\locks\ReentrantLock.h"
 							>
 						</File>