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 2011/10/12 21:55:27 UTC

svn commit: r1182557 - in /qpid/branches/qpid-2920-active/qpid/cpp: examples/old_api/failover/ include/qpid/client/ rubygen/ rubygen/framing.0-10/ src/qpid/ src/qpid/amqp_0_10/ src/qpid/broker/ src/qpid/client/ src/qpid/cluster/ src/qpid/cluster/exp/ s...

Author: aconway
Date: Wed Oct 12 19:55:26 2011
New Revision: 1182557

URL: http://svn.apache.org/viewvc?rev=1182557&view=rev
Log:
QPID-2920: Clean up out-dated FIXME comments.

Modified:
    qpid/branches/qpid-2920-active/qpid/cpp/examples/old_api/failover/Makefile.am
    qpid/branches/qpid-2920-active/qpid/cpp/include/qpid/client/Handle.h
    qpid/branches/qpid-2920-active/qpid/cpp/include/qpid/client/Message.h
    qpid/branches/qpid-2920-active/qpid/cpp/rubygen/amqpgen.rb
    qpid/branches/qpid-2920-active/qpid/cpp/rubygen/framing.0-10/Session.rb
    qpid/branches/qpid-2920-active/qpid/cpp/rubygen/framing.0-10/constants.rb
    qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/Serializer.h
    qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/amqp_0_10/Array.h
    qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/amqp_0_10/Codec.h
    qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/amqp_0_10/Connection.h
    qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/amqp_0_10/Exception.h
    qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/amqp_0_10/Map.cpp
    qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/amqp_0_10/Map.h
    qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/amqp_0_10/Packer.h
    qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/amqp_0_10/Struct32.cpp
    qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/amqp_0_10/Unit.cpp
    qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/amqp_0_10/built_in_types.h
    qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/broker/SemanticState.cpp
    qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/broker/SessionAdapter.cpp
    qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/broker/SessionManager.cpp
    qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/client/ConnectionImpl.cpp
    qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/client/PrivateImplRef.h
    qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/cluster/Connection.cpp
    qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/cluster/Cpg.cpp
    qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/cluster/exp/BrokerContext.cpp
    qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/cluster/exp/Core.cpp
    qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/cluster/exp/CountdownTimer.h
    qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/cluster/exp/EventHandler.cpp
    qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/cluster/exp/QueueContext.cpp
    qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/cluster/exp/QueueContext.h
    qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/cluster/exp/QueueHandler.cpp
    qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/cluster/exp/WiringHandler.cpp
    qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/cluster/exp/hash.h
    qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/framing/Array.cpp
    qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/sys/Activity.h
    qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/sys/AsynchIOHandler.cpp
    qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/sys/PollableQueue.h
    qpid/branches/qpid-2920-active/qpid/cpp/src/tests/PartialFailure.cpp
    qpid/branches/qpid-2920-active/qpid/cpp/src/tests/ReplicationTest.cpp
    qpid/branches/qpid-2920-active/qpid/cpp/src/tests/amqp_0_10/serialize.cpp
    qpid/branches/qpid-2920-active/qpid/cpp/src/tests/cluster2_tests.py
    qpid/branches/qpid-2920-active/qpid/cpp/src/tests/exception_test.cpp
    qpid/branches/qpid-2920-active/qpid/cpp/src/tests/topictest
    qpid/branches/qpid-2920-active/qpid/cpp/src/tests/topictest.ps1

Modified: qpid/branches/qpid-2920-active/qpid/cpp/examples/old_api/failover/Makefile.am
URL: http://svn.apache.org/viewvc/qpid/branches/qpid-2920-active/qpid/cpp/examples/old_api/failover/Makefile.am?rev=1182557&r1=1182556&r2=1182557&view=diff
==============================================================================
--- qpid/branches/qpid-2920-active/qpid/cpp/examples/old_api/failover/Makefile.am (original)
+++ qpid/branches/qpid-2920-active/qpid/cpp/examples/old_api/failover/Makefile.am Wed Oct 12 19:55:26 2011
@@ -38,8 +38,6 @@ examples_DATA=                \
 	replaying_sender.cpp  \
         $(MAKEDIST)
 
-# FIXME aconway 2008-10-10: add verify scripts.
-
 EXTRA_DIST=	             \
 	CMakeLists.txt       \
 	failover_declare_queues.vcproj \

Modified: qpid/branches/qpid-2920-active/qpid/cpp/include/qpid/client/Handle.h
URL: http://svn.apache.org/viewvc/qpid/branches/qpid-2920-active/qpid/cpp/include/qpid/client/Handle.h?rev=1182557&r1=1182556&r2=1182557&view=diff
==============================================================================
--- qpid/branches/qpid-2920-active/qpid/cpp/include/qpid/client/Handle.h (original)
+++ qpid/branches/qpid-2920-active/qpid/cpp/include/qpid/client/Handle.h Wed Oct 12 19:55:26 2011
@@ -63,7 +63,7 @@ template <class T> class Handle {
 
     Impl* impl;
 
-  friend class PrivateImplRef<T>; // FIXME aconway 2009-04-30: Specify
+  friend class PrivateImplRef<T>; 
 };
 
 }} // namespace qpid::client

