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 2009/03/19 16:57:05 UTC

svn commit: r756064 - in /activemq/activemq-cpp/trunk/src/main/activemq: commands/ core/ state/ transport/failover/ transport/mock/

Author: tabish
Date: Thu Mar 19 15:57:03 2009
New Revision: 756064

URL: http://svn.apache.org/viewvc?rev=756064&view=rev
Log:
Changes needed to build on Windows

Modified:
    activemq/activemq-cpp/trunk/src/main/activemq/commands/ActiveMQMessageTemplate.h
    activemq/activemq-cpp/trunk/src/main/activemq/core/ActiveMQConnection.cpp
    activemq/activemq-cpp/trunk/src/main/activemq/core/ActiveMQConsumer.cpp
    activemq/activemq-cpp/trunk/src/main/activemq/core/ActiveMQProducer.cpp
    activemq/activemq-cpp/trunk/src/main/activemq/core/ActiveMQSession.cpp
    activemq/activemq-cpp/trunk/src/main/activemq/core/ActiveMQTransactionContext.cpp
    activemq/activemq-cpp/trunk/src/main/activemq/state/ConnectionStateTracker.cpp
    activemq/activemq-cpp/trunk/src/main/activemq/transport/failover/FailoverTransportFactory.cpp
    activemq/activemq-cpp/trunk/src/main/activemq/transport/mock/MockTransportFactory.cpp

Modified: activemq/activemq-cpp/trunk/src/main/activemq/commands/ActiveMQMessageTemplate.h
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/activemq/commands/ActiveMQMessageTemplate.h?rev=756064&r1=756063&r2=756064&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/activemq/commands/ActiveMQMessageTemplate.h (original)
+++ activemq/activemq-cpp/trunk/src/main/activemq/commands/ActiveMQMessageTemplate.h Thu Mar 19 15:57:03 2009
@@ -36,7 +36,7 @@
 
     public:
 
