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 2011/05/06 23:22:41 UTC

svn commit: r1100383 [3/3] - in /activemq/activemq-cpp/trunk/activemq-cpp/src: examples/ examples/producers/ main/ main/activemq/library/ main/activemq/transport/ main/activemq/wireformat/ main/decaf/internal/ main/decaf/internal/net/ssl/openssl/ main/...

Modified: activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/logging/LogWriter.cpp
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/logging/LogWriter.cpp?rev=1100383&r1=1100382&r2=1100383&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/logging/LogWriter.cpp (original)
+++ activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/logging/LogWriter.cpp Fri May  6 21:22:39 2011
@@ -18,6 +18,7 @@
 
 #include <iostream>
 #include <decaf/lang/Thread.h>
+#include <decaf/internal/DecafRuntime.h>
 #include <decaf/util/concurrent/Concurrent.h>
 #include <decaf/util/concurrent/Mutex.h>
 #include <decaf/util/Config.h>
@@ -25,6 +26,7 @@
 using namespace std;
 using namespace decaf;
 using namespace decaf::lang;
+using namespace decaf::internal;
 using namespace decaf::util;
 using namespace decaf::util::concurrent;
 using namespace decaf::util::logging;
@@ -43,17 +45,19 @@ void LogWriter::log( const std::string& 
                      const std::string& prefix,
                      const std::string& message) {
 
-   synchronized( &getMutex() ) {
+    DecafRuntime* runtime = dynamic_cast<DecafRuntime*>(Runtime::getRuntime());
+    synchronized(runtime->getGlobalLock()) {
       cout << prefix  << " "
-           << message << " - tid: " << Thread::getId() << endl;
+           << message << " - tid: " << Thread::currentThread()->getId() << endl;
    }
 }
 
 ////////////////////////////////////////////////////////////////////////////////
 void LogWriter::log(const std::string& message ) {
 
-    synchronized(&getMutex()) {
-      cout << message << " - tid: " << Thread::getId() << endl;
+    DecafRuntime* runtime = dynamic_cast<DecafRuntime*>(Runtime::getRuntime());
+    synchronized(runtime->getGlobalLock()) {
+      cout << message << " - tid: " << Thread::currentThread()->getId() << endl;
    }
 }
 
@@ -65,9 +69,3 @@ LogWriter& LogWriter::getInstance() {
 
     return instance;
 }
-
-////////////////////////////////////////////////////////////////////////////////
-Mutex& LogWriter::getMutex() {
-    static concurrent::Mutex mutex;
-    return mutex;
-}

Modified: activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/logging/LogWriter.h
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/logging/LogWriter.h?rev=1100383&r1=1100382&r2=1100383&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/logging/LogWriter.h (original)
+++ activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/logging/LogWriter.h Fri May  6 21:22:39 2011
@@ -17,7 +17,9 @@
 #ifndef _DECAF_UTIL_LOGGING_LOGWRITER_H_
 #define _DECAF_UTIL_LOGGING_LOGWRITER_H_
 
-#include <decaf/util/concurrent/Mutex.h>
+#include <decaf/util/Config.h>
+
+#include <string>
 
 namespace decaf{
 namespace util{
@@ -65,13 +67,6 @@ namespace logging{
          */
         static void destroy();
 
-    private:
-
-        /**
-         * Gets the one and only mutex for this instance.
-         */
-        concurrent::Mutex& getMutex();
-
     };
 
 }}}

Modified: activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/logging/SimpleLogger.cpp
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/logging/SimpleLogger.cpp?rev=1100383&r1=1100382&r2=1100383&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/logging/SimpleLogger.cpp (original)
+++ activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/logging/SimpleLogger.cpp Fri May  6 21:22:39 2011
@@ -21,7 +21,7 @@
 
 using namespace std;
 using namespace decaf;
-using namespace decaf::util::concurrent;
+using namespace decaf::util;
 using namespace decaf::util::logging;
 
 ////////////////////////////////////////////////////////////////////////////////

Modified: activemq/activemq-cpp/trunk/activemq-cpp/src/test-benchmarks/main.cpp
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/activemq-cpp/src/test-benchmarks/main.cpp?rev=1100383&r1=1100382&r2=1100383&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/activemq-cpp/src/test-benchmarks/main.cpp (original)
+++ activemq/activemq-cpp/trunk/activemq-cpp/src/test-benchmarks/main.cpp Fri May  6 21:22:39 2011
@@ -25,6 +25,7 @@
 int main( int argc AMQCPP_UNUSED, char **argv AMQCPP_UNUSED ) {
 
     activemq::library::ActiveMQCPP::initializeLibrary();
+    bool wasSuccessful = false;
 
     try {
         CppUnit::TextUi::TestRunner runner;
@@ -36,21 +37,19 @@ int main( int argc AMQCPP_UNUSED, char *
         std::cout << "Starting the Benchmarks:" << std::endl;
         std::cout << "-----------------------------------------------------\n";
 
-        bool wasSuccessful = runner.run( "", false );
+        wasSuccessful = runner.run( "", false );
 
         std::cout << "-----------------------------------------------------\n";
         std::cout << "Finished with the Benchmarks." << std::endl;
         std::cout << "=====================================================\n";
 
-        activemq::library::ActiveMQCPP::shutdownLibrary();
-
-        return !wasSuccessful;
-
     } catch(...) {
         std::cout << "----------------------------------------" << std::endl;
         std::cout << "- AN ERROR HAS OCCURED:                -" << std::endl;
         std::cout << "----------------------------------------" << std::endl;
-
-        activemq::library::ActiveMQCPP::shutdownLibrary();
     }
+
+    activemq::library::ActiveMQCPP::shutdownLibrary();
+
+    return !wasSuccessful;
 }

Modified: activemq/activemq-cpp/trunk/activemq-cpp/src/test-integration/activemq/test/ExpirationTest.cpp
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/activemq-cpp/src/test-integration/activemq/test/ExpirationTest.cpp?rev=1100383&r1=1100382&r2=1100383&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/activemq-cpp/src/test-integration/activemq/test/ExpirationTest.cpp (original)
+++ activemq/activemq-cpp/trunk/activemq-cpp/src/test-integration/activemq/test/ExpirationTest.cpp Fri May  6 21:22:39 2011
@@ -81,7 +81,7 @@ namespace test {
                 }
 
                 // Create the Thread Id String
-                string threadIdStr = Long::toString( Thread::getId() );
+                string threadIdStr = Long::toString( Thread::currentThread()->getId() );
 
                 // Create a messages
                 string text = (string)"Hello world! from thread " + threadIdStr;

Modified: activemq/activemq-cpp/trunk/activemq-cpp/src/test-integration/activemq/test/SlowListenerTest.cpp
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/activemq-cpp/src/test-integration/activemq/test/SlowListenerTest.cpp?rev=1100383&r1=1100382&r2=1100383&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/activemq-cpp/src/test-integration/activemq/test/SlowListenerTest.cpp (original)
+++ activemq/activemq-cpp/trunk/activemq-cpp/src/test-integration/activemq/test/SlowListenerTest.cpp Fri May  6 21:22:39 2011
@@ -52,7 +52,7 @@ namespace test{
 
             synchronized( &threadIds ) {
                 count++;
-                threadIds.add( Thread::getId() );
+                threadIds.add( Thread::currentThread()->getId() );
             }
 
             Thread::sleep( 20 );

Modified: activemq/activemq-cpp/trunk/activemq-cpp/src/test/decaf/lang/PointerTest.cpp
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/activemq-cpp/src/test/decaf/lang/PointerTest.cpp?rev=1100383&r1=1100382&r2=1100383&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/activemq-cpp/src/test/decaf/lang/PointerTest.cpp (original)
+++ activemq/activemq-cpp/trunk/activemq-cpp/src/test/decaf/lang/PointerTest.cpp Fri May  6 21:22:39 2011
@@ -491,7 +491,7 @@ public:
         while( closed )
             mutex.wait();
         enter_latch->countDown();
-        if( enter_latch->await( 0 ) ) {
+        if (enter_latch->getCount() == 0) {
             closed = true;
         }
         mutex.unlock();
@@ -536,10 +536,11 @@ public:
 ////////////////////////////////////////////////////////////////////////////////
 void PointerTest::testThreadSafety() {
 
-    Pointer<PointerTestThread> thread[10];
+    const int NUM_THREADS = 1;
+    Pointer<PointerTestThread> thread[NUM_THREADS];
     Gate gate;
 
-    for( int i = 0; i < 10; i++ ) {
+    for( int i = 0; i < NUM_THREADS; i++ ) {
         thread[i].reset( new PointerTestThread( &gate ) );
         thread[i]->start();
     }
@@ -549,16 +550,16 @@ void PointerTest::testThreadSafety() {
         // before the threads.
         {
             Pointer<std::string> s( new std::string() );
-            for( int i = 0; i < 10; i++ )
+            for( int i = 0; i < NUM_THREADS; i++ )
                 thread[i]->setString( s );
         }
 
         // Signal the threads to free the string.
-        gate.open( 10 );
+        gate.open( NUM_THREADS );
         gate.close();
     }
 
-    for( int i = 0; i < 10; i++ ) {
+    for( int i = 0; i < NUM_THREADS; i++ ) {
         thread[i]->join();
     }
 }

Modified: activemq/activemq-cpp/trunk/activemq-cpp/src/test/decaf/lang/SystemTest.h
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/activemq-cpp/src/test/decaf/lang/SystemTest.h?rev=1100383&r1=1100382&r2=1100383&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/activemq-cpp/src/test/decaf/lang/SystemTest.h (original)
+++ activemq/activemq-cpp/trunk/activemq-cpp/src/test/decaf/lang/SystemTest.h Fri May  6 21:22:39 2011
@@ -27,13 +27,13 @@ namespace lang{
     class SystemTest : public CppUnit::TestFixture {
 
         CPPUNIT_TEST_SUITE( SystemTest );
-        CPPUNIT_TEST( test_availableProcessors );
-        CPPUNIT_TEST( test_getenv );
+//        CPPUNIT_TEST( test_availableProcessors );
+//        CPPUNIT_TEST( test_getenv );
         CPPUNIT_TEST( test_getenv2 );
-        CPPUNIT_TEST( test_setenv );
-        CPPUNIT_TEST( test_unsetenv );
-        CPPUNIT_TEST( test_currentTimeMillis );
-        CPPUNIT_TEST( test_nanoTime );
+//        CPPUNIT_TEST( test_setenv );
+//        CPPUNIT_TEST( test_unsetenv );
+//        CPPUNIT_TEST( test_currentTimeMillis );
+//        CPPUNIT_TEST( test_nanoTime );
         CPPUNIT_TEST_SUITE_END();
 
     public:

Modified: activemq/activemq-cpp/trunk/activemq-cpp/src/test/decaf/lang/ThreadTest.cpp
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/activemq-cpp/src/test/decaf/lang/ThreadTest.cpp?rev=1100383&r1=1100382&r2=1100383&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/activemq-cpp/src/test/decaf/lang/ThreadTest.cpp (original)
+++ activemq/activemq-cpp/trunk/activemq-cpp/src/test/decaf/lang/ThreadTest.cpp Fri May  6 21:22:39 2011
@@ -63,6 +63,70 @@ namespace lang{
                 delay = d;
             }
         }
+
+        virtual ~SimpleThread() {}
+    };
+
+    class ChildThread1 : public Thread {
+    private:
+
+        Thread* parent;
+        bool sync;
+
+    public:
+
+        ChildThread1(Thread* parent, bool sync) : Thread(), parent(parent), sync(sync) {
+        }
+
+        virtual ~ChildThread1() {}
+
+        decaf::util::concurrent::Mutex lock;
+
+        virtual void run() {
+
+            if (sync) {
+                synchronized(&lock) {
+                    lock.notify();
+                    try {
+                        lock.wait();
+                    } catch(InterruptedException& e) {
+                    }
+                }
+            }
+            parent->interrupt();
+        }
+    };
+
+    class SpinThread : public Runnable {
+    public:
+
+        SpinThread() : Runnable(), done(false) {}
+
+        virtual ~SpinThread() {}
+
+        bool done;
+
+        virtual void run() {
+
+            while (!Thread::currentThread()->isInterrupted())
+                ;
+            while (!done)
+                ;
+        }
+    };
+
+    class RunThread : public Runnable {
+    public:
+
+        RunThread() : Runnable(), didThreadRun(false) {}
+
+        virtual ~RunThread() {}
+
+        bool didThreadRun;
+
+        virtual void run() {
+            didThreadRun = true;
+        }
     };
 
     class YieldThread : public Runnable {
@@ -135,7 +199,7 @@ namespace lang{
         virtual void run(){
 
             // Sleep for 2 seconds.
-            Thread::sleep( 2000 );
+            Thread::sleep( 1000 );
         }
 
     };
@@ -174,6 +238,89 @@ namespace lang{
 
     };
 
+    class InterruptibleSleeper : public Runnable {
+    private:
+
+        bool interrupted;
+
+    public:
+
+        InterruptibleSleeper() : Runnable(), interrupted(false) {
+        }
+
+        virtual ~InterruptibleSleeper(){}
+
+        virtual void run() {
+
+            try{
+                Thread::sleep(10000);
+            } catch(InterruptedException& ex) {
+                interrupted = true;
+            }
+        }
+
+        bool wasInterrupted() const {
+            return interrupted;
+        }
+    };
+
+    class InterruptibleJoiner : public Runnable {
+    private:
+
+        bool interrupted;
+        Thread* parent;
+
+    public:
+
+        InterruptibleJoiner(Thread* parent) : Runnable(), interrupted(false), parent(parent) {
+        }
+
+        virtual ~InterruptibleJoiner(){}
+
+        virtual void run() {
+
+            try{
+                parent->join(10000);
+            } catch(InterruptedException& ex) {
+                interrupted = true;
+            }
+        }
+
+        bool wasInterrupted() const {
+            return interrupted;
+        }
+    };
+
+    class InterruptibleWaiter : public Runnable {
+    private:
+
+        bool interrupted;
+
+    public:
+
+        decaf::util::concurrent::Mutex lock;
+
+        InterruptibleWaiter() : Runnable(), interrupted(false), lock() {
+        }
+
+        virtual ~InterruptibleWaiter(){}
+
+        virtual void run() {
+
+            synchronized(&lock) {
+                try {
+                    lock.wait();
+                } catch(InterruptedException& e) {
+                    interrupted = true;
+                }
+            }
+        }
+
+        bool wasInterrupted() const {
+            return interrupted;
+        }
+    };
+
     class Handler : public Thread::UncaughtExceptionHandler {
     public:
 
@@ -227,6 +374,27 @@ void ThreadTest::testConstructor_3() {
 }
 
 ////////////////////////////////////////////////////////////////////////////////
+void ThreadTest::testRun() {
+
+    RunThread rt;
+    Thread t(&rt);
+
+    try {
+        t.start();
+        int count = 0;
+        while (!rt.didThreadRun && count < 20) {
+            Thread::sleep(100);
+            count++;
+        }
+        CPPUNIT_ASSERT_MESSAGE("Thread did not run", rt.didThreadRun);
+        t.join();
+    } catch(InterruptedException& e) {
+        CPPUNIT_FAIL("Joined thread was interrupted");
+    }
+    CPPUNIT_ASSERT_MESSAGE("Joined thread is still alive", !t.isAlive());
+}
+
+////////////////////////////////////////////////////////////////////////////////
 void ThreadTest::testDelegate(){
 
     Delegate test;
@@ -282,7 +450,7 @@ void ThreadTest::testJoin1() {
     CPPUNIT_ASSERT( delta >= 1 && delta <= 3 );
 
     // Thread should be able to join itself, use a timeout so we don't freeze
-    Thread::currentThread()->join( 100 );
+    Thread::currentThread()->join( 5 );
 }
 
 ////////////////////////////////////////////////////////////////////////////////
@@ -308,7 +476,7 @@ void ThreadTest::testJoin2() {
     CPPUNIT_ASSERT( delta >= 1 && delta <= 3 );
 
     // Thread should be able to join itself, use a timeout so we don't freeze
-    Thread::currentThread()->join( 100 );
+    Thread::currentThread()->join( 5 );
 }
 
 ////////////////////////////////////////////////////////////////////////////////
@@ -329,7 +497,7 @@ void ThreadTest::testJoin3() {
     CPPUNIT_ASSERT_MESSAGE( "Joined Thread is still alive", !test.isAlive() );
 
     // Thread should be able to join itself, use a timeout so we don't freeze
-    Thread::currentThread()->join( 100 );
+    Thread::currentThread()->join( 5 );
 }
 
 ////////////////////////////////////////////////////////////////////////////////
@@ -348,7 +516,7 @@ void ThreadTest::testJoin4() {
     }
 
     // Thread should be able to join itself, use a timeout so we don't freeze
-    Thread::currentThread()->join( 100 );
+    Thread::currentThread()->join( 5 );
 }
 
 ////////////////////////////////////////////////////////////////////////////////
@@ -392,7 +560,7 @@ void ThreadTest::testIsAlive() {
 
 ////////////////////////////////////////////////////////////////////////////////
 void ThreadTest::testGetId() {
-    CPPUNIT_ASSERT( Thread::getId() > 0 );
+    CPPUNIT_ASSERT( Thread::currentThread()->getId() > 0 );
 }
 
 ////////////////////////////////////////////////////////////////////////////////
@@ -446,7 +614,7 @@ void ThreadTest::testSleep2Arg() {
 
 ////////////////////////////////////////////////////////////////////////////////
 void ThreadTest::testGetState() {
-    std::auto_ptr<SimpleThread> runnable( new SimpleThread( 500 ) );
+    std::auto_ptr<SimpleThread> runnable( new SimpleThread( 1000 ) );
     Thread ct( runnable.get() );
 
     CPPUNIT_ASSERT_MESSAGE( "A thread that wasn't started is alive.", !ct.isAlive() );
@@ -460,7 +628,7 @@ void ThreadTest::testGetState() {
     }
 
     CPPUNIT_ASSERT_MESSAGE( "Started thread returned false", ct.isAlive() );
-    CPPUNIT_ASSERT( ct.getState() == Thread::RUNNABLE );
+    CPPUNIT_ASSERT( ct.getState() == Thread::TIMED_WAITING );
 
     try {
         ct.join();
@@ -499,9 +667,175 @@ void ThreadTest::testUncaughtExceptionHa
 void ThreadTest::testCurrentThread() {
 
     CPPUNIT_ASSERT( Thread::currentThread() != NULL );
-    CPPUNIT_ASSERT( Thread::currentThread()->getName() == "Main Thread" );
+    CPPUNIT_ASSERT( Thread::currentThread()->getName() != "" );
     CPPUNIT_ASSERT( Thread::currentThread()->getPriority() == Thread::NORM_PRIORITY );
     CPPUNIT_ASSERT( Thread::currentThread()->getState() == Thread::RUNNABLE );
 
     CPPUNIT_ASSERT( Thread::currentThread() == Thread::currentThread() );
 }
+
+////////////////////////////////////////////////////////////////////////////////
+void ThreadTest::testInterrupt() {
+
+    bool interrupted = false;
+    try {
+        ChildThread1 ct(Thread::currentThread(), false);
+        synchronized(&ct.lock) {
+            ct.start();
+            ct.lock.wait();
+        }
+    } catch(InterruptedException& e) {
+        interrupted = true;
+    } catch(Exception& ex) {
+        ex.printStackTrace();
+        CPPUNIT_FAIL("Caught unexpected message.");
+    }
+
+    CPPUNIT_ASSERT_MESSAGE("Failed to Interrupt thread1", interrupted);
+
+    interrupted = false;
+    try {
+        ChildThread1 ct(Thread::currentThread(), true);
+        synchronized(&ct.lock) {
+            ct.start();
+            ct.lock.wait();
+            ct.lock.notify();
+        }
+        Thread::sleep(20000);
+    } catch(InterruptedException& e) {
+        interrupted = true;
+    } catch(Exception& ex) {
+        ex.printStackTrace();
+        CPPUNIT_FAIL("Caught unexpected message.");
+    }
+    CPPUNIT_ASSERT_MESSAGE("Failed to Interrupt thread2", interrupted);
+}
+
+////////////////////////////////////////////////////////////////////////////////
+void ThreadTest::testInterrupted() {
+
+    CPPUNIT_ASSERT_MESSAGE("Interrupted returned true for non-interrupted thread",
+                           !Thread::interrupted());
+    Thread::currentThread()->interrupt();
+    CPPUNIT_ASSERT_MESSAGE("Interrupted returned true for non-interrupted thread", Thread::interrupted());
+    CPPUNIT_ASSERT_MESSAGE("Failed to clear interrupted flag", !Thread::interrupted());
+}
+
+////////////////////////////////////////////////////////////////////////////////
+void ThreadTest::testIsInterrupted() {
+
+    SpinThread spin;
+    Thread spinner(&spin);
+    spinner.start();
+    Thread::yield();
+
+    try {
+        CPPUNIT_ASSERT_MESSAGE("Non-Interrupted thread returned true", !spinner.isInterrupted());
+        spinner.interrupt();
+        CPPUNIT_ASSERT_MESSAGE("Interrupted thread returned false", spinner.isInterrupted());
+        spin.done = true;
+    } catch(...) {
+        spinner.interrupt();
+        spin.done = true;
+    }
+
+    spinner.join();
+}
+
+////////////////////////////////////////////////////////////////////////////////
+void ThreadTest::testSetName() {
+
+    JoinTest st;
+    st.setName("Bogus Name");
+    CPPUNIT_ASSERT_EQUAL_MESSAGE("Failed to set thread name", std::string("Bogus Name"), st.getName());
+    st.setName("Another Bogus Name");
+    CPPUNIT_ASSERT_EQUAL_MESSAGE("Failed to set thread name", std::string("Another Bogus Name"), st.getName());
+    st.start();
+}
+
+////////////////////////////////////////////////////////////////////////////////
+void ThreadTest::testInterruptSleep() {
+
+    std::auto_ptr<InterruptibleSleeper> runnable(new InterruptibleSleeper());
+    Thread ct( runnable.get() );
+    ct.start();
+
+    for(int i = 0; i < 10; ++i) {
+        if (ct.getState() == Thread::SLEEPING) {
+            break;
+        } else {
+            Thread::sleep(10);
+        }
+    }
+    CPPUNIT_ASSERT(ct.getState() == Thread::SLEEPING);
+
+    ct.interrupt();
+    for(int i = 0; i < 10; ++i) {
+        if (runnable->wasInterrupted()) {
+            break;
+        } else {
+            Thread::sleep(10);
+        }
+    }
+    CPPUNIT_ASSERT(runnable->wasInterrupted());
+
+    ct.join();
+}
+
+////////////////////////////////////////////////////////////////////////////////
+void ThreadTest::testInterruptJoin() {
+
+    std::auto_ptr<InterruptibleJoiner> runnable(new InterruptibleJoiner(Thread::currentThread()));
+    Thread ct( runnable.get() );
+    ct.start();
+
+    for(int i = 0; i < 10; ++i) {
+        if (ct.getState() == Thread::SLEEPING) {
+            break;
+        } else {
+            Thread::sleep(10);
+        }
+    }
+    CPPUNIT_ASSERT(ct.getState() == Thread::SLEEPING);
+
+    ct.interrupt();
+    for(int i = 0; i < 10; ++i) {
+        if (runnable->wasInterrupted()) {
+            break;
+        } else {
+            Thread::sleep(10);
+        }
+    }
+    CPPUNIT_ASSERT(runnable->wasInterrupted());
+
+    ct.join();
+}
+
+////////////////////////////////////////////////////////////////////////////////
+void ThreadTest::testInterruptWait() {
+
+    std::auto_ptr<InterruptibleWaiter> runnable(new InterruptibleWaiter());
+    Thread ct( runnable.get() );
+    ct.start();
+
+    for(int i = 0; i < 10; ++i) {
+        if (ct.getState() == Thread::WAITING) {
+            break;
+        } else {
+            Thread::sleep(10);
+        }
+    }
+    CPPUNIT_ASSERT(ct.getState() == Thread::WAITING);
+
+    ct.interrupt();
+    for(int i = 0; i < 10; ++i) {
+        if (runnable->wasInterrupted()) {
+            break;
+        } else {
+            Thread::sleep(10);
+        }
+    }
+    CPPUNIT_ASSERT(runnable->wasInterrupted());
+
+    ct.join();
+}

Modified: activemq/activemq-cpp/trunk/activemq-cpp/src/test/decaf/lang/ThreadTest.h
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/activemq-cpp/src/test/decaf/lang/ThreadTest.h?rev=1100383&r1=1100382&r2=1100383&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/activemq-cpp/src/test/decaf/lang/ThreadTest.h (original)
+++ activemq/activemq-cpp/trunk/activemq-cpp/src/test/decaf/lang/ThreadTest.h Fri May  6 21:22:39 2011
@@ -34,6 +34,7 @@ namespace lang{
       CPPUNIT_TEST( testConstructor_1 );
       CPPUNIT_TEST( testConstructor_2 );
       CPPUNIT_TEST( testConstructor_3 );
+      CPPUNIT_TEST( testRun );
       CPPUNIT_TEST( testDelegate );
       CPPUNIT_TEST( testDerived );
       CPPUNIT_TEST( testJoin1 );
@@ -48,6 +49,13 @@ namespace lang{
       CPPUNIT_TEST( testSleep2Arg );
       CPPUNIT_TEST( testUncaughtExceptionHandler );
       CPPUNIT_TEST( testCurrentThread );
+      CPPUNIT_TEST( testInterrupt );
+      CPPUNIT_TEST( testInterrupted );
+      CPPUNIT_TEST( testIsInterrupted );
+      CPPUNIT_TEST( testSetName );
+      CPPUNIT_TEST( testInterruptSleep );
+      CPPUNIT_TEST( testInterruptJoin );
+      CPPUNIT_TEST( testInterruptWait );
       CPPUNIT_TEST_SUITE_END();
 
     public:
@@ -61,6 +69,7 @@ namespace lang{
         void testConstructor_1();
         void testConstructor_2();
         void testConstructor_3();
+        void testRun();
         void testDelegate();
         void testDerived();
         void testJoin1();
@@ -75,6 +84,13 @@ namespace lang{
         void testSleep2Arg();
         void testUncaughtExceptionHandler();
         void testCurrentThread();
+        void testInterrupt();
+        void testInterrupted();
+        void testIsInterrupted();
+        void testSetName();
+        void testInterruptSleep();
+        void testInterruptJoin();
+        void testInterruptWait();
 
     };
 

Modified: activemq/activemq-cpp/trunk/activemq-cpp/src/test/decaf/util/TimerTest.cpp
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/activemq-cpp/src/test/decaf/util/TimerTest.cpp?rev=1100383&r1=1100382&r2=1100383&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/activemq-cpp/src/test/decaf/util/TimerTest.cpp (original)
+++ activemq/activemq-cpp/trunk/activemq-cpp/src/test/decaf/util/TimerTest.cpp Fri May  6 21:22:39 2011
@@ -34,12 +34,7 @@ using namespace decaf::lang;
 using namespace decaf::lang::exceptions;
 using namespace decaf::util;
 using namespace decaf::util::concurrent;
-
-////////////////////////////////////////////////////////////////////////////////
-namespace {
-    decaf::util::concurrent::Mutex gsync;
-    decaf::util::concurrent::atomic::AtomicInteger timerCounter;
-}
+using namespace decaf::util::concurrent::atomic;
 
 ////////////////////////////////////////////////////////////////////////////////
 namespace decaf{
@@ -64,6 +59,10 @@ namespace util{
     class TimerTestTask : public TimerTask {
     private:
 
+        decaf::util::concurrent::Mutex* gsync;
+
+        decaf::util::concurrent::atomic::AtomicInteger* timerCounter;
+
         // Pointer to a Report object to log run data
         TimerTaskReport* report;
 
@@ -81,28 +80,34 @@ namespace util{
 
     public:
 
-        TimerTestTask() {
+        TimerTestTask(AtomicInteger* counter, Mutex* gsync) {
             this->report = NULL;
             this->sleepInRun = false;
             this->incrementCount = false;
             this->terminateCount = -1;
             this->timer = NULL;
+            this->timerCounter = counter;
+            this->gsync = gsync;
         }
 
-        TimerTestTask( TimerTaskReport* report ) {
+        TimerTestTask(TimerTaskReport* report, AtomicInteger* counter, Mutex* gsync) {
             this->report = report;
             this->sleepInRun = false;
             this->incrementCount = false;
             this->terminateCount = -1;
             this->timer = NULL;
+            this->timerCounter = counter;
+            this->gsync = gsync;
         }
 
-        TimerTestTask( Timer* t, TimerTaskReport* report ) {
+        TimerTestTask(Timer* t, TimerTaskReport* report, AtomicInteger* counter, Mutex* gsync) {
             this->report = report;
             this->sleepInRun = false;
             this->incrementCount = false;
             this->terminateCount = -1;
             this->timer = t;
+            this->timerCounter = counter;
+            this->gsync = gsync;
         }
 
         virtual ~TimerTestTask() {}
@@ -114,10 +119,10 @@ namespace util{
             }
 
             if( incrementCount ) {
-                timerCounter.incrementAndGet();
+                timerCounter->incrementAndGet();
             }
 
-            if( terminateCount == timerCounter.get() && timer != NULL ) {
+            if( terminateCount == timerCounter->get() && timer != NULL ) {
                 timer->cancel();
             }
 
@@ -127,8 +132,8 @@ namespace util{
                 } catch( InterruptedException& e ) {}
             }
 
-            synchronized( &gsync ) {
-                gsync.notify();
+            synchronized( gsync ) {
+                gsync->notify();
             }
         }
 
@@ -193,12 +198,12 @@ void TimerTest::testConstructor() {
     // Ensure a task is run
     t.reset( new Timer() );
 
-    TimerTestTask* testTask = new TimerTestTask( &report );
+    TimerTestTask* testTask = new TimerTestTask( &report, &this->timerCounter, &this->gsync );
     t->schedule( testTask, 200 );
 
-    synchronized( &gsync ) {
+    synchronized( &this->gsync ) {
         try {
-            gsync.wait( 2000000 );
+            this->gsync.wait( 2000000 );
         } catch( InterruptedException& e ) {}
     }
 
@@ -217,7 +222,7 @@ void TimerTest::testCancel() {
     // Ensure a task throws an IllegalStateException after cancelled
     t.reset( new Timer() );
 
-    TimerTestTask* testTask = new TimerTestTask( &report );
+    TimerTestTask* testTask = new TimerTestTask( &report, &this->timerCounter, &this->gsync );
     t->cancel();
 
     CPPUNIT_ASSERT_THROW_MESSAGE(
@@ -230,11 +235,11 @@ void TimerTest::testCancel() {
 
     // Ensure a task is run but not after cancel
     t.reset( new Timer() );
-    testTask = new TimerTestTask( &report );
+    testTask = new TimerTestTask( &report, &this->timerCounter, &this->gsync );
     t->schedule( testTask, 100, 500 );
-    synchronized( &gsync ) {
+    synchronized( &this->gsync ) {
         try {
-            gsync.wait( 1000 );
+            this->gsync.wait( 1000 );
         } catch( InterruptedException& e ) {}
     }
 
@@ -242,9 +247,9 @@ void TimerTest::testCancel() {
                             1 == report.wasRun.get() );
 
     t->cancel();
-    synchronized( &gsync ) {
+    synchronized( &this->gsync ) {
         try {
-            gsync.wait( 500 );
+            this->gsync.wait( 500 );
         } catch( InterruptedException& e ) {}
     }
 
@@ -254,11 +259,11 @@ void TimerTest::testCancel() {
     // Ensure you can call cancel more than once
     report.wasRun.set( 0 );
     t.reset( new Timer() );
-    testTask = new TimerTestTask( &report );
+    testTask = new TimerTestTask( &report, &this->timerCounter, &this->gsync );
     t->schedule( testTask, 100, 500 );
-    synchronized( &gsync ) {
+    synchronized( &this->gsync ) {
         try {
-            gsync.wait( 500 );
+            this->gsync.wait( 500 );
         } catch( InterruptedException& e ) {}
     }
 
@@ -269,9 +274,9 @@ void TimerTest::testCancel() {
     t->cancel();
     t->cancel();
 
-    synchronized( &gsync ) {
+    synchronized( &this->gsync ) {
         try {
-            gsync.wait( 500 );
+            this->gsync.wait( 500 );
         } catch( InterruptedException& e ) {}
     }
 
@@ -282,18 +287,18 @@ void TimerTest::testCancel() {
     // run
     report.wasRun.set( 0 );
     t.reset( new Timer() );
-    testTask = new TimerTestTask( t.get(), &report );
+    testTask = new TimerTestTask( t.get(), &report, &this->timerCounter, &this->gsync );
     testTask->setIncrementCount( true );
     testTask->setTerminateCount( 5 ); // Terminate after 5 runs
     t->schedule( testTask, 100, 100 );
-    synchronized( &gsync ) {
+    synchronized( &this->gsync ) {
         try {
-            gsync.wait( 200 );
-            gsync.wait( 200 );
-            gsync.wait( 200 );
-            gsync.wait( 200 );
-            gsync.wait( 200 );
-            gsync.wait( 200 );
+            this->gsync.wait( 200 );
+            this->gsync.wait( 200 );
+            this->gsync.wait( 200 );
+            this->gsync.wait( 200 );
+            this->gsync.wait( 200 );
+            this->gsync.wait( 200 );
         } catch( InterruptedException& e ) {}
     }
 
@@ -322,7 +327,7 @@ void TimerTest::testPurge() {
 
     int j = 0;
     for( int i = 0; i < 100; i++ ) {
-        tasks[i] = new TimerTestTask();
+        tasks[i] = new TimerTestTask(&this->timerCounter, &this->gsync);
         t->schedule( tasks[i], delayTime[j++], 200 );
         if( j == 9 ) {
             j = 0;
@@ -345,7 +350,7 @@ void TimerTest::testSchedule_TimerTask_D
 
     // Ensure a Timer throws an IllegalStateException after cancelled
     t.reset( new Timer() );
-    TimerTestTask* testTask = new TimerTestTask();
+    TimerTestTask* testTask = new TimerTestTask(&this->timerCounter, &this->gsync);
     Date d( System::currentTimeMillis() + 100 );
     t->cancel();
     bool exception = false;
@@ -363,7 +368,7 @@ void TimerTest::testSchedule_TimerTask_D
 
     // Ensure a Timer throws an IllegalStateException if task already cancelled
     t.reset( new Timer() );
-    testTask = new TimerTestTask();
+    testTask = new TimerTestTask(&this->timerCounter, &this->gsync);
     d.setTime( System::currentTimeMillis() + 100 );
     testTask->cancel();
     exception = false;
@@ -381,7 +386,7 @@ void TimerTest::testSchedule_TimerTask_D
 
     // Ensure a Timer throws an IllegalArgumentException if delay is negative
     t.reset( new Timer() );
-    testTask = new TimerTestTask();
+    testTask = new TimerTestTask(&this->timerCounter, &this->gsync);
     d.setTime( -100 );
     exception = false;
     try {
@@ -424,7 +429,7 @@ void TimerTest::testSchedule_TimerTask_D
 
     // Ensure a task is run
     t.reset( new Timer() );
-    testTask = new TimerTestTask( &report );
+    testTask = new TimerTestTask( &report, &this->timerCounter, &this->gsync );
     d.setTime( System::currentTimeMillis() + 200 );
     t->schedule( testTask, d );
     try {
@@ -437,19 +442,19 @@ void TimerTest::testSchedule_TimerTask_D
 
     // Ensure multiple tasks are run
     t.reset( new Timer() );
-    testTask = new TimerTestTask();
+    testTask = new TimerTestTask(&this->timerCounter, &this->gsync);
     testTask->setIncrementCount( true );
     d.setTime( System::currentTimeMillis() + 100 );
     t->schedule( testTask, d );
-    testTask = new TimerTestTask();
+    testTask = new TimerTestTask(&this->timerCounter, &this->gsync);
     testTask->setIncrementCount( true );
     d.setTime( System::currentTimeMillis() + 150 );
     t->schedule( testTask, d );
-    testTask = new TimerTestTask();
+    testTask = new TimerTestTask(&this->timerCounter, &this->gsync);
     testTask->setIncrementCount( true );
     d.setTime( System::currentTimeMillis() + 70 );
     t->schedule( testTask, d );
-    testTask = new TimerTestTask();
+    testTask = new TimerTestTask(&this->timerCounter, &this->gsync);
     testTask->setIncrementCount( true );
     d.setTime( System::currentTimeMillis() + 10 );
     t->schedule( testTask, d );
@@ -470,7 +475,7 @@ void TimerTest::testSchedule_TimerTask_D
 
     // Ensure a Timer throws an IllegalStateException after cancelled
     t.reset( new Timer() );
-    Pointer<TimerTestTask> testTask( new TimerTestTask() );
+    Pointer<TimerTestTask> testTask( new TimerTestTask(&this->timerCounter, &this->gsync) );
     Date d( System::currentTimeMillis() + 100 );
     t->cancel();
     bool exception = false;
@@ -486,7 +491,7 @@ void TimerTest::testSchedule_TimerTask_D
 
     // Ensure a Timer throws an IllegalStateException if task already cancelled
     t.reset( new Timer() );
-    testTask.reset( new TimerTestTask() );
+    testTask.reset( new TimerTestTask(&this->timerCounter, &this->gsync));
     d.setTime( System::currentTimeMillis() + 100 );
     testTask->cancel();
     exception = false;
@@ -502,7 +507,7 @@ void TimerTest::testSchedule_TimerTask_D
 
     // Ensure a Timer throws an IllegalArgumentException if delay is negative
     t.reset( new Timer() );
-    testTask.reset( new TimerTestTask() );
+    testTask.reset( new TimerTestTask(&this->timerCounter, &this->gsync));
     d.setTime( -100 );
     exception = false;
     try {
@@ -543,7 +548,7 @@ void TimerTest::testSchedule_TimerTask_D
 
     // Ensure a task is run
     t.reset( new Timer() );
-    testTask.reset( new TimerTestTask( &report ) );
+    testTask.reset( new TimerTestTask( &report, &this->timerCounter, &this->gsync ) );
     d.setTime( System::currentTimeMillis() + 200 );
     t->schedule( testTask, d );
     try {
@@ -556,19 +561,19 @@ void TimerTest::testSchedule_TimerTask_D
 
     // Ensure multiple tasks are run
     t.reset( new Timer() );
-    testTask.reset( new TimerTestTask() );
+    testTask.reset( new TimerTestTask(&this->timerCounter, &this->gsync));
     testTask->setIncrementCount( true );
     d.setTime( System::currentTimeMillis() + 100 );
     t->schedule( testTask, d );
-    testTask.reset( new TimerTestTask() );
+    testTask.reset( new TimerTestTask(&this->timerCounter, &this->gsync));
     testTask->setIncrementCount( true );
     d.setTime( System::currentTimeMillis() + 150 );
     t->schedule( testTask, d );
-    testTask.reset( new TimerTestTask() );
+    testTask.reset( new TimerTestTask(&this->timerCounter, &this->gsync));
     testTask->setIncrementCount( true );
     d.setTime( System::currentTimeMillis() + 70 );
     t->schedule( testTask, d );
-    testTask.reset( new TimerTestTask() );
+    testTask.reset( new TimerTestTask(&this->timerCounter, &this->gsync));
     testTask->setIncrementCount( true );
     d.setTime( System::currentTimeMillis() + 10 );
     t->schedule( testTask, d );
@@ -589,7 +594,7 @@ void TimerTest::testSchedule_TimerTask_L
 
     // Ensure a Timer throws an IllegalStateException after cancelled
     t.reset( new Timer() );
-    TimerTestTask* testTask = new TimerTestTask();
+    TimerTestTask* testTask = new TimerTestTask(&this->timerCounter, &this->gsync);
     t->cancel();
     bool exception = false;
     try {
@@ -604,7 +609,7 @@ void TimerTest::testSchedule_TimerTask_L
 
     // Ensure a Timer throws an IllegalStateException if task already cancelled
     t.reset( new Timer() );
-    testTask = new TimerTestTask();
+    testTask = new TimerTestTask(&this->timerCounter, &this->gsync);
     testTask->cancel();
     exception = false;
     try {
@@ -620,7 +625,7 @@ void TimerTest::testSchedule_TimerTask_L
 
     // Ensure a Timer throws an IllegalArgumentException if delay is negative
     t.reset( new Timer() );
-    testTask = new TimerTestTask();
+    testTask = new TimerTestTask(&this->timerCounter, &this->gsync);
     exception = false;
     try {
         t->schedule( testTask, -100 );
@@ -660,7 +665,7 @@ void TimerTest::testSchedule_TimerTask_L
 
     // Ensure a task is run
     t.reset( new Timer() );
-    testTask = new TimerTestTask( &report );
+    testTask = new TimerTestTask( &report, &this->timerCounter, &this->gsync );
     t->schedule( testTask, 200 );
     try {
         Thread::sleep( 400 );
@@ -672,16 +677,16 @@ void TimerTest::testSchedule_TimerTask_L
 
     // Ensure multiple tasks are run
     t.reset( new Timer() );
-    testTask = new TimerTestTask();
+    testTask = new TimerTestTask(&this->timerCounter, &this->gsync);
     testTask->setIncrementCount( true );
     t->schedule( testTask, 100 );
-    testTask = new TimerTestTask();
+    testTask = new TimerTestTask(&this->timerCounter, &this->gsync);
     testTask->setIncrementCount( true );
     t->schedule( testTask, 150 );
-    testTask = new TimerTestTask();
+    testTask = new TimerTestTask(&this->timerCounter, &this->gsync);
     testTask->setIncrementCount( true );
     t->schedule( testTask, 70 );
-    testTask = new TimerTestTask();
+    testTask = new TimerTestTask(&this->timerCounter, &this->gsync);
     testTask->setIncrementCount( true );
     t->schedule( testTask, 10 );
     try {
@@ -702,7 +707,7 @@ void TimerTest::testSchedule_TimerTask_L
 
     // Ensure a Timer throws an IllegalStateException after cancelled
     t.reset( new Timer() );
-    Pointer<TimerTestTask> testTask( new TimerTestTask() );
+    Pointer<TimerTestTask> testTask( new TimerTestTask(&this->timerCounter, &this->gsync) );
     t->cancel();
     bool exception = false;
     try {
@@ -715,7 +720,7 @@ void TimerTest::testSchedule_TimerTask_L
 
     // Ensure a Timer throws an IllegalStateException if task already cancelled
     t.reset( new Timer() );
-    testTask.reset( new TimerTestTask() );
+    testTask.reset( new TimerTestTask(&this->timerCounter, &this->gsync) );
     testTask->cancel();
     exception = false;
     try {
@@ -729,7 +734,7 @@ void TimerTest::testSchedule_TimerTask_L
 
     // Ensure a Timer throws an IllegalArgumentException if delay is negative
     t.reset( new Timer() );
-    testTask.reset( new TimerTestTask() );
+    testTask.reset( new TimerTestTask(&this->timerCounter, &this->gsync) );
     exception = false;
     try {
         t->schedule( testTask, -100 );
@@ -767,7 +772,7 @@ void TimerTest::testSchedule_TimerTask_L
 
     // Ensure a task is run
     t.reset( new Timer() );
-    testTask.reset( new TimerTestTask( &report ) );
+    testTask.reset( new TimerTestTask( &report, &this->timerCounter, &this->gsync ) );
     t->schedule( testTask, 200 );
     try {
         Thread::sleep( 400 );
@@ -779,16 +784,16 @@ void TimerTest::testSchedule_TimerTask_L
 
     // Ensure multiple tasks are run
     t.reset( new Timer() );
-    testTask.reset( new TimerTestTask() );
+    testTask.reset( new TimerTestTask(&this->timerCounter, &this->gsync));
     testTask->setIncrementCount( true );
     t->schedule( testTask, 100 );
-    testTask.reset( new TimerTestTask() );
+    testTask.reset( new TimerTestTask(&this->timerCounter, &this->gsync));
     testTask->setIncrementCount( true );
     t->schedule( testTask, 150 );
-    testTask.reset( new TimerTestTask() );
+    testTask.reset( new TimerTestTask(&this->timerCounter, &this->gsync));
     testTask->setIncrementCount( true );
     t->schedule( testTask, 70 );
-    testTask.reset( new TimerTestTask() );
+    testTask.reset( new TimerTestTask(&this->timerCounter, &this->gsync));
     testTask->setIncrementCount( true );
     t->schedule( testTask, 10 );
     try {
@@ -809,7 +814,7 @@ void TimerTest::testSchedule_TimerTask_L
 
     // Ensure a Timer throws an IllegalStateException after cancelled
     t.reset( new Timer() );
-    TimerTestTask* testTask = new TimerTestTask();
+    TimerTestTask* testTask = new TimerTestTask(&this->timerCounter, &this->gsync);
     t->cancel();
     bool exception = false;
     try {
@@ -823,7 +828,7 @@ void TimerTest::testSchedule_TimerTask_L
 
     // Ensure a Timer throws an IllegalStateException if task already cancelled
     t.reset( new Timer() );
-    testTask = new TimerTestTask();
+    testTask = new TimerTestTask(&this->timerCounter, &this->gsync);
     testTask->cancel();
     exception = false;
     try {
@@ -839,7 +844,7 @@ void TimerTest::testSchedule_TimerTask_L
     // Ensure a Timer throws an IllegalArgumentException if delay is
     // negative
     t.reset( new Timer() );
-    testTask = new TimerTestTask();
+    testTask = new TimerTestTask(&this->timerCounter, &this->gsync);
     exception = false;
     try {
         t->schedule( testTask, -100, 100 );
@@ -853,7 +858,7 @@ void TimerTest::testSchedule_TimerTask_L
 
     // Ensure a Timer throws an IllegalArgumentException if period is negative
     t.reset( new Timer() );
-    testTask = new TimerTestTask();
+    testTask = new TimerTestTask(&this->timerCounter, &this->gsync);
     exception = false;
     try {
         t->schedule( testTask, 100, -100 );
@@ -867,7 +872,7 @@ void TimerTest::testSchedule_TimerTask_L
 
     // Ensure a Timer throws an IllegalArgumentException if period is zero
     t.reset( new Timer() );
-    testTask = new TimerTestTask();
+    testTask = new TimerTestTask(&this->timerCounter, &this->gsync);
     exception = false;
     try {
         t->schedule( testTask, 100, 0 );
@@ -904,7 +909,7 @@ void TimerTest::testSchedule_TimerTask_L
 
     // Ensure a task is run at least twice
     t.reset( new Timer() );
-    testTask = new TimerTestTask( &report );
+    testTask = new TimerTestTask( &report, &this->timerCounter, &this->gsync );
     t->schedule( testTask, 100, 100 );
     try {
         Thread::sleep( 400 );
@@ -917,16 +922,16 @@ void TimerTest::testSchedule_TimerTask_L
 
     // Ensure multiple tasks are run
     t.reset( new Timer() );
-    testTask = new TimerTestTask();
+    testTask = new TimerTestTask(&this->timerCounter, &this->gsync);
     testTask->setIncrementCount( true );
     t->schedule( testTask, 100, 100 ); // at least 9 times
-    testTask = new TimerTestTask();
+    testTask = new TimerTestTask(&this->timerCounter, &this->gsync);
     testTask->setIncrementCount( true );
     t->schedule( testTask, 200, 100 ); // at least 7 times
-    testTask = new TimerTestTask();
+    testTask = new TimerTestTask(&this->timerCounter, &this->gsync);
     testTask->setIncrementCount( true );
     t->schedule( testTask, 300, 200 ); // at least 4 times
-    testTask = new TimerTestTask();
+    testTask = new TimerTestTask(&this->timerCounter, &this->gsync);
     testTask->setIncrementCount( true );
     t->schedule( testTask, 100, 200 ); // at least 4 times
     try {
@@ -946,7 +951,7 @@ void TimerTest::testSchedule_TimerTask_L
 
     // Ensure a Timer throws an IllegalStateException after cancelled
     t.reset( new Timer() );
-    Pointer<TimerTestTask> testTask( new TimerTestTask() );
+    Pointer<TimerTestTask> testTask( new TimerTestTask(&this->timerCounter, &this->gsync) );
     t->cancel();
     bool exception = false;
     try {
@@ -958,7 +963,7 @@ void TimerTest::testSchedule_TimerTask_L
 
     // Ensure a Timer throws an IllegalStateException if task already cancelled
     t.reset( new Timer() );
-    testTask.reset( new TimerTestTask() );
+    testTask.reset( new TimerTestTask(&this->timerCounter, &this->gsync));
     testTask->cancel();
     exception = false;
     try {
@@ -972,7 +977,7 @@ void TimerTest::testSchedule_TimerTask_L
     // Ensure a Timer throws an IllegalArgumentException if delay is
     // negative
     t.reset( new Timer() );
-    testTask.reset( new TimerTestTask() );
+    testTask.reset( new TimerTestTask(&this->timerCounter, &this->gsync) );
     exception = false;
     try {
         t->schedule( testTask, -100, 100 );
@@ -984,7 +989,7 @@ void TimerTest::testSchedule_TimerTask_L
 
     // Ensure a Timer throws an IllegalArgumentException if period is negative
     t.reset( new Timer() );
-    testTask.reset( new TimerTestTask() );
+    testTask.reset( new TimerTestTask(&this->timerCounter, &this->gsync) );
     exception = false;
     try {
         t->schedule( testTask, 100, -100 );
@@ -996,7 +1001,7 @@ void TimerTest::testSchedule_TimerTask_L
 
     // Ensure a Timer throws an IllegalArgumentException if period is zero
     t.reset( new Timer() );
-    testTask.reset( new TimerTestTask() );
+    testTask.reset( new TimerTestTask(&this->timerCounter, &this->gsync) );
     exception = false;
     try {
         t->schedule( testTask, 100, 0 );
@@ -1031,7 +1036,7 @@ void TimerTest::testSchedule_TimerTask_L
 
     // Ensure a task is run at least twice
     t.reset( new Timer() );
-    testTask.reset( new TimerTestTask( &report ) );
+    testTask.reset( new TimerTestTask( &report, &this->timerCounter, &this->gsync ) );
     t->schedule( testTask, 100, 100 );
     try {
         Thread::sleep( 400 );
@@ -1044,16 +1049,16 @@ void TimerTest::testSchedule_TimerTask_L
 
     // Ensure multiple tasks are run
     t.reset( new Timer() );
-    testTask.reset( new TimerTestTask() );
+    testTask.reset( new TimerTestTask(&this->timerCounter, &this->gsync));
     testTask->setIncrementCount( true );
     t->schedule( testTask, 100, 100 ); // at least 9 times
-    testTask.reset( new TimerTestTask() );
+    testTask.reset( new TimerTestTask(&this->timerCounter, &this->gsync));
     testTask->setIncrementCount( true );
     t->schedule( testTask, 200, 100 ); // at least 7 times
-    testTask.reset( new TimerTestTask() );
+    testTask.reset( new TimerTestTask(&this->timerCounter, &this->gsync));
     testTask->setIncrementCount( true );
     t->schedule( testTask, 300, 200 ); // at least 4 times
-    testTask.reset( new TimerTestTask() );
+    testTask.reset( new TimerTestTask(&this->timerCounter, &this->gsync));
     testTask->setIncrementCount( true );
     t->schedule( testTask, 100, 200 ); // at least 4 times
     try {
@@ -1073,7 +1078,7 @@ void TimerTest::testSchedule_TimerTask_D
 
     // Ensure a Timer throws an IllegalStateException after cancelled
     t.reset( new Timer() );
-    TimerTestTask* testTask = new TimerTestTask();
+    TimerTestTask* testTask = new TimerTestTask(&this->timerCounter, &this->gsync);
     Date d( System::currentTimeMillis() + 100 );
     t->cancel();
     bool exception = false;
@@ -1089,7 +1094,7 @@ void TimerTest::testSchedule_TimerTask_D
     // Ensure a Timer throws an IllegalStateException if task already cancelled
     t.reset( new Timer() );
     d.setTime( System::currentTimeMillis() + 100 );
-    testTask = new TimerTestTask();
+    testTask = new TimerTestTask(&this->timerCounter, &this->gsync);
     testTask->cancel();
     exception = false;
     try {
@@ -1106,7 +1111,7 @@ void TimerTest::testSchedule_TimerTask_D
     // negative
     t.reset( new Timer() );
     d.setTime( -100 );
-    testTask = new TimerTestTask();
+    testTask = new TimerTestTask(&this->timerCounter, &this->gsync);
     exception = false;
     try {
         t->schedule( testTask, d, 100 );
@@ -1122,7 +1127,7 @@ void TimerTest::testSchedule_TimerTask_D
     // negative
     t.reset( new Timer() );
     d.setTime( System::currentTimeMillis() + 100 );
-    testTask = new TimerTestTask();
+    testTask = new TimerTestTask(&this->timerCounter, &this->gsync);
     exception = false;
     try {
         t->schedule( testTask, d, -100 );
@@ -1162,7 +1167,7 @@ void TimerTest::testSchedule_TimerTask_D
     // Ensure a task is run at least twice
     t.reset( new Timer() );
     d.setTime( System::currentTimeMillis() + 100 );
-    testTask = new TimerTestTask( &report );
+    testTask = new TimerTestTask( &report, &this->timerCounter, &this->gsync );
     t->schedule( testTask, d, 100 );
     try {
         Thread::sleep( 800 );
@@ -1175,19 +1180,19 @@ void TimerTest::testSchedule_TimerTask_D
 
     // Ensure multiple tasks are run
     t.reset( new Timer() );
-    testTask = new TimerTestTask();
+    testTask = new TimerTestTask(&this->timerCounter, &this->gsync);
     testTask->setIncrementCount( true );
     d.setTime( System::currentTimeMillis() + 100 );
     t->schedule( testTask, d, 100 ); // at least 9 times
-    testTask = new TimerTestTask();
+    testTask = new TimerTestTask(&this->timerCounter, &this->gsync);
     testTask->setIncrementCount( true );
     d.setTime( System::currentTimeMillis() + 200 );
     t->schedule( testTask, d, 100 ); // at least 7 times
-    testTask = new TimerTestTask();
+    testTask = new TimerTestTask(&this->timerCounter, &this->gsync);
     testTask->setIncrementCount( true );
     d.setTime( System::currentTimeMillis() + 300 );
     t->schedule( testTask, d, 200 ); // at least 4 times
-    testTask = new TimerTestTask();
+    testTask = new TimerTestTask(&this->timerCounter, &this->gsync);
     testTask->setIncrementCount( true );
     d.setTime( System::currentTimeMillis() + 100 );
     t->schedule( testTask, d, 200 ); // at least 4 times
@@ -1208,7 +1213,7 @@ void TimerTest::testSchedule_TimerTask_D
 
     // Ensure a Timer throws an IllegalStateException after cancelled
     t.reset( new Timer() );
-    Pointer<TimerTestTask> testTask( new TimerTestTask() );
+    Pointer<TimerTestTask> testTask( new TimerTestTask(&this->timerCounter, &this->gsync) );
     Date d( System::currentTimeMillis() + 100 );
     t->cancel();
     bool exception = false;
@@ -1222,7 +1227,7 @@ void TimerTest::testSchedule_TimerTask_D
     // Ensure a Timer throws an IllegalStateException if task already cancelled
     t.reset( new Timer() );
     d.setTime( System::currentTimeMillis() + 100 );
-    testTask.reset( new TimerTestTask() );
+    testTask.reset( new TimerTestTask(&this->timerCounter, &this->gsync));
     testTask->cancel();
     exception = false;
     try {
@@ -1237,7 +1242,7 @@ void TimerTest::testSchedule_TimerTask_D
     // negative
     t.reset( new Timer() );
     d.setTime( -100 );
-    testTask.reset( new TimerTestTask() );
+    testTask.reset( new TimerTestTask(&this->timerCounter, &this->gsync) );
     exception = false;
     try {
         t->schedule( testTask, d, 100 );
@@ -1251,7 +1256,7 @@ void TimerTest::testSchedule_TimerTask_D
     // negative
     t.reset( new Timer() );
     d.setTime( System::currentTimeMillis() + 100 );
-    testTask.reset( new TimerTestTask() );
+    testTask.reset( new TimerTestTask(&this->timerCounter, &this->gsync) );
     exception = false;
     try {
         t->schedule( testTask, d, -100 );
@@ -1289,7 +1294,7 @@ void TimerTest::testSchedule_TimerTask_D
     // Ensure a task is run at least twice
     t.reset( new Timer() );
     d.setTime( System::currentTimeMillis() + 100 );
-    testTask.reset( new TimerTestTask( &report ) );
+    testTask.reset( new TimerTestTask( &report, &this->timerCounter, &this->gsync ) );
     t->schedule( testTask, d, 100 );
     try {
         Thread::sleep( 800 );
@@ -1302,19 +1307,19 @@ void TimerTest::testSchedule_TimerTask_D
 
     // Ensure multiple tasks are run
     t.reset( new Timer() );
-    testTask.reset( new TimerTestTask() );
+    testTask.reset( new TimerTestTask(&this->timerCounter, &this->gsync));
     testTask->setIncrementCount( true );
     d.setTime( System::currentTimeMillis() + 100 );
     t->schedule( testTask, d, 100 ); // at least 9 times
-    testTask.reset( new TimerTestTask() );
+    testTask.reset( new TimerTestTask(&this->timerCounter, &this->gsync));
     testTask->setIncrementCount( true );
     d.setTime( System::currentTimeMillis() + 200 );
     t->schedule( testTask, d, 100 ); // at least 7 times
-    testTask.reset( new TimerTestTask() );
+    testTask.reset( new TimerTestTask(&this->timerCounter, &this->gsync));
     testTask->setIncrementCount( true );
     d.setTime( System::currentTimeMillis() + 300 );
     t->schedule( testTask, d, 200 ); // at least 4 times
-    testTask.reset( new TimerTestTask() );
+    testTask.reset( new TimerTestTask(&this->timerCounter, &this->gsync));
     testTask->setIncrementCount( true );
     d.setTime( System::currentTimeMillis() + 100 );
     t->schedule( testTask, d, 200 ); // at least 4 times
@@ -1335,7 +1340,7 @@ void TimerTest::testScheduleAtFixedRate_
 
     // Ensure a Timer throws an IllegalStateException after cancelled
     t.reset( new Timer() );
-    TimerTestTask* testTask = new TimerTestTask();
+    TimerTestTask* testTask = new TimerTestTask(&this->timerCounter, &this->gsync);
     t->cancel();
     bool exception = false;
     try {
@@ -1349,7 +1354,7 @@ void TimerTest::testScheduleAtFixedRate_
 
     // Ensure a Timer throws an IllegalArgumentException if delay is negative
     t.reset( new Timer() );
-    testTask = new TimerTestTask();
+    testTask = new TimerTestTask(&this->timerCounter, &this->gsync);
     exception = false;
     try {
         t->scheduleAtFixedRate( testTask, -100, 100 );
@@ -1364,7 +1369,7 @@ void TimerTest::testScheduleAtFixedRate_
 
     // Ensure a Timer throws an IllegalArgumentException if period is negative
     t.reset( new Timer() );
-    testTask = new TimerTestTask();
+    testTask = new TimerTestTask(&this->timerCounter, &this->gsync);
     exception = false;
     try {
         t->scheduleAtFixedRate( testTask, 100, -100 );
@@ -1379,7 +1384,7 @@ void TimerTest::testScheduleAtFixedRate_
 
     // Ensure a task is run at least twice
     t.reset( new Timer() );
-    testTask = new TimerTestTask( &report );
+    testTask = new TimerTestTask( &report, &this->timerCounter, &this->gsync );
     t->scheduleAtFixedRate( testTask, 100, 100 );
     try {
         Thread::sleep( 400 );
@@ -1416,7 +1421,7 @@ void TimerTest::testScheduleAtFixedRate_
 
     // Ensure a Timer throws an IllegalStateException after cancelled
     t.reset( new Timer() );
-    Pointer<TimerTestTask> testTask( new TimerTestTask() );
+    Pointer<TimerTestTask> testTask( new TimerTestTask(&this->timerCounter, &this->gsync) );
     t->cancel();
     bool exception = false;
     try {
@@ -1428,7 +1433,7 @@ void TimerTest::testScheduleAtFixedRate_
 
     // Ensure a Timer throws an IllegalArgumentException if delay is negative
     t.reset( new Timer() );
-    testTask.reset( new TimerTestTask() );
+    testTask.reset( new TimerTestTask(&this->timerCounter, &this->gsync) );
     exception = false;
     try {
         t->scheduleAtFixedRate( testTask, -100, 100 );
@@ -1441,7 +1446,7 @@ void TimerTest::testScheduleAtFixedRate_
 
     // Ensure a Timer throws an IllegalArgumentException if period is negative
     t.reset( new Timer() );
-    testTask.reset( new TimerTestTask() );
+    testTask.reset( new TimerTestTask(&this->timerCounter, &this->gsync) );
     exception = false;
     try {
         t->scheduleAtFixedRate( testTask, 100, -100 );
@@ -1454,7 +1459,7 @@ void TimerTest::testScheduleAtFixedRate_
 
     // Ensure a task is run at least twice
     t.reset( new Timer() );
-    testTask.reset( new TimerTestTask( &report ) );
+    testTask.reset( new TimerTestTask( &report, &this->timerCounter, &this->gsync ) );
     t->scheduleAtFixedRate( testTask, 100, 100 );
     try {
         Thread::sleep( 400 );
@@ -1491,7 +1496,7 @@ void TimerTest::testScheduleAtFixedRate_
 
     // Ensure a Timer throws an IllegalStateException after cancelled
     t.reset( new Timer() );
-    TimerTestTask* testTask = new TimerTestTask();
+    TimerTestTask* testTask = new TimerTestTask(&this->timerCounter, &this->gsync);
     t->cancel();
     bool exception = false;
     Date d( System::currentTimeMillis() + 100 );
@@ -1506,7 +1511,7 @@ void TimerTest::testScheduleAtFixedRate_
 
     // Ensure a Timer throws an IllegalArgumentException if delay is negative
     t.reset( new Timer() );
-    testTask = new TimerTestTask();
+    testTask = new TimerTestTask(&this->timerCounter, &this->gsync);
     exception = false;
     d.setTime( -100 );
     try {
@@ -1522,7 +1527,7 @@ void TimerTest::testScheduleAtFixedRate_
 
     // Ensure a Timer throws an IllegalArgumentException if period is negative
     t.reset( new Timer() );
-    testTask = new TimerTestTask();
+    testTask = new TimerTestTask(&this->timerCounter, &this->gsync);
     exception = false;
     try {
         t->scheduleAtFixedRate( testTask, d, -100 );
@@ -1564,7 +1569,7 @@ void TimerTest::testScheduleAtFixedRate_
 
     // Ensure a task is run at least twice
     t.reset( new Timer() );
-    testTask = new TimerTestTask( &report );
+    testTask = new TimerTestTask( &report, &this->timerCounter, &this->gsync );
     d.setTime( System::currentTimeMillis() + 100 );
     t->scheduleAtFixedRate( testTask, d, 100 );
     try {
@@ -1603,7 +1608,7 @@ void TimerTest::testScheduleAtFixedRate_
 
     // Ensure a Timer throws an IllegalStateException after cancelled
     t.reset( new Timer() );
-    Pointer<TimerTestTask> testTask( new TimerTestTask() );
+    Pointer<TimerTestTask> testTask( new TimerTestTask(&this->timerCounter, &this->gsync) );
     t->cancel();
     bool exception = false;
     Date d( System::currentTimeMillis() + 100 );
@@ -1616,7 +1621,7 @@ void TimerTest::testScheduleAtFixedRate_
 
     // Ensure a Timer throws an IllegalArgumentException if delay is negative
     t.reset( new Timer() );
-    testTask.reset( new TimerTestTask() );
+    testTask.reset( new TimerTestTask(&this->timerCounter, &this->gsync) );
     exception = false;
     d.setTime( -100 );
     try {
@@ -1630,7 +1635,7 @@ void TimerTest::testScheduleAtFixedRate_
 
     // Ensure a Timer throws an IllegalArgumentException if period is negative
     t.reset( new Timer() );
-    testTask.reset( new TimerTestTask() );
+    testTask.reset( new TimerTestTask(&this->timerCounter, &this->gsync) );
     exception = false;
     try {
         t->scheduleAtFixedRate( testTask, d, -100 );
@@ -1670,7 +1675,7 @@ void TimerTest::testScheduleAtFixedRate_
 
     // Ensure a task is run at least twice
     t.reset( new Timer() );
-    testTask.reset( new TimerTestTask( &report ) );
+    testTask.reset( new TimerTestTask( &report, &this->timerCounter, &this->gsync ) );
     d.setTime( System::currentTimeMillis() + 100 );
     t->scheduleAtFixedRate( testTask, d, 100 );
     try {

Modified: activemq/activemq-cpp/trunk/activemq-cpp/src/test/decaf/util/TimerTest.h
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/activemq-cpp/src/test/decaf/util/TimerTest.h?rev=1100383&r1=1100382&r2=1100383&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/activemq-cpp/src/test/decaf/util/TimerTest.h (original)
+++ activemq/activemq-cpp/trunk/activemq-cpp/src/test/decaf/util/TimerTest.h Fri May  6 21:22:39 2011
@@ -21,10 +21,19 @@
 #include <cppunit/TestFixture.h>
 #include <cppunit/extensions/HelperMacros.h>
 
+#include <decaf/util/concurrent/atomic/AtomicInteger.h>
+#include <decaf/util/concurrent/Mutex.h>
+
 namespace decaf {
 namespace util {
 
     class TimerTest : public CppUnit::TestFixture {
+    private:
+
+        decaf::util::concurrent::atomic::AtomicInteger timerCounter;
+        decaf::util::concurrent::Mutex gsync;
+
+    private:
 
         CPPUNIT_TEST_SUITE( TimerTest );
         CPPUNIT_TEST( testConstructor );

Modified: activemq/activemq-cpp/trunk/activemq-cpp/src/test/decaf/util/concurrent/ExecutorsTest.cpp
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/activemq-cpp/src/test/decaf/util/concurrent/ExecutorsTest.cpp?rev=1100383&r1=1100382&r2=1100383&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/activemq-cpp/src/test/decaf/util/concurrent/ExecutorsTest.cpp (original)
+++ activemq/activemq-cpp/trunk/activemq-cpp/src/test/decaf/util/concurrent/ExecutorsTest.cpp Fri May  6 21:22:39 2011
@@ -75,7 +75,6 @@ void ExecutorsTest::testDefaultThreadFac
     Thread* theThread = defaultFactory->newThread(runner);
 
     CPPUNIT_ASSERT(theThread != NULL);
-    CPPUNIT_ASSERT_EQUAL(false, theThread->isDaemon());
     const int expected = Thread::NORM_PRIORITY;
     CPPUNIT_ASSERT_EQUAL(expected, theThread->getPriority());
 

Modified: activemq/activemq-cpp/trunk/activemq-cpp/src/test/testRegistry.cpp
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/activemq-cpp/src/test/testRegistry.cpp?rev=1100383&r1=1100382&r2=1100383&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/activemq-cpp/src/test/testRegistry.cpp (original)
+++ activemq/activemq-cpp/trunk/activemq-cpp/src/test/testRegistry.cpp Fri May  6 21:22:39 2011
@@ -347,118 +347,118 @@ CPPUNIT_TEST_SUITE_REGISTRATION( decaf::
 #include <decaf/security/SecureRandomTest.h>
 CPPUNIT_TEST_SUITE_REGISTRATION( decaf::security::SecureRandomTest );
 
-////////////////////////////////////////////////////////////////////////////////////////////////////////////
-// Marshaler Tests
-//
-#include <activemq/wireformat/openwire/marshal/generated/ActiveMQBlobMessageMarshallerTest.h>
-CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::ActiveMQBlobMessageMarshallerTest );
-#include <activemq/wireformat/openwire/marshal/generated/ActiveMQBytesMessageMarshallerTest.h>
-CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::ActiveMQBytesMessageMarshallerTest );
-#include <activemq/wireformat/openwire/marshal/generated/ActiveMQMapMessageMarshallerTest.h>
-CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::ActiveMQMapMessageMarshallerTest );
-#include <activemq/wireformat/openwire/marshal/generated/ActiveMQMessageMarshallerTest.h>
-CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::ActiveMQMessageMarshallerTest );
-#include <activemq/wireformat/openwire/marshal/generated/ActiveMQObjectMessageMarshallerTest.h>
-CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::ActiveMQObjectMessageMarshallerTest );
-#include <activemq/wireformat/openwire/marshal/generated/ActiveMQQueueMarshallerTest.h>
-CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::ActiveMQQueueMarshallerTest );
-#include <activemq/wireformat/openwire/marshal/generated/ActiveMQStreamMessageMarshallerTest.h>
-CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::ActiveMQStreamMessageMarshallerTest );
-#include <activemq/wireformat/openwire/marshal/generated/ActiveMQTempQueueMarshallerTest.h>
-CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::ActiveMQTempQueueMarshallerTest );
-#include <activemq/wireformat/openwire/marshal/generated/ActiveMQTempTopicMarshallerTest.h>
-CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::ActiveMQTempTopicMarshallerTest );
-#include <activemq/wireformat/openwire/marshal/generated/ActiveMQTextMessageMarshallerTest.h>
-CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::ActiveMQTextMessageMarshallerTest );
-#include <activemq/wireformat/openwire/marshal/generated/ActiveMQTopicMarshallerTest.h>
-CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::ActiveMQTopicMarshallerTest );
-#include <activemq/wireformat/openwire/marshal/generated/BrokerIdMarshallerTest.h>
-CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::BrokerIdMarshallerTest );
-#include <activemq/wireformat/openwire/marshal/generated/BrokerInfoMarshallerTest.h>
-CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::BrokerInfoMarshallerTest );
-#include <activemq/wireformat/openwire/marshal/generated/ConnectionControlMarshallerTest.h>
-CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::ConnectionControlMarshallerTest );
-#include <activemq/wireformat/openwire/marshal/generated/ConnectionErrorMarshallerTest.h>
-CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::ConnectionErrorMarshallerTest );
-#include <activemq/wireformat/openwire/marshal/generated/ConnectionIdMarshallerTest.h>
-CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::ConnectionIdMarshallerTest );
-#include <activemq/wireformat/openwire/marshal/generated/ConnectionInfoMarshallerTest.h>
-CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::ConnectionInfoMarshallerTest );
-#include <activemq/wireformat/openwire/marshal/generated/ConsumerControlMarshallerTest.h>
-CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::ConsumerControlMarshallerTest );
-#include <activemq/wireformat/openwire/marshal/generated/ConsumerIdMarshallerTest.h>
-CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::ConsumerIdMarshallerTest );
-#include <activemq/wireformat/openwire/marshal/generated/ConsumerInfoMarshallerTest.h>
-CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::ConsumerInfoMarshallerTest );
-#include <activemq/wireformat/openwire/marshal/generated/ControlCommandMarshallerTest.h>
-CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::ControlCommandMarshallerTest );
-#include <activemq/wireformat/openwire/marshal/generated/DataArrayResponseMarshallerTest.h>
-CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::DataArrayResponseMarshallerTest );
-#include <activemq/wireformat/openwire/marshal/generated/DataResponseMarshallerTest.h>
-CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::DataResponseMarshallerTest );
-#include <activemq/wireformat/openwire/marshal/generated/DestinationInfoMarshallerTest.h>
-CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::DestinationInfoMarshallerTest );
-#include <activemq/wireformat/openwire/marshal/generated/DiscoveryEventMarshallerTest.h>
-CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::DiscoveryEventMarshallerTest );
-#include <activemq/wireformat/openwire/marshal/generated/ExceptionResponseMarshallerTest.h>
-CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::ExceptionResponseMarshallerTest );
-#include <activemq/wireformat/openwire/marshal/generated/FlushCommandMarshallerTest.h>
-CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::FlushCommandMarshallerTest );
-#include <activemq/wireformat/openwire/marshal/generated/IntegerResponseMarshallerTest.h>
-CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::IntegerResponseMarshallerTest );
-#include <activemq/wireformat/openwire/marshal/generated/JournalQueueAckMarshallerTest.h>
-CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::JournalQueueAckMarshallerTest );
-#include <activemq/wireformat/openwire/marshal/generated/JournalTopicAckMarshallerTest.h>
-CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::JournalTopicAckMarshallerTest );
-#include <activemq/wireformat/openwire/marshal/generated/JournalTraceMarshallerTest.h>
-CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::JournalTraceMarshallerTest );
-#include <activemq/wireformat/openwire/marshal/generated/JournalTransactionMarshallerTest.h>
-CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::JournalTransactionMarshallerTest );
-#include <activemq/wireformat/openwire/marshal/generated/KeepAliveInfoMarshallerTest.h>
-CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::KeepAliveInfoMarshallerTest );
-#include <activemq/wireformat/openwire/marshal/generated/LastPartialCommandMarshallerTest.h>
-CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::LastPartialCommandMarshallerTest );
-#include <activemq/wireformat/openwire/marshal/generated/LocalTransactionIdMarshallerTest.h>
-CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::LocalTransactionIdMarshallerTest );
-#include <activemq/wireformat/openwire/marshal/generated/MessageAckMarshallerTest.h>
-CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::MessageAckMarshallerTest );
-#include <activemq/wireformat/openwire/marshal/generated/MessageDispatchMarshallerTest.h>
-CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::MessageDispatchMarshallerTest );
-#include <activemq/wireformat/openwire/marshal/generated/MessageDispatchNotificationMarshallerTest.h>
-CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::MessageDispatchNotificationMarshallerTest );
-#include <activemq/wireformat/openwire/marshal/generated/MessageIdMarshallerTest.h>
-CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::MessageIdMarshallerTest );
-#include <activemq/wireformat/openwire/marshal/generated/MessagePullMarshallerTest.h>
-CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::MessagePullMarshallerTest );
-#include <activemq/wireformat/openwire/marshal/generated/NetworkBridgeFilterMarshallerTest.h>
-CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::NetworkBridgeFilterMarshallerTest );
-#include <activemq/wireformat/openwire/marshal/generated/PartialCommandMarshallerTest.h>
-CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::PartialCommandMarshallerTest );
-#include <activemq/wireformat/openwire/marshal/generated/ProducerAckMarshallerTest.h>
-CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::ProducerAckMarshallerTest );
-#include <activemq/wireformat/openwire/marshal/generated/ProducerIdMarshallerTest.h>
-CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::ProducerIdMarshallerTest );
-#include <activemq/wireformat/openwire/marshal/generated/ProducerInfoMarshallerTest.h>
-CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::ProducerInfoMarshallerTest );
-#include <activemq/wireformat/openwire/marshal/generated/RemoveInfoMarshallerTest.h>
-CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::RemoveInfoMarshallerTest );
-#include <activemq/wireformat/openwire/marshal/generated/RemoveSubscriptionInfoMarshallerTest.h>
-CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::RemoveSubscriptionInfoMarshallerTest );
-#include <activemq/wireformat/openwire/marshal/generated/ReplayCommandMarshallerTest.h>
-CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::ReplayCommandMarshallerTest );
-#include <activemq/wireformat/openwire/marshal/generated/ResponseMarshallerTest.h>
-CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::ResponseMarshallerTest );
-#include <activemq/wireformat/openwire/marshal/generated/SessionIdMarshallerTest.h>
-CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::SessionIdMarshallerTest );
-#include <activemq/wireformat/openwire/marshal/generated/SessionInfoMarshallerTest.h>
-CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::SessionInfoMarshallerTest );
-#include <activemq/wireformat/openwire/marshal/generated/ShutdownInfoMarshallerTest.h>
-CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::ShutdownInfoMarshallerTest );
-#include <activemq/wireformat/openwire/marshal/generated/SubscriptionInfoMarshallerTest.h>
-CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::SubscriptionInfoMarshallerTest );
-#include <activemq/wireformat/openwire/marshal/generated/TransactionInfoMarshallerTest.h>
-CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::TransactionInfoMarshallerTest );
-#include <activemq/wireformat/openwire/marshal/generated/WireFormatInfoMarshallerTest.h>
-CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::WireFormatInfoMarshallerTest );
-#include <activemq/wireformat/openwire/marshal/generated/XATransactionIdMarshallerTest.h>
-CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::XATransactionIdMarshallerTest );
+//////////////////////////////////////////////////////////////////////////////////////////////////////////////
+//// Marshaler Tests
+////
+//#include <activemq/wireformat/openwire/marshal/generated/ActiveMQBlobMessageMarshallerTest.h>
+//CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::ActiveMQBlobMessageMarshallerTest );
+//#include <activemq/wireformat/openwire/marshal/generated/ActiveMQBytesMessageMarshallerTest.h>
+//CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::ActiveMQBytesMessageMarshallerTest );
+//#include <activemq/wireformat/openwire/marshal/generated/ActiveMQMapMessageMarshallerTest.h>
+//CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::ActiveMQMapMessageMarshallerTest );
+//#include <activemq/wireformat/openwire/marshal/generated/ActiveMQMessageMarshallerTest.h>
+//CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::ActiveMQMessageMarshallerTest );
+//#include <activemq/wireformat/openwire/marshal/generated/ActiveMQObjectMessageMarshallerTest.h>
+//CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::ActiveMQObjectMessageMarshallerTest );
+//#include <activemq/wireformat/openwire/marshal/generated/ActiveMQQueueMarshallerTest.h>
+//CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::ActiveMQQueueMarshallerTest );
+//#include <activemq/wireformat/openwire/marshal/generated/ActiveMQStreamMessageMarshallerTest.h>
+//CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::ActiveMQStreamMessageMarshallerTest );
+//#include <activemq/wireformat/openwire/marshal/generated/ActiveMQTempQueueMarshallerTest.h>
+//CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::ActiveMQTempQueueMarshallerTest );
+//#include <activemq/wireformat/openwire/marshal/generated/ActiveMQTempTopicMarshallerTest.h>
+//CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::ActiveMQTempTopicMarshallerTest );
+//#include <activemq/wireformat/openwire/marshal/generated/ActiveMQTextMessageMarshallerTest.h>
+//CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::ActiveMQTextMessageMarshallerTest );
+//#include <activemq/wireformat/openwire/marshal/generated/ActiveMQTopicMarshallerTest.h>
+//CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::ActiveMQTopicMarshallerTest );
+//#include <activemq/wireformat/openwire/marshal/generated/BrokerIdMarshallerTest.h>
+//CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::BrokerIdMarshallerTest );
+//#include <activemq/wireformat/openwire/marshal/generated/BrokerInfoMarshallerTest.h>
+//CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::BrokerInfoMarshallerTest );
+//#include <activemq/wireformat/openwire/marshal/generated/ConnectionControlMarshallerTest.h>
+//CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::ConnectionControlMarshallerTest );
+//#include <activemq/wireformat/openwire/marshal/generated/ConnectionErrorMarshallerTest.h>
+//CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::ConnectionErrorMarshallerTest );
+//#include <activemq/wireformat/openwire/marshal/generated/ConnectionIdMarshallerTest.h>
+//CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::ConnectionIdMarshallerTest );
+//#include <activemq/wireformat/openwire/marshal/generated/ConnectionInfoMarshallerTest.h>
+//CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::ConnectionInfoMarshallerTest );
+//#include <activemq/wireformat/openwire/marshal/generated/ConsumerControlMarshallerTest.h>
+//CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::ConsumerControlMarshallerTest );
+//#include <activemq/wireformat/openwire/marshal/generated/ConsumerIdMarshallerTest.h>
+//CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::ConsumerIdMarshallerTest );
+//#include <activemq/wireformat/openwire/marshal/generated/ConsumerInfoMarshallerTest.h>
+//CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::ConsumerInfoMarshallerTest );
+//#include <activemq/wireformat/openwire/marshal/generated/ControlCommandMarshallerTest.h>
+//CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::ControlCommandMarshallerTest );
+//#include <activemq/wireformat/openwire/marshal/generated/DataArrayResponseMarshallerTest.h>
+//CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::DataArrayResponseMarshallerTest );
+//#include <activemq/wireformat/openwire/marshal/generated/DataResponseMarshallerTest.h>
+//CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::DataResponseMarshallerTest );
+//#include <activemq/wireformat/openwire/marshal/generated/DestinationInfoMarshallerTest.h>
+//CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::DestinationInfoMarshallerTest );
+//#include <activemq/wireformat/openwire/marshal/generated/DiscoveryEventMarshallerTest.h>
+//CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::DiscoveryEventMarshallerTest );
+//#include <activemq/wireformat/openwire/marshal/generated/ExceptionResponseMarshallerTest.h>
+//CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::ExceptionResponseMarshallerTest );
+//#include <activemq/wireformat/openwire/marshal/generated/FlushCommandMarshallerTest.h>
+//CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::FlushCommandMarshallerTest );
+//#include <activemq/wireformat/openwire/marshal/generated/IntegerResponseMarshallerTest.h>
+//CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::IntegerResponseMarshallerTest );
+//#include <activemq/wireformat/openwire/marshal/generated/JournalQueueAckMarshallerTest.h>
+//CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::JournalQueueAckMarshallerTest );
+//#include <activemq/wireformat/openwire/marshal/generated/JournalTopicAckMarshallerTest.h>
+//CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::JournalTopicAckMarshallerTest );
+//#include <activemq/wireformat/openwire/marshal/generated/JournalTraceMarshallerTest.h>
+//CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::JournalTraceMarshallerTest );
+//#include <activemq/wireformat/openwire/marshal/generated/JournalTransactionMarshallerTest.h>
+//CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::JournalTransactionMarshallerTest );
+//#include <activemq/wireformat/openwire/marshal/generated/KeepAliveInfoMarshallerTest.h>
+//CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::KeepAliveInfoMarshallerTest );
+//#include <activemq/wireformat/openwire/marshal/generated/LastPartialCommandMarshallerTest.h>
+//CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::LastPartialCommandMarshallerTest );
+//#include <activemq/wireformat/openwire/marshal/generated/LocalTransactionIdMarshallerTest.h>
+//CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::LocalTransactionIdMarshallerTest );
+//#include <activemq/wireformat/openwire/marshal/generated/MessageAckMarshallerTest.h>
+//CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::MessageAckMarshallerTest );
+//#include <activemq/wireformat/openwire/marshal/generated/MessageDispatchMarshallerTest.h>
+//CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::MessageDispatchMarshallerTest );
+//#include <activemq/wireformat/openwire/marshal/generated/MessageDispatchNotificationMarshallerTest.h>
+//CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::MessageDispatchNotificationMarshallerTest );
+//#include <activemq/wireformat/openwire/marshal/generated/MessageIdMarshallerTest.h>
+//CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::MessageIdMarshallerTest );
+//#include <activemq/wireformat/openwire/marshal/generated/MessagePullMarshallerTest.h>
+//CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::MessagePullMarshallerTest );
+//#include <activemq/wireformat/openwire/marshal/generated/NetworkBridgeFilterMarshallerTest.h>
+//CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::NetworkBridgeFilterMarshallerTest );
+//#include <activemq/wireformat/openwire/marshal/generated/PartialCommandMarshallerTest.h>
+//CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::PartialCommandMarshallerTest );
+//#include <activemq/wireformat/openwire/marshal/generated/ProducerAckMarshallerTest.h>
+//CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::ProducerAckMarshallerTest );
+//#include <activemq/wireformat/openwire/marshal/generated/ProducerIdMarshallerTest.h>
+//CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::ProducerIdMarshallerTest );
+//#include <activemq/wireformat/openwire/marshal/generated/ProducerInfoMarshallerTest.h>
+//CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::ProducerInfoMarshallerTest );
+//#include <activemq/wireformat/openwire/marshal/generated/RemoveInfoMarshallerTest.h>
+//CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::RemoveInfoMarshallerTest );
+//#include <activemq/wireformat/openwire/marshal/generated/RemoveSubscriptionInfoMarshallerTest.h>
+//CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::RemoveSubscriptionInfoMarshallerTest );
+//#include <activemq/wireformat/openwire/marshal/generated/ReplayCommandMarshallerTest.h>
+//CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::ReplayCommandMarshallerTest );
+//#include <activemq/wireformat/openwire/marshal/generated/ResponseMarshallerTest.h>
+//CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::ResponseMarshallerTest );
+//#include <activemq/wireformat/openwire/marshal/generated/SessionIdMarshallerTest.h>
+//CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::SessionIdMarshallerTest );
+//#include <activemq/wireformat/openwire/marshal/generated/SessionInfoMarshallerTest.h>
+//CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::SessionInfoMarshallerTest );
+//#include <activemq/wireformat/openwire/marshal/generated/ShutdownInfoMarshallerTest.h>
+//CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::ShutdownInfoMarshallerTest );
+//#include <activemq/wireformat/openwire/marshal/generated/SubscriptionInfoMarshallerTest.h>
+//CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::SubscriptionInfoMarshallerTest );
+//#include <activemq/wireformat/openwire/marshal/generated/TransactionInfoMarshallerTest.h>
+//CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::TransactionInfoMarshallerTest );
+//#include <activemq/wireformat/openwire/marshal/generated/WireFormatInfoMarshallerTest.h>
+//CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::WireFormatInfoMarshallerTest );
+//#include <activemq/wireformat/openwire/marshal/generated/XATransactionIdMarshallerTest.h>
+//CPPUNIT_TEST_SUITE_REGISTRATION( activemq::wireformat::openwire::marshal::generated::XATransactionIdMarshallerTest );