Modified: qpid/branches/qpid-2920-active/qpid/cpp/include/qpid/client/Message.h
URL: http://svn.apache.org/viewvc/qpid/branches/qpid-2920-active/qpid/cpp/include/qpid/client/Message.h?rev=1182557&r1=1182556&r2=1182557&view=diff
==============================================================================
--- qpid/branches/qpid-2920-active/qpid/cpp/include/qpid/client/Message.h (original)
+++ qpid/branches/qpid-2920-active/qpid/cpp/include/qpid/client/Message.h Wed Oct 12 19:55:26 2011
@@ -31,7 +31,7 @@ namespace qpid {
 
 namespace framing {
 class FieldTable;
-class SequenceNumber;           // FIXME aconway 2009-04-17: remove with getID?
+class SequenceNumber;
 }
 
 namespace client {
@@ -161,7 +161,6 @@ public:
     /** Get a non-modifyable reference to the message headers. */
     QPID_CLIENT_EXTERN const framing::FieldTable& getHeaders() const;
 
-    // FIXME aconway 2009-04-17: does this need to be in public API?
     ///@internal
     QPID_CLIENT_EXTERN const framing::SequenceNumber& getId() const;
 

Modified: qpid/branches/qpid-2920-active/qpid/cpp/rubygen/amqpgen.rb
URL: http://svn.apache.org/viewvc/qpid/branches/qpid-2920-active/qpid/cpp/rubygen/amqpgen.rb?rev=1182557&r1=1182556&r2=1182557&view=diff
==============================================================================
--- qpid/branches/qpid-2920-active/qpid/cpp/rubygen/amqpgen.rb (original)
+++ qpid/branches/qpid-2920-active/qpid/cpp/rubygen/amqpgen.rb Wed Oct 12 19:55:26 2011
@@ -394,12 +394,10 @@ class AmqpClass < AmqpElement
     @methods_on[chassis] ||= methods_.select { |m| m.on_chassis? chassis }
   end
 
-  # FIXME aconway 2008-04-11: 
   def l4?()                     # preview
     !["connection", "session", "execution"].include?(name) && !control?
   end
 
-  # FIXME aconway 2008-04-11: 
   def control?()
     ["connection", "session"].include?(name)
   end

Modified: qpid/branches/qpid-2920-active/qpid/cpp/rubygen/framing.0-10/Session.rb
URL: http://svn.apache.org/viewvc/qpid/branches/qpid-2920-active/qpid/cpp/rubygen/framing.0-10/Session.rb?rev=1182557&r1=1182556&r2=1182557&view=diff
==============================================================================
--- qpid/branches/qpid-2920-active/qpid/cpp/rubygen/framing.0-10/Session.rb (original)
+++ qpid/branches/qpid-2920-active/qpid/cpp/rubygen/framing.0-10/Session.rb Wed Oct 12 19:55:26 2011
@@ -18,7 +18,7 @@
 # under the License.
 #
 # Usage: output_directory xml_spec_file [xml_spec_file...]
-# 
+#
 $: << '..'
 require 'cppgen'
 
@@ -31,7 +31,7 @@ class CppGen
     gen_methods.each { |m| m.set_sync_default(sync_default) }
   end
 
-  
+
   # Generates a doxygen comment for AmqpMethod m.
   def doxygen(m)
     doxygen_comment {
@@ -125,7 +125,7 @@ end
 
 class SessionNoKeywordGen < CppGen
   include SyncAsync
-  
+
   def initialize(outdir, amqp, async)
     super(outdir, amqp)
     @async=async
@@ -140,11 +140,10 @@ class SessionNoKeywordGen < CppGen
     h_file(@file) {
       include "qpid/client/#{@version_base}.h"
       include "qpid/client/ClientImportExport.h"
-      namespace(@namespace) { 
+      namespace(@namespace) {
         doxygen_comment {
           genl "AMQP #{@amqp.version} #{sync_adjective} session API."
           genl @amqp.class_("session").doc
-          # FIXME aconway 2008-05-23: additional doc on sync/async use.
         }
         cpp_class(@classname, "public #{@version_base}") {
           public
@@ -152,13 +151,13 @@ class SessionNoKeywordGen < CppGen
           session_methods(sync_default).each { |m|
             genl
             doxygen(m)
-            args=m.sig_c_default.join(", ") 
-            genl "QPID_CLIENT_EXTERN #{m.return_type(@async)} #{m.session_function}(#{args});" 
+            args=m.sig_c_default.join(", ")
+            genl "QPID_CLIENT_EXTERN #{m.return_type(@async)} #{m.session_function}(#{args});"
           }
         }
       }}
 
-    cpp_file(@file) { 
+    cpp_file(@file) {
       include "qpid/client/#{@classname}"
       include "qpid/framing/all_method_bodies.h"
       include "qpid/client/SessionImpl.h"
@@ -228,11 +227,11 @@ class SessionGen < CppGen
       # Generate keyword tag declarations.
       genl "#define BOOST_PARAMETER_MAX_ARITY #{max_arity}"
       include "<boost/parameter.hpp>"
-      namespace("qpid::client::arg") { 
+      namespace("qpid::client::arg") {
         keyword_methods.map{ |m| m.param_names_c }.flatten.uniq.each { |k|
           genl "BOOST_PARAMETER_KEYWORD(keyword_tags, #{k})"
         }}
-    }    
+    }
     public_api("#{@fqclass.file}.h")
     h_file(@fqclass.file) {
       include @fqbase.file
@@ -263,7 +262,7 @@ declarations.
 \\ingroup clientapi
 
 
-\\details 
+\\details
 
 <h2>Publishing Messages</h2>
 <ul>
@@ -274,7 +273,7 @@ declarations.
 
 for (int i=0; i&lt;10; i++) {
     message.setData(message_data.str());
-    async(session).messageTransfer(arg::content=message,  arg::destination="amq.direct");        
+    async(session).messageTransfer(arg::content=message,  arg::destination="amq.direct");
 }
 
 session.sync();
@@ -359,23 +358,23 @@ session.sync();
 <h2>Accepting, Acquiring, Rejecting, or Releasing Messages</h2>
 <ul>
 <li><p>messageAccept()  &mdash; acknowledges messages</p>
-<pre>SequenceSet tobeAccepted; 
-toAccepted.add(msg.getId()); 
+<pre>SequenceSet tobeAccepted;
+toAccepted.add(msg.getId());
 session.messageAccept(toBeAccepted);</pre>
 </li>
 <li><p>messageAcquire()</p>
 <pre>SequenceSet tobeAcquired;
-toBeAcquired.add(msg.getId()); 
+toBeAcquired.add(msg.getId());
 session.messageAcquire(toBeAcquired);</pre>
 </li>
 <li><p>messageReject()</p>
-<pre>SequenceSet tobeRejected; 
-toRejected.add(msg.getId()); 
+<pre>SequenceSet tobeRejected;
+toRejected.add(msg.getId());
 session.messageReject(toBeRejected);</pre>
 </li>
 <li><p>messageRelease()</p>
-<pre>SequenceSet tobeReleased; 
-toReleased.add(msg.getId()); 
+<pre>SequenceSet tobeReleased;
+toReleased.add(msg.getId());
 session.messageRelease(toBeReleased);</pre></li>
 </ul>
 

Modified: qpid/branches/qpid-2920-active/qpid/cpp/rubygen/framing.0-10/constants.rb
URL: http://svn.apache.org/viewvc/qpid/branches/qpid-2920-active/qpid/cpp/rubygen/framing.0-10/constants.rb?rev=1182557&r1=1182556&r2=1182557&view=diff
==============================================================================
--- qpid/branches/qpid-2920-active/qpid/cpp/rubygen/framing.0-10/constants.rb (original)
+++ qpid/branches/qpid-2920-active/qpid/cpp/rubygen/framing.0-10/constants.rb Wed Oct 12 19:55:26 2011
@@ -187,7 +187,7 @@ EOS
       include "<assert.h>"
       namespace("qpid::framing") {
         create_exception("execution", "error-code", "SessionException", "InvalidArgumentException")
-        # FIXME aconway 2008-10-07: there are no good exception codes in 0-10 for an invalid code.
+        # There are no good exception codes in 0-10 for an invalid code.
         # The following choices are arbitrary.
         create_exception("connection", "close-code", "ConnectionException", "FramingErrorException")
         create_exception("session", "detach-code", "ChannelException", "NotAttachedException")

Modified: qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/Serializer.h
URL: http://svn.apache.org/viewvc/qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/Serializer.h?rev=1182557&r1=1182556&r2=1182557&view=diff
==============================================================================
--- qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/Serializer.h (original)
+++ qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/Serializer.h Wed Oct 12 19:55:26 2011
@@ -10,9 +10,9 @@
  * 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
@@ -24,7 +24,7 @@
 
 #include <limits>
 #include <algorithm>
-#include "qpid/Exception.h"     // FIXME aconway 2008-04-03: proper exception class.
+#include "qpid/Exception.h"
 
 namespace qpid {
 
@@ -59,18 +59,18 @@ template <class Derived> class Serialize
       public:
         ScopedLimit(Serializer& s, size_t l)
             : serializer(s), save(serializer.setLimit(l)) {}
-        
+
         ~ScopedLimit() { serializer.setAbsLimit(save); }
-        
+
       private:
         Serializer& serializer;
         size_t save;
     };
 
     static size_t maxLimit() { return  std::numeric_limits<size_t>::max(); }
-    
+
     Serializer() : bytes(0), limit(maxLimit()) {}
-    
+
     typedef Derived& result_type; // unary functor requirement.
 
     /** Wrapper functor to pass serializer functors by reference. */
@@ -112,7 +112,7 @@ template <class Derived> class Serialize
     void setAbsLimit(size_t n) {
         limit = n;
         if (bytes > limit)
-            throw Exception("Framing error: data overrun"); // FIXME aconway 2008-04-03: proper exception.
+            throw Exception("Framing error: data overrun");
     }
 
   protected:
@@ -120,14 +120,14 @@ template <class Derived> class Serialize
     void addBytes(size_t n) {
         size_t newBytes=bytes+n;
         if (newBytes > limit)
-            throw Exception("Framing error: data overrun"); // FIXME aconway 2008-04-03: proper exception.
+            throw Exception("Framing error: data overrun"); //
         bytes = newBytes;
     }
-    
+
   private:
     void checkLimit() {
     }
-        
+
     size_t bytes;               // how many bytes serialized.
     size_t limit;               // bytes may not exceed this limit.
 };
@@ -142,7 +142,7 @@ template <class Derived> class EncoderBa
   public:
     using Serializer<Derived>::operator();
     using Serializer<Derived>::self;
-    
+
     /** Default op() for non-primitive types. */
     template <class T> Derived& operator()(const T& t) {
         serializable(const_cast<T&>(t)).serialize(self()); return self();
@@ -180,7 +180,7 @@ template <class Derived> class DecoderBa
 /** Serialize a type by converting it to/from another type.
  * To serialize type Foo by converting to/from type Bar create
  * a serializable() overload like this:
- * 
+ *
  * SerializeAs<Foo,Bar> serializable(Foo& t) { return SerializeAs<Foo,Bar>(t); }
  */
 template <class Type, class AsType>

Modified: qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/amqp_0_10/Array.h
URL: http://svn.apache.org/viewvc/qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/amqp_0_10/Array.h?rev=1182557&r1=1182556&r2=1182557&view=diff
==============================================================================
--- qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/amqp_0_10/Array.h (original)
+++ qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/amqp_0_10/Array.h Wed Oct 12 19:55:26 2011
@@ -108,9 +108,9 @@ template<> class ArrayDomain<UnknownType
 
 std::ostream& operator<<(std::ostream& o, const Array& a);
 
-// FIXME aconway 2008-04-08: hack to supress encoding of
-// command-fragments and in-doubt as there is a problem with the spec
-// (command-fragments does not have a one byte type code.)
+// Hack to supress encoding of command-fragments and in-doubt as there
+// is a problem with the spec (command-fragments does not have a one
+// byte type code.)
 namespace session { class CommandFragment; }
 namespace dtx { class Xid; }
 

Modified: qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/amqp_0_10/Codec.h
URL: http://svn.apache.org/viewvc/qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/amqp_0_10/Codec.h?rev=1182557&r1=1182556&r2=1182557&view=diff
==============================================================================
--- qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/amqp_0_10/Codec.h (original)
+++ qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/amqp_0_10/Codec.h Wed Oct 12 19:55:26 2011
@@ -115,7 +115,7 @@ struct Codec {
 
         using DecoderBase<Decoder<InIter> >::operator();
         
-        // FIXME aconway 2008-03-10:  wrong encoding, need packing support
+        // Wrong encoding, need packing support
         Decoder& operator()(bool& x) { raw((char&)x); return *this; }
 
         Decoder& operator()(char& x) { raw((char&)x); return *this; }
@@ -165,7 +165,7 @@ struct Codec {
 
         using EncoderBase<Size>::operator();
 
-        // FIXME aconway 2008-03-10:  wrong encoding, need packing support
+        // Wrong encoding, need packing support
         Size& operator()(bool x)  { size += sizeof(x); return *this; }
         
         Size& operator()(char x)  { size += sizeof(x); return *this; }
@@ -183,10 +183,6 @@ struct Codec {
         Size& operator()(float x)  { size += sizeof(x); return *this; }
         Size& operator()(double x)  { size += sizeof(x); return *this; }
 
-        // FIXME aconway 2008-04-03: optimize op()(Iter,Iter)
-        // for Iter with fixed-size value_type:
-        // distance(begin,end)*sizeof(value_type)
-
         void raw(const void*, size_t n){ size += n; }
 
         template <class T> Size& littleEnd(T) { size+= sizeof(T); return *this; }
@@ -195,7 +191,6 @@ struct Codec {
         size_t size;
     };
 
-    // FIXME aconway 2008-03-11: rename to encoder(), decoder()
     template <class InIter> static Decoder<InIter> decode(const InIter &i) {
         return Decoder<InIter>(i);
     }

Modified: qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/amqp_0_10/Connection.h
URL: http://svn.apache.org/viewvc/qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/amqp_0_10/Connection.h?rev=1182557&r1=1182556&r2=1182557&view=diff
==============================================================================
--- qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/amqp_0_10/Connection.h (original)
+++ qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/amqp_0_10/Connection.h Wed Oct 12 19:55:26 2011
@@ -76,7 +76,6 @@ class Connection  : public sys::Connecti
     size_t getBuffered() const;
 
     /** Used by cluster code to set a special version on "update" connections. */
-    // FIXME aconway 2009-07-30: find a cleaner mechanism for this.
     void setVersion(const framing::ProtocolVersion&);
 };
 

Modified: qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/amqp_0_10/Exception.h
URL: http://svn.apache.org/viewvc/qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/amqp_0_10/Exception.h?rev=1182557&r1=1182556&r2=1182557&view=diff
==============================================================================
--- qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/amqp_0_10/Exception.h (original)
+++ qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/amqp_0_10/Exception.h Wed Oct 12 19:55:26 2011
@@ -33,8 +33,6 @@ namespace amqp_0_10 {
  * non-0 timeout may be available for re-attachment on another connection.
  */
 struct ConnectionException : public qpid::Exception {
-    // FIXME aconway 2008-04-04: Merge qpid::ConnectionException
-    // into this when the old code is removed.
     typedef connection::CloseCode Code;
     ConnectionException(Code c, const std::string m)
         : qpid::Exception(m), code(c) {}
@@ -46,15 +44,11 @@ struct ConnectionException : public qpid
  * if an attempt is made to use a session that is not attached.
  */
 struct SessionException : public qpid::Exception  {
-    // FIXME aconway 2008-04-04: should not have a code at this level.
-    // Leave in place till old preview code is gone.
     SessionException(int /*code*/, const std::string& msg) : qpid::Exception(msg) {} 
 };
 
 /** Raised when the state of a session has been destroyed */
 struct SessionDestroyedException : public SessionException {
-    // FIXME aconway 2008-04-04: should not have a code at this level.
-    // Leave in place till old preview code is gone.
     SessionDestroyedException(int code, const std::string& msg) : SessionException(code, msg){} 
 };
 

Modified: qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/amqp_0_10/Map.cpp
URL: http://svn.apache.org/viewvc/qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/amqp_0_10/Map.cpp?rev=1182557&r1=1182556&r2=1182557&view=diff
==============================================================================
--- qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/amqp_0_10/Map.cpp (original)
+++ qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/amqp_0_10/Map.cpp Wed Oct 12 19:55:26 2011
@@ -31,7 +31,7 @@ MapValue::MapValue() : code(codeFor(uint
 MapValue::MapValue(const MapValue& x) : code(x.code), blob(x.blob) {}
 
 bool  MapValue::operator==(const MapValue& x) const {
-    return code == x.code;      // FIXME aconway 2008-04-01: incomplete
+    return code == x.code;
 }
 
 struct OstreamVisitor : public MapValue::Visitor<std::ostream&> {
@@ -59,7 +59,6 @@ std::ostream& operator<<(std::ostream& o
 }
 
 uint32_t Map::contentSize() const {
-    // FIXME aconway 2008-04-03: preview to 0-10 mapping: +4 for count.
     return /*4 +*/ Codec::Size()(begin(), end()); 
 }
 

Modified: qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/amqp_0_10/Map.h
URL: http://svn.apache.org/viewvc/qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/amqp_0_10/Map.h?rev=1182557&r1=1182556&r2=1182557&view=diff
==============================================================================
--- qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/amqp_0_10/Map.h (original)
+++ qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/amqp_0_10/Map.h Wed Oct 12 19:55:26 2011
@@ -159,8 +159,6 @@ template <class V> typename V::result_ty
 }
 
 template <class S> void Map::encode(S& s) const {
-    // FIXME aconway 2008-04-03: replace preview mapping with 0-10 mapping:
-    // s(contentSize())(uint32_t(size())); // size, count
     s(contentSize());
     for (const_iterator i = begin(); i != end(); ++i)
         s(i->first)(i->second); // key (type value)
@@ -168,12 +166,12 @@ template <class S> void Map::encode(S& s
 
 template <class S> void Map::decode(S& s) {
     uint32_t decodedSize /*, count*/;
-    // FIXME aconway 2008-04-03: replace preview mapping with 0-10 mapping:
+    // FIXME: replace preview mapping with 0-10 mapping:
     // s(contentSize())(uint32_t(size())); // size, count
     // s(decodedSize)(count);
     s(decodedSize);
     typename S::ScopedLimit l(s, decodedSize); // Make sure we don't overrun.
-    // FIXME aconway 2008-04-03:  replace preview with 0-10:
+    // FIXME: replace preview with 0-10:
     // for ( ; count > 0; --count) {
     while (s.bytesRemaining() > 0) {
         key_type k; MapValue v;

Modified: qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/amqp_0_10/Packer.h
URL: http://svn.apache.org/viewvc/qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/amqp_0_10/Packer.h?rev=1182557&r1=1182556&r2=1182557&view=diff
==============================================================================
--- qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/amqp_0_10/Packer.h (original)
+++ qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/amqp_0_10/Packer.h Wed Oct 12 19:55:26 2011
@@ -99,9 +99,9 @@ class PackedDecoder {
             decode(t);
         else
             t = T();
-        // FIXME aconway 2008-04-10: When we have all optionals
-        // represented by boost::optional the line above should be:
-        // throw CommandInvalidException("A required value was omitted.");
+        // When we have all optionals represented by boost::optional
+        // the line above should be: throw CommandInvalidException("A
+        // required value was omitted.");
         bits >>= 1;
         return *this;
     }

Modified: qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/amqp_0_10/Struct32.cpp
URL: http://svn.apache.org/viewvc/qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/amqp_0_10/Struct32.cpp?rev=1182557&r1=1182556&r2=1182557&view=diff
==============================================================================
--- qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/amqp_0_10/Struct32.cpp (original)
+++ qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/amqp_0_10/Struct32.cpp Wed Oct 12 19:55:26 2011
@@ -24,8 +24,6 @@ namespace qpid {
 namespace amqp_0_10 {
 
 Struct32::Struct32() {
-    // FIXME aconway 2008-04-16: this is only here to force a valid
-    // default-constructed Struct32 for serialize tests, clean up.
     *this = in_place<message::MessageResumeResult>();
 }
 

Modified: qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/amqp_0_10/Unit.cpp
URL: http://svn.apache.org/viewvc/qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/amqp_0_10/Unit.cpp?rev=1182557&r1=1182556&r2=1182557&view=diff
==============================================================================
--- qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/amqp_0_10/Unit.cpp (original)
+++ qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/amqp_0_10/Unit.cpp Wed Oct 12 19:55:26 2011
@@ -30,7 +30,7 @@ void Unit::updateVariant() {
       case COMMAND: variant=CommandHolder(); break;
       case HEADER: variant=Header(); break;
       case BODY: variant=Body(header.getDataSize()); break;
-      default: assert(0);       // FIXME aconway 2008-04-14: exception?
+      default: assert(0);
     }
 }
 

Modified: qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/amqp_0_10/built_in_types.h
URL: http://svn.apache.org/viewvc/qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/amqp_0_10/built_in_types.h?rev=1182557&r1=1182556&r2=1182557&view=diff
==============================================================================
--- qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/amqp_0_10/built_in_types.h (original)
+++ qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/amqp_0_10/built_in_types.h Wed Oct 12 19:55:26 2011
@@ -150,11 +150,10 @@ class UnknownType;
 template <class T> struct  ArrayDomain;
 typedef ArrayDomain<UnknownType> Array;
 
-// FIXME aconway 2008-04-08: TODO
 struct ByteRanges { template <class S> void serialize(S&) {} };
 struct List  { template <class S> void serialize(S&) {} };
 
-// FIXME aconway 2008-03-10: dummy ostream operators
+// Dummy ostream operators
 inline std::ostream& operator<<(std::ostream& o, const ByteRanges&) { return o; }
 inline std::ostream& operator<<(std::ostream& o, const SequenceSet&) { return o; }
 inline std::ostream& operator<<(std::ostream& o, const List&) { return o; }

Modified: qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/broker/SemanticState.cpp
URL: http://svn.apache.org/viewvc/qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/broker/SemanticState.cpp?rev=1182557&r1=1182556&r2=1182557&view=diff
==============================================================================
--- qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/broker/SemanticState.cpp (original)
+++ qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/broker/SemanticState.cpp Wed Oct 12 19:55:26 2011
@@ -350,11 +350,8 @@ bool SemanticState::ConsumerImpl::filter
 bool SemanticState::ConsumerImpl::accept(intrusive_ptr<Message> msg)
 {
     assertClusterSafe();
-    // FIXME aconway 2009-06-08: if we have byte & message credit but
-    // checkCredit fails because the message is to big, we should
-    // remain on queue's listener list for possible smaller messages
-    // in future.
-    //
+    // FIXME: QPID-1909: Consumer with byte credit can get ignored if
+    // a large message "eclipses" a small one.
     blocked = !(filter(msg) && checkCredit(msg));
     return !blocked;
 }

Modified: qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/broker/SessionAdapter.cpp
URL: http://svn.apache.org/viewvc/qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/broker/SessionAdapter.cpp?rev=1182557&r1=1182556&r2=1182557&view=diff
==============================================================================
--- qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/broker/SessionAdapter.cpp (original)
+++ qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/broker/SessionAdapter.cpp Wed Oct 12 19:55:26 2011
@@ -491,7 +491,6 @@ void SessionAdapter::MessageHandlerImpl:
 
 framing::MessageAcquireResult SessionAdapter::MessageHandlerImpl::acquire(const framing::SequenceSet& transfers)
 {
-    // FIXME aconway 2008-05-12: create SequenceSet directly, no need for intermediate results vector.
     SequenceNumberSet results;
     RangedOperation f = boost::bind(&SemanticState::acquire, &state, _1, _2, boost::ref(results));
     transfers.for_each(f);

Modified: qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/broker/SessionManager.cpp
URL: http://svn.apache.org/viewvc/qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/broker/SessionManager.cpp?rev=1182557&r1=1182556&r2=1182557&view=diff
==============================================================================
--- qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/broker/SessionManager.cpp (original)
+++ qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/broker/SessionManager.cpp Wed Oct 12 19:55:26 2011
@@ -62,7 +62,7 @@ std::auto_ptr<SessionState>  SessionMana
         state->attach(h);
     }
     return state;
-    // FIXME aconway 2008-04-29: implement force 
+    // FIXME: implement force 
 }
 
 void  SessionManager::detach(std::auto_ptr<SessionState> session) {

Modified: qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/client/ConnectionImpl.cpp
URL: http://svn.apache.org/viewvc/qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/client/ConnectionImpl.cpp?rev=1182557&r1=1182556&r2=1182557&view=diff
==============================================================================
--- qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/client/ConnectionImpl.cpp (original)
+++ qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/client/ConnectionImpl.cpp Wed Oct 12 19:55:26 2011
@@ -405,13 +405,10 @@ void ConnectionImpl::failedConnection() 
 
     std::ostringstream msg;
     msg << *this << " closed";
-
-    // FIXME aconway 2008-06-06: exception use, amqp0-10 does not seem to have
-    // an appropriate close-code. connection-forced is not right.
-    handler.fail(msg.str());//ensure connection is marked as failed before notifying sessions
-
-    // At this point if the object isn't open and isn't closing it must have failed to open
-    // so we can't do the rest of the cleanup
+    // Ensure connection is marked as failed before notifying sessions
+    handler.fail(msg.str());
+    // At this point if the object isn't open and isn't closing it
+    // must have failed to open so we can't do the rest of the cleanup
     if (!isClosing && !isOpen) return;
 
     Mutex::ScopedLock l(lock);

Modified: qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/client/PrivateImplRef.h
URL: http://svn.apache.org/viewvc/qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/client/PrivateImplRef.h?rev=1182557&r1=1182556&r2=1182557&view=diff
==============================================================================
--- qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/client/PrivateImplRef.h (original)
+++ qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/client/PrivateImplRef.h Wed Oct 12 19:55:26 2011
@@ -29,7 +29,6 @@
 namespace qpid {
 namespace client {
 
-// FIXME aconway 2009-04-24: details!
 /** @file
  *
  * Helper class to implement a class with a private, reference counted

Modified: qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/cluster/Connection.cpp
URL: http://svn.apache.org/viewvc/qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/cluster/Connection.cpp?rev=1182557&r1=1182556&r2=1182557&view=diff
==============================================================================
--- qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/cluster/Connection.cpp (original)
+++ qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/cluster/Connection.cpp Wed Oct 12 19:55:26 2011
@@ -547,7 +547,7 @@ void Connection::deliveryRecord(const st
         } else {                // Message at original position in original queue
             m = queue->find(position);
         }
-        // FIXME aconway 2011-08-19: removed:
+        // Removed this line:
         // if (!m.payload)
         //      throw Exception(QPID_MSG("deliveryRecord no update message"));
         //

Modified: qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/cluster/Cpg.cpp
URL: http://svn.apache.org/viewvc/qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/cluster/Cpg.cpp?rev=1182557&r1=1182556&r2=1182557&view=diff
==============================================================================
--- qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/cluster/Cpg.cpp (original)
+++ qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/cluster/Cpg.cpp Wed Oct 12 19:55:26 2011
@@ -128,7 +128,7 @@ Cpg::Cpg(Handler& h) : IOHandle(new sys:
 
     QPID_LOG(debug, "Initializing CPG");
     cpg_error_t err = cpg_initialize(&handle, &callbacks);
-    int retries = 6; // FIXME aconway 2009-08-06: make this configurable.
+    int retries = 6;
     while (err == CPG_ERR_TRY_AGAIN && --retries) {
         QPID_LOG(notice, "Re-trying CPG initialization.");
         sys::sleep(5);

Modified: qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/cluster/exp/BrokerContext.cpp
URL: http://svn.apache.org/viewvc/qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/cluster/exp/BrokerContext.cpp?rev=1182557&r1=1182556&r2=1182557&view=diff
==============================================================================
--- qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/cluster/exp/BrokerContext.cpp (original)
+++ qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/cluster/exp/BrokerContext.cpp Wed Oct 12 19:55:26 2011
@@ -58,8 +58,6 @@ const ProtocolVersion pv;     // shortha
 QPID_TSS bool tssReplicate = true;
 }
 
-// FIXME aconway 2011-09-26: de-const the broker::Cluster interface,
-// then de-const here.
 Multicaster& BrokerContext::mcaster(const broker::QueuedMessage& qm) {
     return core.getGroup(hashof(qm)).getMulticaster();
 }
@@ -96,7 +94,6 @@ void sendFrame(Multicaster& mcaster, con
 
 bool BrokerContext::enqueue(Queue& queue, const boost::intrusive_ptr<Message>& msg)
 {
-    // FIXME aconway 2011-10-03: pass shared ptr on broker::Cluster interface.
     if (!tssReplicate) return true;
     Group& group = core.getGroup(hashof(queue));
     MessageHolder::Channel channel =
@@ -135,7 +132,6 @@ void BrokerContext::requeue(const broker
                        qm.payload->getRedelivered()));
 }
 
-// FIXME aconway 2011-06-08: should be be using shared_ptr to q here?
 void BrokerContext::create(broker::Queue& q) {
     if (!tssReplicate) return;
     assert(!QueueContext::get(q));

Modified: qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/cluster/exp/Core.cpp
URL: http://svn.apache.org/viewvc/qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/cluster/exp/Core.cpp?rev=1182557&r1=1182556&r2=1182557&view=diff
==============================================================================
--- qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/cluster/exp/Core.cpp (original)
+++ qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/cluster/exp/Core.cpp Wed Oct 12 19:55:26 2011
@@ -59,10 +59,9 @@ Core::Core(const Settings& s, broker::Br
         brokerHandler = bh.get();
         // BrokerContext belongs to Broker
         broker.setCluster(std::auto_ptr<broker::Cluster>(bh));
-        // FIXME aconway 2011-09-26: multi-group
         eh.start();
         eh.getCpg().join(groupName);
-        // TODO aconway 2010-11-18: logging standards        // FIXME aconway 2011-09-26: multi-group
+        // TODO aconway 2010-11-18: logging standards
         QPID_LOG(debug, "cluster: joined CPG group " << groupName << ", member-id=" << eh.getSelf());
     }
     QPID_LOG(notice, "cluster: joined cluster " << s.name

Modified: qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/cluster/exp/CountdownTimer.h
URL: http://svn.apache.org/viewvc/qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/cluster/exp/CountdownTimer.h?rev=1182557&r1=1182556&r2=1182557&view=diff
==============================================================================
--- qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/cluster/exp/CountdownTimer.h (original)
+++ qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/cluster/exp/CountdownTimer.h Wed Oct 12 19:55:26 2011
@@ -23,7 +23,6 @@
  */
 
 #include "qpid/sys/Timer.h"
-#include "qpid/log/Statement.h" // FIXME aconway 2011-09-19: remove
 #include <boost/function.hpp>
 
 namespace qpid {

Modified: qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/cluster/exp/EventHandler.cpp
URL: http://svn.apache.org/viewvc/qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/cluster/exp/EventHandler.cpp?rev=1182557&r1=1182556&r2=1182557&view=diff
==============================================================================
--- qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/cluster/exp/EventHandler.cpp (original)
+++ qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/cluster/exp/EventHandler.cpp Wed Oct 12 19:55:26 2011
@@ -104,7 +104,6 @@ void EventHandler::configChange (
     const cpg_address *left, int nLeft,
     const cpg_address *joined, int nJoined)
 {
-    // FIXME aconway 2010-10-20: TODO
     QPID_LOG(notice, "cluster: new membership: " << PrintAddrs(members, nMembers));
     QPID_LOG_IF(notice, nLeft, "cluster:   members left: " << PrintAddrs(left, nLeft));
     QPID_LOG_IF(notice, nJoined, "cluster:   members joined: " << PrintAddrs(joined, nJoined));

Modified: qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/cluster/exp/QueueContext.cpp
URL: http://svn.apache.org/viewvc/qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/cluster/exp/QueueContext.cpp?rev=1182557&r1=1182556&r2=1182557&view=diff
==============================================================================
--- qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/cluster/exp/QueueContext.cpp (original)
+++ qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/cluster/exp/QueueContext.cpp Wed Oct 12 19:55:26 2011
@@ -69,7 +69,6 @@ void QueueContext::replicaState(
     if ((before != after || selfDelivered) && isOwner(after)) {
         QPID_LOG(trace, "cluster start consumers on " << queue.getName() << ", timer "
                  << (after==SHARED_OWNER? "start" : "stop"));
-        sys::Mutex::ScopedLock l(lock); // FIXME aconway 2011-09-29: REMOVE
         queue.startConsumers();
         if (after == SHARED_OWNER) timer.start();
         else timer.stop();

Modified: qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/cluster/exp/QueueContext.h
URL: http://svn.apache.org/viewvc/qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/cluster/exp/QueueContext.h?rev=1182557&r1=1182556&r2=1182557&view=diff
==============================================================================
--- qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/cluster/exp/QueueContext.h (original)
+++ qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/cluster/exp/QueueContext.h Wed Oct 12 19:55:26 2011
@@ -30,9 +30,6 @@
 #include "qpid/cluster/types.h"
 #include <boost/intrusive_ptr.hpp>
 
-// FIXME aconway 2011-06-08: refactor broker::Cluster to put queue ups on
-// class broker::Cluster::Queue. This becomes the cluster context.
-
 namespace qpid {
 namespace broker {
 class Queue;
@@ -97,7 +94,7 @@ class QueueContext : public RefCounted {
 private:
     sys::Mutex lock;
     CountdownTimer timer;
-    broker::Queue& queue;       // FIXME aconway 2011-06-08: should be shared/weak ptr?
+    broker::Queue& queue; // FIXME aconway 2011-06-08: should be shared/weak ptr?
     Multicaster& mcast;
     size_t consumers;
     size_t hash;

Modified: qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/cluster/exp/QueueHandler.cpp
URL: http://svn.apache.org/viewvc/qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/cluster/exp/QueueHandler.cpp?rev=1182557&r1=1182556&r2=1182557&view=diff
==============================================================================
--- qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/cluster/exp/QueueHandler.cpp (original)
+++ qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/cluster/exp/QueueHandler.cpp Wed Oct 12 19:55:26 2011
@@ -59,16 +59,10 @@ void QueueHandler::left(const MemberId& 
         i->second->unsubscribe(member);
 }
 
-// FIXME aconway 2011-06-08: do we need to hold on to the shared pointer for lifecycle?
-// FIXME aconway 2011-09-13: called from wiring handler, need to consider for multi-cpg.
 void QueueHandler::add(boost::shared_ptr<broker::Queue> q) {
-    // FIXME aconway 2011-06-08: move create operation from Wiring to Queue handler.
-    // FIXME aconway 2011-05-10: assert not already in map.
-
     // Local queues already have a context, remote queues need one.
     if (!QueueContext::get(*q))
-        new QueueContext(*q, consumeLock, multicaster); // Context attaches itself to the Queue
-    // FIXME aconway 2011-09-15: thread safety: called from wiring handler..
+        new QueueContext(*q, consumeLock, multicaster); // Context attaches to the Queue
     queues[q->getName()] = boost::intrusive_ptr<QueueReplica>(
         new QueueReplica(q, self()));
 }

Modified: qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/cluster/exp/WiringHandler.cpp
URL: http://svn.apache.org/viewvc/qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/cluster/exp/WiringHandler.cpp?rev=1182557&r1=1182556&r2=1182557&view=diff
==============================================================================
--- qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/cluster/exp/WiringHandler.cpp (original)
+++ qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/cluster/exp/WiringHandler.cpp Wed Oct 12 19:55:26 2011
@@ -72,9 +72,6 @@ void WiringHandler::createQueue(const st
     }
     boost::shared_ptr<broker::Queue> q = broker.getQueues().find(name);
     assert(q);                  // FIXME aconway 2011-05-10: error handling.
-    // TODO aconway 2011-05-10: if we implement multi-group for queues
-    // then this call is a potential problem: comes from wiring
-    // delivery thread, not queues.
     queueHandler->add(q);
     QPID_LOG(debug, "cluster: create queue " << q->getName());
 }

Modified: qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/cluster/exp/hash.h
URL: http://svn.apache.org/viewvc/qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/cluster/exp/hash.h?rev=1182557&r1=1182556&r2=1182557&view=diff
==============================================================================
--- qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/cluster/exp/hash.h (original)
+++ qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/cluster/exp/hash.h Wed Oct 12 19:55:26 2011
@@ -39,7 +39,6 @@ class QueueContext;
 /**@file hash functions */
 
 // The following all uses the cached hash value on the Queue::getContext()
-// FIXME aconway 2011-09-26: de-const broker::Cluster interface then de-const here.
 size_t hashof(const broker::Queue& q);
 size_t hashof(const QueueContext& qc);
 size_t hashof(const broker::QueuedMessage& qm);

Modified: qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/framing/Array.cpp
URL: http://svn.apache.org/viewvc/qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/framing/Array.cpp?rev=1182557&r1=1182556&r2=1182557&view=diff
==============================================================================
--- qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/framing/Array.cpp (original)
+++ qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/framing/Array.cpp Wed Oct 12 19:55:26 2011
@@ -119,7 +119,6 @@ bool Array::operator==(const Array& x) c
 
 void Array::insert(iterator i, ValuePtr value) {
     if (type != value->getType()) {
-        // FIXME aconway 2008-10-31:  put meaningful strings in this message.
         throw Exception(QPID_MSG("Wrong type of value in Array, expected " << type
                                  << " but found " << TypeCode(value->getType())));
     }

Modified: qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/sys/Activity.h
URL: http://svn.apache.org/viewvc/qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/sys/Activity.h?rev=1182557&r1=1182556&r2=1182557&view=diff
==============================================================================
--- qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/sys/Activity.h (original)
+++ qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/sys/Activity.h Wed Oct 12 19:55:26 2011
@@ -62,8 +62,6 @@ class Activity {
 
   friend class Scope;
 
-    // FIXME aconway 2011-09-30: fix pre-conditions with asserts, don't allow
-    // multiple stops/starts.
     /**
      * Set state to "stopped", so no new threads can enter.
      * Notify function will be called when all busy threads have left.

Modified: qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/sys/AsynchIOHandler.cpp
URL: http://svn.apache.org/viewvc/qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/sys/AsynchIOHandler.cpp?rev=1182557&r1=1182556&r2=1182557&view=diff
==============================================================================
--- qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/sys/AsynchIOHandler.cpp (original)
+++ qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/sys/AsynchIOHandler.cpp Wed Oct 12 19:55:26 2011
@@ -112,9 +112,8 @@ void AsynchIOHandler::readbuff(AsynchIO&
     // Check here for read credit
     if (readCredit.get() != InfiniteCredit) {
         if (readCredit.get() == 0) {
-            // FIXME aconway 2009-10-01:  Workaround to avoid "false wakeups".
-            // readbuff is sometimes called with no credit.
-            // This should be fixed somewhere else to avoid such calls.
+            // Avoid "false wakeups" if readbuff is called with no
+            // credit.
             aio->unread(buff);
             return;
         }

Modified: qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/sys/PollableQueue.h
URL: http://svn.apache.org/viewvc/qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/sys/PollableQueue.h?rev=1182557&r1=1182556&r2=1182557&view=diff
==============================================================================
--- qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/sys/PollableQueue.h (original)
+++ qpid/branches/qpid-2920-active/qpid/cpp/src/qpid/sys/PollableQueue.h Wed Oct 12 19:55:26 2011
@@ -29,7 +29,6 @@
 #include <boost/bind.hpp>
 #include <algorithm>
 #include <deque>
-#include "qpid/log/Statement.h" // FIXME aconway 2011-08-05:
 
 namespace qpid {
 namespace sys {

Modified: qpid/branches/qpid-2920-active/qpid/cpp/src/tests/PartialFailure.cpp
URL: http://svn.apache.org/viewvc/qpid/branches/qpid-2920-active/qpid/cpp/src/tests/PartialFailure.cpp?rev=1182557&r1=1182556&r2=1182557&view=diff
==============================================================================
--- qpid/branches/qpid-2920-active/qpid/cpp/src/tests/PartialFailure.cpp (original)
+++ qpid/branches/qpid-2920-active/qpid/cpp/src/tests/PartialFailure.cpp Wed Oct 12 19:55:26 2011
@@ -111,11 +111,6 @@ QPID_AUTO_TEST_CASE(testCoincidentErrors
 
 // Verify normal cluster-wide errors.
 QPID_AUTO_TEST_CASE(testNormalErrors) {
-    // FIXME aconway 2009-04-10: Would like to put a scope just around
-    // the statements expected to fail (in BOOST_CHECK_yTHROW) but that
-    // sproadically lets out messages, possibly because they're in
-    // Connection thread.
-
     ClusterFixture cluster(3, updateArgs, -1);
     Client c0(cluster[0], "c0");
     Client c1(cluster[1], "c1");
@@ -240,9 +235,6 @@ QPID_AUTO_TEST_CASE(testMultiPartialFail
         c0.session.messageTransfer(content=pMessage("b", "q"));
         c3.session.messageTransfer(content=pMessage("c", "q"));
         BOOST_CHECK_EQUAL(c3.session.queueQuery("q").getMessageCount(), 4u);
-        // FIXME aconway 2009-06-30: This check fails sporadically with 2 != 3.
-        // It should pass reliably.
-        // BOOST_CHECK_EQUAL(2u, knownBrokerPorts(c0.connection, 2).size());
 
         // Close inside ScopedSuppressLogging to avoid warnings 
         c0.close();

Modified: qpid/branches/qpid-2920-active/qpid/cpp/src/tests/ReplicationTest.cpp
URL: http://svn.apache.org/viewvc/qpid/branches/qpid-2920-active/qpid/cpp/src/tests/ReplicationTest.cpp?rev=1182557&r1=1182556&r2=1182557&view=diff
==============================================================================
--- qpid/branches/qpid-2920-active/qpid/cpp/src/tests/ReplicationTest.cpp (original)
+++ qpid/branches/qpid-2920-active/qpid/cpp/src/tests/ReplicationTest.cpp Wed Oct 12 19:55:26 2011
@@ -48,7 +48,6 @@ namespace tests {
 
 QPID_AUTO_TEST_SUITE(ReplicationTestSuite)
 
-// FIXME aconway 2009-11-26: clean this up.
 // The CMake-based build passes in the module suffix; if it's not there, this
 // is a Linux/UNIX libtool-based build.
 #if defined (QPID_MODULE_PREFIX) && defined (QPID_MODULE_SUFFIX)

Modified: qpid/branches/qpid-2920-active/qpid/cpp/src/tests/amqp_0_10/serialize.cpp
URL: http://svn.apache.org/viewvc/qpid/branches/qpid-2920-active/qpid/cpp/src/tests/amqp_0_10/serialize.cpp?rev=1182557&r1=1182556&r2=1182557&view=diff
==============================================================================
--- qpid/branches/qpid-2920-active/qpid/cpp/src/tests/amqp_0_10/serialize.cpp (original)
+++ qpid/branches/qpid-2920-active/qpid/cpp/src/tests/amqp_0_10/serialize.cpp Wed Oct 12 19:55:26 2011
@@ -7,9 +7,9 @@
  * 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
@@ -106,7 +106,7 @@ QPID_AUTO_TEST_CASE(testSetLimit) {
     try {
         encode('4');
         BOOST_FAIL("Expected exception");
-    } catch (...) {}            // FIXME aconway 2008-04-03: catch proper exception
+    } catch (...) {}
     BOOST_CHECK_EQUAL(data, "123");
 }
 
@@ -121,14 +121,14 @@ QPID_AUTO_TEST_CASE(testScopedLimit) {
         try {
             encode('d');
             BOOST_FAIL("Expected exception");
-        } catch(...) {}         // FIXME aconway 2008-04-03: catch proper exception
+        } catch(...) {}
     }
     BOOST_CHECK_EQUAL(data, "\003123abc");
     encode('x')('y')('z');
     try {
         encode('!');
         BOOST_FAIL("Expected exception");
-    } catch(...) {}         // FIXME aconway 2008-04-03: catch proper exception
+    } catch(...) {}
     BOOST_CHECK_EQUAL(data.size(), 10u);
 }
 
@@ -197,7 +197,7 @@ QPID_AUTO_TEST_CASE(testControlEncodeDec
     string data;
     Control::Holder h(in_place<connection::Tune>(1,2,3,4));
     Codec::encode(std::back_inserter(data))(h);
-    
+
     BOOST_CHECK_EQUAL(data.size(), Codec::size(h));
 
     Codec::Decoder<string::iterator> decode(data.begin());
@@ -226,7 +226,7 @@ QPID_AUTO_TEST_CASE(testStruct32) {
     Codec::decode(data.begin())(structSize);
     BOOST_CHECK_EQUAL(structSize, Codec::size(dp) + 2);  // +2 for code
     BOOST_CHECK_EQUAL(structSize, data.size()-4);        // encoded body
-    
+
     BOOST_CHECK_EQUAL(data.size(), Codec::size(s));
     Struct32 s2;
     Codec::decode(data.begin())(s2);
@@ -276,7 +276,7 @@ QPID_AUTO_TEST_CASE(testPacked) {
     Codec::encode(back_inserter(data))('a')(boost::optional<char>('b'))(boost::optional<char>())('c');
     BOOST_CHECK_EQUAL(data, "abc");
     data.clear();
-    
+
     DummyPacked dummy('a','b','c');
 
     Codec::encode(back_inserter(data))(dummy);
@@ -309,7 +309,7 @@ QPID_AUTO_TEST_CASE(testUnitControl) {
 
     string data2;
     Codec::encode(back_inserter(data2))(unit);
-    
+
     BOOST_CHECK_EQUAL(data, data2);
 }
 
@@ -325,7 +325,7 @@ QPID_AUTO_TEST_CASE(testArray) {
     string data3;
     Codec::encode(back_inserter(data3))(a);
     BOOST_CHECK_EQUAL(data, data3);
-    
+
     Array x;
     Codec::decode(data.begin())(x);
     BOOST_CHECK_EQUAL(x.size(), 3u);
@@ -354,10 +354,10 @@ QPID_AUTO_TEST_CASE(testStruct) {
     encodedBits <<= 8;
     encodedBits += uint8_t(data[4]);
     BOOST_CHECK_EQUAL(encodedBits, packBits(dp));
-        
+
     data.clear();
     Struct32 h(dp);
-    Codec::encode(back_inserter(data))(h);    
+    Codec::encode(back_inserter(data))(h);
 
     Struct32 h2;
     Codec::decode(data.begin())(h2);
@@ -403,7 +403,6 @@ struct RecodeUnit {
         BOOST_CHECK_MESSAGE(data == data2, BOOST_CURRENT_FUNCTION);
 
         // Decode unit
-        // FIXME aconway 2008-04-15: must set limit to decode a header.
         Codec::Decoder<string::iterator> decode(data2.begin(), data2.size()-1);
 
         FrameHeader h;
@@ -414,7 +413,7 @@ struct RecodeUnit {
 
         // Re-encode unit
         string data3;
-        Codec::encode(back_inserter(data3))(u2.getHeader())(u2);        
+        Codec::encode(back_inserter(data3))(u2.getHeader())(u2);
         data3.push_back(char(0xCE)); // Preview end-of-frame
 
         BOOST_CHECK_MESSAGE(data3 == data2, BOOST_CURRENT_FUNCTION);

Modified: qpid/branches/qpid-2920-active/qpid/cpp/src/tests/cluster2_tests.py
URL: http://svn.apache.org/viewvc/qpid/branches/qpid-2920-active/qpid/cpp/src/tests/cluster2_tests.py?rev=1182557&r1=1182556&r2=1182557&view=diff
==============================================================================
--- qpid/branches/qpid-2920-active/qpid/cpp/src/tests/cluster2_tests.py (original)
+++ qpid/branches/qpid-2920-active/qpid/cpp/src/tests/cluster2_tests.py Wed Oct 12 19:55:26 2011
@@ -98,7 +98,6 @@ class Cluster2Tests(BrokerTest):
         content = ["a","b","c"]
         for m in content: s0.send(Message(m))
         # Verify enqueued on members 0 and 1
-        # FIXME aconway 2011-05-13:
         self.verify_content(content, sn0.receiver("q;{mode:browse}"))
         self.verify_content(content, sn1.receiver("q;{mode:browse}"))
 

Modified: qpid/branches/qpid-2920-active/qpid/cpp/src/tests/exception_test.cpp
URL: http://svn.apache.org/viewvc/qpid/branches/qpid-2920-active/qpid/cpp/src/tests/exception_test.cpp?rev=1182557&r1=1182556&r2=1182557&view=diff
==============================================================================
--- qpid/branches/qpid-2920-active/qpid/cpp/src/tests/exception_test.cpp (original)
+++ qpid/branches/qpid-2920-active/qpid/cpp/src/tests/exception_test.cpp Wed Oct 12 19:55:26 2011
@@ -33,10 +33,6 @@ namespace tests {
 
 QPID_AUTO_TEST_SUITE(exception_test)
 
-// FIXME aconway 2008-06-12: need to update our exception handling to
-// 0-10 handling and extend this test to provoke all the exceptional
-// conditions we know of and verify the correct exception is thrown.
-
 using namespace std;
 using namespace qpid;
 using namespace sys;
@@ -88,7 +84,7 @@ QPID_AUTO_TEST_CASE(TestSessionBusy) {
         ScopedSuppressLogging sl; // Suppress messages for expected errors.
         f.connection.newSession(f.session.getId().getName());
         BOOST_FAIL("Expected SessionBusyException for " << f.session.getId().getName());
-    } catch (const SessionBusyException&) {} // FIXME aconway 2008-09-22: client is not throwing correct exception.
+    } catch (const SessionBusyException&) {}
 }
 
 QPID_AUTO_TEST_CASE(DisconnectedPop) {

Modified: qpid/branches/qpid-2920-active/qpid/cpp/src/tests/topictest
URL: http://svn.apache.org/viewvc/qpid/branches/qpid-2920-active/qpid/cpp/src/tests/topictest?rev=1182557&r1=1182556&r2=1182557&view=diff
==============================================================================
--- qpid/branches/qpid-2920-active/qpid/cpp/src/tests/topictest (original)
+++ qpid/branches/qpid-2920-active/qpid/cpp/src/tests/topictest Wed Oct 12 19:55:26 2011
@@ -56,6 +56,6 @@ publish() {
 for ((i=$SUBSCRIBERS ; i--; )); do
     subscribe $i &
 done
-# FIXME aconway 2007-03-27: Hack around startup race. Fix topic test.
+
 sleep 2
 publish 2>&1 || exit 1

Modified: qpid/branches/qpid-2920-active/qpid/cpp/src/tests/topictest.ps1
URL: http://svn.apache.org/viewvc/qpid/branches/qpid-2920-active/qpid/cpp/src/tests/topictest.ps1?rev=1182557&r1=1182556&r2=1182557&view=diff
==============================================================================
--- qpid/branches/qpid-2920-active/qpid/cpp/src/tests/topictest.ps1 (original)
+++ qpid/branches/qpid-2920-active/qpid/cpp/src/tests/topictest.ps1 Wed Oct 12 19:55:26 2011
@@ -67,7 +67,6 @@ while ($i -gt 0) {
   $i--
 }
 
-# FIXME aconway 2007-03-27: Hack around startup race. Fix topic test.
 Start-Sleep 2
 publish $sub
 exit $LastExitCode



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