-        ActiveMQMessageTemplate() : Message() {
+		ActiveMQMessageTemplate() : commands::Message() {
             this->propertiesInterceptor.reset(
                 new wireformat::openwire::utils::MessagePropertyInterceptor(
                     this, &this->getMessageProperties() ) );

Modified: activemq/activemq-cpp/trunk/src/main/activemq/core/ActiveMQConnection.cpp
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/activemq/core/ActiveMQConnection.cpp?rev=756064&r1=756063&r2=756064&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/activemq/core/ActiveMQConnection.cpp (original)
+++ activemq/activemq-cpp/trunk/src/main/activemq/core/ActiveMQConnection.cpp Thu Mar 19 15:57:03 2009
@@ -628,7 +628,7 @@
 }
 
 ////////////////////////////////////////////////////////////////////////////////
-void ActiveMQConnection::fire( const exceptions::ActiveMQException& ex ) {
+void ActiveMQConnection::fire( const ActiveMQException& ex ) {
     if( exceptionListener != NULL ) {
         try {
             exceptionListener->onException( ex );

Modified: activemq/activemq-cpp/trunk/src/main/activemq/core/ActiveMQConsumer.cpp
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/activemq/core/ActiveMQConsumer.cpp?rev=756064&r1=756063&r2=756064&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/activemq/core/ActiveMQConsumer.cpp (original)
+++ activemq/activemq-cpp/trunk/src/main/activemq/core/ActiveMQConsumer.cpp Thu Mar 19 15:57:03 2009
@@ -531,7 +531,7 @@
 }
 
 ////////////////////////////////////////////////////////////////////////////////
-void ActiveMQConsumer::checkClosed() const throw( exceptions::ActiveMQException ) {
+void ActiveMQConsumer::checkClosed() const throw( ActiveMQException ) {
     if( this->isClosed() ) {
         throw ActiveMQException(
             __FILE__, __LINE__,

Modified: activemq/activemq-cpp/trunk/src/main/activemq/core/ActiveMQProducer.cpp
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/activemq/core/ActiveMQProducer.cpp?rev=756064&r1=756063&r2=756064&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/activemq/core/ActiveMQProducer.cpp (original)
+++ activemq/activemq-cpp/trunk/src/main/activemq/core/ActiveMQProducer.cpp Thu Mar 19 15:57:03 2009
@@ -202,7 +202,7 @@
 }
 
 ////////////////////////////////////////////////////////////////////////////////
-void ActiveMQProducer::checkClosed() const throw( exceptions::ActiveMQException ) {
+void ActiveMQProducer::checkClosed() const throw( activemq::exceptions::ActiveMQException ) {
     if( closed ) {
         throw ActiveMQException(
             __FILE__, __LINE__,

Modified: activemq/activemq-cpp/trunk/src/main/activemq/core/ActiveMQSession.cpp
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/activemq/core/ActiveMQSession.cpp?rev=756064&r1=756063&r2=756064&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/activemq/core/ActiveMQSession.cpp (original)
+++ activemq/activemq-cpp/trunk/src/main/activemq/core/ActiveMQSession.cpp Thu Mar 19 15:57:03 2009
@@ -969,7 +969,7 @@
 }
 
 ////////////////////////////////////////////////////////////////////////////////
-void ActiveMQSession::checkClosed() const throw( exceptions::ActiveMQException ) {
+void ActiveMQSession::checkClosed() const throw( activemq::exceptions::ActiveMQException ) {
     if( closed ) {
         throw ActiveMQException(
             __FILE__, __LINE__,

Modified: activemq/activemq-cpp/trunk/src/main/activemq/core/ActiveMQTransactionContext.cpp
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/activemq/core/ActiveMQTransactionContext.cpp?rev=756064&r1=756063&r2=756064&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/activemq/core/ActiveMQTransactionContext.cpp (original)
+++ activemq/activemq-cpp/trunk/src/main/activemq/core/ActiveMQTransactionContext.cpp Thu Mar 19 15:57:03 2009
@@ -202,7 +202,7 @@
 }
 
 ////////////////////////////////////////////////////////////////////////////////
-void ActiveMQTransactionContext::startTransaction() throw( exceptions::ActiveMQException ) {
+void ActiveMQTransactionContext::startTransaction() throw( activemq::exceptions::ActiveMQException ) {
 
     try{
 
@@ -227,7 +227,7 @@
 
 ////////////////////////////////////////////////////////////////////////////////
 void ActiveMQTransactionContext::clearSynchronizations()
-    throw( exceptions::ActiveMQException ) {
+    throw( activemq::exceptions::ActiveMQException ) {
 
 
     try{

Modified: activemq/activemq-cpp/trunk/src/main/activemq/state/ConnectionStateTracker.cpp
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/activemq/state/ConnectionStateTracker.cpp?rev=756064&r1=756063&r2=756064&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/activemq/state/ConnectionStateTracker.cpp (original)
+++ activemq/activemq-cpp/trunk/src/main/activemq/state/ConnectionStateTracker.cpp Thu Mar 19 15:57:03 2009
@@ -270,7 +270,7 @@
 
 ////////////////////////////////////////////////////////////////////////////////
 Pointer<Command> ConnectionStateTracker::processDestinationInfo( DestinationInfo* info )
-    throw ( exceptions::ActiveMQException ) {
+    throw ( activemq::exceptions::ActiveMQException ) {
 
     try{
         if( info != NULL ) {
@@ -288,7 +288,7 @@
 
 ////////////////////////////////////////////////////////////////////////////////
 Pointer<Command> ConnectionStateTracker::processRemoveDestination( DestinationInfo* info )
-    throw ( exceptions::ActiveMQException ) {
+    throw ( activemq::exceptions::ActiveMQException ) {
 
     try{
         if( info != NULL ) {
@@ -306,7 +306,7 @@
 
 ////////////////////////////////////////////////////////////////////////////////
 Pointer<Command> ConnectionStateTracker::processProducerInfo( ProducerInfo* info )
-    throw ( exceptions::ActiveMQException ) {
+    throw ( activemq::exceptions::ActiveMQException ) {
 
     try{
 
@@ -335,7 +335,7 @@
 
 ////////////////////////////////////////////////////////////////////////////////
 Pointer<Command> ConnectionStateTracker::processRemoveProducer( ProducerId* id )
-    throw ( exceptions::ActiveMQException ) {
+    throw ( activemq::exceptions::ActiveMQException ) {
 
     try{
 
@@ -363,7 +363,7 @@
 
 ////////////////////////////////////////////////////////////////////////////////
 Pointer<Command> ConnectionStateTracker::processConsumerInfo( ConsumerInfo* info )
-    throw ( exceptions::ActiveMQException ) {
+    throw ( activemq::exceptions::ActiveMQException ) {
 
     try{
 
@@ -392,7 +392,7 @@
 
 ////////////////////////////////////////////////////////////////////////////////
 Pointer<Command> ConnectionStateTracker::processRemoveConsumer( ConsumerId* id )
-    throw ( exceptions::ActiveMQException ) {
+    throw ( activemq::exceptions::ActiveMQException ) {
 
     try{
         if( id != NULL ) {
@@ -419,7 +419,7 @@
 
 ////////////////////////////////////////////////////////////////////////////////
 Pointer<Command> ConnectionStateTracker::processSessionInfo( SessionInfo* info)
-    throw ( exceptions::ActiveMQException ) {
+    throw ( activemq::exceptions::ActiveMQException ) {
 
     try{
 
@@ -441,7 +441,7 @@
 
 ////////////////////////////////////////////////////////////////////////////////
 Pointer<Command> ConnectionStateTracker::processRemoveSession( SessionId* id)
-    throw ( exceptions::ActiveMQException ) {
+    throw ( activemq::exceptions::ActiveMQException ) {
 
     try{
 
@@ -463,7 +463,7 @@
 
 ////////////////////////////////////////////////////////////////////////////////
 Pointer<Command> ConnectionStateTracker::processConnectionInfo( ConnectionInfo* info )
-    throw ( exceptions::ActiveMQException ) {
+    throw ( activemq::exceptions::ActiveMQException ) {
 
     try{
 
@@ -481,7 +481,7 @@
 
 ////////////////////////////////////////////////////////////////////////////////
 Pointer<Command> ConnectionStateTracker::processRemoveConnection( ConnectionId* id )
-    throw ( exceptions::ActiveMQException ) {
+    throw ( activemq::exceptions::ActiveMQException ) {
 
     try{
 
@@ -498,7 +498,7 @@
 
 ////////////////////////////////////////////////////////////////////////////////
 Pointer<Command> ConnectionStateTracker::processMessage( Message* message )
-    throw ( exceptions::ActiveMQException ) {
+    throw ( activemq::exceptions::ActiveMQException ) {
 
     try{
         if( message != NULL ) {
@@ -531,7 +531,7 @@
 
 ////////////////////////////////////////////////////////////////////////////////
 Pointer<Command> ConnectionStateTracker::processMessageAck( MessageAck* ack )
-    throw ( exceptions::ActiveMQException ) {
+    throw ( activemq::exceptions::ActiveMQException ) {
 
     try{
 
@@ -560,7 +560,7 @@
 
 ////////////////////////////////////////////////////////////////////////////////
 Pointer<Command> ConnectionStateTracker::processBeginTransaction( TransactionInfo* info )
-    throw ( exceptions::ActiveMQException ) {
+    throw ( activemq::exceptions::ActiveMQException ) {
 
     try{
 
@@ -590,7 +590,7 @@
 
 ////////////////////////////////////////////////////////////////////////////////
 Pointer<Command> ConnectionStateTracker::processPrepareTransaction( TransactionInfo* info )
-    throw ( exceptions::ActiveMQException ) {
+    throw ( activemq::exceptions::ActiveMQException ) {
 
     try{
 
@@ -620,7 +620,7 @@
 
 ////////////////////////////////////////////////////////////////////////////////
 Pointer<Command> ConnectionStateTracker::processCommitTransactionOnePhase( TransactionInfo* info )
-    throw ( exceptions::ActiveMQException ) {
+    throw ( activemq::exceptions::ActiveMQException ) {
 
     try{
 
@@ -651,7 +651,7 @@
 
 ////////////////////////////////////////////////////////////////////////////////
 Pointer<Command> ConnectionStateTracker::processCommitTransactionTwoPhase( TransactionInfo* info )
-    throw ( exceptions::ActiveMQException ) {
+    throw ( activemq::exceptions::ActiveMQException ) {
 
     try{
 
@@ -682,7 +682,7 @@
 
 ////////////////////////////////////////////////////////////////////////////////
 Pointer<Command> ConnectionStateTracker::processRollbackTransaction( TransactionInfo* info )
-    throw ( exceptions::ActiveMQException ) {
+    throw ( activemq::exceptions::ActiveMQException ) {
 
     try{
 
@@ -713,7 +713,7 @@
 
 ////////////////////////////////////////////////////////////////////////////////
 Pointer<Command> ConnectionStateTracker::processEndTransaction( TransactionInfo* info )
-    throw ( exceptions::ActiveMQException ) {
+    throw ( activemq::exceptions::ActiveMQException ) {
 
     try{
 

Modified: activemq/activemq-cpp/trunk/src/main/activemq/transport/failover/FailoverTransportFactory.cpp
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/activemq/transport/failover/FailoverTransportFactory.cpp?rev=756064&r1=756063&r2=756064&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/activemq/transport/failover/FailoverTransportFactory.cpp (original)
+++ activemq/activemq-cpp/trunk/src/main/activemq/transport/failover/FailoverTransportFactory.cpp Thu Mar 19 15:57:03 2009
@@ -39,7 +39,7 @@
 
 ////////////////////////////////////////////////////////////////////////////////
 Pointer<Transport> FailoverTransportFactory::create( const decaf::net::URI& location )
-    throw ( exceptions::ActiveMQException ) {
+throw ( activemq::exceptions::ActiveMQException ) {
 
     try{
 
@@ -61,7 +61,7 @@
 
 ////////////////////////////////////////////////////////////////////////////////
 Pointer<Transport> FailoverTransportFactory::createComposite( const decaf::net::URI& location )
-    throw ( exceptions::ActiveMQException ) {
+    throw ( activemq::exceptions::ActiveMQException ) {
 
     try{
 
@@ -80,7 +80,7 @@
 Pointer<Transport> FailoverTransportFactory::doCreateComposite(
     const decaf::net::URI& location,
     const decaf::util::Properties& properties )
-        throw ( exceptions::ActiveMQException ) {
+        throw ( activemq::exceptions::ActiveMQException ) {
 
     try {
 

Modified: activemq/activemq-cpp/trunk/src/main/activemq/transport/mock/MockTransportFactory.cpp
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/activemq/transport/mock/MockTransportFactory.cpp?rev=756064&r1=756063&r2=756064&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/activemq/transport/mock/MockTransportFactory.cpp (original)
+++ activemq/activemq-cpp/trunk/src/main/activemq/transport/mock/MockTransportFactory.cpp Thu Mar 19 15:57:03 2009
@@ -44,7 +44,7 @@
 
 ////////////////////////////////////////////////////////////////////////////////
 Pointer<Transport> MockTransportFactory::create( const decaf::net::URI& location )
-    throw ( exceptions::ActiveMQException ) {
+    throw ( activemq::exceptions::ActiveMQException ) {
 
     try{
 
@@ -74,7 +74,7 @@
 
 ////////////////////////////////////////////////////////////////////////////////
 Pointer<Transport> MockTransportFactory::createComposite( const decaf::net::URI& location )
-    throw ( exceptions::ActiveMQException ) {
+    throw ( activemq::exceptions::ActiveMQException ) {
 
     try{
 
@@ -96,7 +96,7 @@
     const decaf::net::URI& location AMQCPP_UNUSED,
     const Pointer<wireformat::WireFormat>& wireFormat,
     const decaf::util::Properties& properties )
-        throw ( exceptions::ActiveMQException ) {
+        throw ( activemq::exceptions::ActiveMQException ) {
 
     try {