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/05/30 17:22:09 UTC

svn commit: r542840 - in /activemq/activemq-cpp/trunk/src/main/decaf: io/ lang/ lang/exceptions/ net/ util/logging/

Author: tabish
Date: Wed May 30 08:22:07 2007
New Revision: 542840

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

Modified:
    activemq/activemq-cpp/trunk/src/main/decaf/io/BlockingByteArrayInputStream.h
    activemq/activemq-cpp/trunk/src/main/decaf/io/ByteArrayInputStream.h
    activemq/activemq-cpp/trunk/src/main/decaf/io/ByteArrayOutputStream.h
    activemq/activemq-cpp/trunk/src/main/decaf/io/EOFException.h
    activemq/activemq-cpp/trunk/src/main/decaf/io/FilterInputStream.h
    activemq/activemq-cpp/trunk/src/main/decaf/io/FilterOutputStream.h
    activemq/activemq-cpp/trunk/src/main/decaf/io/StandardErrorOutputStream.h
    activemq/activemq-cpp/trunk/src/main/decaf/lang/Exception.cpp
    activemq/activemq-cpp/trunk/src/main/decaf/lang/Exception.h
    activemq/activemq-cpp/trunk/src/main/decaf/lang/Thread.cpp
    activemq/activemq-cpp/trunk/src/main/decaf/lang/Thread.h
    activemq/activemq-cpp/trunk/src/main/decaf/lang/Throwable.h
    activemq/activemq-cpp/trunk/src/main/decaf/lang/exceptions/ExceptionDefines.h
    activemq/activemq-cpp/trunk/src/main/decaf/lang/exceptions/IllegalArgumentException.h
    activemq/activemq-cpp/trunk/src/main/decaf/lang/exceptions/IllegalMonitorStateException.h
    activemq/activemq-cpp/trunk/src/main/decaf/lang/exceptions/IllegalStateException.h
    activemq/activemq-cpp/trunk/src/main/decaf/lang/exceptions/IndexOutOfBoundsException.h
    activemq/activemq-cpp/trunk/src/main/decaf/lang/exceptions/InterruptedException.h
    activemq/activemq-cpp/trunk/src/main/decaf/lang/exceptions/NoSuchElementException.h
    activemq/activemq-cpp/trunk/src/main/decaf/lang/exceptions/NullPointerException.h
    activemq/activemq-cpp/trunk/src/main/decaf/lang/exceptions/RuntimeException.h
    activemq/activemq-cpp/trunk/src/main/decaf/net/BufferedSocket.cpp
    activemq/activemq-cpp/trunk/src/main/decaf/net/SocketInputStream.h
    activemq/activemq-cpp/trunk/src/main/decaf/net/SocketOutputStream.h
    activemq/activemq-cpp/trunk/src/main/decaf/util/logging/SimpleFormatter.h
    activemq/activemq-cpp/trunk/src/main/decaf/util/logging/SimpleLogger.h
    activemq/activemq-cpp/trunk/src/main/decaf/util/logging/StreamHandler.h

Modified: activemq/activemq-cpp/trunk/src/main/decaf/io/BlockingByteArrayInputStream.h
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/decaf/io/BlockingByteArrayInputStream.h?view=diff&rev=542840&r1=542839&r2=542840
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/decaf/io/BlockingByteArrayInputStream.h (original)
+++ activemq/activemq-cpp/trunk/src/main/decaf/io/BlockingByteArrayInputStream.h Wed May 30 08:22:07 2007
@@ -89,17 +89,17 @@
          * Waits on a signal from this object, which is generated
          * by a call to Notify.  Must have this object locked before
          * calling.
-         * @throws ActiveMQException
+         * @throws Exception
          */
