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 2007/07/26 16:29:28 UTC

svn commit: r559828 - in /activemq/activemq-cpp/trunk/src/decaf/src: main/decaf/io/ main/decaf/net/ test/ test/decaf/io/ test/decaf/net/

Author: tabish
Date: Thu Jul 26 07:29:25 2007
New Revision: 559828

URL: http://svn.apache.org/viewvc?view=rev&rev=559828
Log:
http://issues.apache.org/activemq/browse/AMQCPP-103

Working on APRizing the sockets, currently somewhat functional.

Modified:
    activemq/activemq-cpp/trunk/src/decaf/src/main/decaf/io/BlockingByteArrayInputStream.cpp
    activemq/activemq-cpp/trunk/src/decaf/src/main/decaf/io/BlockingByteArrayInputStream.h
    activemq/activemq-cpp/trunk/src/decaf/src/main/decaf/io/BufferedInputStream.cpp
    activemq/activemq-cpp/trunk/src/decaf/src/main/decaf/io/BufferedInputStream.h
    activemq/activemq-cpp/trunk/src/decaf/src/main/decaf/io/ByteArrayInputStream.cpp
    activemq/activemq-cpp/trunk/src/decaf/src/main/decaf/io/ByteArrayInputStream.h
    activemq/activemq-cpp/trunk/src/decaf/src/main/decaf/io/DataInputStream.cpp
    activemq/activemq-cpp/trunk/src/decaf/src/main/decaf/io/DataInputStream.h
    activemq/activemq-cpp/trunk/src/decaf/src/main/decaf/io/FilterInputStream.h
    activemq/activemq-cpp/trunk/src/decaf/src/main/decaf/io/InputStream.h
    activemq/activemq-cpp/trunk/src/decaf/src/main/decaf/net/SocketInputStream.cpp
    activemq/activemq-cpp/trunk/src/decaf/src/main/decaf/net/SocketInputStream.h
    activemq/activemq-cpp/trunk/src/decaf/src/test/decaf/io/BufferedInputStreamTest.h
    activemq/activemq-cpp/trunk/src/decaf/src/test/decaf/net/SocketFactoryTest.h
    activemq/activemq-cpp/trunk/src/decaf/src/test/decaf/net/SocketTest.h
    activemq/activemq-cpp/trunk/src/decaf/src/test/testRegistry.cpp

Modified: activemq/activemq-cpp/trunk/src/decaf/src/main/decaf/io/BlockingByteArrayInputStream.cpp
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/decaf/src/main/decaf/io/BlockingByteArrayInputStream.cpp?view=diff&rev=559828&r1=559827&r2=559828
==============================================================================
--- activemq/activemq-cpp/trunk/src/decaf/src/main/decaf/io/BlockingByteArrayInputStream.cpp (original)
+++ activemq/activemq-cpp/trunk/src/decaf/src/main/decaf/io/BlockingByteArrayInputStream.cpp Thu Jul 26 07:29:25 2007
@@ -101,9 +101,9 @@
 }
 
 ////////////////////////////////////////////////////////////////////////////////
