You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@qpid.apache.org by gs...@apache.org on 2010/03/12 09:20:48 UTC

svn commit: r922175 - in /qpid/trunk/qpid/cpp: include/qpid/client/amqp0_10/FailoverUpdates.h src/qpid/client/amqp0_10/FailoverUpdates.cpp src/qpid/client/amqp0_10/SimpleUrlParser.cpp src/qpid/client/amqp0_10/SimpleUrlParser.h

Author: gsim
Date: Fri Mar 12 08:20:48 2010
New Revision: 922175

URL: http://svn.apache.org/viewvc?rev=922175&view=rev
Log:
QPID-2382: Checked in missing files from last commit

Added:
    qpid/trunk/qpid/cpp/include/qpid/client/amqp0_10/FailoverUpdates.h
    qpid/trunk/qpid/cpp/src/qpid/client/amqp0_10/FailoverUpdates.cpp
    qpid/trunk/qpid/cpp/src/qpid/client/amqp0_10/SimpleUrlParser.cpp
    qpid/trunk/qpid/cpp/src/qpid/client/amqp0_10/SimpleUrlParser.h

Added: qpid/trunk/qpid/cpp/include/qpid/client/amqp0_10/FailoverUpdates.h
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/cpp/include/qpid/client/amqp0_10/FailoverUpdates.h?rev=922175&view=auto
==============================================================================
--- qpid/trunk/qpid/cpp/include/qpid/client/amqp0_10/FailoverUpdates.h (added)
+++ qpid/trunk/qpid/cpp/include/qpid/client/amqp0_10/FailoverUpdates.h Fri Mar 12 08:20:48 2010
@@ -0,0 +1,53 @@
+#ifndef QPID_CLIENT_AMQP0_10_FAILOVERUPDATES_H
+#define QPID_CLIENT_AMQP0_10_FAILOVERUPDATES_H
+
+/*
+ *
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ * 
+ *   http://www.apache.org/licenses/LICENSE-2.0
+ * 
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ *
+ */
+namespace qpid {
+
+namespace messaging {
+class Connection;
+}
+
+namespace client {
+namespace amqp0_10 {
+
+struct FailoverUpdatesImpl;
+/**
+ * A utility to listen for updates on cluster membership - published
+ * via the amq.failover exchange - and update the list of known urls
+ * for a connection accordingly.
+ */
+class FailoverUpdates
+{
+  public:
+    FailoverUpdates(qpid::messaging::Connection& connection);
+    ~FailoverUpdates();
+  private:
+    FailoverUpdatesImpl* impl;
+
+    //no need to copy instances of this class
+    FailoverUpdates(const FailoverUpdates&);
+    FailoverUpdates& operator=(const FailoverUpdates&);
+};
+}}} // namespace qpid::client::amqp0_10
+
+#endif  /*!QPID_CLIENT_AMQP0_10_FAILOVERUPDATES_H*/

Added: qpid/trunk/qpid/cpp/src/qpid/client/amqp0_10/FailoverUpdates.cpp
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/cpp/src/qpid/client/amqp0_10/FailoverUpdates.cpp?rev=922175&view=auto
==============================================================================
--- qpid/trunk/qpid/cpp/src/qpid/client/amqp0_10/FailoverUpdates.cpp (added)
+++ qpid/trunk/qpid/cpp/src/qpid/client/amqp0_10/FailoverUpdates.cpp Fri Mar 12 08:20:48 2010
@@ -0,0 +1,84 @@
+/*
+ *
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ * 
+ *   http://www.apache.org/licenses/LICENSE-2.0
+ * 
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ *
+ */
+#include "qpid/client/amqp0_10/FailoverUpdates.h"
+#include "qpid/messaging/Connection.h"
+#include "qpid/messaging/Message.h"
+#include "qpid/messaging/Receiver.h"
+#include "qpid/messaging/Session.h"
+#include "qpid/sys/Runnable.h"
+#include "qpid/sys/Thread.h"
+#include "qpid/log/Statement.h"
+#include "qpid/Exception.h"
+#include "qpid/Url.h"
+#include <vector>
+
+namespace qpid {
+namespace client {
+namespace amqp0_10 {
+
+using namespace qpid::messaging;
+
+struct FailoverUpdatesImpl : qpid::sys::Runnable
+{
+    Connection connection;
+    Session session;
+    Receiver receiver;
+    qpid::sys::Thread thread;
+    volatile bool quit;
+
+    FailoverUpdatesImpl(Connection& c) : connection(c), quit(false)
+    {
+        session = connection.newSession("failover-updates");
+        receiver = session.createReceiver("amq.failover");
+        thread = qpid::sys::Thread(*this);
+    }
+
+    void run()
+    {
+        try {
+            Message message;
+            while (!quit && receiver.fetch(message)) {
+                connection.setOption("urls", message.getHeaders()["amq.failover"]);
+                session.acknowledge();
+            }
+        } catch (const qpid::TransportFailure& e) {
+            QPID_LOG(warning, "Failover updates stopped on loss of connection. " << e.what());
+        } catch (const std::exception& e) {
+            QPID_LOG(warning, "Failover updates stopped due to exception: " << e.what());
+        }
+        receiver.close();
+        session.close();
+    }
+
+    void wait()
+    {
+        quit = true;
+        thread.join();
+    }
+};
+
+FailoverUpdates::FailoverUpdates(Connection& connection) : impl(new FailoverUpdatesImpl(connection)) {}
+FailoverUpdates::~FailoverUpdates() { if (impl) { impl->wait(); delete impl; } }
+FailoverUpdates::FailoverUpdates(const FailoverUpdates&) : impl(0) {}
+FailoverUpdates& FailoverUpdates::operator=(const FailoverUpdates&) { return *this; }
+
+
+}}} // namespace qpid::client::amqp0_10