-        virtual void lock() throw( exceptions::ActiveMQException ){
+        virtual void lock() throw( Exception ){
             mutex.lock();
         }
 
         /**
          * Unlocks the object.
-         * @throws ActiveMQException
+         * @throws Exception
          */
-        virtual void unlock() throw( exceptions::ActiveMQException ){
+        virtual void unlock() throw( Exception ){
             mutex.unlock();
         }
 
@@ -107,9 +107,9 @@
          * Waits on a signal from this object, which is generated
          * by a call to Notify.  Must have this object locked before
          * calling.
-         * @throws ActiveMQException
+         * @throws Exception
          */
-        virtual void wait() throw( exceptions::ActiveMQException ){
+        virtual void wait() throw( Exception ){
             mutex.wait();
         }
 
@@ -119,9 +119,9 @@
          * calling.  This wait will timeout after the specified time
          * interval.
          * @param time in millisecsonds to wait, or WAIT_INIFINITE
-         * @throws ActiveMQException
+         * @throws Exception
          */
-        virtual void wait( unsigned long millisecs ) throw( exceptions::ActiveMQException ){
+        virtual void wait( unsigned long millisecs ) throw( Exception ){
             mutex.wait(millisecs);
         }
 
@@ -129,9 +129,9 @@
          * Signals a waiter on this object that it can now wake
          * up and continue.  Must have this object locked before
          * calling.
-         * @throws ActiveMQException
+         * @throws Exception
          */
-        virtual void notify() throw( exceptions::ActiveMQException ){
+        virtual void notify() throw( Exception ){
             mutex.notify();
         }
 
@@ -139,9 +139,9 @@
          * Signals the waiters on this object that it can now wake
          * up and continue.  Must have this object locked before
          * calling.
-         * @throws ActiveMQException
+         * @throws Exception
          */
-        virtual void notifyAll() throw( exceptions::ActiveMQException ){
+        virtual void notifyAll() throw( Exception ){
             mutex.notifyAll();
         }
 

Modified: activemq/activemq-cpp/trunk/src/main/decaf/io/ByteArrayInputStream.h
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/decaf/io/ByteArrayInputStream.h?view=diff&rev=542840&r1=542839&r2=542840
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/decaf/io/ByteArrayInputStream.h (original)
+++ activemq/activemq-cpp/trunk/src/main/decaf/io/ByteArrayInputStream.h Wed May 30 08:22:07 2007
@@ -102,17 +102,17 @@
          * Waits on a signal from this object, which is generated
          * by a call to Notify.  Must have this object locked before
          * calling.
-         * @throws ActiveMQException
+         * @throws Exception
          */
-        virtual void lock() throw( exceptions::ActiveMQException ){
+        virtual void lock() throw( Exception ){
             mutex.lock();
         }
 
         /**
          * Unlocks the object.
-         * @throws ActiveMQException
+         * @throws Exception
          */
-        virtual void unlock() throw( exceptions::ActiveMQException ){
+        virtual void unlock() throw( Exception ){
             mutex.unlock();
         }
 
@@ -120,9 +120,9 @@
          * Waits on a signal from this object, which is generated
          * by a call to Notify.  Must have this object locked before
          * calling.
-         * @throws ActiveMQException
+         * @throws Exception
          */
-        virtual void wait() throw( exceptions::ActiveMQException ){
+        virtual void wait() throw( Exception ){
             mutex.wait();
         }
 
@@ -133,9 +133,9 @@
          * interval.
          * @param millisecs the time in millisecsonds to wait, or
          * WAIT_INIFINITE
-         * @throws ActiveMQException
+         * @throws Exception
          */
-        virtual void wait( unsigned long millisecs ) throw( exceptions::ActiveMQException ){
+        virtual void wait( unsigned long millisecs ) throw( Exception ){
             mutex.wait(millisecs);
         }
 
@@ -143,9 +143,9 @@
          * Signals a waiter on this object that it can now wake
          * up and continue.  Must have this object locked before
          * calling.
-         * @throws ActiveMQException
+         * @throws Exception
          */
-        virtual void notify() throw( exceptions::ActiveMQException ){
+        virtual void notify() throw( Exception ){
             mutex.notify();
         }
 
@@ -153,9 +153,9 @@
          * Signals the waiters on this object that it can now wake
          * up and continue.  Must have this object locked before
          * calling.
-         * @throws ActiveMQException
+         * @throws Exception
          */
-        virtual void notifyAll() throw( exceptions::ActiveMQException ){
+        virtual void notifyAll() throw( Exception ){
             mutex.notifyAll();
         }
 

Modified: activemq/activemq-cpp/trunk/src/main/decaf/io/ByteArrayOutputStream.h
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/decaf/io/ByteArrayOutputStream.h?view=diff&rev=542840&r1=542839&r2=542840
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/decaf/io/ByteArrayOutputStream.h (original)
+++ activemq/activemq-cpp/trunk/src/main/decaf/io/ByteArrayOutputStream.h Wed May 30 08:22:07 2007
@@ -28,12 +28,12 @@
     class ByteArrayOutputStream : public OutputStream
     {
     private:
-         
-        /** 
+
+        /**
          * Default buffer to use, if none provided.
          */
         std::vector<unsigned char> defaultBuffer;
-        
+
         /**
          * Reference to the buffer being used by this stream.
          */
@@ -43,14 +43,14 @@
          * Synchronization object.
          */
         concurrent::Mutex mutex;
-      
+
     public:
 
         /**
          * Default Constructor - uses a default internal buffer
          */
         ByteArrayOutputStream();
-        
+
         /**
          * Uses the given buffer as the target.  Calls setBuffer.
          * @param buffer the target buffer.
@@ -60,8 +60,8 @@
         /**
          * Destructor
          */
-   	    virtual ~ByteArrayOutputStream() {};
-      
+           virtual ~ByteArrayOutputStream() {};
+
         /**
          * Sets the internal buffer.  This input stream will wrap around
          * the given buffer and all writes will be performed directly on
@@ -70,7 +70,7 @@
          * @param buffer The target buffer.
          */
         virtual void setBuffer( std::vector<unsigned char>& buffer );
-        
+
         /**
          * Get a snapshot of the data
          * @return pointer to the data
@@ -79,10 +79,10 @@
             if( activeBuffer->size() == 0 ){
                 return NULL;
             }
-            
+
             return &(*activeBuffer)[0];
         }
-      
+
         /**
          * Get the Size of the Internal Buffer
          * @return size of the internal buffer
@@ -95,39 +95,39 @@
          * Waits on a signal from this object, which is generated
          * by a call to Notify.  Must have this object locked before
          * calling.
-         * @throws ActiveMQException
+         * @throws Exception
          */
-        virtual void lock() throw( exceptions::ActiveMQException ){
+        virtual void lock() throw( Exception ){
             mutex.lock();
         }
-    
+
         /**
          * Unlocks the object.
-         * @throws ActiveMQException
+         * @throws Exception
          */
-        virtual void unlock() throw( exceptions::ActiveMQException ){ 
+        virtual void unlock() throw( Exception ){
             mutex.unlock();
         }
-        
+
         /**
          * Waits on a signal from this object, which is generated
          * by a call to Notify.  Must have this object locked before
          * calling.
-         * @throws ActiveMQException
+         * @throws Exception
          */
-        virtual void wait() throw( exceptions::ActiveMQException ){
+        virtual void wait() throw( Exception ){
             mutex.wait();
         }
-    
+
         /**
          * Waits on a signal from this object, which is generated
          * by a call to Notify.  Must have this object locked before
          * calling.  This wait will timeout after the specified time
          * interval.
          * @param time in millisecsonds to wait, or WAIT_INIFINITE
-         * @throws ActiveMQException
+         * @throws Exception
          */
-        virtual void wait( unsigned long millisecs ) throw( exceptions::ActiveMQException ){
+        virtual void wait( unsigned long millisecs ) throw( Exception ){
             mutex.wait(millisecs);
         }
 
@@ -135,45 +135,45 @@
          * Signals a waiter on this object that it can now wake
          * up and continue.  Must have this object locked before
          * calling.
-         * @throws ActiveMQException
+         * @throws Exception
          */
-        virtual void notify() throw( exceptions::ActiveMQException ){
+        virtual void notify() throw( Exception ){
             mutex.notify();
         }
-        
+
         /**
          * Signals the waiters on this object that it can now wake
          * up and continue.  Must have this object locked before
          * calling.
-         * @throws ActiveMQException
+         * @throws Exception
          */
-        virtual void notifyAll() throw( exceptions::ActiveMQException ){
+        virtual void notifyAll() throw( Exception ){
             mutex.notifyAll();
         }
-       
+
         /**
          * Writes a single byte to the output stream.
          * @param c the byte.
          * @throws IOException thrown if an error occurs.
          */
-        virtual void write( unsigned char c ) 
+        virtual void write( unsigned char c )
            throw ( IOException );
-      
+
         /**
          * Writes an array of bytes to the output stream.
          * @param buffer The array of bytes to write.
          * @param len The number of bytes from the buffer to be written.
          * @throws IOException thrown if an error occurs.
          */
-        virtual void write( const unsigned char* buffer, std::size_t len ) 
+        virtual void write( const unsigned char* buffer, std::size_t len )
             throw ( IOException );
-      
+
         /**
          * Invokes flush on the target output stream, has no affect.
          * @throws IOException
          */
         virtual void flush() throw ( IOException ){ /* do nothing */ }
-      
+
         /**
          * Clear current Stream contents
          * @throws IOException

Modified: activemq/activemq-cpp/trunk/src/main/decaf/io/EOFException.h
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/decaf/io/EOFException.h?view=diff&rev=542840&r1=542839&r2=542840
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/decaf/io/EOFException.h (original)
+++ activemq/activemq-cpp/trunk/src/main/decaf/io/EOFException.h Wed May 30 08:22:07 2007
@@ -42,7 +42,7 @@
         EOFException( const exceptions::Exception& ex ) throw()
         : IOException()
         {
-            *(exceptions::ActiveMQException*)this = ex;
+            *(exceptions::Exception*)this = ex;
         }
 
         /**

Modified: activemq/activemq-cpp/trunk/src/main/decaf/io/FilterInputStream.h
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/decaf/io/FilterInputStream.h?view=diff&rev=542840&r1=542839&r2=542840
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/decaf/io/FilterInputStream.h (original)
+++ activemq/activemq-cpp/trunk/src/main/decaf/io/FilterInputStream.h Wed May 30 08:22:07 2007
@@ -162,17 +162,17 @@
          * Waits on a signal from this object, which is generated
          * by a call to Notify.  Must have this object locked before
          * calling.
-         * @throws ActiveMQException
+         * @throws Exception
          */
-        virtual void lock() throw( exceptions::ActiveMQException ){
+        virtual void lock() throw( Exception ){
             mutex.lock();
         }
 
         /**
          * Unlocks the object.
-         * @throws ActiveMQException
+         * @throws Exception
          */
-        virtual void unlock() throw( exceptions::ActiveMQException ){
+        virtual void unlock() throw( Exception ){
             mutex.unlock();
         }
 
@@ -180,9 +180,9 @@
          * Waits on a signal from this object, which is generated
          * by a call to Notify.  Must have this object locked before
          * calling.
-         * @throws ActiveMQException
+         * @throws Exception
          */
-        virtual void wait() throw( exceptions::ActiveMQException ){
+        virtual void wait() throw( Exception ){
             mutex.wait();
         }
 
@@ -192,9 +192,9 @@
          * calling.  This wait will timeout after the specified time
          * interval.
          * @param millisecs the time in millisecsonds to wait, or WAIT_INIFINITE
-         * @throws ActiveMQException
+         * @throws Exception
          */
-        virtual void wait( unsigned long millisecs ) throw( exceptions::ActiveMQException ){
+        virtual void wait( unsigned long millisecs ) throw( Exception ){
             mutex.wait(millisecs);
         }
 
@@ -202,9 +202,9 @@
          * Signals a waiter on this object that it can now wake
          * up and continue.  Must have this object locked before
          * calling.
-         * @throws ActiveMQException
+         * @throws Exception
          */
-        virtual void notify() throw( exceptions::ActiveMQException ){
+        virtual void notify() throw( Exception ){
             mutex.notify();
         }
 

Modified: activemq/activemq-cpp/trunk/src/main/decaf/io/FilterOutputStream.h
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/decaf/io/FilterOutputStream.h?view=diff&rev=542840&r1=542839&r2=542840
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/decaf/io/FilterOutputStream.h (original)
+++ activemq/activemq-cpp/trunk/src/main/decaf/io/FilterOutputStream.h Wed May 30 08:22:07 2007
@@ -146,17 +146,17 @@
          * Waits on a signal from this object, which is generated
          * by a call to Notify.  Must have this object locked before
          * calling.
-         * @throws ActiveMQException
+         * @throws Exception
          */
-        virtual void lock() throw( exceptions::ActiveMQException ){
+        virtual void lock() throw( Exception ){
             mutex.lock();
         }
 
         /**
          * Unlocks the object.
-         * @throws ActiveMQException
+         * @throws Exception
          */
-        virtual void unlock() throw( exceptions::ActiveMQException ){
+        virtual void unlock() throw( Exception ){
             mutex.unlock();
         }
 
@@ -164,9 +164,9 @@
          * Waits on a signal from this object, which is generated
          * by a call to Notify.  Must have this object locked before
          * calling.
-         * @throws ActiveMQException
+         * @throws Exception
          */
-        virtual void wait() throw( exceptions::ActiveMQException ){
+        virtual void wait() throw( Exception ){
             mutex.wait();
         }
 
@@ -176,9 +176,9 @@
          * calling.  This wait will timeout after the specified time
          * interval.
          * @param millisecs the time in millisecsonds to wait, or WAIT_INIFINITE
-         * @throws ActiveMQException
+         * @throws Exception
          */
-        virtual void wait( unsigned long millisecs ) throw( exceptions::ActiveMQException ){
+        virtual void wait( unsigned long millisecs ) throw( Exception ){
             mutex.wait(millisecs);
         }
 
@@ -186,9 +186,9 @@
          * Signals a waiter on this object that it can now wake
          * up and continue.  Must have this object locked before
          * calling.
-         * @throws ActiveMQException
+         * @throws Exception
          */
-        virtual void notify() throw( exceptions::ActiveMQException ){
+        virtual void notify() throw( Exception ){
             mutex.notify();
         }
 
@@ -196,9 +196,9 @@
          * Signals the waiters on this object that it can now wake
          * up and continue.  Must have this object locked before
          * calling.
-         * @throws ActiveMQException
+         * @throws Exception
          */
-        virtual void notifyAll() throw( exceptions::ActiveMQException ){
+        virtual void notifyAll() throw( Exception ){
             mutex.notifyAll();
         }
 

Modified: activemq/activemq-cpp/trunk/src/main/decaf/io/StandardErrorOutputStream.h
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/decaf/io/StandardErrorOutputStream.h?view=diff&rev=542840&r1=542839&r2=542840
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/decaf/io/StandardErrorOutputStream.h (original)
+++ activemq/activemq-cpp/trunk/src/main/decaf/io/StandardErrorOutputStream.h Wed May 30 08:22:07 2007
@@ -47,17 +47,17 @@
          * Waits on a signal from this object, which is generated
          * by a call to Notify.  Must have this object locked before
          * calling.
-         * @throws ActiveMQException
+         * @throws Exception
          */
-        virtual void lock() throw( exceptions::ActiveMQException ){
+        virtual void lock() throw( Exception ){
             mutex.lock();
         }
 
         /**
          * Unlocks the object.
-         * @throws ActiveMQException
+         * @throws Exception
          */
-        virtual void unlock() throw( exceptions::ActiveMQException ){
+        virtual void unlock() throw( Exception ){
             mutex.unlock();
         }
 
@@ -65,9 +65,9 @@
          * Waits on a signal from this object, which is generated
          * by a call to Notify.  Must have this object locked before
          * calling.
-         * @throws ActiveMQException
+         * @throws Exception
          */
-        virtual void wait() throw( exceptions::ActiveMQException ){
+        virtual void wait() throw( Exception ){
             mutex.wait();
         }
 
@@ -77,9 +77,9 @@
          * calling.  This wait will timeout after the specified time
          * interval.
          * @param time in millisecsonds to wait, or WAIT_INIFINITE
-         * @throws ActiveMQException
+         * @throws Exception
          */
-        virtual void wait( unsigned long millisecs ) throw( exceptions::ActiveMQException ){
+        virtual void wait( unsigned long millisecs ) throw( Exception ){
             mutex.wait( millisecs );
         }
 
@@ -87,9 +87,9 @@
          * Signals a waiter on this object that it can now wake
          * up and continue.  Must have this object locked before
          * calling.
-         * @throws ActiveMQException
+         * @throws Exception
          */
-        virtual void notify() throw( exceptions::ActiveMQException ){
+        virtual void notify() throw( Exception ){
             mutex.notify();
         }
 
@@ -97,9 +97,9 @@
          * Signals the waiters on this object that it can now wake
          * up and continue.  Must have this object locked before
          * calling.
-         * @throws ActiveMQException
+         * @throws Exception
          */
-        virtual void notifyAll() throw( exceptions::ActiveMQException ){
+        virtual void notifyAll() throw( Exception ){
             mutex.notifyAll();
         }
 

Modified: activemq/activemq-cpp/trunk/src/main/decaf/lang/Exception.cpp
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/decaf/lang/Exception.cpp?view=diff&rev=542840&r1=542839&r2=542840
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/decaf/lang/Exception.cpp (original)
+++ activemq/activemq-cpp/trunk/src/main/decaf/lang/Exception.cpp Wed May 30 08:22:07 2007
@@ -17,6 +17,7 @@
 #include <stdio.h>
 #include "Exception.h"
 #include <decaf/util/logging/LoggerDefines.h>
+#include <sstream>
 
 using namespace std;
 using namespace decaf;
@@ -33,16 +34,13 @@
 }
 
 ////////////////////////////////////////////////////////////////////////////////
-Exception::Exception( const Exception& ex ) throw()
-: Throwable()
-{
+Exception::Exception( const Exception& ex ) throw() : Throwable() {
     *this = ex;
 }
 
 ////////////////////////////////////////////////////////////////////////////////
 Exception::Exception( const char* file, const int lineNumber,
-                   const char* msg, ... ) throw()
-{
+                   const char* msg, ... ) throw() {
     va_list vargs;
     va_start( vargs, msg ) ;
     buildMessage( msg, vargs );
@@ -63,8 +61,8 @@
 }
 
 ////////////////////////////////////////////////////////////////////////////////
-void Exception::buildMessage(const char* format, va_list& vargs)
-{
+void Exception::buildMessage(const char* format, va_list& vargs) {
+
     // Allocate buffer with a guess of it's size
     int size = 128;
 
@@ -98,12 +96,12 @@
 }
 
 ////////////////////////////////////////////////////////////////////////////////
-void Exception::setMark( const char* file, const int lineNumber ){
+void Exception::setMark( const char* file, const int lineNumber ) {
 
     // Add this mark to the end of the stack trace.
     stackTrace.push_back( std::make_pair( (std::string)file, (int)lineNumber ) );
 
-    ostringstream stream;
+    std::ostringstream stream;
     stream << "\tFILE: " << stackTrace[stackTrace.size()-1].first;
     stream << ", LINE: " << stackTrace[stackTrace.size()-1].second;
 
@@ -112,27 +110,27 @@
 }
 
 ////////////////////////////////////////////////////////////////////////////////
-Exception* Exception::clone() const{
-    return new ActiveMQException( *this );
+Exception* Exception::clone() const {
+    return new Exception( *this );
 }
 
 ////////////////////////////////////////////////////////////////////////////////
-std::vector< std::pair< std::string, int> > Exception::getStackTrace() const{
+std::vector< std::pair< std::string, int> > Exception::getStackTrace() const {
     return stackTrace;
 }
 
 ////////////////////////////////////////////////////////////////////////////////
-void Exception::printStackTrace() const{
+void Exception::printStackTrace() const {
     printStackTrace( std::cerr );
 }
 
 ////////////////////////////////////////////////////////////////////////////////
-void Exception::printStackTrace( std::ostream& stream ) const{
+void Exception::printStackTrace( std::ostream& stream ) const {
     stream << getStackTraceString();
 }
 
 ////////////////////////////////////////////////////////////////////////////////
-std::string Exception::getStackTraceString() const{
+std::string Exception::getStackTraceString() const {
 
     // Create the output stream.
     std::ostringstream stream;
@@ -155,4 +153,3 @@
     this->stackTrace = ex.stackTrace;
     return *this;
 }
-

Modified: activemq/activemq-cpp/trunk/src/main/decaf/lang/Exception.h
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/decaf/lang/Exception.h?view=diff&rev=542840&r1=542839&r2=542840
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/decaf/lang/Exception.h (original)
+++ activemq/activemq-cpp/trunk/src/main/decaf/lang/Exception.h Wed May 30 08:22:07 2007
@@ -134,7 +134,7 @@
 
         /**
          * Assignment operator.
-         * @param const reference to another ActiveMQException
+         * @param const reference to another Exception
          */
         virtual Exception& operator =( const Exception& ex );
 

Modified: activemq/activemq-cpp/trunk/src/main/decaf/lang/Thread.cpp
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/decaf/lang/Thread.cpp?view=diff&rev=542840&r1=542839&r2=542840
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/decaf/lang/Thread.cpp (original)
+++ activemq/activemq-cpp/trunk/src/main/decaf/lang/Thread.cpp Wed May 30 08:22:07 2007
@@ -24,10 +24,11 @@
 #endif
 
 #include <decaf/lang/Exception.h>
-#include <activemq/exceptions/RuntimeException.h>
+#include <decaf/lang/exceptions/RuntimeException.h>
 
 using namespace decaf;
 using namespace decaf::lang;
+using namespace decaf::lang::exceptions;
 
 ////////////////////////////////////////////////////////////////////////////////
 Thread::Thread()
@@ -54,7 +55,7 @@
 void Thread::start() throw ( Exception )
 {
     if (this->started) {
-        throw exceptions::ActiveMQException( __FILE__, __LINE__,
+        throw Exception( __FILE__, __LINE__,
             "Thread already started");
     }
 
@@ -68,7 +69,7 @@
         runCallback,
         this);
     if (err != 0) {
-        throw exceptions::ActiveMQException( __FILE__, __LINE__,
+        throw Exception( __FILE__, __LINE__,
             "Coud not start thread");
     }
 
@@ -78,7 +79,7 @@
     this->threadHandle =
         (HANDLE)::_beginthreadex(NULL, 0, runCallback, this, 0, &threadId);
     if (this->threadHandle == NULL) {
-        throw exceptions::ActiveMQException( __FILE__, __LINE__,
+        throw Exception( __FILE__, __LINE__,
             "Coud not start thread");
     }
 
@@ -89,10 +90,10 @@
 }
 
 ////////////////////////////////////////////////////////////////////////////////
-void Thread::join() throw( exceptions::ActiveMQException )
+void Thread::join() throw( Exception )
 {
     if (!this->started) {
-        throw exceptions::ActiveMQException( __FILE__, __LINE__,
+        throw Exception( __FILE__, __LINE__,
             "Thread::join() called without having called Thread::start()");
     }
     if (!this->joined) {
@@ -150,7 +151,7 @@
     try{
         thread->task->run();
     } catch( ... ){
-        exceptions::RuntimeException ex(__FILE__, __LINE__, "unhandled exception bubbled up to Thread::run");
+        RuntimeException ex(__FILE__, __LINE__, "unhandled exception bubbled up to Thread::run");
         ex.printStackTrace();
     }
 

Modified: activemq/activemq-cpp/trunk/src/main/decaf/lang/Thread.h
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/decaf/lang/Thread.h?view=diff&rev=542840&r1=542839&r2=542840
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/decaf/lang/Thread.h (original)
+++ activemq/activemq-cpp/trunk/src/main/decaf/lang/Thread.h Wed May 30 08:22:07 2007
@@ -88,13 +88,13 @@
          * @exception runtime_error is thrown if the system could
          * not start the thread.
          */
-        virtual void start() throw ( exceptions::ActiveMQException );
+        virtual void start() throw ( Exception );
 
         /**
          * Wait til the thread exits. This is when the run()
          * method has returned or has thrown an exception.
          */
-        virtual void join() throw ( exceptions::ActiveMQException );
+        virtual void join() throw ( Exception );
 
         /**
          * Default implementation of the run method - does nothing.

Modified: activemq/activemq-cpp/trunk/src/main/decaf/lang/Throwable.h
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/decaf/lang/Throwable.h?view=diff&rev=542840&r1=542839&r2=542840
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/decaf/lang/Throwable.h (original)
+++ activemq/activemq-cpp/trunk/src/main/decaf/lang/Throwable.h Wed May 30 08:22:07 2007
@@ -24,7 +24,8 @@
 #include <iostream>
 #include <exception>
 
-namespace cms{
+namespace decaf{
+namespace lang{
 
     /**
      * This class represents an error that has occurred.
@@ -84,6 +85,6 @@
 
     };
 
-}
+}}
 
 #endif /*_DECAF_LANG_THROWABLE_H_*/

Modified: activemq/activemq-cpp/trunk/src/main/decaf/lang/exceptions/ExceptionDefines.h
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/decaf/lang/exceptions/ExceptionDefines.h?view=diff&rev=542840&r1=542839&r2=542840
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/decaf/lang/exceptions/ExceptionDefines.h (original)
+++ activemq/activemq-cpp/trunk/src/main/decaf/lang/exceptions/ExceptionDefines.h Wed May 30 08:22:07 2007
@@ -22,7 +22,7 @@
  * Macro for catching and rethrowing an exception of
  * a given type.
  * @param type The type of the exception to throw
- * (e.g. ActiveMQException ).
+ * (e.g. Exception ).
  */
 #define DECAF_CATCH_RETHROW( type ) \
     catch( type& ex ){ \
@@ -61,7 +61,7 @@
  */
 #define DECAF_CATCHALL_NOTHROW( ) \
     catch( ... ){ \
-        exceptions::ActiveMQException ex( __FILE__, __LINE__, \
+        lang::Exception ex( __FILE__, __LINE__, \
             "caught unknown exception, not rethrowing" ); \
     }
 
@@ -69,7 +69,7 @@
  * Macro for catching and rethrowing an exception of
  * a given type.
  * @param type The type of the exception to throw
- * (e.g. ActiveMQException ).
+ * (e.g. Exception ).
  */
 #define DECAF_CATCH_NOTHROW( type ) \
     catch( type& ex ){ \

Modified: activemq/activemq-cpp/trunk/src/main/decaf/lang/exceptions/IllegalArgumentException.h
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/decaf/lang/exceptions/IllegalArgumentException.h?view=diff&rev=542840&r1=542839&r2=542840
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/decaf/lang/exceptions/IllegalArgumentException.h (original)
+++ activemq/activemq-cpp/trunk/src/main/decaf/lang/exceptions/IllegalArgumentException.h Wed May 30 08:22:07 2007
@@ -17,7 +17,7 @@
 #ifndef _DECAF_LANG_EXCEPTIONS_ILLEGALARGUMENTEXCEPTION_H_
 #define _DECAF_LANG_EXCEPTIONS_ILLEGALARGUMENTEXCEPTION_H_
 
-#include <activemq/exceptions/ActiveMQException.h>
+#include <decaf/lang/Exception.h>
 
 namespace decaf{
 namespace lang{
@@ -26,7 +26,7 @@
     /*
      * Thrown when an illegal argument was passed into a method.
      */
-    class IllegalArgumentException : public ActiveMQException
+    class IllegalArgumentException : public Exception
     {
     public:
 
@@ -36,22 +36,22 @@
         IllegalArgumentException() throw() {}
 
         /**
-         * Conversion Constructor from some other ActiveMQException
+         * Conversion Constructor from some other Exception
          * @param An exception that should become this type of Exception
          */
-        IllegalArgumentException( const ActiveMQException& ex ) throw()
-        : ActiveMQException()
+        IllegalArgumentException( const Exception& ex ) throw()
+        : Exception()
         {
-            *(ActiveMQException*)this = ex;
+            *(Exception*)this = ex;
         }
 
         /**
          * Copy Constructor
          */
         IllegalArgumentException( const IllegalArgumentException& ex ) throw()
-        : ActiveMQException()
+        : Exception()
         {
-            *(ActiveMQException*)this = ex;
+            *(Exception*)this = ex;
         }
 
         /**
@@ -65,7 +65,7 @@
          */
         IllegalArgumentException(const char* file, const int lineNumber,
             const char* msg, ...) throw()
-        : ActiveMQException()
+        : Exception()
         {
             va_list vargs ;
             va_start(vargs, msg) ;
@@ -80,7 +80,7 @@
          * to preserve the type of the original exception as well as the message.
          * All subclasses should override.
          */
-        virtual ActiveMQException* clone() const{
+        virtual Exception* clone() const{
             return new IllegalArgumentException( *this );
         }
 

Modified: activemq/activemq-cpp/trunk/src/main/decaf/lang/exceptions/IllegalMonitorStateException.h
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/decaf/lang/exceptions/IllegalMonitorStateException.h?view=diff&rev=542840&r1=542839&r2=542840
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/decaf/lang/exceptions/IllegalMonitorStateException.h (original)
+++ activemq/activemq-cpp/trunk/src/main/decaf/lang/exceptions/IllegalMonitorStateException.h Wed May 30 08:22:07 2007
@@ -37,7 +37,7 @@
         IllegalMonitorStateException() throw() {};
 
         /**
-         * Conversion Constructor from some other ActiveMQException
+         * Conversion Constructor from some other Exception
          * @param An exception that should become this type of Exception
          */
         IllegalMonitorStateException(const Exception& ex) throw()

Modified: activemq/activemq-cpp/trunk/src/main/decaf/lang/exceptions/IllegalStateException.h
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/decaf/lang/exceptions/IllegalStateException.h?view=diff&rev=542840&r1=542839&r2=542840
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/decaf/lang/exceptions/IllegalStateException.h (original)
+++ activemq/activemq-cpp/trunk/src/main/decaf/lang/exceptions/IllegalStateException.h Wed May 30 08:22:07 2007
@@ -37,7 +37,7 @@
         IllegalStateException() throw() {};
 
         /**
-         * Conversion Constructor from some other ActiveMQException
+         * Conversion Constructor from some other Exception
          * @param An exception that should become this type of Exception
          */
         IllegalStateException(const Exception& ex) throw()

Modified: activemq/activemq-cpp/trunk/src/main/decaf/lang/exceptions/IndexOutOfBoundsException.h
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/decaf/lang/exceptions/IndexOutOfBoundsException.h?view=diff&rev=542840&r1=542839&r2=542840
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/decaf/lang/exceptions/IndexOutOfBoundsException.h (original)
+++ activemq/activemq-cpp/trunk/src/main/decaf/lang/exceptions/IndexOutOfBoundsException.h Wed May 30 08:22:07 2007
@@ -36,7 +36,7 @@
       IndexOutOfBoundsException() throw() {}
 
       /**
-       * Conversion Constructor from some other ActiveMQException
+       * Conversion Constructor from some other Exception
        * @param An exception that should become this type of Exception
        */
       IndexOutOfBoundsException( const Exception& ex ) throw()

Modified: activemq/activemq-cpp/trunk/src/main/decaf/lang/exceptions/InterruptedException.h
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/decaf/lang/exceptions/InterruptedException.h?view=diff&rev=542840&r1=542839&r2=542840
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/decaf/lang/exceptions/InterruptedException.h (original)
+++ activemq/activemq-cpp/trunk/src/main/decaf/lang/exceptions/InterruptedException.h Wed May 30 08:22:07 2007
@@ -36,7 +36,7 @@
         InterruptedException() throw() {};
 
         /**
-         * Conversion Constructor from some other ActiveMQException
+         * Conversion Constructor from some other Exception
          * @param An exception that should become this type of Exception
          */
         InterruptedException(const Exception& ex) throw()

Modified: activemq/activemq-cpp/trunk/src/main/decaf/lang/exceptions/NoSuchElementException.h
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/decaf/lang/exceptions/NoSuchElementException.h?view=diff&rev=542840&r1=542839&r2=542840
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/decaf/lang/exceptions/NoSuchElementException.h (original)
+++ activemq/activemq-cpp/trunk/src/main/decaf/lang/exceptions/NoSuchElementException.h Wed May 30 08:22:07 2007
@@ -37,7 +37,7 @@
         NoSuchElementException() throw() {};
 
         /**
-         * Conversion Constructor from some other ActiveMQException
+         * Conversion Constructor from some other Exception
          * @param An exception that should become this type of Exception
          */
         NoSuchElementException( const Exception& ex ) throw()

Modified: activemq/activemq-cpp/trunk/src/main/decaf/lang/exceptions/NullPointerException.h
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/decaf/lang/exceptions/NullPointerException.h?view=diff&rev=542840&r1=542839&r2=542840
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/decaf/lang/exceptions/NullPointerException.h (original)
+++ activemq/activemq-cpp/trunk/src/main/decaf/lang/exceptions/NullPointerException.h Wed May 30 08:22:07 2007
@@ -36,13 +36,13 @@
         NullPointerException() throw() {};
 
         /**
-         * Conversion Constructor from some other ActiveMQException
+         * Conversion Constructor from some other Exception
          * @param An exception that should become this type of Exception
          */
         NullPointerException( const Exception& ex ) throw()
         : Exception()
         {
-            *(ActiveMQException*)this = ex;
+            *(Exception*)this = ex;
         }
 
         /**

Modified: activemq/activemq-cpp/trunk/src/main/decaf/lang/exceptions/RuntimeException.h
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/decaf/lang/exceptions/RuntimeException.h?view=diff&rev=542840&r1=542839&r2=542840
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/decaf/lang/exceptions/RuntimeException.h (original)
+++ activemq/activemq-cpp/trunk/src/main/decaf/lang/exceptions/RuntimeException.h Wed May 30 08:22:07 2007
@@ -44,7 +44,7 @@
         RuntimeException( const Exception& ex ) throw()
         : Exception()
         {
-            *(ActiveMQException*)this = ex;
+            *(Exception*)this = ex;
         }
 
         /**

Modified: activemq/activemq-cpp/trunk/src/main/decaf/net/BufferedSocket.cpp
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/decaf/net/BufferedSocket.cpp?view=diff&rev=542840&r1=542839&r2=542840
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/decaf/net/BufferedSocket.cpp (original)
+++ activemq/activemq-cpp/trunk/src/main/decaf/net/BufferedSocket.cpp Wed May 30 08:22:07 2007
@@ -66,7 +66,7 @@
     {
         close();
     }
-    AMQ_CATCH_NOTHROW( ActiveMQException )
+    AMQ_CATCH_NOTHROW( Exception )
     AMQ_CATCHALL_NOTHROW()
 }
 
@@ -92,7 +92,7 @@
             socket->getOutputStream(), (std::size_t)outputBufferSize );
     }
     AMQ_CATCH_RETHROW( SocketException )
-    AMQ_CATCH_EXCEPTION_CONVERT( ActiveMQException, SocketException )
+    AMQ_CATCH_EXCEPTION_CONVERT( Exception, SocketException )
     AMQ_CATCHALL_THROW( SocketException )
 }
 
@@ -129,6 +129,6 @@
         }
     }
     AMQ_CATCH_RETHROW( SocketException )
-    AMQ_CATCH_EXCEPTION_CONVERT( ActiveMQException, SocketException )
+    AMQ_CATCH_EXCEPTION_CONVERT( Exception, SocketException )
     AMQ_CATCHALL_THROW( SocketException )
 }

Modified: activemq/activemq-cpp/trunk/src/main/decaf/net/SocketInputStream.h
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/decaf/net/SocketInputStream.h?view=diff&rev=542840&r1=542839&r2=542840
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/decaf/net/SocketInputStream.h (original)
+++ activemq/activemq-cpp/trunk/src/main/decaf/net/SocketInputStream.h Wed May 30 08:22:07 2007
@@ -21,6 +21,7 @@
 #include <decaf/io/InputStream.h>
 #include <decaf/net/Socket.h>
 #include <decaf/lang/Mutex.h>
+#include <decaf/lang/Exception.h>
 
 namespace decaf{
 namespace net{
@@ -52,17 +53,17 @@
 
         /**
          * Locks the object.
-         * @throws ActiveMQException
+         * @throws Exception
          */
-        virtual void lock() throw( exceptions::ActiveMQException ){
+        virtual void lock() throw( lang::Exception ){
             mutex.lock();
         }
 
         /**
          * Unlocks the object.
-         * @throws ActiveMQException
+         * @throws Exception
          */
-        virtual void unlock() throw( exceptions::ActiveMQException ){
+        virtual void unlock() throw( lang::Exception ){
             mutex.unlock();
         }
 
@@ -70,9 +71,9 @@
          * Waits on a signal from this object, which is generated
          * by a call to Notify.  Must have this object locked before
          * calling.
-         * @throws ActiveMQException
+         * @throws Exception
          */
-        virtual void wait() throw( exceptions::ActiveMQException ){
+        virtual void wait() throw( lang::Exception ){
             mutex.wait();
         }
 
@@ -82,10 +83,10 @@
          * calling.  This wait will timeout after the specified time
          * interval.
          * @param millisecs time in millisecsonds to wait, or WAIT_INIFINITE
-         * @throws ActiveMQException
+         * @throws Exception
          */
         virtual void wait( unsigned long millisecs )
-            throw( exceptions::ActiveMQException ) {
+            throw( lang::Exception ) {
 
             mutex.wait( millisecs );
         }
@@ -94,9 +95,9 @@
          * Signals a waiter on this object that it can now wake
          * up and continue.  Must have this object locked before
          * calling.
-         * @throws ActiveMQException
+         * @throws Exception
          */
-        virtual void notify() throw( exceptions::ActiveMQException ){
+        virtual void notify() throw( lang::Exception ){
             mutex.notify();
         }
 
@@ -104,9 +105,9 @@
          * Signals the waiters on this object that it can now wake
          * up and continue.  Must have this object locked before
          * calling.
-         * @throws ActiveMQException
+         * @throws Exception
          */
-        virtual void notifyAll() throw( exceptions::ActiveMQException ){
+        virtual void notifyAll() throw( lang::Exception ){
             mutex.notifyAll();
         }
 

Modified: activemq/activemq-cpp/trunk/src/main/decaf/net/SocketOutputStream.h
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/decaf/net/SocketOutputStream.h?view=diff&rev=542840&r1=542839&r2=542840
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/decaf/net/SocketOutputStream.h (original)
+++ activemq/activemq-cpp/trunk/src/main/decaf/net/SocketOutputStream.h Wed May 30 08:22:07 2007
@@ -49,17 +49,17 @@
 
         /**
          * Locks the object.
-         * @throws ActiveMQException
+         * @throws Exception
          */
-        virtual void lock() throw( exceptions::ActiveMQException ){
+        virtual void lock() throw( lang::Exception ){
             mutex.lock();
         }
 
         /**
          * Unlocks the object.
-         * @throws ActiveMQException
+         * @throws Exception
          */
-        virtual void unlock() throw( exceptions::ActiveMQException ){
+        virtual void unlock() throw( lang::Exception ){
             mutex.unlock();
         }
 
@@ -67,9 +67,9 @@
          * Waits on a signal from this object, which is generated
          * by a call to Notify.  Must have this object locked before
          * calling.
-         * @throws ActiveMQException
+         * @throws Exception
          */
-        virtual void wait() throw( exceptions::ActiveMQException ){
+        virtual void wait() throw( lang::Exception ){
             mutex.wait();
         }
 
@@ -79,10 +79,10 @@
          * calling.  This wait will timeout after the specified time
          * interval.
          * @param millisecs time in millisecsonds to wait, or WAIT_INIFINITE
-         * @throws ActiveMQException
+         * @throws Exception
          */
         virtual void wait( unsigned long millisecs )
-            throw( exceptions::ActiveMQException ) {
+            throw( lang::Exception ) {
 
             mutex.wait( millisecs );
         }
@@ -91,9 +91,9 @@
          * Signals a waiter on this object that it can now wake
          * up and continue.  Must have this object locked before
          * calling.
-         * @throws ActiveMQException
+         * @throws Exception
          */
-        virtual void notify() throw( exceptions::ActiveMQException ){
+        virtual void notify() throw( lang::Exception ){
             mutex.notify();
         }
 
@@ -102,7 +102,7 @@
          * up and continue.  Must have this object locked before
          * calling.
          */
-        virtual void notifyAll() throw( exceptions::ActiveMQException ){
+        virtual void notifyAll() throw( lang::Exception ){
             mutex.notifyAll();
          }
 
@@ -133,7 +133,7 @@
          * of the socket object to close it.
          * @throws CMSException
          */
-        virtual void close() throw( cms::CMSException ){}
+        virtual void close() throw( lang::Exception ){}
 
     };
 

Modified: activemq/activemq-cpp/trunk/src/main/decaf/util/logging/SimpleFormatter.h
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/decaf/util/logging/SimpleFormatter.h?view=diff&rev=542840&r1=542839&r2=542840
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/decaf/util/logging/SimpleFormatter.h (original)
+++ activemq/activemq-cpp/trunk/src/main/decaf/util/logging/SimpleFormatter.h Wed May 30 08:22:07 2007
@@ -71,6 +71,6 @@
 
     };
 
-}})
+}}}
 
 #endif /*_DECAF_UTIL_LOGGING_SIMPLEFORMATTER_H_*/

Modified: activemq/activemq-cpp/trunk/src/main/decaf/util/logging/SimpleLogger.h
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/decaf/util/logging/SimpleLogger.h?view=diff&rev=542840&r1=542839&r2=542840
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/decaf/util/logging/SimpleLogger.h (original)
+++ activemq/activemq-cpp/trunk/src/main/decaf/util/logging/SimpleLogger.h Wed May 30 08:22:07 2007
@@ -89,6 +89,6 @@
 
    };
 
-}})
+}}}
 
 #endif /*_DECAF_UTIL_LOGGING_SIMPLELOGGER_H_*/

Modified: activemq/activemq-cpp/trunk/src/main/decaf/util/logging/StreamHandler.h
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/decaf/util/logging/StreamHandler.h?view=diff&rev=542840&r1=542839&r2=542840
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/decaf/util/logging/StreamHandler.h (original)
+++ activemq/activemq-cpp/trunk/src/main/decaf/util/logging/StreamHandler.h Wed May 30 08:22:07 2007
@@ -74,7 +74,7 @@
             try {
                 this->close();
             }
-            AMQ_CATCH_NOTHROW(exceptions::ActiveMQException)
+            AMQ_CATCH_NOTHROW( lang::Exception)
             AMQ_CATCALL_NOTHROW()
         }
 
@@ -112,7 +112,7 @@
             try {
 
                 if( !stream ) {
-                    throw exceptions::NullPointerException(
+                    throw lang::exceptions::NullPointerException(
                         __FILE__, __LINE__,
                         "StreamHandler::publish - Stream not set.");
                 }
@@ -128,8 +128,8 @@
                     }
                 }
             }
-            AMQ_CATCH_RETHROW( exceptions::ActiveMQException )
-            AMQ_CATCHALL_THROW( exceptions::ActiveMQException )
+            AMQ_CATCH_RETHROW( lang::Exception )
+            AMQ_CATCHALL_THROW( lang::Exception )
         }
 
         /**
@@ -212,6 +212,6 @@
 
     };
 
-}})
+}}}
 
 #endif /*_DECAF_UTIL_LOGGING_STREAMHANDLER_H_*/