-std::size_t BlockingByteArrayInputStream::read( unsigned char* buffer,
-                                                std::size_t bufferSize )
-                                                throw ( IOException ){
+int BlockingByteArrayInputStream::read( unsigned char* buffer,
+                                        std::size_t bufferSize )
+                                            throw ( IOException ){
     synchronized( this ){
 
         std::size_t ix = 0;

Modified: activemq/activemq-cpp/trunk/src/decaf/src/main/decaf/io/BlockingByteArrayInputStream.h
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/decaf/src/main/decaf/io/BlockingByteArrayInputStream.h?view=diff&rev=559828&r1=559827&r2=559828
==============================================================================
--- activemq/activemq-cpp/trunk/src/decaf/src/main/decaf/io/BlockingByteArrayInputStream.h (original)
+++ activemq/activemq-cpp/trunk/src/decaf/src/main/decaf/io/BlockingByteArrayInputStream.h Thu Jul 26 07:29:25 2007
@@ -171,10 +171,10 @@
          * in the buffer via a call to setByteArray.
          * @param buffer (out) the target buffer
          * @param bufferSize the size of the output buffer.
-         * @return the number of bytes read.
+         * @return the number of bytes read. or -1 if EOF
          * @throws IOException f an error occurs.
          */
-        virtual std::size_t read( unsigned char* buffer, std::size_t bufferSize )
+        virtual int read( unsigned char* buffer, std::size_t bufferSize )
             throw ( IOException );
 
         /**

Modified: activemq/activemq-cpp/trunk/src/decaf/src/main/decaf/io/BufferedInputStream.cpp
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/decaf/src/main/decaf/io/BufferedInputStream.cpp?view=diff&rev=559828&r1=559827&r2=559828
==============================================================================
--- activemq/activemq-cpp/trunk/src/decaf/src/main/decaf/io/BufferedInputStream.cpp (original)
+++ activemq/activemq-cpp/trunk/src/decaf/src/main/decaf/io/BufferedInputStream.cpp Thu Jul 26 07:29:25 2007
@@ -85,8 +85,8 @@
 }
 
 ////////////////////////////////////////////////////////////////////////////////
-std::size_t BufferedInputStream::read( unsigned char* targetBuffer,
-    std::size_t targetBufferSize ) throw ( IOException ){
+int BufferedInputStream::read( unsigned char* targetBuffer,
+                               std::size_t targetBufferSize ) throw ( IOException ){
 
     try{
         // If there's no data left, reset to pointers to the beginning of the

Modified: activemq/activemq-cpp/trunk/src/decaf/src/main/decaf/io/BufferedInputStream.h
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/decaf/src/main/decaf/io/BufferedInputStream.h?view=diff&rev=559828&r1=559827&r2=559828
==============================================================================
--- activemq/activemq-cpp/trunk/src/decaf/src/main/decaf/io/BufferedInputStream.h (original)
+++ activemq/activemq-cpp/trunk/src/decaf/src/main/decaf/io/BufferedInputStream.h Thu Jul 26 07:29:25 2007
@@ -101,7 +101,7 @@
          * @return The number of bytes read.
          * @throws IOException thrown if an error occurs.
          */
-        virtual std::size_t read( unsigned char* buffer, std::size_t bufferSize )
+        virtual int read( unsigned char* buffer, std::size_t bufferSize )
             throw ( IOException );
 
         /**

Modified: activemq/activemq-cpp/trunk/src/decaf/src/main/decaf/io/ByteArrayInputStream.cpp
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/decaf/src/main/decaf/io/ByteArrayInputStream.cpp?view=diff&rev=559828&r1=559827&r2=559828
==============================================================================
--- activemq/activemq-cpp/trunk/src/decaf/src/main/decaf/io/ByteArrayInputStream.cpp (original)
+++ activemq/activemq-cpp/trunk/src/decaf/src/main/decaf/io/ByteArrayInputStream.cpp Thu Jul 26 07:29:25 2007
@@ -91,8 +91,8 @@
 }
 
 ////////////////////////////////////////////////////////////////////////////////
-std::size_t ByteArrayInputStream::read( unsigned char* buffer,
-                                        std::size_t bufferSize )
+int ByteArrayInputStream::read( unsigned char* buffer,
+                                std::size_t bufferSize )
                                    throw ( IOException ){
     std::size_t ix = 0;
 

Modified: activemq/activemq-cpp/trunk/src/decaf/src/main/decaf/io/ByteArrayInputStream.h
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/decaf/src/main/decaf/io/ByteArrayInputStream.h?view=diff&rev=559828&r1=559827&r2=559828
==============================================================================
--- activemq/activemq-cpp/trunk/src/decaf/src/main/decaf/io/ByteArrayInputStream.h (original)
+++ activemq/activemq-cpp/trunk/src/decaf/src/main/decaf/io/ByteArrayInputStream.h Thu Jul 26 07:29:25 2007
@@ -187,7 +187,7 @@
          * @return The number of bytes read.
          * @throws IOException thrown if an error occurs.
          */
-        virtual std::size_t read( unsigned char* buffer, std::size_t bufferSize )
+        virtual int read( unsigned char* buffer, std::size_t bufferSize )
             throw ( IOException );
 
         /**

Modified: activemq/activemq-cpp/trunk/src/decaf/src/main/decaf/io/DataInputStream.cpp
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/decaf/src/main/decaf/io/DataInputStream.cpp?view=diff&rev=559828&r1=559827&r2=559828
==============================================================================
--- activemq/activemq-cpp/trunk/src/decaf/src/main/decaf/io/DataInputStream.cpp (original)
+++ activemq/activemq-cpp/trunk/src/decaf/src/main/decaf/io/DataInputStream.cpp Thu Jul 26 07:29:25 2007
@@ -32,7 +32,7 @@
 DataInputStream::~DataInputStream() {}
 
 ////////////////////////////////////////////////////////////////////////////////
-std::size_t DataInputStream::read( std::vector<unsigned char>& buffer )
+int DataInputStream::read( std::vector<unsigned char>& buffer )
     throw ( io::IOException ) {
 
     try {
@@ -43,9 +43,9 @@
 }
 
 ////////////////////////////////////////////////////////////////////////////////
-std::size_t DataInputStream::read( unsigned char* buffer,
-                                   std::size_t offset,
-                                   std::size_t length )
+int DataInputStream::read( unsigned char* buffer,
+                           std::size_t offset,
+                           std::size_t length )
     throw ( IOException, IndexOutOfBoundsException, NullPointerException ) {
 
     try {

Modified: activemq/activemq-cpp/trunk/src/decaf/src/main/decaf/io/DataInputStream.h
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/decaf/src/main/decaf/io/DataInputStream.h?view=diff&rev=559828&r1=559827&r2=559828
==============================================================================
--- activemq/activemq-cpp/trunk/src/decaf/src/main/decaf/io/DataInputStream.h (original)
+++ activemq/activemq-cpp/trunk/src/decaf/src/main/decaf/io/DataInputStream.h Thu Jul 26 07:29:25 2007
@@ -86,7 +86,7 @@
          *          more data because the stream is EOF.
          * @throws IOException
          */
-        virtual std::size_t read( std::vector< unsigned char >& buffer )
+        virtual int read( std::vector< unsigned char >& buffer )
             throw ( io::IOException );
 
         /**
@@ -130,9 +130,9 @@
          *          more data because the stream is EOF.
          * @throws IOException
          */
-        virtual std::size_t read( unsigned char* buffer,
-                                  std::size_t offset,
-                                  std::size_t length )
+        virtual int read( unsigned char* buffer,
+                          std::size_t offset,
+                          std::size_t length )
             throw ( io::IOException,
                     lang::exceptions::IndexOutOfBoundsException,
                     lang::exceptions::NullPointerException );

Modified: activemq/activemq-cpp/trunk/src/decaf/src/main/decaf/io/FilterInputStream.h
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/decaf/src/main/decaf/io/FilterInputStream.h?view=diff&rev=559828&r1=559827&r2=559828
==============================================================================
--- activemq/activemq-cpp/trunk/src/decaf/src/main/decaf/io/FilterInputStream.h (original)
+++ activemq/activemq-cpp/trunk/src/decaf/src/main/decaf/io/FilterInputStream.h Thu Jul 26 07:29:25 2007
@@ -108,7 +108,7 @@
          * @return The number of bytes read or -1 if EOS is detected
          * @throws IOException thrown if an error occurs.
          */
-        virtual std::size_t read( unsigned char* buffer, std::size_t bufferSize )
+        virtual int read( unsigned char* buffer, std::size_t bufferSize )
             throw ( IOException )
         {
             try {

Modified: activemq/activemq-cpp/trunk/src/decaf/src/main/decaf/io/InputStream.h
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/decaf/src/main/decaf/io/InputStream.h?view=diff&rev=559828&r1=559827&r2=559828
==============================================================================
--- activemq/activemq-cpp/trunk/src/decaf/src/main/decaf/io/InputStream.h (original)
+++ activemq/activemq-cpp/trunk/src/decaf/src/main/decaf/io/InputStream.h Thu Jul 26 07:29:25 2007
@@ -60,7 +60,7 @@
          * @return The number of bytes read or -1 if EOF is detected
          * @throws IOException thrown if an error occurs.
          */
-        virtual std::size_t read( unsigned char* buffer, std::size_t bufferSize )
+        virtual int read( unsigned char* buffer, std::size_t bufferSize )
             throw ( IOException ) = 0;
 
         /**
@@ -79,7 +79,8 @@
          * @returns total butes skipped
          * @throws IOException if an error occurs
          */
-        virtual std::size_t skip( std::size_t num ) throw ( io::IOException, lang::exceptions::UnsupportedOperationException ) = 0;
+        virtual std::size_t skip( std::size_t num )
+            throw ( io::IOException, lang::exceptions::UnsupportedOperationException ) = 0;
 
     };
 

Modified: activemq/activemq-cpp/trunk/src/decaf/src/main/decaf/net/SocketInputStream.cpp
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/decaf/src/main/decaf/net/SocketInputStream.cpp?view=diff&rev=559828&r1=559827&r2=559828
==============================================================================
--- activemq/activemq-cpp/trunk/src/decaf/src/main/decaf/net/SocketInputStream.cpp (original)
+++ activemq/activemq-cpp/trunk/src/decaf/src/main/decaf/net/SocketInputStream.cpp Thu Jul 26 07:29:25 2007
@@ -144,8 +144,8 @@
 }
 
 ////////////////////////////////////////////////////////////////////////////////
-std::size_t SocketInputStream::read( unsigned char* buffer,
-                                     std::size_t bufferSize ) throw ( IOException )
+int SocketInputStream::read( unsigned char* buffer,
+                             std::size_t bufferSize ) throw ( IOException )
 {
     apr_size_t size = (apr_size_t)bufferSize;
     apr_status_t result = APR_SUCCESS;
@@ -154,8 +154,15 @@
     // size is the number of bytes actually read, can be <= bufferSize.
     result = apr_socket_recv( socket, (char*)buffer, &size );
 
-    // Check for a closed socket.
-    if( size == 0 || closed || APR_STATUS_IS_EOF( result ) ){
+    // Check for EOF, on windows we only get size==0 so check that to, if we
+    // were closed though then we throw an IOException so the caller knows we
+    // aren't usable anymore.
+    if( ( APR_STATUS_IS_EOF( result ) || size == 0 ) && !closed ) {
+        return -1;
+    }
+
+    // Check for a closed call from socket class, if closed then this read fails.
+    if( closed ){
         throw IOException(
             __FILE__, __LINE__,
             "activemq::io::SocketInputStream::read - The connection is broken" );
@@ -163,7 +170,6 @@
 
     // Check for error.
     if( result != APR_SUCCESS ){
-        // Otherwise, this was a bad error - throw an exception.
         throw IOException(
             __FILE__, __LINE__,
             "decaf::net::SocketInputStream::read - %s",

Modified: activemq/activemq-cpp/trunk/src/decaf/src/main/decaf/net/SocketInputStream.h
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/decaf/src/main/decaf/net/SocketInputStream.h?view=diff&rev=559828&r1=559827&r2=559828
==============================================================================
--- activemq/activemq-cpp/trunk/src/decaf/src/main/decaf/net/SocketInputStream.h (original)
+++ activemq/activemq-cpp/trunk/src/decaf/src/main/decaf/net/SocketInputStream.h Thu Jul 26 07:29:25 2007
@@ -135,8 +135,8 @@
          * @return The number of bytes read.
          * @throws IOException thrown if an error occurs.
          */
-        virtual std::size_t read( unsigned char* buffer,
-                                  std::size_t bufferSize )
+        virtual int read( unsigned char* buffer,
+                          std::size_t bufferSize )
             throw ( io::IOException );
 
         /**

Modified: activemq/activemq-cpp/trunk/src/decaf/src/test/decaf/io/BufferedInputStreamTest.h
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/decaf/src/test/decaf/io/BufferedInputStreamTest.h?view=diff&rev=559828&r1=559827&r2=559828
==============================================================================
--- activemq/activemq-cpp/trunk/src/decaf/src/test/decaf/io/BufferedInputStreamTest.h (original)
+++ activemq/activemq-cpp/trunk/src/decaf/src/test/decaf/io/BufferedInputStreamTest.h Thu Jul 26 07:29:25 2007
@@ -59,7 +59,7 @@
 
                 return data.c_str()[pos++];
             }
-            virtual std::size_t read( unsigned char* buffer, std::size_t bufferSize ) throw (IOException){
+            virtual int read( unsigned char* buffer, std::size_t bufferSize ) throw (IOException){
                 std::size_t numToRead = std::min( bufferSize, available() );
 
                 const char* str = data.c_str();

Modified: activemq/activemq-cpp/trunk/src/decaf/src/test/decaf/net/SocketFactoryTest.h
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/decaf/src/test/decaf/net/SocketFactoryTest.h?view=diff&rev=559828&r1=559827&r2=559828
==============================================================================
--- activemq/activemq-cpp/trunk/src/decaf/src/test/decaf/net/SocketFactoryTest.h (original)
+++ activemq/activemq-cpp/trunk/src/decaf/src/test/decaf/net/SocketFactoryTest.h Thu Jul 26 07:29:25 2007
@@ -97,7 +97,10 @@
                         io::InputStream* stream = socket->getInputStream();
                         memset( buf, 0, 1000 );
                         try{
-                            stream->read( buf, 1000 );
+                            if( stream->read( buf, 1000 ) == -1 ) {
+                                done = true;
+                                continue;
+                            }
 
                             lastMessage = (char*)buf;
 

Modified: activemq/activemq-cpp/trunk/src/decaf/src/test/decaf/net/SocketTest.h
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/decaf/src/test/decaf/net/SocketTest.h?view=diff&rev=559828&r1=559827&r2=559828
==============================================================================
--- activemq/activemq-cpp/trunk/src/decaf/src/test/decaf/net/SocketTest.h (original)
+++ activemq/activemq-cpp/trunk/src/decaf/src/test/decaf/net/SocketTest.h Thu Jul 26 07:29:25 2007
@@ -103,7 +103,11 @@
 
                         memset( buf, 0, 1000 );
                         try{
-                            stream->read( buf, 1000 );
+
+                            if( stream->read( buf, 1000 ) == -1 ) {
+                                done = true;
+                                continue;
+                            }
 
                             lastMessage = (char*)buf;
 

Modified: activemq/activemq-cpp/trunk/src/decaf/src/test/testRegistry.cpp
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/decaf/src/test/testRegistry.cpp?view=diff&rev=559828&r1=559827&r2=559828
==============================================================================
--- activemq/activemq-cpp/trunk/src/decaf/src/test/testRegistry.cpp (original)
+++ activemq/activemq-cpp/trunk/src/decaf/src/test/testRegistry.cpp Thu Jul 26 07:29:25 2007
@@ -18,53 +18,53 @@
 // All CPP Unit tests are registered in here so we can disable them and
 // enable them easily in one place.
 //
-//#include <decaf/io/BufferedInputStreamTest.h>
-//CPPUNIT_TEST_SUITE_REGISTRATION( decaf::io::BufferedInputStreamTest );
-//#include <decaf/io/BufferedOutputStreamTest.h>
-//CPPUNIT_TEST_SUITE_REGISTRATION( decaf::io::BufferedOutputStreamTest );
-//#include <decaf/io/ByteArrayInputStreamTest.h>
-//CPPUNIT_TEST_SUITE_REGISTRATION( decaf::io::ByteArrayInputStreamTest );
-//#include <decaf/io/ByteArrayOutputStreamTest.h>
-//CPPUNIT_TEST_SUITE_REGISTRATION( decaf::io::ByteArrayOutputStreamTest );
-//#include <decaf/io/DataInputStreamTest.h>
-//CPPUNIT_TEST_SUITE_REGISTRATION( decaf::io::DataInputStreamTest );
-//#include <decaf/io/DataOutputStreamTest.h>
-//CPPUNIT_TEST_SUITE_REGISTRATION( decaf::io::DataOutputStreamTest );
-//
-//#include <decaf/lang/BooleanTest.h>
-//CPPUNIT_TEST_SUITE_REGISTRATION( decaf::lang::BooleanTest );
-//#include <decaf/lang/ExceptionTest.h>
-//CPPUNIT_TEST_SUITE_REGISTRATION( decaf::lang::ExceptionTest );
-//#include <decaf/lang/IntegerTest.h>
-//CPPUNIT_TEST_SUITE_REGISTRATION( decaf::lang::IntegerTest );
-//#include <decaf/lang/LongTest.h>
-//CPPUNIT_TEST_SUITE_REGISTRATION( decaf::lang::LongTest );
-//#include <decaf/lang/ThreadTest.h>
-//CPPUNIT_TEST_SUITE_REGISTRATION( decaf::lang::ThreadTest );
+#include <decaf/io/BufferedInputStreamTest.h>
+CPPUNIT_TEST_SUITE_REGISTRATION( decaf::io::BufferedInputStreamTest );
+#include <decaf/io/BufferedOutputStreamTest.h>
+CPPUNIT_TEST_SUITE_REGISTRATION( decaf::io::BufferedOutputStreamTest );
+#include <decaf/io/ByteArrayInputStreamTest.h>
+CPPUNIT_TEST_SUITE_REGISTRATION( decaf::io::ByteArrayInputStreamTest );
+#include <decaf/io/ByteArrayOutputStreamTest.h>
+CPPUNIT_TEST_SUITE_REGISTRATION( decaf::io::ByteArrayOutputStreamTest );
+#include <decaf/io/DataInputStreamTest.h>
+CPPUNIT_TEST_SUITE_REGISTRATION( decaf::io::DataInputStreamTest );
+#include <decaf/io/DataOutputStreamTest.h>
+CPPUNIT_TEST_SUITE_REGISTRATION( decaf::io::DataOutputStreamTest );
+
+#include <decaf/lang/BooleanTest.h>
+CPPUNIT_TEST_SUITE_REGISTRATION( decaf::lang::BooleanTest );
+#include <decaf/lang/ExceptionTest.h>
+CPPUNIT_TEST_SUITE_REGISTRATION( decaf::lang::ExceptionTest );
+#include <decaf/lang/IntegerTest.h>
+CPPUNIT_TEST_SUITE_REGISTRATION( decaf::lang::IntegerTest );
+#include <decaf/lang/LongTest.h>
+CPPUNIT_TEST_SUITE_REGISTRATION( decaf::lang::LongTest );
+#include <decaf/lang/ThreadTest.h>
+CPPUNIT_TEST_SUITE_REGISTRATION( decaf::lang::ThreadTest );
 
 #include <decaf/net/SocketFactoryTest.h>
 CPPUNIT_TEST_SUITE_REGISTRATION( decaf::net::SocketFactoryTest );
-//#include <decaf/net/SocketTest.h>
-//CPPUNIT_TEST_SUITE_REGISTRATION( decaf::net::SocketTest );
+#include <decaf/net/SocketTest.h>
+CPPUNIT_TEST_SUITE_REGISTRATION( decaf::net::SocketTest );
+
+#include <decaf/util/concurrent/CountDownLatchTest.h>
+CPPUNIT_TEST_SUITE_REGISTRATION( decaf::util::concurrent::CountDownLatchTest );
+#include <decaf/util/concurrent/MutexTest.h>
+CPPUNIT_TEST_SUITE_REGISTRATION( decaf::util::concurrent::MutexTest );
+#include <decaf/util/concurrent/ThreadPoolTest.h>
+CPPUNIT_TEST_SUITE_REGISTRATION( decaf::util::concurrent::ThreadPoolTest );
 
-//#include <decaf/util/concurrent/CountDownLatchTest.h>
-//CPPUNIT_TEST_SUITE_REGISTRATION( decaf::util::concurrent::CountDownLatchTest );
-//#include <decaf/util/concurrent/MutexTest.h>
-//CPPUNIT_TEST_SUITE_REGISTRATION( decaf::util::concurrent::MutexTest );
-//#include <decaf/util/concurrent/ThreadPoolTest.h>
-//CPPUNIT_TEST_SUITE_REGISTRATION( decaf::util::concurrent::ThreadPoolTest );
-//
-//#include <decaf/util/DateTest.h>
-//CPPUNIT_TEST_SUITE_REGISTRATION( decaf::util::DateTest );
-//#include <decaf/util/GuidTest.h>
-//CPPUNIT_TEST_SUITE_REGISTRATION( decaf::util::GuidTest );
-//#include <decaf/util/MapTest.h>
-//CPPUNIT_TEST_SUITE_REGISTRATION( decaf::util::MapTest );
-//#include <decaf/util/QueueTest.h>
-//CPPUNIT_TEST_SUITE_REGISTRATION( decaf::util::QueueTest );
-//#include <decaf/util/RandomTest.h>
-//CPPUNIT_TEST_SUITE_REGISTRATION( decaf::util::RandomTest );
-//#include <decaf/util/SetTest.h>
-//CPPUNIT_TEST_SUITE_REGISTRATION( decaf::util::SetTest );
-//#include <decaf/util/StringTokenizerTest.h>
-//CPPUNIT_TEST_SUITE_REGISTRATION( decaf::util::StringTokenizerTest );
+#include <decaf/util/DateTest.h>
+CPPUNIT_TEST_SUITE_REGISTRATION( decaf::util::DateTest );
+#include <decaf/util/GuidTest.h>
+CPPUNIT_TEST_SUITE_REGISTRATION( decaf::util::GuidTest );
+#include <decaf/util/MapTest.h>
+CPPUNIT_TEST_SUITE_REGISTRATION( decaf::util::MapTest );
+#include <decaf/util/QueueTest.h>
+CPPUNIT_TEST_SUITE_REGISTRATION( decaf::util::QueueTest );
+#include <decaf/util/RandomTest.h>
+CPPUNIT_TEST_SUITE_REGISTRATION( decaf::util::RandomTest );
+#include <decaf/util/SetTest.h>
+CPPUNIT_TEST_SUITE_REGISTRATION( decaf::util::SetTest );
+#include <decaf/util/StringTokenizerTest.h>
+CPPUNIT_TEST_SUITE_REGISTRATION( decaf::util::StringTokenizerTest );