You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@qpid.apache.org by ac...@apache.org on 2009/02/25 23:53:44 UTC

svn commit: r747947 - in /qpid/trunk/qpid/cpp/src: qpid/cluster/Cluster.cpp qpid/cluster/Cluster.h tests/FrameDecoder.cpp tests/Makefile.am

Author: aconway
Date: Wed Feb 25 22:53:43 2009
New Revision: 747947

URL: http://svn.apache.org/viewvc?rev=747947&view=rev
Log:
Add FrameDecoder unit test, update comments in Cluster.h/cpp.

Added:
    qpid/trunk/qpid/cpp/src/tests/FrameDecoder.cpp   (with props)
Modified:
    qpid/trunk/qpid/cpp/src/qpid/cluster/Cluster.cpp
    qpid/trunk/qpid/cpp/src/qpid/cluster/Cluster.h
    qpid/trunk/qpid/cpp/src/tests/Makefile.am

Modified: qpid/trunk/qpid/cpp/src/qpid/cluster/Cluster.cpp
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/cpp/src/qpid/cluster/Cluster.cpp?rev=747947&r1=747946&r2=747947&view=diff
==============================================================================
--- qpid/trunk/qpid/cpp/src/qpid/cluster/Cluster.cpp (original)
+++ qpid/trunk/qpid/cpp/src/qpid/cluster/Cluster.cpp Wed Feb 25 22:53:43 2009
@@ -104,12 +104,12 @@
                       boost::bind(&Cluster::leave, this),
                       "Error delivering frames",
                       poller),
-    connections(*this),
     decoder(boost::bind(&PollableFrameQueue::push, &deliverFrameQueue, _1), connections),
     expiryPolicy(new ExpiryPolicy(boost::bind(&Cluster::isLeader, this), mcast, myId, broker.getTimer())),
     frameId(0),
     initialized(false),
     state(INIT),
+    connections(*this),
     lastSize(0),
     lastBroker(false),
     sequence(0)
@@ -161,7 +161,7 @@
 }
 
 void Cluster::erase(const ConnectionId& id) {
-    // Called only by Connection::deliverClose in deliver thread, no need to lock.
+    // Called only by Connection::deliverClose in deliver thread with lock held.
     connections.erase(id);
 }
 

Modified: qpid/trunk/qpid/cpp/src/qpid/cluster/Cluster.h
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/cpp/src/qpid/cluster/Cluster.h?rev=747947&r1=747946&r2=747947&view=diff
==============================================================================
--- qpid/trunk/qpid/cpp/src/qpid/cluster/Cluster.h (original)
+++ qpid/trunk/qpid/cpp/src/qpid/cluster/Cluster.h Wed Feb 25 22:53:43 2009
@@ -196,12 +196,13 @@
     PollerDispatch dispatcher;
     PollableEventQueue deliverEventQueue;
     PollableFrameQueue deliverFrameQueue;
-    ConnectionMap connections;
     boost::shared_ptr<FailoverExchange> failoverExchange;
     Quorum quorum;
 
-    // Used only in delivery thread
+    // Used only in deliverdEvent thread
     Decoder decoder;
+
+    // Used only in deliveredFrame thread
     ClusterMap::Set elders;
     boost::intrusive_ptr<ExpiryPolicy> expiryPolicy;
     uint64_t frameId;
@@ -223,6 +224,8 @@
         UPDATER, ///< Offer accepted, sending a state update.
         LEFT     ///< Final state, left the cluster.
     } state;
+
+    ConnectionMap connections;
     ClusterMap map;
     size_t lastSize;
     bool lastBroker;

Added: qpid/trunk/qpid/cpp/src/tests/FrameDecoder.cpp
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/cpp/src/tests/FrameDecoder.cpp?rev=747947&view=auto
==============================================================================
--- qpid/trunk/qpid/cpp/src/tests/FrameDecoder.cpp (added)
+++ qpid/trunk/qpid/cpp/src/tests/FrameDecoder.cpp Wed Feb 25 22:53:43 2009
@@ -0,0 +1,73 @@
+/*
+ *
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ * 
+ *   http://www.apache.org/licenses/LICENSE-2.0
+ * 
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ *
+ */
+
+#include "unit_test.h"
+#include "qpid/framing/AMQFrame.h"
+#include "qpid/framing/FrameDecoder.h"
+#include "qpid/framing/AMQContentBody.h"
+#include "qpid/framing/Buffer.h"
+#include <string>
+
+
+QPID_AUTO_TEST_SUITE(FrameDecoderTest)
+
+using namespace std;
+using namespace qpid::framing;
+
+
+string makeData(int size) {
+    string data;
+    data.resize(size);
+    for (int i =0; i < size; ++i)
+        data[i] = 'a' + (i%26);
+    return data;
+}
+string encodeFrame(string data) {
+    AMQFrame f((AMQContentBody(data)));
+    string encoded;
+    encoded.resize(f.encodedSize());
+    Buffer b(&encoded[0], encoded.size());
+    f.encode(b);
+    return encoded;
+}
+
+string getData(const AMQFrame& frame) {
+    const AMQContentBody* content = dynamic_cast<const AMQContentBody*>(frame.getBody());
+    BOOST_CHECK(content);
+    return content->getData();
+}
+
+QPID_AUTO_TEST_CASE(testByteFragments) {
+    string data = makeData(42);
+    string encoded = encodeFrame(data);
+    FrameDecoder decoder;
+    for (size_t i = 0; i < encoded.size()-1; ++i) {
+        Buffer buf(&encoded[i], 1);
+        BOOST_CHECK(!decoder.decode(buf));
+    }
+    Buffer buf(&encoded[encoded.size()-1], 1);
+    BOOST_CHECK(decoder.decode(buf));
+    BOOST_CHECK_EQUAL(data, getData(decoder.frame));
+}
+
+
+                    
+QPID_AUTO_TEST_SUITE_END()

Propchange: qpid/trunk/qpid/cpp/src/tests/FrameDecoder.cpp
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: qpid/trunk/qpid/cpp/src/tests/FrameDecoder.cpp
------------------------------------------------------------------------------
    svn:keywords = Rev Date

Modified: qpid/trunk/qpid/cpp/src/tests/Makefile.am
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/cpp/src/tests/Makefile.am?rev=747947&r1=747946&r2=747947&view=diff
==============================================================================
--- qpid/trunk/qpid/cpp/src/tests/Makefile.am (original)
+++ qpid/trunk/qpid/cpp/src/tests/Makefile.am Wed Feb 25 22:53:43 2009
@@ -94,7 +94,8 @@
 	QueueEvents.cpp \
 	ProxyTest.cpp \
 	RetryList.cpp \
-	RateFlowcontrolTest.cpp
+	RateFlowcontrolTest.cpp \
+	FrameDecoder.cpp
 
 if HAVE_XML
 unit_test_SOURCES+= XmlClientSessionTest.cpp



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