You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@activemq.apache.org by ta...@apache.org on 2012/11/07 20:29:55 UTC

svn commit: r1406762 - in /activemq/activemq-cpp/trunk/activemq-cpp/src/main: ./ decaf/util/ decaf/util/comparators/ decaf/util/concurrent/ decaf/util/concurrent/locks/ decaf/util/zip/

Author: tabish
Date: Wed Nov  7 19:29:54 2012
New Revision: 1406762

URL: http://svn.apache.org/viewvc?rev=1406762&view=rev
Log:
Some cleanup of old code in preperation for future 3.5 release.

Added:
    activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/comparators/Less.cpp   (with props)
    activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/concurrent/CancellationException.cpp   (with props)
    activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/concurrent/ExecutionException.cpp   (with props)
    activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/concurrent/RejectedExecutionException.cpp   (with props)
    activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/concurrent/Synchronizable.cpp   (with props)
    activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/concurrent/TimeoutException.cpp   (with props)
    activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/concurrent/locks/Condition.cpp   (with props)
    activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/concurrent/locks/Lock.cpp   (with props)
    activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/concurrent/locks/ReadWriteLock.cpp   (with props)
    activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/zip/Checksum.cpp   (with props)
Modified:
    activemq/activemq-cpp/trunk/activemq-cpp/src/main/Makefile.am
    activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/ConcurrentModificationException.cpp
    activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/ConcurrentModificationException.h
    activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/NoSuchElementException.cpp
    activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/NoSuchElementException.h
    activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/concurrent/CancellationException.h
    activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/concurrent/ExecutionException.h
    activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/concurrent/RejectedExecutionException.h
    activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/concurrent/Synchronizable.h
    activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/concurrent/TimeoutException.h
    activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/concurrent/locks/Condition.h
    activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/concurrent/locks/Lock.h
    activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/concurrent/locks/ReadWriteLock.h
    activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/zip/Checksum.h
    activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/zip/DataFormatException.cpp
    activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/zip/DataFormatException.h
    activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/zip/ZipException.cpp
    activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/zip/ZipException.h

Modified: activemq/activemq-cpp/trunk/activemq-cpp/src/main/Makefile.am
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/activemq-cpp/src/main/Makefile.am?rev=1406762&r1=1406761&r2=1406762&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/activemq-cpp/src/main/Makefile.am (original)
+++ activemq/activemq-cpp/trunk/activemq-cpp/src/main/Makefile.am Wed Nov  7 19:29:54 2012
@@ -485,10 +485,12 @@ cc_sources = \
     decaf/util/Timer.cpp \
     decaf/util/TimerTask.cpp \
     decaf/util/UUID.cpp \
+    decaf/util/comparators/Less.cpp \
     decaf/util/concurrent/AbstractExecutorService.cpp \
     decaf/util/concurrent/BlockingQueue.cpp \
     decaf/util/concurrent/BrokenBarrierException.cpp \
     decaf/util/concurrent/Callable.cpp \
+    decaf/util/concurrent/CancellationException.cpp \
     decaf/util/concurrent/ConcurrentHashMap.cpp \
     decaf/util/concurrent/ConcurrentMap.cpp \
     decaf/util/concurrent/ConcurrentStlMap.cpp \
@@ -496,6 +498,7 @@ cc_sources = \
     decaf/util/concurrent/CopyOnWriteArraySet.cpp \
     decaf/util/concurrent/CountDownLatch.cpp \
     decaf/util/concurrent/Delayed.cpp \
+    decaf/util/concurrent/ExecutionException.cpp \
     decaf/util/concurrent/Executor.cpp \
     decaf/util/concurrent/ExecutorService.cpp \
     decaf/util/concurrent/Executors.cpp \
@@ -504,20 +507,26 @@ cc_sources = \
     decaf/util/concurrent/LinkedBlockingQueue.cpp \
     decaf/util/concurrent/Lock.cpp \
     decaf/util/concurrent/Mutex.cpp \
+    decaf/util/concurrent/RejectedExecutionException.cpp \
     decaf/util/concurrent/RejectedExecutionHandler.cpp \
     decaf/util/concurrent/RunnableFuture.cpp \
     decaf/util/concurrent/Semaphore.cpp \
+    decaf/util/concurrent/Synchronizable.cpp \
     decaf/util/concurrent/SynchronousQueue.cpp \
     decaf/util/concurrent/ThreadFactory.cpp \
     decaf/util/concurrent/ThreadPoolExecutor.cpp \
     decaf/util/concurrent/TimeUnit.cpp \
+    decaf/util/concurrent/TimeoutException.cpp \
     decaf/util/concurrent/atomic/AtomicBoolean.cpp \
     decaf/util/concurrent/atomic/AtomicInteger.cpp \
     decaf/util/concurrent/atomic/AtomicRefCounter.cpp \
     decaf/util/concurrent/atomic/AtomicReference.cpp \
     decaf/util/concurrent/locks/AbstractOwnableSynchronizer.cpp \
     decaf/util/concurrent/locks/AbstractQueuedSynchronizer.cpp \
+    decaf/util/concurrent/locks/Condition.cpp \
+    decaf/util/concurrent/locks/Lock.cpp \
     decaf/util/concurrent/locks/LockSupport.cpp \
+    decaf/util/concurrent/locks/ReadWriteLock.cpp \
     decaf/util/concurrent/locks/ReentrantLock.cpp \
     decaf/util/concurrent/locks/ReentrantReadWriteLock.cpp \
     decaf/util/logging/ConsoleHandler.cpp \
@@ -538,6 +547,7 @@ cc_sources = \
     decaf/util/zip/CRC32.cpp \
     decaf/util/zip/CheckedInputStream.cpp \
     decaf/util/zip/CheckedOutputStream.cpp \
+    decaf/util/zip/Checksum.cpp \
     decaf/util/zip/DataFormatException.cpp \
     decaf/util/zip/Deflater.cpp \
     decaf/util/zip/DeflaterOutputStream.cpp \

Modified: activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/ConcurrentModificationException.cpp
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/ConcurrentModificationException.cpp?rev=1406762&r1=1406761&r2=1406762&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/ConcurrentModificationException.cpp (original)
+++ activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/ConcurrentModificationException.cpp Wed Nov  7 19:29:54 2012
@@ -28,5 +28,42 @@ ConcurrentModificationException::Concurr
 }
 
 ////////////////////////////////////////////////////////////////////////////////