Added: qpid/trunk/qpid/cpp/src/qpid/client/amqp0_10/SimpleUrlParser.cpp
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/cpp/src/qpid/client/amqp0_10/SimpleUrlParser.cpp?rev=922175&view=auto
==============================================================================
--- qpid/trunk/qpid/cpp/src/qpid/client/amqp0_10/SimpleUrlParser.cpp (added)
+++ qpid/trunk/qpid/cpp/src/qpid/client/amqp0_10/SimpleUrlParser.cpp Fri Mar 12 08:20:48 2010
@@ -0,0 +1,79 @@
+/*
+ *
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ * 
+ *   http://www.apache.org/licenses/LICENSE-2.0
+ * 
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ *
+ */
+#include "SimpleUrlParser.h"
+#include "qpid/client/ConnectionSettings.h"
+#include "qpid/Exception.h"
+#include <boost/lexical_cast.hpp>
+
+namespace qpid {
+namespace client {
+namespace amqp0_10 {
+
+bool split(const std::string& in, char delim, std::pair<std::string, std::string>& result)
+{
+    std::string::size_type i = in.find(delim);
+    if (i != std::string::npos) {
+        result.first = in.substr(0, i);
+        if (i+1 < in.size()) {
+            result.second = in.substr(i+1);
+        }
+        return true;
+    } else {
+        return false;
+    }
+}
+
+void parseUsernameAndPassword(const std::string& in, qpid::client::ConnectionSettings& result)
+{
+    std::pair<std::string, std::string> parts;
+    if (!split(in, '/', parts)) {
+        result.username = in;
+    } else {
+        result.username = parts.first;
+        result.password = parts.second;
+    }
+}
+
+void parseHostAndPort(const std::string& in, qpid::client::ConnectionSettings& result)
+{
+    std::pair<std::string, std::string> parts;
+    if (!split(in, ':', parts)) {
+        result.host = in;
+    } else {
+        result.host = parts.first;
+        if (parts.second.size()) {
+            result.port = boost::lexical_cast<uint16_t>(parts.second);
+        }
+    }
+}
+
+void SimpleUrlParser::parse(const std::string& url, qpid::client::ConnectionSettings& result)
+{
+    std::pair<std::string, std::string> parts;
+    if (!split(url, '@', parts)) {
+        parseHostAndPort(url, result);
+    } else {
+        parseUsernameAndPassword(parts.first, result);
+        parseHostAndPort(parts.second, result);
+    }
+}
+
+}}} // namespace qpid::client::amqp0_10

Added: qpid/trunk/qpid/cpp/src/qpid/client/amqp0_10/SimpleUrlParser.h
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/cpp/src/qpid/client/amqp0_10/SimpleUrlParser.h?rev=922175&view=auto
==============================================================================
--- qpid/trunk/qpid/cpp/src/qpid/client/amqp0_10/SimpleUrlParser.h (added)
+++ qpid/trunk/qpid/cpp/src/qpid/client/amqp0_10/SimpleUrlParser.h Fri Mar 12 08:20:48 2010
@@ -0,0 +1,42 @@
+#ifndef QPID_CLIENT_AMQP0_10_SIMPLEURLPARSER_H
+#define QPID_CLIENT_AMQP0_10_SIMPLEURLPARSER_H
+
+/*
+ *
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ * 
+ *   http://www.apache.org/licenses/LICENSE-2.0
+ * 
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ *
+ */
+#include <string>
+
+namespace qpid {
+namespace client {
+
+struct ConnectionSettings;
+
+namespace amqp0_10 {
+
+/**
+ * Parses a simple url of the form user/password@hostname:port
+ */
+struct SimpleUrlParser
+{
+    static void parse(const std::string& url, qpid::client::ConnectionSettings& result);
+};
+}}} // namespace qpid::client::amqp0_10
+
+#endif  /*!QPID_CLIENT_AMQP0_10_SIMPLEURLPARSER_H*/



---------------------------------------------------------------------
Apache Qpid - AMQP Messaging Implementation
Project:      http://qpid.apache.org
Use/Interact: mailto:commits-subscribe@qpid.apache.org