You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@activemq.apache.org by ch...@apache.org on 2006/07/06 00:36:42 UTC

svn commit: r419371 [1/10] - in /incubator/activemq/trunk/openwire-cpp/src/main/cpp: activemq/ activemq/command/ activemq/protocol/ activemq/protocol/openwire/ activemq/transport/ activemq/transport/tcp/ cms/ ppr/ ppr/io/ ppr/io/encoding/ ppr/net/ ppr/...

Author: chirino
Date: Wed Jul  5 15:36:36 2006
New Revision: 419371

URL: http://svn.apache.org/viewvc?rev=419371&view=rev
Log:
set the eol style to native

Modified:
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/BrokerException.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/Connection.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/ConnectionClosedException.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/ConnectionException.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/ConnectionFactory.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/ConsumerClosedException.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/DestinationFilter.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/Dispatcher.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/IAcknowledger.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/ICommand.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/IDataStructure.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/ISynchronization.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/MessageAckType.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/MessageConsumer.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/MessageConsumerSynchronization.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/MessageProducer.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/Session.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/TransactionContext.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/TransactionType.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/command/ActiveMQBytesMessage.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/command/ActiveMQDestination.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/command/ActiveMQMapMessage.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/command/ActiveMQMessage.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/command/ActiveMQObjectMessage.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/command/ActiveMQQueue.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/command/ActiveMQStreamMessage.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/command/ActiveMQTempDestination.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/command/ActiveMQTempQueue.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/command/ActiveMQTempTopic.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/command/ActiveMQTextMessage.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/command/ActiveMQTopic.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/command/BaseCommand.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/command/BaseDataStructure.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/command/BooleanExpression.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/command/BrokerError.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/command/BrokerId.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/command/BrokerInfo.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/command/ConnectionControl.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/command/ConnectionError.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/command/ConnectionId.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/command/ConnectionInfo.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/command/ConsumerControl.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/command/ConsumerId.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/command/ConsumerInfo.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/command/ControlCommand.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/command/DataArrayResponse.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/command/DataResponse.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/command/DestinationInfo.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/command/DiscoveryEvent.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/command/ExceptionResponse.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/command/FlushCommand.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/command/IntegerResponse.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/command/JournalQueueAck.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/command/JournalTopicAck.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/command/JournalTrace.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/command/JournalTransaction.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/command/KeepAliveInfo.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/command/LastPartialCommand.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/command/LocalTransactionId.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/command/Message.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/command/MessageAck.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/command/MessageDispatch.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/command/MessageDispatchNotification.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/command/MessageId.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/command/NetworkBridgeFilter.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/command/PartialCommand.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/command/ProducerId.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/command/ProducerInfo.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/command/RemoveInfo.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/command/RemoveSubscriptionInfo.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/command/ReplayCommand.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/command/Response.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/command/SessionId.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/command/SessionInfo.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/command/ShutdownInfo.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/command/SubscriptionInfo.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/command/TransactionId.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/command/TransactionInfo.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/command/WireFormatInfo.hpp   (props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/command/XATransactionId.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/protocol/IMarshaller.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/protocol/IProtocol.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/protocol/openwire/OpenWireMarshaller.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/protocol/openwire/OpenWireProtocol.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/transport/CorrelatorFilter.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/transport/FutureResponse.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/transport/ICommandListener.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/transport/ITransport.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/transport/ITransportFactory.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/transport/LoggingFilter.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/transport/MutexFilter.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/transport/TransportFactory.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/transport/TransportFilter.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/transport/tcp/TcpTransport.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/cms/CmsException.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/cms/IBytesMessage.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/cms/IConnection.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/cms/IConnectionFactory.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/cms/IDestination.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/cms/IExceptionListener.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/cms/IMapMessage.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/cms/IMessage.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/cms/IMessageConsumer.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/cms/IMessageListener.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/cms/IMessageProducer.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/cms/IQueue.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/cms/ISession.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/cms/IStartable.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/cms/ITemporaryQueue.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/cms/ITemporaryTopic.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/cms/ITextMessage.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/cms/ITopic.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/cms/MessageEOFException.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/cms/MessageFormatException.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/cms/MessageNotReadableException.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/cms/MessageNotWritableException.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/ppr/ConversionException.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/ppr/IllegalArgumentException.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/ppr/InvalidOperationException.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/ppr/TraceException.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/ppr/io/BufferedInputStream.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/ppr/io/BufferedOutputStream.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/ppr/io/ByteArrayInputStream.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/ppr/io/ByteArrayOutputStream.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/ppr/io/DataInputStream.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/ppr/io/DataOutputStream.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/ppr/io/EOFException.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/ppr/io/IInputStream.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/ppr/io/IOException.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/ppr/io/IOutputStream.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/ppr/io/SocketInputStream.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/ppr/io/SocketOutputStream.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/ppr/io/encoding/AsciiToUTF8Encoder.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/ppr/io/encoding/CharsetEncoderRegistry.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/ppr/io/encoding/CharsetEncodingException.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/ppr/io/encoding/ICharsetEncoder.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/ppr/net/IServerSocket.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/ppr/net/IServerSocketFactory.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/ppr/net/ISocket.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/ppr/net/ISocketFactory.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/ppr/net/ServerSocket.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/ppr/net/ServerSocketFactory.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/ppr/net/Socket.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/ppr/net/SocketException.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/ppr/net/SocketFactory.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/ppr/net/Uri.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/ppr/thread/Semaphore.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/ppr/thread/SimpleMutex.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/ppr/thread/Thread.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/ppr/util/Endian.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/ppr/util/Guid.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/ppr/util/Hex.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/ppr/util/MapItemHolder.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/ppr/util/Time.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/ppr/util/ifr/v1/array.hpp   (props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/ppr/util/ifr/v1/atomic.hpp   (props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/ppr/util/ifr/v1/cloneable.hpp   (props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/ppr/util/ifr/v1/colltraits.hpp   (props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/ppr/util/ifr/v1/endian.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/ppr/util/ifr/v1/namespace.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/ppr/util/ifr/v1/p.hpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/main/cpp/ppr/util/ifr/v1/platform.hpp   (props changed)

Modified: incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/BrokerException.hpp
URL: http://svn.apache.org/viewvc/incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/BrokerException.hpp?rev=419371&r1=419370&r2=419371&view=diff
==============================================================================
--- incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/BrokerException.hpp (original)
+++ incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/BrokerException.hpp Wed Jul  5 15:36:36 2006
@@ -1,54 +1,54 @@
-/*
- * Copyright 2006 The Apache Software Foundation or its licensors, as
- * applicable.
- *
- * Licensed 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.
- */
-#ifndef ActiveMQ_BrokerException_hpp_
-#define ActiveMQ_BrokerException_hpp_
-
-#include <string>
-#include "activemq/command/BrokerError.hpp"
-#include "cms/CmsException.hpp"
-#include "ppr/util/ifr/p"
-
-namespace apache
-{
-  namespace activemq
-  {
-    using namespace std;
-    using namespace ifr;
-    using namespace apache::cms;
-    using namespace apache::activemq::command;
-
-/*
- * 
- */
-class BrokerException : public CmsException
-{
-private:
-    p<BrokerError> brokerError ;
-    
-public:
-    BrokerException(p<BrokerError> brokerError) ;
-    virtual ~BrokerException() throw() {}
-
-    virtual p<BrokerError> getBrokerError() ;
-    virtual p<string> getJavaStackTrace() ;
-};
-
-/* namespace */
-  }
-}
-
-#endif /*ActiveMQ_BrokerException_hpp_*/
+/*
+ * Copyright 2006 The Apache Software Foundation or its licensors, as
+ * applicable.
+ *
+ * Licensed 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.
+ */
+#ifndef ActiveMQ_BrokerException_hpp_
+#define ActiveMQ_BrokerException_hpp_
+
+#include <string>
+#include "activemq/command/BrokerError.hpp"
+#include "cms/CmsException.hpp"
+#include "ppr/util/ifr/p"
+
+namespace apache
+{
+  namespace activemq
+  {
+    using namespace std;
+    using namespace ifr;
+    using namespace apache::cms;
+    using namespace apache::activemq::command;
+
+/*
+ * 
+ */
+class BrokerException : public CmsException
+{
+private:
+    p<BrokerError> brokerError ;
+    
+public:
+    BrokerException(p<BrokerError> brokerError) ;
+    virtual ~BrokerException() throw() {}
+
+    virtual p<BrokerError> getBrokerError() ;
+    virtual p<string> getJavaStackTrace() ;
+};
+
+/* namespace */
+  }
+}
+
+#endif /*ActiveMQ_BrokerException_hpp_*/

Propchange: incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/BrokerException.hpp
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/Connection.hpp
URL: http://svn.apache.org/viewvc/incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/Connection.hpp?rev=419371&r1=419370&r2=419371&view=diff
==============================================================================
--- incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/Connection.hpp (original)
+++ incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/Connection.hpp Wed Jul  5 15:36:36 2006
@@ -1,124 +1,124 @@
-/*
- * Copyright 2006 The Apache Software Foundation or its licensors, as
- * applicable.
- *
- * Licensed 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.
- */
-#ifndef ActiveMQ_Connection_hpp_
-#define ActiveMQ_Connection_hpp_
-
-#include <iostream>
-#include <list>
-#include <string>
-#include <map>
-
-#include "cms/ISession.hpp"
-#include "cms/IConnection.hpp"
-#include "cms/IExceptionListener.hpp"
-#include "cms/CmsException.hpp"
-#include "activemq/ConnectionClosedException.hpp"
-#include "activemq/MessageConsumer.hpp"
-#include "activemq/command/BrokerInfo.hpp"
-#include "activemq/command/WireFormatInfo.hpp"
-#include "activemq/command/ExceptionResponse.hpp"
-#include "activemq/command/ConnectionInfo.hpp"
-#include "activemq/command/LocalTransactionId.hpp"
-#include "activemq/command/MessageDispatch.hpp"
-#include "activemq/command/SessionInfo.hpp"
-#include "activemq/command/SessionId.hpp"
-#include "activemq/command/ShutdownInfo.hpp"
-#include "activemq/transport/ITransport.hpp"
-#include "activemq/transport/ICommandListener.hpp"
-#include "ppr/thread/SimpleMutex.hpp"
-#include "ppr/util/ifr/p"
-
-// Turn off warning message for ignored exception specification
-#ifdef _MSC_VER
-#pragma warning( disable : 4290 )
-#endif
-
-namespace apache
-{
-  namespace activemq
-  {
-    using namespace std;
-    using namespace ifr;
-    using namespace apache::cms;
-    using namespace apache::activemq::command;
-    using namespace apache::activemq::transport;
-    using namespace apache::ppr::thread;
-    using namespace apache::ppr::util;
-
-/*
- * 
- */
-class Connection : public IConnection, public ICommandListener
-{
-private:
-    p<ConnectionInfo>     connectionInfo ;
-    p<ITransport>         transport ;
-    p<BrokerInfo>         brokerInfo ;        // from MQ broker
-    p<WireFormatInfo>     brokerWireFormat ;  // from MQ broker
-    p<IExceptionListener> listener ;
-    list< p<ISession> >   sessions ;
-    bool                  connected,
-                          closed ;
-    AcknowledgementMode   acknowledgementMode ;
-    long long             sessionCounter,
-                          tempDestinationCounter,
-                          localTransactionCounter ;
-    SimpleMutex           mutex ;
-
-public:
-    // Constructors
-    Connection(p<ITransport> transport, p<ConnectionInfo> connectionInfo) ;
-    virtual ~Connection() ;
-
-    // Attribute methods
-    virtual void setExceptionListener(p<IExceptionListener> listener) ;
-    virtual p<IExceptionListener> getExceptionListener() ;
-    virtual p<ITransport> getTransport() ;
-    virtual void setTransport(p<ITransport> transport) ;
-    virtual p<string> getClientId() ;
-    virtual void setClientId(const char* value) throw (CmsException) ;
-    virtual p<BrokerInfo> getBrokerInfo() ;
-    virtual p<WireFormatInfo> getBrokerWireFormat() ;
-    virtual AcknowledgementMode getAcknowledgementMode() ;
-    virtual void setAcknowledgementMode(AcknowledgementMode mode) ;
-//    virtual void addConsumer(p<ConsumerId> consumerId, p<MessageConsumer> messageConsumer) ;
-//    virtual void removeConsumer(p<ConsumerId> consumerId) ;
-    virtual p<ConnectionId> getConnectionId() ;
-
-    // Operation methods
-    virtual p<ISession> createSession() throw(CmsException) ;
-    virtual p<ISession> createSession(AcknowledgementMode mode) throw(CmsException) ;
-    virtual p<Response> syncRequest(p<BaseCommand> command) throw(CmsException) ;
-    virtual void oneway(p<BaseCommand> command) throw(CmsException) ;
-    virtual void disposeOf(p<IDataStructure> dataStructure) throw(CmsException) ;
-    virtual p<string> createTemporaryDestinationName() ;
-    virtual p<LocalTransactionId> createLocalTransactionId() ;
-    virtual void close() ;
-
-protected:
-    // Implementation methods
-    p<SessionInfo> createSessionInfo(AcknowledgementMode mode) ;
-    void checkConnected() throw(CmsException) ;
-    void onCommand(p<ITransport> transport, p<BaseCommand> command) ;
-    void onError(p<ITransport> transport, exception& error) ;
-} ;
-
-/* namespace */
-  }
-}
-
-#endif /*ActiveMQ_Connection_hpp_*/
+/*
+ * Copyright 2006 The Apache Software Foundation or its licensors, as
+ * applicable.
+ *
+ * Licensed 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.
+ */
+#ifndef ActiveMQ_Connection_hpp_
+#define ActiveMQ_Connection_hpp_
+
+#include <iostream>
+#include <list>
+#include <string>
+#include <map>
+
+#include "cms/ISession.hpp"
+#include "cms/IConnection.hpp"
+#include "cms/IExceptionListener.hpp"
+#include "cms/CmsException.hpp"
+#include "activemq/ConnectionClosedException.hpp"
+#include "activemq/MessageConsumer.hpp"
+#include "activemq/command/BrokerInfo.hpp"
+#include "activemq/command/WireFormatInfo.hpp"
+#include "activemq/command/ExceptionResponse.hpp"
+#include "activemq/command/ConnectionInfo.hpp"
+#include "activemq/command/LocalTransactionId.hpp"
+#include "activemq/command/MessageDispatch.hpp"
+#include "activemq/command/SessionInfo.hpp"
+#include "activemq/command/SessionId.hpp"
+#include "activemq/command/ShutdownInfo.hpp"
+#include "activemq/transport/ITransport.hpp"
+#include "activemq/transport/ICommandListener.hpp"
+#include "ppr/thread/SimpleMutex.hpp"
+#include "ppr/util/ifr/p"
+
+// Turn off warning message for ignored exception specification
+#ifdef _MSC_VER
+#pragma warning( disable : 4290 )
+#endif
+
+namespace apache
+{
+  namespace activemq
+  {
+    using namespace std;
+    using namespace ifr;
+    using namespace apache::cms;
+    using namespace apache::activemq::command;
+    using namespace apache::activemq::transport;
+    using namespace apache::ppr::thread;
+    using namespace apache::ppr::util;
+
+/*
+ * 
+ */
+class Connection : public IConnection, public ICommandListener
+{
+private:
+    p<ConnectionInfo>     connectionInfo ;
+    p<ITransport>         transport ;
+    p<BrokerInfo>         brokerInfo ;        // from MQ broker
+    p<WireFormatInfo>     brokerWireFormat ;  // from MQ broker
+    p<IExceptionListener> listener ;
+    list< p<ISession> >   sessions ;
+    bool                  connected,
+                          closed ;
+    AcknowledgementMode   acknowledgementMode ;
+    long long             sessionCounter,
+                          tempDestinationCounter,
+                          localTransactionCounter ;
+    SimpleMutex           mutex ;
+
+public:
+    // Constructors
+    Connection(p<ITransport> transport, p<ConnectionInfo> connectionInfo) ;
+    virtual ~Connection() ;
+
+    // Attribute methods
+    virtual void setExceptionListener(p<IExceptionListener> listener) ;
+    virtual p<IExceptionListener> getExceptionListener() ;
+    virtual p<ITransport> getTransport() ;
+    virtual void setTransport(p<ITransport> transport) ;
+    virtual p<string> getClientId() ;
+    virtual void setClientId(const char* value) throw (CmsException) ;
+    virtual p<BrokerInfo> getBrokerInfo() ;
+    virtual p<WireFormatInfo> getBrokerWireFormat() ;
+    virtual AcknowledgementMode getAcknowledgementMode() ;
+    virtual void setAcknowledgementMode(AcknowledgementMode mode) ;
+//    virtual void addConsumer(p<ConsumerId> consumerId, p<MessageConsumer> messageConsumer) ;
+//    virtual void removeConsumer(p<ConsumerId> consumerId) ;
+    virtual p<ConnectionId> getConnectionId() ;
+
+    // Operation methods
+    virtual p<ISession> createSession() throw(CmsException) ;
+    virtual p<ISession> createSession(AcknowledgementMode mode) throw(CmsException) ;
+    virtual p<Response> syncRequest(p<BaseCommand> command) throw(CmsException) ;
+    virtual void oneway(p<BaseCommand> command) throw(CmsException) ;
+    virtual void disposeOf(p<IDataStructure> dataStructure) throw(CmsException) ;
+    virtual p<string> createTemporaryDestinationName() ;
+    virtual p<LocalTransactionId> createLocalTransactionId() ;
+    virtual void close() ;
+
+protected:
+    // Implementation methods
+    p<SessionInfo> createSessionInfo(AcknowledgementMode mode) ;
+    void checkConnected() throw(CmsException) ;
+    void onCommand(p<ITransport> transport, p<BaseCommand> command) ;
+    void onError(p<ITransport> transport, exception& error) ;
+} ;
+
+/* namespace */
+  }
+}
+
+#endif /*ActiveMQ_Connection_hpp_*/

Propchange: incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/Connection.hpp
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/ConnectionClosedException.hpp
URL: http://svn.apache.org/viewvc/incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/ConnectionClosedException.hpp?rev=419371&r1=419370&r2=419371&view=diff
==============================================================================
--- incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/ConnectionClosedException.hpp (original)
+++ incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/ConnectionClosedException.hpp Wed Jul  5 15:36:36 2006
@@ -1,41 +1,41 @@
-/*
- * Copyright 2006 The Apache Software Foundation or its licensors, as
- * applicable.
- *
- * Licensed 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.
- */
-#ifndef ActiveMQ_ConnectionClosedException_hpp_
-#define ActiveMQ_ConnectionClosedException_hpp_
-
-#include "cms/CmsException.hpp"
-
-namespace apache
-{
-  namespace activemq
-  {
-    using namespace apache::cms;
-
-/*
- * Signals that a connection is being used when it is already closed.
- */
-class ConnectionClosedException : public CmsException
-{
-public:
-    ConnectionClosedException(const char* message) ;
-};
-
-/* namespace */
-  }
-}
-
-#endif /*ActiveMQ_ConnectionClosedException_hpp_*/
+/*
+ * Copyright 2006 The Apache Software Foundation or its licensors, as
+ * applicable.
+ *
+ * Licensed 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.
+ */
+#ifndef ActiveMQ_ConnectionClosedException_hpp_
+#define ActiveMQ_ConnectionClosedException_hpp_
+
+#include "cms/CmsException.hpp"
+
+namespace apache
+{
+  namespace activemq
+  {
+    using namespace apache::cms;
+
+/*
+ * Signals that a connection is being used when it is already closed.
+ */
+class ConnectionClosedException : public CmsException
+{
+public:
+    ConnectionClosedException(const char* message) ;
+};
+
+/* namespace */
+  }
+}
+
+#endif /*ActiveMQ_ConnectionClosedException_hpp_*/

Propchange: incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/ConnectionClosedException.hpp
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/ConnectionException.hpp
URL: http://svn.apache.org/viewvc/incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/ConnectionException.hpp?rev=419371&r1=419370&r2=419371&view=diff
==============================================================================
--- incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/ConnectionException.hpp (original)
+++ incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/ConnectionException.hpp Wed Jul  5 15:36:36 2006
@@ -1,47 +1,47 @@
-/*
- * Copyright 2006 The Apache Software Foundation or its licensors, as
- * applicable.
- *
- * Licensed 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.
- */
-#ifndef ActiveMQ_ConnectionException_hpp_
-#define ActiveMQ_ConnectionException_hpp_
-
-#include "ppr/TraceException.hpp"
-
-namespace apache
-{
-  namespace activemq
-  {
-    using namespace std ;
-    using namespace apache::ppr;
-
-/*
- * Signals that a connection error has occured.
- */
-class ConnectionException : public TraceException
-{
-public:
-    ConnectionException() : TraceException()
-       { /* no-op */ } ;
-    ConnectionException(const char *const& msg) : TraceException(msg)
-       { /* no-op */ } ;
-    ConnectionException(const char* fileName, int lineNo, const char* msg) : TraceException(msg)
-       { /* no-op */ } ;
-} ;
-
-/* namespace */
-  }
-}
-
-#endif /*ActiveMQ_ConnectionException_hpp_*/
+/*
+ * Copyright 2006 The Apache Software Foundation or its licensors, as
+ * applicable.
+ *
+ * Licensed 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.
+ */
+#ifndef ActiveMQ_ConnectionException_hpp_
+#define ActiveMQ_ConnectionException_hpp_
+
+#include "ppr/TraceException.hpp"
+
+namespace apache
+{
+  namespace activemq
+  {
+    using namespace std ;
+    using namespace apache::ppr;
+
+/*
+ * Signals that a connection error has occured.
+ */
+class ConnectionException : public TraceException
+{
+public:
+    ConnectionException() : TraceException()
+       { /* no-op */ } ;
+    ConnectionException(const char *const& msg) : TraceException(msg)
+       { /* no-op */ } ;
+    ConnectionException(const char* fileName, int lineNo, const char* msg) : TraceException(msg)
+       { /* no-op */ } ;
+} ;
+
+/* namespace */
+  }
+}
+
+#endif /*ActiveMQ_ConnectionException_hpp_*/

Propchange: incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/ConnectionException.hpp
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/ConnectionFactory.hpp
URL: http://svn.apache.org/viewvc/incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/ConnectionFactory.hpp?rev=419371&r1=419370&r2=419371&view=diff
==============================================================================
--- incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/ConnectionFactory.hpp (original)
+++ incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/ConnectionFactory.hpp Wed Jul  5 15:36:36 2006
@@ -1,88 +1,88 @@
-/*
- * Copyright 2006 The Apache Software Foundation or its licensors, as
- * applicable.
- *
- * Licensed 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.
- */
-#ifndef ActiveMQ_ConnectionFactory_hpp_
-#define ActiveMQ_ConnectionFactory_hpp_
-
-// Must be included before any STL includes
-#include "ppr/util/Guid.hpp"
-
-#include <string>
-#include "cms/IConnection.hpp"
-#include "cms/IConnectionFactory.hpp"
-#include "activemq/ConnectionException.hpp"
-#include "activemq/command/ConnectionInfo.hpp"
-#include "activemq/command/ConnectionId.hpp"
-#include "activemq/protocol/IProtocol.hpp"
-#include "activemq/transport/ITransport.hpp"
-#include "activemq/transport/ITransportFactory.hpp"
-#include "activemq/transport/TransportFactory.hpp"
-#include "ppr/net/Uri.hpp"
-#include "ppr/util/ifr/p"
-
-namespace apache
-{
-  namespace activemq
-  {
-      using namespace apache::activemq::command;
-      using namespace apache::activemq::protocol;
-      using namespace apache::activemq::transport;
-      using namespace apache::ppr::net;
-      using namespace ifr;
-
-/*
- * 
- */
-class ConnectionFactory : public IConnectionFactory
-{
-private:
-    p<Uri>               brokerUri ;
-    p<string>            username ;
-    p<string>            password ;
-    p<string>            clientId ;
-    p<IProtocol>         protocol ;
-    p<ITransportFactory> transportFactory ;
-
-public:
-    // Constructors
-    ConnectionFactory() ;
-    ConnectionFactory(p<Uri> uri) ;
-
-    // Attribute methods
-    virtual p<Uri> getBrokerUri() ;
-    virtual void setBrokerUri(p<Uri> brokerUri) ;
-    virtual p<string> getUsername() ;
-    virtual void setUsername(const char* username) ;
-    virtual p<string> getPassword() ;
-    virtual void setPassword(const char* password) ;
-    virtual p<string> getClientId() ;
-    virtual void setClientId(const char* clientId) ;
-
-    // Operation methods
-    virtual p<IConnection> createConnection() throw (ConnectionException) ;
-    virtual p<IConnection> createConnection(const char* username, const char* password) throw (ConnectionException) ;
-
-protected:
-    // Implementation methods
-    virtual p<ConnectionInfo> createConnectionInfo(const char* username, const char* password) ;
-    virtual p<ITransport> createTransport() throw (ConnectionException) ;
-} ;
-
-/* namespace */
-  }
-}
-
-#endif /*ActiveMQ_ConnectionFactory_hpp_*/
+/*
+ * Copyright 2006 The Apache Software Foundation or its licensors, as
+ * applicable.
+ *
+ * Licensed 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.
+ */
+#ifndef ActiveMQ_ConnectionFactory_hpp_
+#define ActiveMQ_ConnectionFactory_hpp_
+
+// Must be included before any STL includes
+#include "ppr/util/Guid.hpp"
+
+#include <string>
+#include "cms/IConnection.hpp"
+#include "cms/IConnectionFactory.hpp"
+#include "activemq/ConnectionException.hpp"
+#include "activemq/command/ConnectionInfo.hpp"
+#include "activemq/command/ConnectionId.hpp"
+#include "activemq/protocol/IProtocol.hpp"
+#include "activemq/transport/ITransport.hpp"
+#include "activemq/transport/ITransportFactory.hpp"
+#include "activemq/transport/TransportFactory.hpp"
+#include "ppr/net/Uri.hpp"
+#include "ppr/util/ifr/p"
+
+namespace apache
+{
+  namespace activemq
+  {
+      using namespace apache::activemq::command;
+      using namespace apache::activemq::protocol;
+      using namespace apache::activemq::transport;
+      using namespace apache::ppr::net;
+      using namespace ifr;
+
+/*
+ * 
+ */
+class ConnectionFactory : public IConnectionFactory
+{
+private:
+    p<Uri>               brokerUri ;
+    p<string>            username ;
+    p<string>            password ;
+    p<string>            clientId ;
+    p<IProtocol>         protocol ;
+    p<ITransportFactory> transportFactory ;
+
+public:
+    // Constructors
+    ConnectionFactory() ;
+    ConnectionFactory(p<Uri> uri) ;
+
+    // Attribute methods
+    virtual p<Uri> getBrokerUri() ;
+    virtual void setBrokerUri(p<Uri> brokerUri) ;
+    virtual p<string> getUsername() ;
+    virtual void setUsername(const char* username) ;
+    virtual p<string> getPassword() ;
+    virtual void setPassword(const char* password) ;
+    virtual p<string> getClientId() ;
+    virtual void setClientId(const char* clientId) ;
+
+    // Operation methods
+    virtual p<IConnection> createConnection() throw (ConnectionException) ;
+    virtual p<IConnection> createConnection(const char* username, const char* password) throw (ConnectionException) ;
+
+protected:
+    // Implementation methods
+    virtual p<ConnectionInfo> createConnectionInfo(const char* username, const char* password) ;
+    virtual p<ITransport> createTransport() throw (ConnectionException) ;
+} ;
+
+/* namespace */
+  }
+}
+
+#endif /*ActiveMQ_ConnectionFactory_hpp_*/

Propchange: incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/ConnectionFactory.hpp
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/ConsumerClosedException.hpp
URL: http://svn.apache.org/viewvc/incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/ConsumerClosedException.hpp?rev=419371&r1=419370&r2=419371&view=diff
==============================================================================
--- incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/ConsumerClosedException.hpp (original)
+++ incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/ConsumerClosedException.hpp Wed Jul  5 15:36:36 2006
@@ -1,41 +1,41 @@
-/*
- * Copyright 2006 The Apache Software Foundation or its licensors, as
- * applicable.
- *
- * Licensed 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.
- */
-#ifndef ActiveMQ_ConsumerClosedException_hpp_
-#define ActiveMQ_ConsumerClosedException_hpp_
-
-#include "cms/CmsException.hpp"
-
-namespace apache
-{
-  namespace activemq
-  {
-      using namespace apache::cms;
-
-/*
- * Signals that a consumer is being used when it is already closed.
- */
-class ConsumerClosedException : public CmsException
-{
-public:
-    ConsumerClosedException(const char* message) ;
-};
-
-/* namespace */
-  }
-}
-
-#endif /*ActiveMQ_ConsumerClosedException_hpp_*/
+/*
+ * Copyright 2006 The Apache Software Foundation or its licensors, as
+ * applicable.
+ *
+ * Licensed 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.
+ */
+#ifndef ActiveMQ_ConsumerClosedException_hpp_
+#define ActiveMQ_ConsumerClosedException_hpp_
+
+#include "cms/CmsException.hpp"
+
+namespace apache
+{
+  namespace activemq
+  {
+      using namespace apache::cms;
+
+/*
+ * Signals that a consumer is being used when it is already closed.
+ */
+class ConsumerClosedException : public CmsException
+{
+public:
+    ConsumerClosedException(const char* message) ;
+};
+
+/* namespace */
+  }
+}
+
+#endif /*ActiveMQ_ConsumerClosedException_hpp_*/

Propchange: incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/ConsumerClosedException.hpp
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/DestinationFilter.hpp
URL: http://svn.apache.org/viewvc/incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/DestinationFilter.hpp?rev=419371&r1=419370&r2=419371&view=diff
==============================================================================
--- incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/DestinationFilter.hpp (original)
+++ incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/DestinationFilter.hpp Wed Jul  5 15:36:36 2006
@@ -1,52 +1,52 @@
-/*
- * Copyright 2006 The Apache Software Foundation or its licensors, as
- * applicable.
- *
- * Licensed 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.
- */
-#ifndef ActiveMQ_DestinationFilter_hpp_
-#define ActiveMQ_DestinationFilter_hpp_
-
-#include "activemq/command/ActiveMQMessage.hpp"
-#include "activemq/command/ActiveMQDestination.hpp"
-#include "ppr/util/ifr/p"
-
-namespace apache
-{
-  namespace activemq
-  {
-    using namespace ifr;
-    using namespace apache::activemq::command;
-
-/*
- * 
- */
-class DestinationFilter
-{
-public:
-    const static char* ANY_DESCENDENT ;
-    const static char* ANY_CHILD ;
-
-public:
-    DestinationFilter() ;
-    virtual ~DestinationFilter() ;
-
-    virtual bool matches(p<ActiveMQMessage> message) ;
-    virtual bool matches(p<ActiveMQDestination> destination) = 0 ;
-};
-
-/* namespace */
-  }
-}
-
-#endif /*ActiveMQ_DestinationFilter_hpp_*/
+/*
+ * Copyright 2006 The Apache Software Foundation or its licensors, as
+ * applicable.
+ *
+ * Licensed 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.
+ */
+#ifndef ActiveMQ_DestinationFilter_hpp_
+#define ActiveMQ_DestinationFilter_hpp_
+
+#include "activemq/command/ActiveMQMessage.hpp"
+#include "activemq/command/ActiveMQDestination.hpp"
+#include "ppr/util/ifr/p"
+
+namespace apache
+{
+  namespace activemq
+  {
+    using namespace ifr;
+    using namespace apache::activemq::command;
+
+/*
+ * 
+ */
+class DestinationFilter
+{
+public:
+    const static char* ANY_DESCENDENT ;
+    const static char* ANY_CHILD ;
+
+public:
+    DestinationFilter() ;
+    virtual ~DestinationFilter() ;
+
+    virtual bool matches(p<ActiveMQMessage> message) ;
+    virtual bool matches(p<ActiveMQDestination> destination) = 0 ;
+};
+
+/* namespace */
+  }
+}
+
+#endif /*ActiveMQ_DestinationFilter_hpp_*/

Propchange: incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/DestinationFilter.hpp
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/Dispatcher.hpp
URL: http://svn.apache.org/viewvc/incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/Dispatcher.hpp?rev=419371&r1=419370&r2=419371&view=diff
==============================================================================
--- incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/Dispatcher.hpp (original)
+++ incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/Dispatcher.hpp Wed Jul  5 15:36:36 2006
@@ -1,65 +1,65 @@
-/*
- * Copyright 2006 The Apache Software Foundation or its licensors, as
- * applicable.
- *
- * Licensed 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.
- */
-#ifndef ActiveMQ_Dispatcher_hpp_
-#define ActiveMQ_Dispatcher_hpp_
-
-#include <string>
-#include <list>
-#include <queue>
-#include "cms/IMessage.hpp"
-#include "activemq/command/Response.hpp"
-#include "ppr/thread/SimpleMutex.hpp"
-#include "ppr/thread/Semaphore.hpp"
-#include "ppr/util/ifr/p"
-
-namespace apache
-{
-  namespace activemq
-  {
-    using namespace ifr;
-    using namespace apache::activemq::command;
-    using namespace apache::cms;
-    using namespace apache::ppr::thread;
-
-/*
- * Handles the multi-threaded dispatching between transport and consumers.
- */
-class Dispatcher
-{
-private:
-    p<queue< p<IMessage> > > dispatchQueue ;
-    p<list< p<IMessage> > >  redeliverList ;
-    SimpleMutex              mutex ;
-    Semaphore                semaphore ;
-
-public:
-    Dispatcher() ;
-    virtual ~Dispatcher() {}
-
-    virtual void redeliverRolledBackMessages() ;
-    virtual void redeliver(p<IMessage> message) ;
-    virtual void enqueue(p<IMessage> message) ;
-    virtual p<IMessage> dequeueNoWait() ;
-    virtual p<IMessage> dequeue(int timeout) ;
-    virtual p<IMessage> dequeue() ;
-} ;
-
-/* namespace */
-  }
-}
-
-#endif /*ActiveMQ_Dispatcher_hpp_*/
+/*
+ * Copyright 2006 The Apache Software Foundation or its licensors, as
+ * applicable.
+ *
+ * Licensed 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.
+ */
+#ifndef ActiveMQ_Dispatcher_hpp_
+#define ActiveMQ_Dispatcher_hpp_
+
+#include <string>
+#include <list>
+#include <queue>
+#include "cms/IMessage.hpp"
+#include "activemq/command/Response.hpp"
+#include "ppr/thread/SimpleMutex.hpp"
+#include "ppr/thread/Semaphore.hpp"
+#include "ppr/util/ifr/p"
+
+namespace apache
+{
+  namespace activemq
+  {
+    using namespace ifr;
+    using namespace apache::activemq::command;
+    using namespace apache::cms;
+    using namespace apache::ppr::thread;
+
+/*
+ * Handles the multi-threaded dispatching between transport and consumers.
+ */
+class Dispatcher
+{
+private:
+    p<queue< p<IMessage> > > dispatchQueue ;
+    p<list< p<IMessage> > >  redeliverList ;
+    SimpleMutex              mutex ;
+    Semaphore                semaphore ;
+
+public:
+    Dispatcher() ;
+    virtual ~Dispatcher() {}
+
+    virtual void redeliverRolledBackMessages() ;
+    virtual void redeliver(p<IMessage> message) ;
+    virtual void enqueue(p<IMessage> message) ;
+    virtual p<IMessage> dequeueNoWait() ;
+    virtual p<IMessage> dequeue(int timeout) ;
+    virtual p<IMessage> dequeue() ;
+} ;
+
+/* namespace */
+  }
+}
+
+#endif /*ActiveMQ_Dispatcher_hpp_*/

Propchange: incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/Dispatcher.hpp
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/IAcknowledger.hpp
URL: http://svn.apache.org/viewvc/incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/IAcknowledger.hpp?rev=419371&r1=419370&r2=419371&view=diff
==============================================================================
--- incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/IAcknowledger.hpp (original)
+++ incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/IAcknowledger.hpp Wed Jul  5 15:36:36 2006
@@ -1,45 +1,45 @@
-/*
- * Copyright 2006 The Apache Software Foundation or its licensors, as
- * applicable.
- *
- * Licensed 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.
- */
-#ifndef ActiveMQ_IAcknowledger_hpp_
-#define ActiveMQ_IAcknowledger_hpp_
-
-#include "ppr/util/ifr/p"
-
-namespace apache
-{
-  namespace activemq
-  {
-    namespace command
-    {
-        class ActiveMQMessage ;
-    }
-    using namespace ifr;
-    using namespace apache::activemq::command;
-
-/*
- * Interface for message acknowledgers.
- */
-struct IAcknowledger : Interface
-{
-    virtual void acknowledge(p<ActiveMQMessage> message) = 0 ;
-} ;
-
-/* namespace */
-  }
-}
-
-#endif /*ActiveMQ_IAcknowledger_hpp_*/
+/*
+ * Copyright 2006 The Apache Software Foundation or its licensors, as
+ * applicable.
+ *
+ * Licensed 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.
+ */
+#ifndef ActiveMQ_IAcknowledger_hpp_
+#define ActiveMQ_IAcknowledger_hpp_
+
+#include "ppr/util/ifr/p"
+
+namespace apache
+{
+  namespace activemq
+  {
+    namespace command
+    {
+        class ActiveMQMessage ;
+    }
+    using namespace ifr;
+    using namespace apache::activemq::command;
+
+/*
+ * Interface for message acknowledgers.
+ */
+struct IAcknowledger : Interface
+{
+    virtual void acknowledge(p<ActiveMQMessage> message) = 0 ;
+} ;
+
+/* namespace */
+  }
+}
+
+#endif /*ActiveMQ_IAcknowledger_hpp_*/

Propchange: incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/IAcknowledger.hpp
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/ICommand.hpp
URL: http://svn.apache.org/viewvc/incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/ICommand.hpp?rev=419371&r1=419370&r2=419371&view=diff
==============================================================================
--- incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/ICommand.hpp (original)
+++ incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/ICommand.hpp Wed Jul  5 15:36:36 2006
@@ -1,43 +1,43 @@
-/*
- * Copyright 2006 The Apache Software Foundation or its licensors, as
- * applicable.
- *
- * Licensed 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.
- */
-#ifndef ActiveMQ_ICommand_hpp_
-#define ActiveMQ_ICommand_hpp_
-
-#include "ppr/util/ifr/p"
-
-namespace apache
-{
-  namespace activemq
-  {
-    using namespace ifr;
-
-/*
- * An OpenWire command
- */
-struct ICommand : Interface
-{
-    virtual int getCommandId() = 0;
-    virtual void setCommandId(int value) = 0;
-    virtual bool getResponseRequired() = 0;
-    virtual void setResponseRequired(bool value) = 0;
-};
-
-/* namespace */
-  }
-}
-
-#endif /*ActiveMQ_ICommand_hpp_*/
+/*
+ * Copyright 2006 The Apache Software Foundation or its licensors, as
+ * applicable.
+ *
+ * Licensed 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.
+ */
+#ifndef ActiveMQ_ICommand_hpp_
+#define ActiveMQ_ICommand_hpp_
+
+#include "ppr/util/ifr/p"
+
+namespace apache
+{
+  namespace activemq
+  {
+    using namespace ifr;
+
+/*
+ * An OpenWire command
+ */
+struct ICommand : Interface
+{
+    virtual int getCommandId() = 0;
+    virtual void setCommandId(int value) = 0;
+    virtual bool getResponseRequired() = 0;
+    virtual void setResponseRequired(bool value) = 0;
+};
+
+/* namespace */
+  }
+}
+
+#endif /*ActiveMQ_ICommand_hpp_*/

Propchange: incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/ICommand.hpp
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/IDataStructure.hpp
URL: http://svn.apache.org/viewvc/incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/IDataStructure.hpp?rev=419371&r1=419370&r2=419371&view=diff
==============================================================================
--- incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/IDataStructure.hpp (original)
+++ incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/IDataStructure.hpp Wed Jul  5 15:36:36 2006
@@ -1,50 +1,50 @@
-/*
- * Copyright 2006 The Apache Software Foundation or its licensors, as
- * applicable.
- *
- * Licensed 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.
- */
-#ifndef ActiveMQ_IDataStructure_hpp_
-#define ActiveMQ_IDataStructure_hpp_
-
-#include "ppr/io/IOutputStream.hpp"
-#include "ppr/io/IInputStream.hpp"
-#include "ppr/util/ifr/p"
-
-namespace apache
-{
-  namespace activemq
-  {
-    namespace protocol
-    {
-      struct IMarshaller ;
-    }
-    using namespace ifr;
-    using namespace apache::activemq::protocol;
-    using namespace apache::ppr::io;
-
-/*
- * An OpenWire data structure.
- */
-struct IDataStructure : Interface
-{
-    virtual unsigned char getDataStructureType() = 0 ;
-    virtual int marshal(p<IMarshaller> marshaller, int mode, p<IOutputStream> writer) = 0 ;
-    virtual void unmarshal(p<IMarshaller> marshaller, int mode, p<IInputStream> reader) = 0 ;
-} ;
-
-/* namespace */
-  }
-}
-
-#endif /*ActiveMQ_IDataStructure_hpp_*/
+/*
+ * Copyright 2006 The Apache Software Foundation or its licensors, as
+ * applicable.
+ *
+ * Licensed 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.
+ */
+#ifndef ActiveMQ_IDataStructure_hpp_
+#define ActiveMQ_IDataStructure_hpp_
+
+#include "ppr/io/IOutputStream.hpp"
+#include "ppr/io/IInputStream.hpp"
+#include "ppr/util/ifr/p"
+
+namespace apache
+{
+  namespace activemq
+  {
+    namespace protocol
+    {
+      struct IMarshaller ;
+    }
+    using namespace ifr;
+    using namespace apache::activemq::protocol;
+    using namespace apache::ppr::io;
+
+/*
+ * An OpenWire data structure.
+ */
+struct IDataStructure : Interface
+{
+    virtual unsigned char getDataStructureType() = 0 ;
+    virtual int marshal(p<IMarshaller> marshaller, int mode, p<IOutputStream> writer) = 0 ;
+    virtual void unmarshal(p<IMarshaller> marshaller, int mode, p<IInputStream> reader) = 0 ;
+} ;
+
+/* namespace */
+  }
+}
+
+#endif /*ActiveMQ_IDataStructure_hpp_*/

Propchange: incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/IDataStructure.hpp
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/ISynchronization.hpp
URL: http://svn.apache.org/viewvc/incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/ISynchronization.hpp?rev=419371&r1=419370&r2=419371&view=diff
==============================================================================
--- incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/ISynchronization.hpp (original)
+++ incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/ISynchronization.hpp Wed Jul  5 15:36:36 2006
@@ -1,47 +1,47 @@
-/*
- * Copyright 2006 The Apache Software Foundation or its licensors, as
- * applicable.
- *
- * Licensed 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.
- */
-#ifndef ActiveMQ_ISynchronization_hpp_
-#define ActiveMQ_ISynchronization_hpp_
-
-#include "ppr/util/ifr/p"
-
-namespace apache
-{
-  namespace activemq
-  {
-    using namespace ifr;
-
-/*
- * 
- */
-struct ISynchronization : Interface
-{
-    // Called before a commit
-    virtual void beforeCommit() = 0 ;
-    
-    // Called after a commit
-    virtual void afterCommit() = 0 ;
-    
-    // Called after a transaction rollback
-    virtual void afterRollback() = 0 ;
-} ;
-
-/* namespace */
-  }
-}
-
-#endif /*ActiveMQ_ISynchronization_hpp_*/
+/*
+ * Copyright 2006 The Apache Software Foundation or its licensors, as
+ * applicable.
+ *
+ * Licensed 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.
+ */
+#ifndef ActiveMQ_ISynchronization_hpp_
+#define ActiveMQ_ISynchronization_hpp_
+
+#include "ppr/util/ifr/p"
+
+namespace apache
+{
+  namespace activemq
+  {
+    using namespace ifr;
+
+/*
+ * 
+ */
+struct ISynchronization : Interface
+{
+    // Called before a commit
+    virtual void beforeCommit() = 0 ;
+    
+    // Called after a commit
+    virtual void afterCommit() = 0 ;
+    
+    // Called after a transaction rollback
+    virtual void afterRollback() = 0 ;
+} ;
+
+/* namespace */
+  }
+}
+
+#endif /*ActiveMQ_ISynchronization_hpp_*/

Propchange: incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/ISynchronization.hpp
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/MessageAckType.hpp
URL: http://svn.apache.org/viewvc/incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/MessageAckType.hpp?rev=419371&r1=419370&r2=419371&view=diff
==============================================================================
--- incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/MessageAckType.hpp (original)
+++ incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/MessageAckType.hpp Wed Jul  5 15:36:36 2006
@@ -1,33 +1,33 @@
-/*
- * Copyright 2006 The Apache Software Foundation or its licensors, as
- * applicable.
- *
- * Licensed 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.
- */
-#ifndef ActiveMQ_MessageAckType_hpp_
-#define ActiveMQ_MessageAckType_hpp_
-
-namespace apache
-{
-  namespace activemq
-  {
-    enum MessageAckType
-    {
-      DeliveredAck = 0,
-      PoisonAck    = 1,
-      ConsumedAck  = 2
-    } ;
-  }
-}
-
-#endif /*ActiveMQ_MessageAckType_hpp_*/
+/*
+ * Copyright 2006 The Apache Software Foundation or its licensors, as
+ * applicable.
+ *
+ * Licensed 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.
+ */
+#ifndef ActiveMQ_MessageAckType_hpp_
+#define ActiveMQ_MessageAckType_hpp_
+
+namespace apache
+{
+  namespace activemq
+  {
+    enum MessageAckType
+    {
+      DeliveredAck = 0,
+      PoisonAck    = 1,
+      ConsumedAck  = 2
+    } ;
+  }
+}
+
+#endif /*ActiveMQ_MessageAckType_hpp_*/

Propchange: incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/MessageAckType.hpp
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/MessageConsumer.hpp
URL: http://svn.apache.org/viewvc/incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/MessageConsumer.hpp?rev=419371&r1=419370&r2=419371&view=diff
==============================================================================
--- incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/MessageConsumer.hpp (original)
+++ incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/MessageConsumer.hpp Wed Jul  5 15:36:36 2006
@@ -1,102 +1,102 @@
-/*
- * Copyright 2006 The Apache Software Foundation or its licensors, as
- * applicable.
- *
- * Licensed 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.
- */
-#ifndef ActiveMQ_MessageConsumer_hpp_
-#define ActiveMQ_MessageConsumer_hpp_
-
-#include <string>
-#include "cms/IDestination.hpp"
-#include "cms/IMessage.hpp"
-#include "cms/IMessageConsumer.hpp"
-#include "cms/IMessageListener.hpp"
-#include "cms/CmsException.hpp"
-#include "activemq/AcknowledgementMode.hpp"
-#include "activemq/MessageAckType.hpp"
-#include "activemq/Dispatcher.hpp"
-#include "activemq/IAcknowledger.hpp"
-#include "activemq/MessageConsumerSynchronization.hpp"
-#include "activemq/ConnectionClosedException.hpp"
-#include "activemq/command/ConsumerInfo.hpp"
-#include "activemq/command/Message.hpp"
-#include "activemq/command/ActiveMQMessage.hpp"
-#include "activemq/command/MessageAck.hpp"
-#include "ppr/util/ifr/p"
-#include "ppr/thread/Thread.hpp"
-
-// Turn off warning message for ignored exception specification
-#ifdef _MSC_VER
-#pragma warning( disable : 4290 )
-#endif
-
-namespace apache
-{
-  namespace activemq
-  {
-      using namespace ifr;
-      using namespace apache::cms;
-      using namespace apache::ppr::thread;
-      class Session ;
-
-/*
- * 
- */
-class MessageConsumer : public IMessageConsumer, public IAcknowledger
-{
-private:
-    p<Session>          session ;
-    p<ConsumerInfo>     consumerInfo ;
-    p<Dispatcher>       dispatcher ;
-    p<IMessageListener> listener ;
-    AcknowledgementMode acknowledgementMode ;
-    bool                closed ;
-    int                 maximumRedeliveryCount,
-                        redeliveryTimeout ;
-
-public:
-    MessageConsumer(p<Session> session, p<ConsumerInfo> consumerInfo, AcknowledgementMode acknowledgementMode) ;
-    virtual ~MessageConsumer() ;
-
-    virtual void setMessageListener(p<IMessageListener> listener) ;
-    virtual p<IMessageListener> getMessageListener() ;
-    virtual p<ConsumerId> getConsumerId() ;
-    virtual void setMaximumRedeliveryCount(int count) ;
-    virtual int getMaximumRedeliveryCount() ;
-    virtual void setRedeliveryTimeout(int timeout) ;
-    virtual int getRedeliveryTimeout() ;
-
-    virtual p<IMessage> receive() ;
-    virtual p<IMessage> receive(int timeout) ;
-    virtual p<IMessage> receiveNoWait() ;
-    virtual void redeliverRolledBackMessages() ;
-    virtual void dispatch(p<IMessage> message) ;
-    virtual void dispatchAsyncMessages() ;
-    virtual void afterRollback(p<ActiveMQMessage> message) ;
-    virtual void acknowledge(p<ActiveMQMessage> message) ;
-    virtual void close() ;
-
-protected:
-    void checkClosed() throw(CmsException) ;
-    p<IMessage> autoAcknowledge(p<IMessage> message) ;
-    void doClientAcknowledge(p<ActiveMQMessage> message) ;
-    void doAcknowledge(p<Message> message) ;
-    p<MessageAck> createMessageAck(p<Message> message) ;
-} ;
-
-/* namespace */
-  }
-}
-
-#endif /*ActiveMQ_IMessageConsumer_hpp_*/
+/*
+ * Copyright 2006 The Apache Software Foundation or its licensors, as
+ * applicable.
+ *
+ * Licensed 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.
+ */
+#ifndef ActiveMQ_MessageConsumer_hpp_
+#define ActiveMQ_MessageConsumer_hpp_
+
+#include <string>
+#include "cms/IDestination.hpp"
+#include "cms/IMessage.hpp"
+#include "cms/IMessageConsumer.hpp"
+#include "cms/IMessageListener.hpp"
+#include "cms/CmsException.hpp"
+#include "activemq/AcknowledgementMode.hpp"
+#include "activemq/MessageAckType.hpp"
+#include "activemq/Dispatcher.hpp"
+#include "activemq/IAcknowledger.hpp"
+#include "activemq/MessageConsumerSynchronization.hpp"
+#include "activemq/ConnectionClosedException.hpp"
+#include "activemq/command/ConsumerInfo.hpp"
+#include "activemq/command/Message.hpp"
+#include "activemq/command/ActiveMQMessage.hpp"
+#include "activemq/command/MessageAck.hpp"
+#include "ppr/util/ifr/p"
+#include "ppr/thread/Thread.hpp"
+
+// Turn off warning message for ignored exception specification
+#ifdef _MSC_VER
+#pragma warning( disable : 4290 )
+#endif
+
+namespace apache
+{
+  namespace activemq
+  {
+      using namespace ifr;
+      using namespace apache::cms;
+      using namespace apache::ppr::thread;
+      class Session ;
+
+/*
+ * 
+ */
+class MessageConsumer : public IMessageConsumer, public IAcknowledger
+{
+private:
+    p<Session>          session ;
+    p<ConsumerInfo>     consumerInfo ;
+    p<Dispatcher>       dispatcher ;
+    p<IMessageListener> listener ;
+    AcknowledgementMode acknowledgementMode ;
+    bool                closed ;
+    int                 maximumRedeliveryCount,
+                        redeliveryTimeout ;
+
+public:
+    MessageConsumer(p<Session> session, p<ConsumerInfo> consumerInfo, AcknowledgementMode acknowledgementMode) ;
+    virtual ~MessageConsumer() ;
+
+    virtual void setMessageListener(p<IMessageListener> listener) ;
+    virtual p<IMessageListener> getMessageListener() ;
+    virtual p<ConsumerId> getConsumerId() ;
+    virtual void setMaximumRedeliveryCount(int count) ;
+    virtual int getMaximumRedeliveryCount() ;
+    virtual void setRedeliveryTimeout(int timeout) ;
+    virtual int getRedeliveryTimeout() ;
+
+    virtual p<IMessage> receive() ;
+    virtual p<IMessage> receive(int timeout) ;
+    virtual p<IMessage> receiveNoWait() ;
+    virtual void redeliverRolledBackMessages() ;
+    virtual void dispatch(p<IMessage> message) ;
+    virtual void dispatchAsyncMessages() ;
+    virtual void afterRollback(p<ActiveMQMessage> message) ;
+    virtual void acknowledge(p<ActiveMQMessage> message) ;
+    virtual void close() ;
+
+protected:
+    void checkClosed() throw(CmsException) ;
+    p<IMessage> autoAcknowledge(p<IMessage> message) ;
+    void doClientAcknowledge(p<ActiveMQMessage> message) ;
+    void doAcknowledge(p<Message> message) ;
+    p<MessageAck> createMessageAck(p<Message> message) ;
+} ;
+
+/* namespace */
+  }
+}
+
+#endif /*ActiveMQ_IMessageConsumer_hpp_*/

Propchange: incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/MessageConsumer.hpp
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/MessageConsumerSynchronization.hpp
URL: http://svn.apache.org/viewvc/incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/MessageConsumerSynchronization.hpp?rev=419371&r1=419370&r2=419371&view=diff
==============================================================================
--- incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/MessageConsumerSynchronization.hpp (original)
+++ incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/MessageConsumerSynchronization.hpp Wed Jul  5 15:36:36 2006
@@ -1,54 +1,54 @@
-/*
- * Copyright 2006 The Apache Software Foundation or its licensors, as
- * applicable.
- *
- * Licensed 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.
- */
-#ifndef ActiveMQ_MessageConsumerSynchronization_hpp_
-#define ActiveMQ_MessageConsumerSynchronization_hpp_
-
-#include "activemq/ISynchronization.hpp"
-#include "activemq/command/ActiveMQMessage.hpp"
-#include "activemq/command/Message.hpp"
-#include "ppr/util/ifr/p"
-
-namespace apache
-{
-  namespace activemq
-  {
-    using namespace ifr;
-    class MessageConsumer;
-
-/*
- * 
- */
-class MessageConsumerSynchronization : public ISynchronization
-{
-private:
-    p<MessageConsumer> consumer ;
-    p<Message>         message ;
-
-public:
-    MessageConsumerSynchronization(p<MessageConsumer> consumer, p<Message> message) ;
-    ~MessageConsumerSynchronization() ;
-
-    virtual void beforeCommit() ;
-    virtual void afterCommit() ;
-    virtual void afterRollback() ;
-} ;
-
-/* namespace */
-  }
-}
-
-#endif /*ActiveMQ_MessageConsumerSynchronization_hpp_*/
+/*
+ * Copyright 2006 The Apache Software Foundation or its licensors, as
+ * applicable.
+ *
+ * Licensed 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.
+ */
+#ifndef ActiveMQ_MessageConsumerSynchronization_hpp_
+#define ActiveMQ_MessageConsumerSynchronization_hpp_
+
+#include "activemq/ISynchronization.hpp"
+#include "activemq/command/ActiveMQMessage.hpp"
+#include "activemq/command/Message.hpp"
+#include "ppr/util/ifr/p"
+
+namespace apache
+{
+  namespace activemq
+  {
+    using namespace ifr;
+    class MessageConsumer;
+
+/*
+ * 
+ */
+class MessageConsumerSynchronization : public ISynchronization
+{
+private:
+    p<MessageConsumer> consumer ;
+    p<Message>         message ;
+
+public:
+    MessageConsumerSynchronization(p<MessageConsumer> consumer, p<Message> message) ;
+    ~MessageConsumerSynchronization() ;
+
+    virtual void beforeCommit() ;
+    virtual void afterCommit() ;
+    virtual void afterRollback() ;
+} ;
+
+/* namespace */
+  }
+}
+
+#endif /*ActiveMQ_MessageConsumerSynchronization_hpp_*/

Propchange: incubator/activemq/trunk/openwire-cpp/src/main/cpp/activemq/MessageConsumerSynchronization.hpp
------------------------------------------------------------------------------
    svn:eol-style = native