-ConcurrentModificationException::~ConcurrentModificationException() throw() {
+ConcurrentModificationException::~ConcurrentModificationException() throw () {
+}
+
+////////////////////////////////////////////////////////////////////////////////
+ConcurrentModificationException::ConcurrentModificationException(const lang::Exception& ex) : lang::exceptions::RuntimeException() {
+    *(lang::Exception*) this = ex;
+}
+
+////////////////////////////////////////////////////////////////////////////////
+ConcurrentModificationException::ConcurrentModificationException(const ConcurrentModificationException& ex) : lang::exceptions::RuntimeException() {
+    *(lang::Exception*) this = ex;
+}
+
+////////////////////////////////////////////////////////////////////////////////
+ConcurrentModificationException::ConcurrentModificationException(
+    const char* file, const int lineNumber, const std::exception* cause, const char* msg, ...) : lang::exceptions::RuntimeException(cause) {
+
+    va_list vargs;
+    va_start(vargs, msg);
+    buildMessage(msg, vargs);
+
+    // Set the first mark for this exception.
+    setMark(file, lineNumber);
+}
+
+////////////////////////////////////////////////////////////////////////////////
+ConcurrentModificationException::ConcurrentModificationException(const std::exception* cause) : lang::exceptions::RuntimeException(cause) {
+}
+
+////////////////////////////////////////////////////////////////////////////////
+ConcurrentModificationException::ConcurrentModificationException(const char* file, const int lineNumber, const char* msg, ...) : lang::exceptions::RuntimeException() {
+
+    va_list vargs;
+    va_start(vargs, msg);
+    buildMessage(msg, vargs);
+
+    // Set the first mark for this exception.
+    setMark(file, lineNumber);
 }

Modified: activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/ConcurrentModificationException.h
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/ConcurrentModificationException.h?rev=1406762&r1=1406761&r2=1406762&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/ConcurrentModificationException.h (original)
+++ activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/ConcurrentModificationException.h Wed Nov  7 19:29:54 2012
@@ -21,8 +21,8 @@
 #include <decaf/util/Config.h>
 #include <decaf/lang/exceptions/RuntimeException.h>
 
-namespace decaf{
-namespace util{
+namespace decaf {
+namespace util {
 
     class DECAF_API ConcurrentModificationException :
         public lang::exceptions::RuntimeException {
@@ -35,71 +35,49 @@ namespace util{
 
         /**
          * Copy Constructor
+         *
          * @param ex the exception to copy
          */
-        ConcurrentModificationException( const lang::Exception& ex )
-        : lang::exceptions::RuntimeException() {
-            *(lang::Exception*)this = ex;
-        }
+        ConcurrentModificationException(const lang::Exception& ex);
 
         /**
          * Copy Constructor
+         *
          * @param ex the exception to copy, which is an instance of this type
          */
-        ConcurrentModificationException( const ConcurrentModificationException& ex )
-        : lang::exceptions::RuntimeException() {
-            *(lang::Exception*)this = ex;
-        }
+        ConcurrentModificationException(const ConcurrentModificationException& ex);
 
         /**
          * Constructor - Initializes the file name and line number where
          * this message occurred.  Sets the message to report, using an
          * optional list of arguments to parse into the message
+         *
          * @param file The file name where exception occurs
          * @param lineNumber The line number where the exception occurred.
          * @param cause The exception that was the cause for this one to be thrown.
          * @param msg The message to report
          * @param ... list of primitives that are formatted into the message
          */
-        ConcurrentModificationException( const char* file, const int lineNumber,
-                                         const std::exception* cause,
-                                         const char* msg, ... )
-        : lang::exceptions::RuntimeException( cause )
-        {
-            va_list vargs;
-            va_start( vargs, msg );
-            buildMessage( msg, vargs );
-
-            // Set the first mark for this exception.
-            setMark( file, lineNumber );
-        }
+        ConcurrentModificationException(const char* file, const int lineNumber,
+                                        const std::exception* cause, const char* msg, ...);
 
         /**
          * Constructor
+         *
          * @param cause Pointer to the exception that caused this one to
          * be thrown, the object is cloned caller retains ownership.
          */
-        ConcurrentModificationException( const std::exception* cause )
-            : lang::exceptions::RuntimeException( cause ) {}
+        ConcurrentModificationException(const std::exception* cause);
 
         /**
          * Constructor
+         *
          * @param file The file name where exception occurs
          * @param lineNumber The line number where the exception occurred.
          * @param msg The message to report
          * @param ... list of primitives that are formatted into the message
          */
-        ConcurrentModificationException( const char* file, const int lineNumber,
-                                         const char* msg, ... )
-        : lang::exceptions::RuntimeException() {
-
-            va_list vargs;
-            va_start( vargs, msg );
-            buildMessage( msg, vargs );
-
-            // Set the first mark for this exception.
-            setMark( file, lineNumber );
-        }
+        ConcurrentModificationException(const char* file, const int lineNumber, const char* msg, ...);
 
         /**
          * Clones this exception.  This is useful for cases where you need
@@ -107,7 +85,7 @@ namespace util{
          * All subclasses should override.
          */
         virtual ConcurrentModificationException* clone() const {
-            return new ConcurrentModificationException( *this );
+            return new ConcurrentModificationException(*this);
         }
 
         virtual ~ConcurrentModificationException() throw();

Modified: activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/NoSuchElementException.cpp
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/NoSuchElementException.cpp?rev=1406762&r1=1406761&r2=1406762&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/NoSuchElementException.cpp (original)
+++ activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/NoSuchElementException.cpp Wed Nov  7 19:29:54 2012
@@ -21,9 +21,45 @@ using namespace decaf;
 using namespace decaf::util;
 
 ////////////////////////////////////////////////////////////////////////////////
-NoSuchElementException::NoSuchElementException() {
+NoSuchElementException::NoSuchElementException() : decaf::lang::exceptions::RuntimeException() {
 }
 
 ////////////////////////////////////////////////////////////////////////////////
-NoSuchElementException::~NoSuchElementException() throw() {
+NoSuchElementException::~NoSuchElementException() throw () {
+}
+
+////////////////////////////////////////////////////////////////////////////////
+NoSuchElementException::NoSuchElementException(const decaf::lang::exceptions::RuntimeException& ex) : decaf::lang::exceptions::RuntimeException() {
+    *(decaf::lang::exceptions::RuntimeException*) this = ex;
+}
+
+////////////////////////////////////////////////////////////////////////////////
+NoSuchElementException::NoSuchElementException(const NoSuchElementException& ex) : decaf::lang::exceptions::RuntimeException() {
+    *(decaf::lang::exceptions::RuntimeException*) this = ex;
+}
+
+////////////////////////////////////////////////////////////////////////////////
+NoSuchElementException::NoSuchElementException(const char* file, const int lineNumber, const std::exception* cause, const char* msg, ...) : decaf::lang::exceptions::RuntimeException(cause) {
+
+    va_list vargs;
+    va_start(vargs, msg);
+    buildMessage(msg, vargs);
+
+    // Set the first mark for this exception.
+    setMark(file, lineNumber);
+}
+
+////////////////////////////////////////////////////////////////////////////////
+NoSuchElementException::NoSuchElementException(const std::exception* cause) : decaf::lang::exceptions::RuntimeException(cause) {
+}
+
+////////////////////////////////////////////////////////////////////////////////
+NoSuchElementException::NoSuchElementException(const char* file, const int lineNumber, const char* msg, ...) : decaf::lang::exceptions::RuntimeException() {
+
+    va_list vargs;
+    va_start(vargs, msg);
+    buildMessage(msg, vargs);
+
+    // Set the first mark for this exception.
+    setMark(file, lineNumber);
 }

Modified: activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/NoSuchElementException.h
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/NoSuchElementException.h?rev=1406762&r1=1406761&r2=1406762&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/NoSuchElementException.h (original)
+++ activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/NoSuchElementException.h Wed Nov  7 19:29:54 2012
@@ -19,8 +19,8 @@
 
 #include <decaf/lang/exceptions/RuntimeException.h>
 
-namespace decaf{
-namespace util{
+namespace decaf {
+namespace util {
 
     /*
      * Thrown from an operation that attempts to access some element that does
@@ -42,11 +42,7 @@ namespace util{
          * @param ex
          *      The Exception whose data is to be copied into this one.
          */
-        NoSuchElementException( const decaf::lang::exceptions::RuntimeException& ex )
-        : decaf::lang::exceptions::RuntimeException()
-        {
-            *(decaf::lang::exceptions::RuntimeException*)this = ex;
-        }
+        NoSuchElementException(const decaf::lang::exceptions::RuntimeException& ex);
 
         /**
          * Copy Constructor
@@ -54,62 +50,40 @@ namespace util{
          * @param ex
          *      The Exception whose data is to be copied into this one.
          */
-        NoSuchElementException( const NoSuchElementException& ex )
-        : decaf::lang::exceptions::RuntimeException()
-        {
-            *(decaf::lang::exceptions::RuntimeException*)this = ex;
-        }
+        NoSuchElementException(const NoSuchElementException& ex);
 
         /**
          * Constructor - Initializes the file name and line number where
          * this message occurred.  Sets the message to report, using an
          * optional list of arguments to parse into the message
+         *
          * @param file The file name where exception occurs
          * @param lineNumber The line number where the exception occurred.
          * @param cause The exception that was the cause for this one to be thrown.
          * @param msg The message to report
          * @param ... list of primitives that are formatted into the message
          */
-        NoSuchElementException( const char* file, const int lineNumber,
-                                const std::exception* cause,
-                                const char* msg, ... ) : decaf::lang::exceptions::RuntimeException( cause )
-        {
-            va_list vargs;
-            va_start( vargs, msg );
-            buildMessage( msg, vargs );
-
-            // Set the first mark for this exception.
-            setMark( file, lineNumber );
-        }
+        NoSuchElementException(const char* file, const int lineNumber, const std::exception* cause, const char* msg, ...);
 
         /**
          * Constructor
+         *
          * @param cause Pointer to the exception that caused this one to
          * be thrown, the object is cloned caller retains ownership.
          */
-        NoSuchElementException( const std::exception* cause ) : decaf::lang::exceptions::RuntimeException( cause ) {}
+        NoSuchElementException(const std::exception* cause);
 
         /**
          * Constructor - Initializes the file name and line number where
          * this message occured.  Sets the message to report, using an
          * optional list of arguments to parse into the message
+         *
          * @param file The file name where exception occurs
          * @param lineNumber The line number where the exception occurred.
          * @param msg The message to report
          * @param ... list of primitives that are formatted into the message
          */
-        NoSuchElementException( const char* file,
-                                const int lineNumber,
-                                const char* msg, ... )
-        : decaf::lang::exceptions::RuntimeException()
-        {
-            va_list vargs;
-            va_start( vargs, msg );
-            buildMessage( msg, vargs );
-
-            // Set the first mark for this exception.
-            setMark( file, lineNumber );
-        }
+        NoSuchElementException(const char* file, const int lineNumber, const char* msg, ...);
 
         /**
          * Clones this exception.  This is useful for cases where you need

Added: activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/comparators/Less.cpp
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/comparators/Less.cpp?rev=1406762&view=auto
==============================================================================
--- activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/comparators/Less.cpp (added)
+++ activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/comparators/Less.cpp Wed Nov  7 19:29:54 2012
@@ -0,0 +1,22 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+#include "Less.h"
+
+
+
+

Propchange: activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/comparators/Less.cpp
------------------------------------------------------------------------------
    svn:eol-style = native

Added: activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/concurrent/CancellationException.cpp
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/concurrent/CancellationException.cpp?rev=1406762&view=auto
==============================================================================
--- activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/concurrent/CancellationException.cpp (added)
+++ activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/concurrent/CancellationException.cpp Wed Nov  7 19:29:54 2012
@@ -0,0 +1,75 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+#include "CancellationException.h"
+
+using namespace decaf;
+using namespace decaf::util;
+using namespace decaf::util::concurrent;
+using namespace decaf::lang;
+
+////////////////////////////////////////////////////////////////////////////////
+CancellationException::CancellationException() : decaf::lang::Exception() {
+}
+
+////////////////////////////////////////////////////////////////////////////////
+CancellationException::CancellationException(const decaf::lang::Exception& ex) : decaf::lang::Exception() {
+    *(Exception*) this = ex;
+}
+
+////////////////////////////////////////////////////////////////////////////////
+CancellationException::CancellationException(const CancellationException& ex) : decaf::lang::Exception() {
+    *(Exception*) this = ex;
+}
+
+////////////////////////////////////////////////////////////////////////////////
+CancellationException::CancellationException(const std::exception* cause) : decaf::lang::Exception(cause) {
+}
+
+////////////////////////////////////////////////////////////////////////////////
+CancellationException::CancellationException(const char* file, const int lineNumber, const char* msg, ...) :
+        decaf::lang::Exception() {
+
+    va_list vargs;
+    va_start( vargs, msg);
+    buildMessage(msg, vargs);
+
+    // Set the first mark for this exception.
+    setMark(file, lineNumber);
+}
+
+////////////////////////////////////////////////////////////////////////////////
+CancellationException::CancellationException(const char* file, const int lineNumber,
+                                             const std::exception* cause, const char* msg, ...) :
+    decaf::lang::Exception(cause) {
+
+    va_list vargs;
+    va_start(vargs, msg);
+    buildMessage(msg, vargs);
+
+    // Set the first mark for this exception.
+    setMark(file, lineNumber);
+}
+
+////////////////////////////////////////////////////////////////////////////////
+CancellationException::~CancellationException() throw () {
+}
+
+////////////////////////////////////////////////////////////////////////////////
+CancellationException* CancellationException::clone() const {
+    return new CancellationException(*this);
+}

Propchange: activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/concurrent/CancellationException.cpp
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/concurrent/CancellationException.h
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/concurrent/CancellationException.h?rev=1406762&r1=1406761&r2=1406762&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/concurrent/CancellationException.h (original)
+++ activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/concurrent/CancellationException.h Wed Nov  7 19:29:54 2012
@@ -19,9 +19,9 @@
 
 #include <decaf/lang/Exception.h>
 
-namespace decaf{
-namespace util{
-namespace concurrent{
+namespace decaf {
+namespace util {
+namespace concurrent {
 
     /*
      * Exception indicating that the result of a value-producing task, such as a
@@ -33,82 +33,55 @@ namespace concurrent{
         /**
          * Default Constructor
          */
-        CancellationException() : decaf::lang::Exception() {}
+        CancellationException();
 
         /**
          * Conversion Constructor from some other Exception
          *
          * @param ex An exception that should become this type of Exception
          */
-        CancellationException( const decaf::lang::Exception& ex )
-        : decaf::lang::Exception()
-        {
-            *(Exception*)this = ex;
-        }
+        CancellationException(const decaf::lang::Exception& ex);
 
         /**
          * Copy Constructor
          *
          * @param ex - The Exception to copy in this new instance.
          */
-        CancellationException( const CancellationException& ex )
-        : decaf::lang::Exception()
-        {
-            *(Exception*)this = ex;
-        }
+        CancellationException(const CancellationException& ex);
 
         /**
          * Constructor
+         *
          * @param cause Pointer to the exception that caused this one to
          * be thrown, the object is cloned caller retains ownership.
          */
-        CancellationException( const std::exception* cause )
-             : decaf::lang::Exception( cause ) {}
+        CancellationException(const std::exception* cause);
 
         /**
          * Constructor - Initializes the file name and line number where
          * this message occurred.  Sets the message to report, using an
          * optional list of arguments to parse into the message
+         *
          * @param file - The file name where exception occurs
          * @param lineNumber - The line number where the exception occurred.
          * @param msg - The message to report
          * @param ... - list of primitives that are formatted into the message
          */
-        CancellationException( const char* file, const int lineNumber,
-                               const char* msg, ... )
-            : decaf::lang::Exception()
-        {
-
-            va_list vargs;
-            va_start( vargs, msg );
-            buildMessage( msg, vargs );
-
-            // Set the first mark for this exception.
-            setMark( file, lineNumber );
-        }
+        CancellationException(const char* file, const int lineNumber, const char* msg, ...);
 
         /**
          * Constructor - Initializes the file name and line number where
          * this message occurred.  Sets the message to report, using an
          * optional list of arguments to parse into the message
+         *
          * @param file - The file name where exception occurs
          * @param lineNumber - The line number where the exception occurred.
          * @param cause - The exception that was the cause for this one to be thrown.
          * @param msg - The message to report
          * @param ... - list of primitives that are formatted into the message
          */
-        CancellationException( const char* file, const int lineNumber,
-                                const std::exception* cause,
-                                const char* msg, ... )
-            : decaf::lang::Exception( cause )
-        {
-            va_list vargs ;
-            va_start( vargs, msg );
-            buildMessage( msg, vargs );
-
-            // Set the first mark for this exception.
-            setMark( file, lineNumber );
-        }
+        CancellationException(const char* file, const int lineNumber,
+                              const std::exception* cause, const char* msg, ...);
 
         /**
          * Clones this exception.  This is useful for cases where you need
@@ -117,11 +90,9 @@ namespace concurrent{
          *
          * @returns a new instance of an exception that is a clone of this one.
          */
-        virtual CancellationException* clone() const{
-            return new CancellationException( *this );
-        }
+        virtual CancellationException* clone() const;
 
-        virtual ~CancellationException() throw() {}
+        virtual ~CancellationException() throw();
 
     };
 

Added: activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/concurrent/ExecutionException.cpp
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/concurrent/ExecutionException.cpp?rev=1406762&view=auto
==============================================================================
--- activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/concurrent/ExecutionException.cpp (added)
+++ activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/concurrent/ExecutionException.cpp Wed Nov  7 19:29:54 2012
@@ -0,0 +1,73 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+#include "ExecutionException.h"
+
+using namespace decaf;
+using namespace decaf::util;
+using namespace decaf::util::concurrent;
+using namespace decaf::lang;
+
+////////////////////////////////////////////////////////////////////////////////
+ExecutionException::ExecutionException() : decaf::lang::Exception() {
+}
+
+////////////////////////////////////////////////////////////////////////////////
+ExecutionException::ExecutionException(const decaf::lang::Exception& ex) : decaf::lang::Exception() {
+    *(Exception*) this = ex;
+}
+
+////////////////////////////////////////////////////////////////////////////////
+ExecutionException::ExecutionException(const ExecutionException& ex) : decaf::lang::Exception() {
+    *(Exception*) this = ex;
+}
+
+////////////////////////////////////////////////////////////////////////////////
+ExecutionException::ExecutionException(const std::exception* cause) : decaf::lang::Exception(cause) {
+}
+
+////////////////////////////////////////////////////////////////////////////////
+ExecutionException::ExecutionException(const char* file, const int lineNumber, const char* msg, ...) : decaf::lang::Exception() {
+
+    va_list vargs;
+    va_start( vargs, msg);
+    buildMessage(msg, vargs);
+
+    // Set the first mark for this exception.
+    setMark(file, lineNumber);
+}
+
+////////////////////////////////////////////////////////////////////////////////
+ExecutionException::ExecutionException(const char* file, const int lineNumber,
+                                       const std::exception* cause, const char* msg, ...) : decaf::lang::Exception(cause) {
+
+    va_list vargs;
+    va_start(vargs, msg);
+    buildMessage(msg, vargs);
+
+    // Set the first mark for this exception.
+    setMark(file, lineNumber);
+}
+
+////////////////////////////////////////////////////////////////////////////////
+ExecutionException::~ExecutionException() throw () {
+}
+
+////////////////////////////////////////////////////////////////////////////////
+ExecutionException* ExecutionException::clone() const {
+    return new ExecutionException(*this);
+}

Propchange: activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/concurrent/ExecutionException.cpp
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/concurrent/ExecutionException.h
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/concurrent/ExecutionException.h?rev=1406762&r1=1406761&r2=1406762&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/concurrent/ExecutionException.h (original)
+++ activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/concurrent/ExecutionException.h Wed Nov  7 19:29:54 2012
@@ -19,9 +19,9 @@
 
 #include <decaf/lang/Exception.h>
 
-namespace decaf{
-namespace util{
-namespace concurrent{
+namespace decaf {
+namespace util {
+namespace concurrent {
 
     /*
      * Exception thrown when attempting to retrieve the result of a task that aborted by
@@ -34,28 +34,21 @@ namespace concurrent{
         /**
          * Default Constructor
          */
-        ExecutionException() : decaf::lang::Exception() {}
+        ExecutionException();
 
         /**
          * Conversion Constructor from some other Exception
+         *
          * @param ex - An exception that should become this type of Exception
          */
-        ExecutionException( const decaf::lang::Exception& ex )
-        : decaf::lang::Exception()
-        {
-            *(Exception*)this = ex;
-        }
+        ExecutionException(const decaf::lang::Exception& ex);
 
         /**
          * Copy Constructor
          *
          * @param ex - The Exception to copy in this new instance.
          */
-        ExecutionException( const ExecutionException& ex )
-        : decaf::lang::Exception()
-        {
-            *(Exception*)this = ex;
-        }
+        ExecutionException(const ExecutionException& ex);
 
         /**
          * Constructor
@@ -63,53 +56,32 @@ namespace concurrent{
          * @param cause Pointer to the exception that caused this one to
          * be thrown, the object is cloned caller retains ownership.
          */
-        ExecutionException( const std::exception* cause )
-            : decaf::lang::Exception( cause ) {}
+        ExecutionException(const std::exception* cause);
 
         /**
          * Constructor - Initializes the file name and line number where
          * this message occurred.  Sets the message to report, using an
          * optional list of arguments to parse into the message
+         *
          * @param file - The file name where exception occurs
          * @param lineNumber - The line number where the exception occurred.
          * @param msg - The message to report
          * @param ...  - The list of primitives that are formatted into the message
          */
-        ExecutionException( const char* file, const int lineNumber,
-                            const char* msg, ... )
-            : decaf::lang::Exception()
-        {
-
-            va_list vargs;
-            va_start( vargs, msg );
-            buildMessage( msg, vargs );
-
-            // Set the first mark for this exception.
-            setMark( file, lineNumber );
-        }
+        ExecutionException(const char* file, const int lineNumber, const char* msg, ...);
 
         /**
          * Constructor - Initializes the file name and line number where
          * this message occurred.  Sets the message to report, using an
          * optional list of arguments to parse into the message
+         *
          * @param file - The file name where exception occurs
          * @param lineNumber - The line number where the exception occurred.
          * @param cause - The exception that was the cause for this one to be thrown.
          * @param msg - The message to report
          * @param ... - list of primitives that are formatted into the message
          */
-        ExecutionException( const char* file, const int lineNumber,
-                            const std::exception* cause,
-                            const char* msg, ... )
-            : decaf::lang::Exception( cause )
-        {
-            va_list vargs ;
-            va_start( vargs, msg );
-            buildMessage( msg, vargs );
-
-            // Set the first mark for this exception.
-            setMark( file, lineNumber );
-        }
+        ExecutionException(const char* file, const int lineNumber, const std::exception* cause, const char* msg, ...);
 
         /**
          * Clones this exception.  This is useful for cases where you need
@@ -118,11 +90,9 @@ namespace concurrent{
          *
          * @returns a new instance of an exception that is a clone of this one.
          */
-        virtual ExecutionException* clone() const{
-            return new ExecutionException( *this );
-        }
+        virtual ExecutionException* clone() const;
 
-        virtual ~ExecutionException() throw() {}
+        virtual ~ExecutionException() throw ();
 
     };
 

Added: activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/concurrent/RejectedExecutionException.cpp
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/concurrent/RejectedExecutionException.cpp?rev=1406762&view=auto
==============================================================================
--- activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/concurrent/RejectedExecutionException.cpp (added)
+++ activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/concurrent/RejectedExecutionException.cpp Wed Nov  7 19:29:54 2012
@@ -0,0 +1,73 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+#include "RejectedExecutionException.h"
+
+using namespace decaf;
+using namespace decaf::util;
+using namespace decaf::util::concurrent;
+using namespace decaf::lang;
+
+////////////////////////////////////////////////////////////////////////////////
+RejectedExecutionException::RejectedExecutionException() : decaf::lang::Exception() {
+}
+
+////////////////////////////////////////////////////////////////////////////////
+RejectedExecutionException::RejectedExecutionException(const decaf::lang::Exception& ex) : decaf::lang::Exception() {
+    *(Exception*) this = ex;
+}
+
+////////////////////////////////////////////////////////////////////////////////
+RejectedExecutionException::RejectedExecutionException(const RejectedExecutionException& ex) : decaf::lang::Exception() {
+    *(Exception*) this = ex;
+}
+
+////////////////////////////////////////////////////////////////////////////////
+RejectedExecutionException::RejectedExecutionException(const std::exception* cause) : decaf::lang::Exception(cause) {
+}
+
+////////////////////////////////////////////////////////////////////////////////
+RejectedExecutionException::RejectedExecutionException(const char* file, const int lineNumber, const char* msg, ...) : decaf::lang::Exception() {
+
+    va_list vargs;
+    va_start( vargs, msg);
+    buildMessage(msg, vargs);
+
+    // Set the first mark for this exception.
+    setMark(file, lineNumber);
+}
+
+////////////////////////////////////////////////////////////////////////////////
+RejectedExecutionException::RejectedExecutionException(
+    const char* file, const int lineNumber, const std::exception* cause, const char* msg, ...) : decaf::lang::Exception(cause) {
+
+    va_list vargs;
+    va_start(vargs, msg);
+    buildMessage(msg, vargs);
+
+    // Set the first mark for this exception.
+    setMark(file, lineNumber);
+}
+
+////////////////////////////////////////////////////////////////////////////////
+RejectedExecutionException::~RejectedExecutionException() throw () {
+}
+
+////////////////////////////////////////////////////////////////////////////////
+RejectedExecutionException* RejectedExecutionException::clone() const {
+    return new RejectedExecutionException(*this);
+}

Propchange: activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/concurrent/RejectedExecutionException.cpp
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/concurrent/RejectedExecutionException.h
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/concurrent/RejectedExecutionException.h?rev=1406762&r1=1406761&r2=1406762&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/concurrent/RejectedExecutionException.h (original)
+++ activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/concurrent/RejectedExecutionException.h Wed Nov  7 19:29:54 2012
@@ -19,9 +19,9 @@
 
 #include <decaf/lang/Exception.h>
 
-namespace decaf{
-namespace util{
-namespace concurrent{
+namespace decaf {
+namespace util {
+namespace concurrent {
 
     /*
      * Exception thrown by an Executor when a task cannot be accepted for execution.
@@ -34,7 +34,7 @@ namespace concurrent{
         /**
          * Default Constructor
          */
-        RejectedExecutionException() : decaf::lang::Exception() {}
+        RejectedExecutionException();
 
         /**
          * Conversion Constructor from some other Exception
@@ -42,72 +42,48 @@ namespace concurrent{
          * @param ex
          *      An exception that should become this type of Exception
          */
-        RejectedExecutionException( const Exception& ex )
-        : decaf::lang::Exception() {
-            *(Exception*)this = ex;
-        }
+        RejectedExecutionException(const Exception& ex);
 
         /**
          * Copy Constructor
          *
          * @param ex - The Exception to copy in this new instance.
          */
-        RejectedExecutionException( const RejectedExecutionException& ex )
-        : decaf::lang::Exception() {
-            *(Exception*)this = ex;
-        }
+        RejectedExecutionException(const RejectedExecutionException& ex);
 
         /**
          * Constructor
+         *
          * @param cause Pointer to the exception that caused this one to
          * be thrown, the object is cloned caller retains ownership.
          */
-        RejectedExecutionException( const std::exception* cause )
-            : decaf::lang::Exception( cause ) {}
+        RejectedExecutionException(const std::exception* cause);
 
         /**
          * Constructor - Initializes the file name and line number where
          * this message occurred.  Sets the message to report, using an
          * optional list of arguments to parse into the message
+         *
          * @param file - The file name where exception occurs
          * @param lineNumber - The line number where the exception occurred.
          * @param msg - The message to report
          * @param ... - list of primitives that are formatted into the message
          */
-        RejectedExecutionException( const char* file, const int lineNumber,
-                                    const char* msg, ... )
-        : decaf::lang::Exception() {
-
-            va_list vargs;
-            va_start( vargs, msg );
-            buildMessage( msg, vargs );
-
-            // Set the first mark for this exception.
-            setMark( file, lineNumber );
-        }
+        RejectedExecutionException(const char* file, const int lineNumber, const char* msg, ...);
 
         /**
          * Constructor - Initializes the file name and line number where
          * this message occurred.  Sets the message to report, using an
          * optional list of arguments to parse into the message
+         *
          * @param file - The file name where exception occurs
          * @param lineNumber - The line number where the exception occurred.
          * @param cause - The exception that was the cause for this one to be thrown.
          * @param msg - The message to report
          * @param ... - list of primitives that are formatted into the message
          */
-        RejectedExecutionException( const char* file, const int lineNumber,
-                                    const std::exception* cause,
-                                    const char* msg, ... )
-        : decaf::lang::Exception( cause ) {
-
-            va_list vargs ;
-            va_start( vargs, msg );
-            buildMessage( msg, vargs );
-
-            // Set the first mark for this exception.
-            setMark( file, lineNumber );
-        }
+        RejectedExecutionException(const char* file, const int lineNumber,
+                                   const std::exception* cause, const char* msg, ...);
 
         /**
          * Clones this exception.  This is useful for cases where you need
@@ -116,11 +92,9 @@ namespace concurrent{
          *
          * @return A new instance this exception type with a copy the current state.
          */
-        virtual RejectedExecutionException* clone() const{
-            return new RejectedExecutionException( *this );
-        }
+        virtual RejectedExecutionException* clone() const;
 
-        virtual ~RejectedExecutionException() throw() {}
+        virtual ~RejectedExecutionException() throw ();
 
     };
 

Added: activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/concurrent/Synchronizable.cpp
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/concurrent/Synchronizable.cpp?rev=1406762&view=auto
==============================================================================
--- activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/concurrent/Synchronizable.cpp (added)
+++ activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/concurrent/Synchronizable.cpp Wed Nov  7 19:29:54 2012
@@ -0,0 +1,29 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+#include "Synchronizable.h"
+
+using namespace decaf;
+using namespace decaf::util;
+using namespace decaf::util::concurrent;
+
+////////////////////////////////////////////////////////////////////////////////
+Synchronizable::~Synchronizable() {
+
+}
+
+

Propchange: activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/concurrent/Synchronizable.cpp
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/concurrent/Synchronizable.h
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/concurrent/Synchronizable.h?rev=1406762&r1=1406761&r2=1406762&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/concurrent/Synchronizable.h (original)
+++ activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/concurrent/Synchronizable.h Wed Nov  7 19:29:54 2012
@@ -24,9 +24,9 @@
 #include <decaf/lang/exceptions/IllegalMonitorStateException.h>
 #include <decaf/util/Config.h>
 
-namespace decaf{
-namespace util{
-namespace concurrent{
+namespace decaf {
+namespace util {
+namespace concurrent {
 
     /**
      * The interface for all synchronizable objects (that is, objects
@@ -37,7 +37,7 @@ namespace concurrent{
     class DECAF_API Synchronizable {
     public:
 
-        virtual ~Synchronizable() {}
+        virtual ~Synchronizable();
 
         /**
          * Locks the object.
@@ -90,7 +90,7 @@ namespace concurrent{
          * @throws IllegalMonitorStateException - if the current thread is not the owner of the
          *         the Synchronizable Object.
          */
-        virtual void wait( long long millisecs ) = 0;
+        virtual void wait(long long millisecs) = 0;
 
         /**
          * Waits on a signal from this object, which is generated by a call to Notify.
@@ -115,7 +115,7 @@ namespace concurrent{
          * @throws IllegalMonitorStateException - if the current thread is not the owner of the
          *         the Synchronizable Object.
          */
-        virtual void wait( long long millisecs, int nanos ) = 0;
+        virtual void wait(long long millisecs, int nanos) = 0;
 
         /**
          * Signals a waiter on this object that it can now wake

Added: activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/concurrent/TimeoutException.cpp
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/concurrent/TimeoutException.cpp?rev=1406762&view=auto
==============================================================================
--- activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/concurrent/TimeoutException.cpp (added)
+++ activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/concurrent/TimeoutException.cpp Wed Nov  7 19:29:54 2012
@@ -0,0 +1,72 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+#include "TimeoutException.h"
+
+using namespace decaf;
+using namespace decaf::util;
+using namespace decaf::util::concurrent;
+using namespace decaf::lang;
+
+////////////////////////////////////////////////////////////////////////////////
+TimeoutException::TimeoutException() : decaf::lang::Exception() {
+}
+
+////////////////////////////////////////////////////////////////////////////////
+TimeoutException::TimeoutException(const decaf::lang::Exception& ex) : decaf::lang::Exception() {
+    *(Exception*) this = ex;
+}
+
+////////////////////////////////////////////////////////////////////////////////
+TimeoutException::TimeoutException(const TimeoutException& ex) : decaf::lang::Exception() {
+    *(Exception*) this = ex;
+}
+
+////////////////////////////////////////////////////////////////////////////////
+TimeoutException::TimeoutException(const std::exception* cause) : decaf::lang::Exception(cause) {
+}
+
+////////////////////////////////////////////////////////////////////////////////
+TimeoutException::TimeoutException(const char* file, const int lineNumber, const char* msg, ...) : decaf::lang::Exception() {
+
+    va_list vargs;
+    va_start( vargs, msg);
+    buildMessage(msg, vargs);
+
+    // Set the first mark for this exception.
+    setMark(file, lineNumber);
+}
+
+////////////////////////////////////////////////////////////////////////////////
+TimeoutException::TimeoutException(const char* file, const int lineNumber, const std::exception* cause, const char* msg, ...) : decaf::lang::Exception(cause) {
+
+    va_list vargs;
+    va_start(vargs, msg);
+    buildMessage(msg, vargs);
+
+    // Set the first mark for this exception.
+    setMark(file, lineNumber);
+}
+
+////////////////////////////////////////////////////////////////////////////////
+TimeoutException::~TimeoutException() throw () {
+}
+
+////////////////////////////////////////////////////////////////////////////////
+TimeoutException* TimeoutException::clone() const {
+    return new TimeoutException(*this);
+}

Propchange: activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/concurrent/TimeoutException.cpp
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/concurrent/TimeoutException.h
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/concurrent/TimeoutException.h?rev=1406762&r1=1406761&r2=1406762&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/concurrent/TimeoutException.h (original)
+++ activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/concurrent/TimeoutException.h Wed Nov  7 19:29:54 2012
@@ -19,9 +19,9 @@
 
 #include <decaf/lang/Exception.h>
 
-namespace decaf{
-namespace util{
-namespace concurrent{
+namespace decaf {
+namespace util {
+namespace concurrent {
 
     /*
      * Exception thrown when a blocking operation times out. Blocking operations for which
@@ -35,16 +35,14 @@ namespace concurrent{
         /**
          * Default Constructor
          */
-        TimeoutException() : decaf::lang::Exception() {}
+        TimeoutException();
 
         /**
          * Conversion Constructor from some other Exception
+         *
          * @param ex An exception that should become this type of Exception
          */
-        TimeoutException( const decaf::lang::Exception& ex )
-        : decaf::lang::Exception() {
-            *(Exception*)this = ex;
-        }
+        TimeoutException(const decaf::lang::Exception& ex);
 
         /**
          * Copy Constructor
@@ -52,64 +50,41 @@ namespace concurrent{
          * @param ex
          *      The exception to copy from.
          */
-        TimeoutException( const TimeoutException& ex )
-        : decaf::lang::Exception() {
-            *(Exception*)this = ex;
-        }
+        TimeoutException(const TimeoutException& ex);
 
         /**
          * Constructor
+         *
          * @param cause
          *      Pointer to the exception that caused this one to
          *      be thrown, the object is cloned caller retains ownership.
          */
-        TimeoutException( const std::exception* cause )
-            : decaf::lang::Exception( cause ) {}
+        TimeoutException(const std::exception* cause);
 
         /**
          * Constructor - Initializes the file name and line number where
          * this message occurred.  Sets the message to report, using an
          * optional list of arguments to parse into the message
+         *
          * @param file The file name where exception occurs
          * @param lineNumber The line number where the exception occurred.
          * @param msg The string message to report
          * @param ... list of primitives that are formatted into the message
          */
-        TimeoutException( const char* file, const int lineNumber,
-                          const char* msg, ... )
-            : decaf::lang::Exception()
-        {
-
-            va_list vargs;
-            va_start( vargs, msg );
-            buildMessage( msg, vargs );
-
-            // Set the first mark for this exception.
-            setMark( file, lineNumber );
-        }
+        TimeoutException(const char* file, const int lineNumber, const char* msg, ...);
 
         /**
          * Constructor - Initializes the file name and line number where
          * this message occurred.  Sets the message to report, using an
          * optional list of arguments to parse into the message
+         *
          * @param file The file name where exception occurs
          * @param lineNumber The line number where the exception occurred.
          * @param cause The exception that was the cause for this one to be thrown.
          * @param msg The string message to report
          * @param ... list of primitives that are formatted into the message
          */
-        TimeoutException( const char* file, const int lineNumber,
-                          const std::exception* cause,
-                          const char* msg, ... )
-            : decaf::lang::Exception( cause )
-        {
-            va_list vargs ;
-            va_start( vargs, msg );
-            buildMessage( msg, vargs );
-
-            // Set the first mark for this exception.
-            setMark( file, lineNumber );
-        }
+        TimeoutException(const char* file, const int lineNumber, const std::exception* cause, const char* msg, ...);
 
         /**
          * Clones this exception.  This is useful for cases where you need
@@ -118,11 +93,9 @@ namespace concurrent{
          *
          * @return a new TimeoutException that is a copy of this one.
          */
-        virtual TimeoutException* clone() const{
-            return new TimeoutException( *this );
-        }
+        virtual TimeoutException* clone() const;
 
-        virtual ~TimeoutException() throw() {}
+        virtual ~TimeoutException() throw();
 
     };
 

Added: activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/concurrent/locks/Condition.cpp
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/concurrent/locks/Condition.cpp?rev=1406762&view=auto
==============================================================================
--- activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/concurrent/locks/Condition.cpp (added)
+++ activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/concurrent/locks/Condition.cpp Wed Nov  7 19:29:54 2012
@@ -0,0 +1,27 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+#include "Condition.h"
+
+using namespace decaf;
+using namespace decaf::util;
+using namespace decaf::util::concurrent;
+using namespace decaf::util::concurrent::locks;
+
+////////////////////////////////////////////////////////////////////////////////
+Condition::~Condition() {
+}

Propchange: activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/concurrent/locks/Condition.cpp
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/concurrent/locks/Condition.h
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/concurrent/locks/Condition.h?rev=1406762&r1=1406761&r2=1406762&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/concurrent/locks/Condition.h (original)
+++ activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/concurrent/locks/Condition.h Wed Nov  7 19:29:54 2012
@@ -132,7 +132,7 @@ namespace locks {
     class DECAF_API Condition {
     public:
 
-        virtual ~Condition() {}
+        virtual ~Condition();
 
         /**
          * Causes the current thread to wait until it is signaled or interrupted.
@@ -300,7 +300,7 @@ namespace locks {
          * @throws IllegalMonitorStateException
          *         if the caller is not the lock owner.
          */
-        virtual long long awaitNanos( long long nanosTimeout ) = 0;
+        virtual long long awaitNanos(long long nanosTimeout) = 0;
 
         /**
          * Causes the current thread to wait until it is signaled or interrupted, or the
@@ -324,7 +324,7 @@ namespace locks {
          * @throws IllegalMonitorStateException
          *         if the caller is not the lock owner.
          */
-        virtual bool await( long long time, const TimeUnit& unit ) = 0;
+        virtual bool await(long long time, const TimeUnit& unit) = 0;
 
         /*
          * Causes the current thread to wait until it is signaled or interrupted, or the

Added: activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/concurrent/locks/Lock.cpp
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/concurrent/locks/Lock.cpp?rev=1406762&view=auto
==============================================================================
--- activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/concurrent/locks/Lock.cpp (added)
+++ activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/concurrent/locks/Lock.cpp Wed Nov  7 19:29:54 2012
@@ -0,0 +1,27 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+#include "Lock.h"
+
+using namespace decaf;
+using namespace decaf::util;
+using namespace decaf::util::concurrent;
+using namespace decaf::util::concurrent::locks;
+
+////////////////////////////////////////////////////////////////////////////////
+Lock::~Lock() {
+}

Propchange: activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/concurrent/locks/Lock.cpp
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/concurrent/locks/Lock.h
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/concurrent/locks/Lock.h?rev=1406762&r1=1406761&r2=1406762&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/concurrent/locks/Lock.h (original)
+++ activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/concurrent/locks/Lock.h Wed Nov  7 19:29:54 2012
@@ -99,7 +99,7 @@ namespace locks {
     class DECAF_API Lock {
     public:
 
-        virtual ~Lock() {}
+        virtual ~Lock();
 
         /**
          * Acquires the lock.
@@ -243,7 +243,7 @@ namespace locks {
          *         if the current thread is interrupted while acquiring the lock (and
          *         interruption of lock acquisition is supported)
          */
-        virtual bool tryLock( long long time, const TimeUnit& unit ) = 0;
+        virtual bool tryLock(long long time, const TimeUnit& unit) = 0;
 
         /**
          * Releases the lock.

Added: activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/concurrent/locks/ReadWriteLock.cpp
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/concurrent/locks/ReadWriteLock.cpp?rev=1406762&view=auto
==============================================================================
--- activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/concurrent/locks/ReadWriteLock.cpp (added)
+++ activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/concurrent/locks/ReadWriteLock.cpp Wed Nov  7 19:29:54 2012
@@ -0,0 +1,27 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+#include "ReadWriteLock.h"
+
+using namespace decaf;
+using namespace decaf::util;
+using namespace decaf::util::concurrent;
+using namespace decaf::util::concurrent::locks;
+
+////////////////////////////////////////////////////////////////////////////////
+ReadWriteLock::~ReadWriteLock() {
+}

Propchange: activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/concurrent/locks/ReadWriteLock.cpp
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/concurrent/locks/ReadWriteLock.h
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/concurrent/locks/ReadWriteLock.h?rev=1406762&r1=1406761&r2=1406762&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/concurrent/locks/ReadWriteLock.h (original)
+++ activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/concurrent/locks/ReadWriteLock.h Wed Nov  7 19:29:54 2012
@@ -90,7 +90,7 @@ namespace locks {
     class DECAF_API ReadWriteLock {
     public:
 
-        virtual ~ReadWriteLock() {}
+        virtual ~ReadWriteLock();
 
         /**
          * Returns the lock used for reading.

Added: activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/zip/Checksum.cpp
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/zip/Checksum.cpp?rev=1406762&view=auto
==============================================================================
--- activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/zip/Checksum.cpp (added)
+++ activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/zip/Checksum.cpp Wed Nov  7 19:29:54 2012
@@ -0,0 +1,26 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+#include "Checksum.h"
+
+using namespace decaf;
+using namespace decaf::util;
+using namespace decaf::util::zip;
+
+////////////////////////////////////////////////////////////////////////////////
+Checksum::~Checksum() {
+}

Propchange: activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/zip/Checksum.cpp
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/zip/Checksum.h
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/zip/Checksum.h?rev=1406762&r1=1406761&r2=1406762&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/zip/Checksum.h (original)
+++ activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/zip/Checksum.h Wed Nov  7 19:29:54 2012
@@ -37,7 +37,7 @@ namespace zip {
     class DECAF_API Checksum {
     public:
 
-        virtual ~Checksum() {}
+        virtual ~Checksum();
 
         /**
          * @returns the current checksum value.

Modified: activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/zip/DataFormatException.cpp
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/zip/DataFormatException.cpp?rev=1406762&r1=1406761&r2=1406762&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/zip/DataFormatException.cpp (original)
+++ activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/zip/DataFormatException.cpp Wed Nov  7 19:29:54 2012
@@ -23,11 +23,50 @@ using namespace decaf::util;
 using namespace decaf::util::zip;
 
 ////////////////////////////////////////////////////////////////////////////////
-DataFormatException::DataFormatException() {
+DataFormatException::DataFormatException() : lang::Exception() {
+}
+
+////////////////////////////////////////////////////////////////////////////////
+DataFormatException::~DataFormatException() throw () {
+}
+
+////////////////////////////////////////////////////////////////////////////////
+DataFormatException::DataFormatException(const lang::Exception& ex) : lang::Exception() {
+    *(lang::Exception*) this = ex;
+}
+
+////////////////////////////////////////////////////////////////////////////////
+DataFormatException::DataFormatException(const DataFormatException& ex) : lang::Exception() {
+    *(lang::Exception*) this = ex;
+}
 
+////////////////////////////////////////////////////////////////////////////////
+DataFormatException::DataFormatException(const char* file, const int lineNumber, const std::exception* cause, const char* msg, ...) : lang::Exception(cause) {
+
+    va_list vargs;
+    va_start(vargs, msg);
+    buildMessage(msg, vargs);
+
+    // Set the first mark for this exception.
+    setMark(file, lineNumber);
+}
+
+////////////////////////////////////////////////////////////////////////////////
+DataFormatException::DataFormatException(const std::exception* cause) : lang::Exception(cause) {
 }
 
 ////////////////////////////////////////////////////////////////////////////////
-DataFormatException::~DataFormatException() throw() {
+DataFormatException::DataFormatException(const char* file, const int lineNumber, const char* msg, ...) : lang::Exception() {
+
+    va_list vargs;
+    va_start(vargs, msg);
+    buildMessage(msg, vargs);
 
+    // Set the first mark for this exception.
+    setMark(file, lineNumber);
+}
+
+////////////////////////////////////////////////////////////////////////////////
+DataFormatException* DataFormatException::clone() const {
+    return new DataFormatException(*this);
 }

Modified: activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/zip/DataFormatException.h
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/zip/DataFormatException.h?rev=1406762&r1=1406761&r2=1406762&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/zip/DataFormatException.h (original)
+++ activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/zip/DataFormatException.h Wed Nov  7 19:29:54 2012
@@ -36,50 +36,37 @@ namespace zip{
 
         /**
          * Copy Constructor
+         *
          * @param ex the exception to copy
          */
-        DataFormatException( const lang::Exception& ex )
-        : lang::Exception() {
-            *(lang::Exception*)this = ex;
-        }
+        DataFormatException(const lang::Exception& ex);
 
         /**
          * Copy Constructor
+         *
          * @param ex the exception to copy, which is an instance of this type
          */
-        DataFormatException( const DataFormatException& ex )
-        : lang::Exception() {
-            *(lang::Exception*)this = ex;
-        }
+        DataFormatException(const DataFormatException& ex);
 
         /**
          * Constructor - Initializes the file name and line number where
          * this message occurred.  Sets the message to report, using an
          * optional list of arguments to parse into the message
+         *
          * @param file The file name where exception occurs
          * @param lineNumber The line number where the exception occurred.
          * @param cause The exception that was the cause for this one to be thrown.
          * @param msg The message to report
          * @param ... list of primitives that are formatted into the message
          */
-        DataFormatException( const char* file, const int lineNumber,
-                             const std::exception* cause,
-                             const char* msg, ... ) : lang::Exception( cause )
-        {
-            va_list vargs;
-            va_start( vargs, msg );
-            buildMessage( msg, vargs );
-
-            // Set the first mark for this exception.
-            setMark( file, lineNumber );
-        }
+        DataFormatException(const char* file, const int lineNumber, const std::exception* cause, const char* msg, ...);
 
         /**
          * Constructor
          * @param cause Pointer to the exception that caused this one to
          * be thrown, the object is cloned caller retains ownership.
          */
-        DataFormatException( const std::exception* cause ) : lang::Exception( cause ) {}
+        DataFormatException(const std::exception* cause);
 
         /**
          * Constructor
@@ -88,16 +75,7 @@ namespace zip{
          * @param msg The message to report
          * @param ... list of primitives that are formatted into the message
          */
-        DataFormatException( const char* file, const int lineNumber,
-                             const char* msg, ... )
-        : lang::Exception() {
-            va_list vargs;
-            va_start( vargs, msg );
-            buildMessage( msg, vargs );
-
-            // Set the first mark for this exception.
-            setMark( file, lineNumber );
-        }
+        DataFormatException(const char* file, const int lineNumber, const char* msg, ...);
 
         /**
          * Clones this exception.  This is useful for cases where you need
@@ -106,9 +84,7 @@ namespace zip{
          *
          * @return a new instance of an Exception that is a copy of this instance.
          */
-        virtual DataFormatException* clone() const {
-            return new DataFormatException( *this );
-        }
+        virtual DataFormatException* clone() const;
 
         virtual ~DataFormatException() throw();
 

Modified: activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/zip/ZipException.cpp
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/zip/ZipException.cpp?rev=1406762&r1=1406761&r2=1406762&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/zip/ZipException.cpp (original)
+++ activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/zip/ZipException.cpp Wed Nov  7 19:29:54 2012
@@ -23,11 +23,49 @@ using namespace decaf::util;
 using namespace decaf::util::zip;
 
 ////////////////////////////////////////////////////////////////////////////////
-ZipException::ZipException() {
+ZipException::ZipException() : IOException() {
+}
+
+////////////////////////////////////////////////////////////////////////////////
+ZipException::~ZipException() throw () {
+}
+
+////////////////////////////////////////////////////////////////////////////////
+ZipException::ZipException(const lang::Exception& ex) : IOException() {
+    *(lang::Exception*) this = ex;
+}
 
+////////////////////////////////////////////////////////////////////////////////
+ZipException::ZipException(const ZipException& ex) : IOException() {
+    *(lang::Exception*) this = ex;
 }
 
 ////////////////////////////////////////////////////////////////////////////////
-ZipException::~ZipException() throw() {
+ZipException::ZipException(const char* file, const int lineNumber, const std::exception* cause, const char* msg, ...) : IOException(cause) {
+    va_list vargs;
+    va_start( vargs, msg);
+    buildMessage(msg, vargs);
+
+    // Set the first mark for this exception.
+    setMark(file, lineNumber);
+}
 
+////////////////////////////////////////////////////////////////////////////////
+ZipException::ZipException(const std::exception* cause) : IOException(cause) {
+}
+
+////////////////////////////////////////////////////////////////////////////////
+ZipException::ZipException(const char* file, const int lineNumber, const char* msg, ...) : IOException() {
+
+    va_list vargs;
+    va_start(vargs, msg);
+    buildMessage(msg, vargs);
+
+    // Set the first mark for this exception.
+    setMark(file, lineNumber);
+}
+
+////////////////////////////////////////////////////////////////////////////////
+ZipException* ZipException::clone() const {
+    return new ZipException(*this);
 }

Modified: activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/zip/ZipException.h
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/zip/ZipException.h?rev=1406762&r1=1406761&r2=1406762&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/zip/ZipException.h (original)
+++ activemq/activemq-cpp/trunk/activemq-cpp/src/main/decaf/util/zip/ZipException.h Wed Nov  7 19:29:54 2012
@@ -39,50 +39,38 @@ namespace zip{
 
         /**
          * Copy Constructor
+         *
          * @param ex the exception to copy
          */
-        ZipException( const lang::Exception& ex )
-        : IOException() {
-            *(lang::Exception*)this = ex;
-        }
+        ZipException(const lang::Exception& ex);
 
         /**
          * Copy Constructor
+         *
          * @param ex the exception to copy, which is an instance of this type
          */
-        ZipException( const ZipException& ex )
-        : IOException() {
-            *(lang::Exception*)this = ex;
-        }
+        ZipException(const ZipException& ex);
 
         /**
          * Constructor - Initializes the file name and line number where
          * this message occurred.  Sets the message to report, using an
          * optional list of arguments to parse into the message
+         *
          * @param file The file name where exception occurs
          * @param lineNumber The line number where the exception occurred.
          * @param cause The exception that was the cause for this one to be thrown.
          * @param msg The message to report
          * @param ... list of primitives that are formatted into the message
          */
-        ZipException( const char* file, const int lineNumber,
-                      const std::exception* cause,
-                      const char* msg, ... ) : IOException( cause )
-        {
-            va_list vargs;
-            va_start( vargs, msg );
-            buildMessage( msg, vargs );
-
-            // Set the first mark for this exception.
-            setMark( file, lineNumber );
-        }
+        ZipException(const char* file, const int lineNumber, const std::exception* cause, const char* msg, ...);
 
         /**
          * Constructor
+         *
          * @param cause Pointer to the exception that caused this one to
          * be thrown, the object is cloned caller retains ownership.
          */
-        ZipException( const std::exception* cause ) : IOException( cause ) {}
+        ZipException(const std::exception* cause);
 
         /**
          * Constructor
@@ -92,17 +80,7 @@ namespace zip{
          * @param msg The message to report
          * @param ... list of primitives that are formatted into the message
          */
-        ZipException( const char* file, const int lineNumber,
-                      const char* msg, ... )
-        : IOException()
-        {
-            va_list vargs;
-            va_start( vargs, msg );
-            buildMessage( msg, vargs );
-
-            // Set the first mark for this exception.
-            setMark( file, lineNumber );
-        }
+        ZipException(const char* file, const int lineNumber, const char* msg, ...);
 
         /**
          * Clones this exception.  This is useful for cases where you need
@@ -111,9 +89,7 @@ namespace zip{
          *
          * @return a new instance of an Exception that is a copy of this one.
          */
-        virtual ZipException* clone() const{
-            return new ZipException( *this );
-        }
+        virtual ZipException* clone() const;
 
         virtual ~ZipException() throw();