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 2018/01/05 16:35:26 UTC

[02/50] [abbrv] qpid-proton git commit: PROTON-1537: [ruby] Fix copyright comments and top-level yard doc

PROTON-1537: [ruby] Fix copyright comments and top-level yard doc

Removed useless #-- #++ brackets around copyright comments; they were supposed
to prevent them being attached as doc comments to the first definition in the
file but they don't. What does work is making sure there are 2 empty lines after
the copyright comment and before the first definition.

Clean up the top level doc comments and references.


Project: http://git-wip-us.apache.org/repos/asf/qpid-proton/repo
Commit: http://git-wip-us.apache.org/repos/asf/qpid-proton/commit/7c004d3e
Tree: http://git-wip-us.apache.org/repos/asf/qpid-proton/tree/7c004d3e
Diff: http://git-wip-us.apache.org/repos/asf/qpid-proton/diff/7c004d3e

Branch: refs/heads/go1
Commit: 7c004d3eb0408bff6548db60e9db228fd1c6880f
Parents: 5690209
Author: Alan Conway <ac...@redhat.com>
Authored: Tue Dec 5 14:50:08 2017 -0500
Committer: Alan Conway <ac...@redhat.com>
Committed: Tue Dec 5 16:54:52 2017 -0500

----------------------------------------------------------------------
 proton-c/bindings/ruby/README.rdoc              | 128 +++++---
 proton-c/bindings/ruby/lib/codec/data.rb        |   3 +-
 proton-c/bindings/ruby/lib/codec/mapping.rb     |   3 +-
 proton-c/bindings/ruby/lib/core/condition.rb    |   3 +-
 proton-c/bindings/ruby/lib/core/connection.rb   |   3 +-
 .../bindings/ruby/lib/core/connection_driver.rb | 314 +++++++++----------
 proton-c/bindings/ruby/lib/core/container.rb    |   3 +-
 proton-c/bindings/ruby/lib/core/delivery.rb     |   3 +-
 proton-c/bindings/ruby/lib/core/disposition.rb  |   3 +-
 proton-c/bindings/ruby/lib/core/endpoint.rb     |   3 +-
 proton-c/bindings/ruby/lib/core/event.rb        |   3 +-
 proton-c/bindings/ruby/lib/core/exceptions.rb   | 217 +++++++------
 proton-c/bindings/ruby/lib/core/link.rb         |   3 +-
 proton-c/bindings/ruby/lib/core/listener.rb     |   3 +-
 proton-c/bindings/ruby/lib/core/message.rb      |   3 +-
 .../bindings/ruby/lib/core/messaging_handler.rb |   3 +-
 proton-c/bindings/ruby/lib/core/receiver.rb     |   3 +-
 proton-c/bindings/ruby/lib/core/sasl.rb         |   3 +-
 proton-c/bindings/ruby/lib/core/sender.rb       |   3 +-
 proton-c/bindings/ruby/lib/core/session.rb      |   3 +-
 proton-c/bindings/ruby/lib/core/ssl.rb          |   3 +-
 proton-c/bindings/ruby/lib/core/ssl_details.rb  |   3 +-
 proton-c/bindings/ruby/lib/core/ssl_domain.rb   |   3 +-
 proton-c/bindings/ruby/lib/core/terminus.rb     |   3 +-
 proton-c/bindings/ruby/lib/core/tracker.rb      |   5 +-
 proton-c/bindings/ruby/lib/core/transfer.rb     |   3 +-
 proton-c/bindings/ruby/lib/core/transport.rb    |   3 +-
 proton-c/bindings/ruby/lib/core/uri.rb          |   3 +-
 proton-c/bindings/ruby/lib/core/url.rb          |   3 +-
 proton-c/bindings/ruby/lib/handler/adapter.rb   |   3 +-
 .../bindings/ruby/lib/messenger/messenger.rb    |   3 +-
 .../bindings/ruby/lib/messenger/subscription.rb |   3 +-
 proton-c/bindings/ruby/lib/messenger/tracker.rb |   3 +-
 .../ruby/lib/messenger/tracker_status.rb        |   3 +-
 proton-c/bindings/ruby/lib/qpid_proton.rb       |   5 +-
 proton-c/bindings/ruby/lib/reactor/container.rb |   3 +-
 proton-c/bindings/ruby/lib/types/array.rb       |   3 +-
 proton-c/bindings/ruby/lib/types/described.rb   |   3 +-
 proton-c/bindings/ruby/lib/types/hash.rb        |   3 +-
 proton-c/bindings/ruby/lib/types/strings.rb     |   3 +-
 .../bindings/ruby/lib/util/error_handler.rb     |   3 +-
 proton-c/bindings/ruby/lib/util/swig_helper.rb  |   3 +-
 proton-c/bindings/ruby/lib/util/timeout.rb      |   3 +-
 proton-c/bindings/ruby/lib/util/version.rb      |   3 +-
 proton-c/bindings/ruby/lib/util/wrapper.rb      |   3 +-
 proton-c/bindings/ruby/spec/data_spec.rb        |   3 +-
 .../ruby/spec/exception_handling_spec.rb        |   3 +-
 proton-c/bindings/ruby/spec/message_spec.rb     |   3 +-
 .../bindings/ruby/tests/old_examples/broker.rb  |   3 +-
 .../bindings/ruby/tests/old_examples/client.rb  |   3 +-
 .../ruby/tests/old_examples/direct_recv.rb      |   3 +-
 .../ruby/tests/old_examples/direct_send.rb      |   3 +-
 .../ruby/tests/old_examples/helloworld.rb       |   3 +-
 .../tests/old_examples/helloworld_direct.rb     |   3 +-
 .../ruby/tests/old_examples/lib/debugging.rb    |   3 +-
 .../ruby/tests/old_examples/lib/driver.rb       |   3 +-
 .../tests/old_examples/lib/qpid_examples.rb     |   3 +-
 .../ruby/tests/old_examples/lib/selectable.rb   |   3 +-
 .../tests/old_examples/lib/send_and_receive.rb  |   3 +-
 .../bindings/ruby/tests/old_examples/server.rb  |   3 +-
 .../ruby/tests/old_examples/simple_recv.rb      |   3 +-
 .../ruby/tests/old_examples/simple_send.rb      |   3 +-
 proton-c/bindings/ruby/tests/test_adapter.rb    |   3 +-
 .../ruby/tests/test_connection_driver.rb        |   3 +-
 proton-c/bindings/ruby/tests/test_container.rb  |   3 +-
 proton-c/bindings/ruby/tests/test_tools.rb      |   3 +-
 proton-c/bindings/ruby/tests/test_uri.rb        |   3 +-
 67 files changed, 416 insertions(+), 439 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/7c004d3e/proton-c/bindings/ruby/README.rdoc
----------------------------------------------------------------------
diff --git a/proton-c/bindings/ruby/README.rdoc b/proton-c/bindings/ruby/README.rdoc
index 75552c8..5eec00f 100644
--- a/proton-c/bindings/ruby/README.rdoc
+++ b/proton-c/bindings/ruby/README.rdoc
@@ -1,73 +1,121 @@
-= Qpid Proton Ruby Language Bindings
+= Qpid Proton AMQP Library
 
-This is a Ruby language binding for the Qpid proton AMQP messaging library.
-You can build clients and servers using this library.
+This is a library for sending and receiving AMQP messages. It can be used to
+build clients and servers.
 
-== Class Overview
-
-The {Qpid::Proton} module contains the key classes:
+== Installing
 
-{Qpid::Proton::Message} represents a message that can be sent or received.
-A message body can be a string or byte sequence encoded any way you choose. However, AMQP also provides standard, interoperable encodings for basic data types like {Hash} and {Array}. The equivalent AMQP encodings can be understood as maps or sequences in any programming langauge with an AMQP library.
+You can install the latest published Gem with
 
-{Qpid::Proton::Link} allows messages to be transferred to or from a remote AMQP process. The {Qpid::Proton::Sender} subclass sends messages, the {Qpid::Proton::Receiver} subclass receives them. Links have a source and target address, as explained below.
+    gem install qpid_proton
 
-Links are grouped in a {Qpid::Proton::Session}. Messages in the same session are sent sequentially, while those on different sessions can be interleaved. A large message being sent on one session does not block messages being sent on another session.
+*NOTE:* before installing the Gem, you must install the proton-C library.
 
-Sessions belong to a {Qpid::Proton::Connection}. If you don't need multiple sessions, a connection will create links directly using a default session.
+The proton-C library can be installed by the package manager on many platforms,
+    e.g.  yum install qpid-proton-c # Fedora < 25, RHEL < 7 dnf install
+    qpid-proton-c # Fedora >= 25, RHEL >= 7
 
-A {Qpid::Proton::Transfer} represents the transfer of a message, the {Qpid::Proton::Delivery} subclass allows a receiver to accept or reject an incoming message. The {Qpid::Proton::Tracker} subclass allows a sender to track the status of a sent message and find out if it was accepted or rejected.
+You can also download a source release or the latest development code from
+http://qpid.apache.org/proton. To build from source:
 
-A transfer is _settled_ when both ends are done with it. Different settlement methods give different levels of reliability: at-most-once, at-least-once, and exactly-once. See below.
+    cmake -DBUILD_BINDINGS=ruby && make
 
-== The anatomy of a Proton application
+This produces a Gem file at:
 
-{Qpid::Proton::Container} is the top-level object in a Proton application. A client uses {Qpid::Proton::Container#connect} to establish connections. A server uses {Qpid::Proton::Container#listen} to accept connections.
+    ${CMAKE_BUILD_DIR}/proton-c/bindings/ruby/qpid_proton-${PN_VERSION}.gem
 
-Proton is an event-driven API. You implement a subclass of {Qpid::Proton::MessagingHandler MessagingHandler} and override functions to handle AMQP events, such as {Qpid::Proton::MessagingHandler#on_message #on_message}. Each connection is associated with a handler for its events. {Qpid::Proton::Container#run} polls all connections and listeners and calls the event handling functions on your handlers.
+You can install the gem with +gem install+
 
-A multi-threaded application can call {Qpid::Proton::Container#run} in more than one thread, the container will use all the {Qpid::Proton::Container#run #run} threads as a thread pool to dispatch events.
+== Overview
 
-== Sources and targets
+{Qpid::Proton::Message} represents a message that can be sent or received.  A
+message body can be a string or byte sequence encoded any way you
+choose. However, AMQP also provides standard, interoperable encodings for basic
+data types like {Hash} and {Array}. The equivalent AMQP encodings can be
+understood as maps or sequences in any programming langauge with an AMQP
+library.
 
-Every link has two addresses, _source_ and _target_. The most common pattern for using these addresses is as follows:
+{Qpid::Proton::Link} allows messages to be transferred to or from a remote AMQP
+process. The {Qpid::Proton::Sender} subclass sends messages, the
+{Qpid::Proton::Receiver} subclass receives them. Links have a source and target
+address, as explained below.
 
-When a client creates a {Qpid::Proton::Receiver Receiver} link, it sets the _source_ address. This means "I want to receive messages from this source". This is often referred to as "subscribing" to the source. When a client creates a {Qpid::Proton::Sender Sender} link, it sets the _target_ address. This means "I want to send to this target".
+Links are grouped in a {Qpid::Proton::Session}. Messages in the same session are
+sent sequentially, while those on different sessions can be interleaved. A large
+message being sent on one session does not block messages being sent on another
+session.
 
-In the case of a broker, the source or target usually refers to a queue or topic. In general they can refer to any AMQP-capable node.
+Sessions belong to a {Qpid::Proton::Connection}. If you don't need multiple
+sessions, a connection will create links directly using a default session.
 
-In the request-response pattern, a request message carries a reply-to address for the response message. This can be any AMQP address, but it is often useful to create a temporary address for the response message. The client creates a receiver with no source address and the dynamic flag set. The server generates a unique source address for the receiver, which is discarded when the link closes. The client uses this source address as the reply-to when it sends the request, so the response is delivered to the client's receiver.
+A {Qpid::Proton::Transfer} represents the transfer of a message, the
+{Qpid::Proton::Delivery} subclass allows a receiver to accept or reject an
+incoming message. The {Qpid::Proton::Tracker} subclass allows a sender to track
+the status of a sent message and find out if it was accepted or rejected.
 
-The server_direct.cpp example shows how to implement a request-response server.
+A transfer is _settled_ when both ends are done with it. Different settlement
+methods give different levels of reliability: at-most-once, at-least-once, and
+exactly-once. See below.
 
-== Settling a Message Transfer
+== Anatomy of a Proton application
 
-A message transfer is _settled_ at one end of a link when that end of the link
-has finished with the message and forgotten it.
+{Qpid::Proton::Container} is the top-level object in a Proton application. A
+client uses {Qpid::Proton::Container#connect} to establish connections. A server
+uses {Qpid::Proton::Container#listen} to accept connections.
 
-_Pre-settled_ messages are settled by the sender before sending. This gives _at most once_ reliability(also known as _best effort_,  _unreliable_ or _fire and forget_) since the sender never knows for sure if the message arrived. If the connection is lost before the message is received by the receiver, the message will not be delivered.
+Proton is an event-driven library. You implement one or more _handlers_ which
+subclass {Qpid::Proton::MessagingHandler MessagingHandler} and override
+functions to handle AMQP events, such as {Qpid::Proton::MessagingHandler#on_message
+#on_message}. Each connection is associated with a handler for its
+events. {Qpid::Proton::Container#run} polls all connections and listeners and
+calls the event handling functions on your handlers.
 
-If the sender does not pre-settle a message, then the receiver settles it once it has been processed. The sender is informed of the settlement via the {Qpid::Proton::Tracker Tracker}. If the connection is lost before the sender has received notice of settlement, the delivery is considered in-doubt and the sender can re-send it. This ensures it eventually gets delivered (provided the connection and link can be reestablished) but it is possible for multiple copies of the same message are delivered, so the receiver must be aware of that. This is known as _at_least_once_ reliability.
+A multi-threaded application can call {Qpid::Proton::Container#run} in more than
+one thread, the container will use all the {Qpid::Proton::Container#run #run}
+threads as a thread pool to dispatch events.
 
-== Installing
+== Sources and targets
 
-You can install the latest published Gem with
+Every link has two addresses, _source_ and _target_. The most common pattern for
+using these addresses is as follows:
 
-    gem install qpid_proton
+When a client creates a {Qpid::Proton::Receiver Receiver} link, it sets the
+_source_ address. This means "I want to receive messages from this source". This
+is often referred to as "subscribing" to the source. When a client creates a
+{Qpid::Proton::Sender Sender} link, it sets the _target_ address. This means "I
+want to send to this target".
 
-*NOTE:* before installing the Gem, you must install the proton-C library.
+In the case of a broker, the source or target usually refers to a queue or
+topic. In general they can refer to any AMQP-capable node.
 
-The proton-C library can be installed by the package manager on many platforms, e.g.
-    yum install qpid-proton-c # Fedora < 25, RHEL < 7
-    dnf install qpid-proton-c # Fedora >= 25, RHEL >= 7
+In the request-response pattern, a request message carries a reply-to address
+for the response message. This can be any AMQP address, but it is often useful
+to create a temporary address for the response message. The client creates a
+receiver with no source address and the dynamic flag set. The server generates a
+unique source address for the receiver, which is discarded when the link
+closes. The client uses this source address as the reply-to when it sends the
+request, so the response is delivered to the client's receiver.
 
-You can also download a source release or the latest development code from http://qpid.apache.org/proton. To build from source:
+The server_direct.cpp example shows how to implement a request-response server.
 
-    cmake -DBUILD_BINDINGS=ruby && make
+== Settling a Message Transfer
 
-This produces a Gem file at:
+A message transfer is _settled_ at one end of a link when that end of the link
+has finished with the message and forgotten it.
 
-    ${CMAKE_BUILD_DIR}/proton-c/bindings/ruby/qpid_proton-${PN_VERSION}.gem
+_Pre-settled_ messages are settled by the sender before sending. This gives _at
+most once_ reliability(also known as _best effort_, _unreliable_ or _fire and
+forget_) since the sender never knows for sure if the message arrived. If the
+connection is lost before the message is received by the receiver, the message
+will not be delivered.
+
+If the sender does not pre-settle a message, then the receiver settles it once
+it has been processed. The sender is informed of the settlement via the
+{Qpid::Proton::Tracker Tracker}. If the connection is lost before the sender has
+received notice of settlement, the delivery is considered in-doubt and the
+sender can re-send it. This ensures it eventually gets delivered (provided the
+connection and link can be reestablished) but it is possible for multiple copies
+of the same message are delivered, so the receiver must be aware of that. This
+is known as _at_least_once_ reliability.
 
-You can install the gem with +gem install+
 

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/7c004d3e/proton-c/bindings/ruby/lib/codec/data.rb
----------------------------------------------------------------------
diff --git a/proton-c/bindings/ruby/lib/codec/data.rb b/proton-c/bindings/ruby/lib/codec/data.rb
index 2742008..f287d64 100644
--- a/proton-c/bindings/ruby/lib/codec/data.rb
+++ b/proton-c/bindings/ruby/lib/codec/data.rb
@@ -1,4 +1,3 @@
-#--
 # 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
@@ -15,7 +14,7 @@
 # KIND, either express or implied.  See the License for the
 # specific language governing permissions and limitations
 # under the License.
-#++
+
 
 module Qpid::Proton::Codec
 

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/7c004d3e/proton-c/bindings/ruby/lib/codec/mapping.rb
----------------------------------------------------------------------
diff --git a/proton-c/bindings/ruby/lib/codec/mapping.rb b/proton-c/bindings/ruby/lib/codec/mapping.rb
index 5a498b4..fbebb57 100644
--- a/proton-c/bindings/ruby/lib/codec/mapping.rb
+++ b/proton-c/bindings/ruby/lib/codec/mapping.rb
@@ -1,4 +1,3 @@
-#--
 # 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
@@ -15,7 +14,7 @@
 # KIND, either express or implied.  See the License for the
 # specific language governing permissions and limitations
 # under the License.
-#++
+
 
 module Qpid::Proton::Codec
 

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/7c004d3e/proton-c/bindings/ruby/lib/core/condition.rb
----------------------------------------------------------------------
diff --git a/proton-c/bindings/ruby/lib/core/condition.rb b/proton-c/bindings/ruby/lib/core/condition.rb
index 05231c6..d22dafe 100644
--- a/proton-c/bindings/ruby/lib/core/condition.rb
+++ b/proton-c/bindings/ruby/lib/core/condition.rb
@@ -1,4 +1,3 @@
-#--
 # 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
@@ -15,7 +14,7 @@
 # KIND, either express or implied.  See the License for the
 # specific language governing permissions and limitations
 # under the License.
-#++
+
 
 module Qpid::Proton
 

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/7c004d3e/proton-c/bindings/ruby/lib/core/connection.rb
----------------------------------------------------------------------
diff --git a/proton-c/bindings/ruby/lib/core/connection.rb b/proton-c/bindings/ruby/lib/core/connection.rb
index 3715080..96fd211 100644
--- a/proton-c/bindings/ruby/lib/core/connection.rb
+++ b/proton-c/bindings/ruby/lib/core/connection.rb
@@ -1,4 +1,3 @@
-#--
 # 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
@@ -15,7 +14,7 @@
 # KIND, either express or implied.  See the License for the
 # specific language governing permissions and limitations
 # under the License.
-#++
+
 
 module Qpid::Proton
 

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/7c004d3e/proton-c/bindings/ruby/lib/core/connection_driver.rb
----------------------------------------------------------------------
diff --git a/proton-c/bindings/ruby/lib/core/connection_driver.rb b/proton-c/bindings/ruby/lib/core/connection_driver.rb
index 969b558..fe52d75 100644
--- a/proton-c/bindings/ruby/lib/core/connection_driver.rb
+++ b/proton-c/bindings/ruby/lib/core/connection_driver.rb
@@ -17,190 +17,188 @@
 
 require 'socket'
 
-module Qpid
-  module Proton
-
-    # Associate an AMQP {Connection} and {Transport} with an {IO}
-    #
-    # - {#read} reads AMQP binary data from the {IO} and generates events
-    # - {#tick} generates timing-related events
-    # - {#event} gets events to be dispatched to {Handler::MessagingHandler}s
-    # - {#write} writes AMQP binary data to the {IO}
-    #
-    # Thread safety: The {ConnectionDriver} is not thread safe but separate
-    # {ConnectionDriver} instances can be processed concurrently. The
-    # {Container} handles multiple connections concurrently in multiple threads.
-    #
-    class ConnectionDriver
-      # Create a {Connection} and {Transport} associated with +io+
-      # @param io [IO] An {IO} or {IO}-like object that responds
-      #   to {IO#read_nonblock} and {IO#write_nonblock}
-      def initialize(io)
-        @impl = Cproton.pni_connection_driver or raise NoMemoryError
-        @io = io
-        @rbuf = ""              # String for re-usable read buffer
-      end
+module Qpid::Proton
+
+  # Associate an AMQP {Connection} and {Transport} with an {IO}
+  #
+  # - {#read} reads AMQP binary data from the {IO} and generates events
+  # - {#tick} generates timing-related events
+  # - {#event} gets events to be dispatched to {Handler::MessagingHandler}s
+  # - {#write} writes AMQP binary data to the {IO}
+  #
+  # Thread safety: The {ConnectionDriver} is not thread safe but separate
+  # {ConnectionDriver} instances can be processed concurrently. The
+  # {Container} handles multiple connections concurrently in multiple threads.
+  #
+  class ConnectionDriver
+    # Create a {Connection} and {Transport} associated with +io+
+    # @param io [IO] An {IO} or {IO}-like object that responds
+    #   to {IO#read_nonblock} and {IO#write_nonblock}
+    def initialize(io)
+      @impl = Cproton.pni_connection_driver or raise NoMemoryError
+      @io = io
+      @rbuf = ""              # String for re-usable read buffer
+    end
 
-      # @return [Connection]
-      def connection()
-        @connection ||= Connection.wrap(Cproton.pni_connection_driver_connection(@impl))
-      end
+    # @return [Connection]
+    def connection()
+      @connection ||= Connection.wrap(Cproton.pni_connection_driver_connection(@impl))
+    end
 
-      # @return [Transport]
-      def transport()
-        @transport ||= Transport.wrap(Cproton.pni_connection_driver_transport(@impl))
-      end
+    # @return [Transport]
+    def transport()
+      @transport ||= Transport.wrap(Cproton.pni_connection_driver_transport(@impl))
+    end
 
-      # @return [IO] Allows ConnectionDriver to be passed directly to {IO#select}
-      def to_io() @io; end
+    # @return [IO] Allows ConnectionDriver to be passed directly to {IO#select}
+    def to_io() @io; end
 
-      # @return [Bool] True if the driver can read more data
-      def can_read?() Cproton.pni_connection_driver_read_size(@impl) > 0; end
+    # @return [Bool] True if the driver can read more data
+    def can_read?() Cproton.pni_connection_driver_read_size(@impl) > 0; end
 
-      # @return [Bool] True if the driver has data to write
-      def can_write?() Cproton.pni_connection_driver_write_size(@impl) > 0; end
+    # @return [Bool] True if the driver has data to write
+    def can_write?() Cproton.pni_connection_driver_write_size(@impl) > 0; end
 
-      # True if the ConnectionDriver has nothing left to do: both sides of the
-      # transport are closed and there are no events to dispatch.
-      def finished?() Cproton.pn_connection_driver_finished(@impl); end
+    # True if the ConnectionDriver has nothing left to do: both sides of the
+    # transport are closed and there are no events to dispatch.
+    def finished?() Cproton.pn_connection_driver_finished(@impl); end
 
-      # Get the next event to dispatch, nil if no events available
-      def event()
-        e = Cproton.pn_connection_driver_next_event(@impl)
-        Event.new(e) if e
-      end
+    # Get the next event to dispatch, nil if no events available
+    def event()
+      e = Cproton.pn_connection_driver_next_event(@impl)
+      Event.new(e) if e
+    end
 
-      # True if {#event} will return non-nil
-      def event?() Cproton.pn_connection_driver_has_event(@impl); end
+    # True if {#event} will return non-nil
+    def event?() Cproton.pn_connection_driver_has_event(@impl); end
 
-      # Iterator for all available events
-      def each_event()
-        while e = event
-          yield e
-        end
+    # Iterator for all available events
+    def each_event()
+      while e = event
+        yield e
       end
+    end
 
-      # Non-blocking read from {#io}, generate events for {#event}
-      # IO errors are returned as transport errors by {#event}, not raised
-      def read
-        size = Cproton.pni_connection_driver_read_size(@impl)
-        return if size <= 0
-        @io.read_nonblock(size, @rbuf) # Use the same string rbuf for reading each time
-        Cproton.pni_connection_driver_read_copy(@impl, @rbuf) unless @rbuf.empty?
-      rescue Errno::EWOULDBLOCK, Errno::EAGAIN, Errno::EINTR
-        # Try again later.
-      rescue EOFError         # EOF is not an error
-        close_read
-      rescue IOError, SystemCallError => e
-        close e
-      end
+    # Non-blocking read from {#io}, generate events for {#event}
+    # IO errors are returned as transport errors by {#event}, not raised
+    def read
+      size = Cproton.pni_connection_driver_read_size(@impl)
+      return if size <= 0
+      @io.read_nonblock(size, @rbuf) # Use the same string rbuf for reading each time
+      Cproton.pni_connection_driver_read_copy(@impl, @rbuf) unless @rbuf.empty?
+    rescue Errno::EWOULDBLOCK, Errno::EAGAIN, Errno::EINTR
+      # Try again later.
+    rescue EOFError         # EOF is not an error
+      close_read
+    rescue IOError, SystemCallError => e
+      close e
+    end
 
-      # Non-blocking write to {#io}
-      # IO errors are returned as transport errors by {#event}, not raised
-      def write
-        n = @io.write_nonblock(Cproton.pn_connection_driver_write_buffer(@impl))
-        Cproton.pn_connection_driver_write_done(@impl, n) if n > 0
-      rescue Errno::EWOULDBLOCK, Errno::EAGAIN, Errno::EINTR
-        # Try again later.
-      rescue IOError, SystemCallError => e
-        close e
-      end
+    # Non-blocking write to {#io}
+    # IO errors are returned as transport errors by {#event}, not raised
+    def write
+      n = @io.write_nonblock(Cproton.pn_connection_driver_write_buffer(@impl))
+      Cproton.pn_connection_driver_write_done(@impl, n) if n > 0
+    rescue Errno::EWOULDBLOCK, Errno::EAGAIN, Errno::EINTR
+      # Try again later.
+    rescue IOError, SystemCallError => e
+      close e
+    end
 
-      # Handle time-related work, for example idle-timeout events.
-      # May generate events for {#event} and change {#can_read?}, {#can_write?}
-      #
-      # @param [Time] now the current time, defaults to {Time#now}.
-      #
-      # @return [Time] time of the next scheduled event, or nil if there are no
-      # scheduled events. If non-nil you must call {#tick} again no later than
-      # this time.
-      def tick(now=Time.now)
-        transport = Cproton.pni_connection_driver_transport(@impl)
-        ms = Cproton.pn_transport_tick(transport, (now.to_r * 1000).to_i)
-        return ms.zero? ? nil : Time.at(ms.to_r / 1000);
-      end
+    # Handle time-related work, for example idle-timeout events.
+    # May generate events for {#event} and change {#can_read?}, {#can_write?}
+    #
+    # @param [Time] now the current time, defaults to {Time#now}.
+    #
+    # @return [Time] time of the next scheduled event, or nil if there are no
+    # scheduled events. If non-nil you must call {#tick} again no later than
+    # this time.
+    def tick(now=Time.now)
+      transport = Cproton.pni_connection_driver_transport(@impl)
+      ms = Cproton.pn_transport_tick(transport, (now.to_r * 1000).to_i)
+      return ms.zero? ? nil : Time.at(ms.to_r / 1000);
+    end
 
-      # Disconnect the write side of the transport, *without* sending an AMQP
-      # close frame. To close politely, you should use {Connection#close}, the
-      # transport will close itself once the protocol close is complete.
-      #
-      def close_write error=nil
-        set_error error
-        Cproton.pn_connection_driver_write_close(@impl)
-        @io.close_write rescue nil # Allow double-close
-      end
+    # Disconnect the write side of the transport, *without* sending an AMQP
+    # close frame. To close politely, you should use {Connection#close}, the
+    # transport will close itself once the protocol close is complete.
+    #
+    def close_write error=nil
+      set_error error
+      Cproton.pn_connection_driver_write_close(@impl)
+      @io.close_write rescue nil # Allow double-close
+    end
 
-      # Is the read side of the driver closed?
-      def read_closed?() Cproton.pn_connection_driver_read_closed(@impl); end
+    # Is the read side of the driver closed?
+    def read_closed?() Cproton.pn_connection_driver_read_closed(@impl); end
 
-      # Is the write side of the driver closed?
-      def write_closed?() Cproton.pn_connection_driver_read_closed(@impl); end
+    # Is the write side of the driver closed?
+    def write_closed?() Cproton.pn_connection_driver_read_closed(@impl); end
 
-      # Disconnect the read side of the transport, without waiting for an AMQP
-      # close frame. See comments on {#close_write}
-      def close_read error=nil
-        set_error error
-        Cproton.pn_connection_driver_read_close(@impl)
-        @io.close_read rescue nil # Allow double-close
-      end
+    # Disconnect the read side of the transport, without waiting for an AMQP
+    # close frame. See comments on {#close_write}
+    def close_read error=nil
+      set_error error
+      Cproton.pn_connection_driver_read_close(@impl)
+      @io.close_read rescue nil # Allow double-close
+    end
 
-      # Disconnect both sides of the transport sending/waiting for AMQP close
-      # frames. See comments on {#close_write}
-      def close error=nil
-        close_write error
-        close_read
-      end
+    # Disconnect both sides of the transport sending/waiting for AMQP close
+    # frames. See comments on {#close_write}
+    def close error=nil
+      close_write error
+      close_read
+    end
 
-      private
+    private
 
-      def set_error err
-        transport.condition ||= Condition.convert(err, "proton:io") if err
-      end
+    def set_error err
+      transport.condition ||= Condition.convert(err, "proton:io") if err
     end
+  end
 
-    # A {ConnectionDriver} that feeds events to a {Handler::MessagingHandler}
-    class HandlerDriver < ConnectionDriver
-      # Combine an {IO} with a {Handler::MessagingHandler} and provide
-      # a simplified way to run the driver via {#process}
-      #
-      # @param io [IO]
-      # @param handler [Handler::MessagingHandler] to receive events in
-      #   {#dispatch} and {#process}
-      def initialize(io, handler)
-        super(io)
-        # Allow multiple handlers for backwards compatibility
-        a = Array(handler)
-        @handler = a.size > 1 ? MessagingHandlers.new(a) : handler
-        @adapter = Handler::Adapter.try_convert(handler)
-      end
-
-      # @return [MessagingHandler] The handler dispatched to by {#process}
-      attr_reader :handler
+  # A {ConnectionDriver} that feeds events to a {Handler::MessagingHandler}
+  class HandlerDriver < ConnectionDriver
+    # Combine an {IO} with a {Handler::MessagingHandler} and provide
+    # a simplified way to run the driver via {#process}
+    #
+    # @param io [IO]
+    # @param handler [Handler::MessagingHandler] to receive events in
+    #   {#dispatch} and {#process}
+    def initialize(io, handler)
+      super(io)
+      # Allow multiple handlers for backwards compatibility
+      a = Array(handler)
+      @handler = a.size > 1 ? MessagingHandlers.new(a) : handler
+      @adapter = Handler::Adapter.try_convert(handler)
+    end
 
-      # Dispatch all events available from {#event} to {#handler}
-      def dispatch() each_event do |e|
-          e.dispatch self       # See private on_transport_ methods below
-          e.dispatch @adapter
-        end
-      end
+    # @return [MessagingHandler] The handler dispatched to by {#process}
+    attr_reader :handler
 
-      # Do {#read}, {#tick}, {#write} and {#dispatch} without blocking.
-      # @param [Time] now the current time
-      # @return [Time] Latest time to call {#process} again for scheduled events,
-      #   or nil if there are no scheduled events
-      def process(now=Time.now)
-        read
-        next_tick = tick(now)
-        dispatch                # Generate data for write
-        write
-        dispatch                # Consume all events
-        return next_tick
+    # Dispatch all events available from {#event} to {#handler}
+    def dispatch() each_event do |e|
+        e.dispatch self       # See private on_transport_ methods below
+        e.dispatch @adapter
       end
+    end
 
-      private
-      def on_transport_tail_closed(event) close_read; end
-      def on_transport_head_closed(event) close_write; end
-      def on_transport_authenticated(event) connection.user = transport.user; end
+    # Do {#read}, {#tick}, {#write} and {#dispatch} without blocking.
+    # @param [Time] now the current time
+    # @return [Time] Latest time to call {#process} again for scheduled events,
+    #   or nil if there are no scheduled events
+    def process(now=Time.now)
+      read
+      next_tick = tick(now)
+      dispatch                # Generate data for write
+      write
+      dispatch                # Consume all events
+      return next_tick
     end
+
+    private
+    def on_transport_tail_closed(event) close_read; end
+    def on_transport_head_closed(event) close_write; end
+    def on_transport_authenticated(event) connection.user = transport.user; end
   end
 end

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/7c004d3e/proton-c/bindings/ruby/lib/core/container.rb
----------------------------------------------------------------------
diff --git a/proton-c/bindings/ruby/lib/core/container.rb b/proton-c/bindings/ruby/lib/core/container.rb
index fdc0247..91a3d2a 100644
--- a/proton-c/bindings/ruby/lib/core/container.rb
+++ b/proton-c/bindings/ruby/lib/core/container.rb
@@ -1,4 +1,3 @@
-#--
 # 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
@@ -15,7 +14,7 @@
 # KIND, either express or implied.  See the License for the
 # specific language governing permissions and limitations
 # under the License.
-#++
+
 
 require 'thread'
 require 'set'

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/7c004d3e/proton-c/bindings/ruby/lib/core/delivery.rb
----------------------------------------------------------------------
diff --git a/proton-c/bindings/ruby/lib/core/delivery.rb b/proton-c/bindings/ruby/lib/core/delivery.rb
index 30307f6..b08c667 100644
--- a/proton-c/bindings/ruby/lib/core/delivery.rb
+++ b/proton-c/bindings/ruby/lib/core/delivery.rb
@@ -1,4 +1,3 @@
-#--
 # 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
@@ -14,7 +13,7 @@
 # KIND, either express or implied.  See the License for the
 # specific language governing permissions and limitations
 # under the License.
-#++
+
 
 module Qpid::Proton
   # Allow a {Receiver} to indicate the status of a received message to the {Sender}

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/7c004d3e/proton-c/bindings/ruby/lib/core/disposition.rb
----------------------------------------------------------------------
diff --git a/proton-c/bindings/ruby/lib/core/disposition.rb b/proton-c/bindings/ruby/lib/core/disposition.rb
index 3a24f7a..71a4593 100644
--- a/proton-c/bindings/ruby/lib/core/disposition.rb
+++ b/proton-c/bindings/ruby/lib/core/disposition.rb
@@ -1,4 +1,3 @@
-#--
 # 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
@@ -15,7 +14,7 @@
 # KIND, either express or implied.  See the License for the
 # specific language governing permissions and limitations
 # under the License.
-#++
+
 
 module Qpid::Proton
 

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/7c004d3e/proton-c/bindings/ruby/lib/core/endpoint.rb
----------------------------------------------------------------------
diff --git a/proton-c/bindings/ruby/lib/core/endpoint.rb b/proton-c/bindings/ruby/lib/core/endpoint.rb
index ea2b11f..bd66f7a 100644
--- a/proton-c/bindings/ruby/lib/core/endpoint.rb
+++ b/proton-c/bindings/ruby/lib/core/endpoint.rb
@@ -1,4 +1,3 @@
-#--
 # 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
@@ -15,7 +14,7 @@
 # KIND, either express or implied.  See the License for the
 # specific language governing permissions and limitations
 # under the License.
-#++
+
 
 module Qpid::Proton
 

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/7c004d3e/proton-c/bindings/ruby/lib/core/event.rb
----------------------------------------------------------------------
diff --git a/proton-c/bindings/ruby/lib/core/event.rb b/proton-c/bindings/ruby/lib/core/event.rb
index 552a605..37a089b 100644
--- a/proton-c/bindings/ruby/lib/core/event.rb
+++ b/proton-c/bindings/ruby/lib/core/event.rb
@@ -1,4 +1,3 @@
-#--
 # 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
@@ -15,7 +14,7 @@
 # KIND, either express or implied.  See the License for the
 # specific language governing permissions and limitations
 # under the License.
-#++
+
 
 module Qpid::Proton
   # AMQP protocol event.

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/7c004d3e/proton-c/bindings/ruby/lib/core/exceptions.rb
----------------------------------------------------------------------
diff --git a/proton-c/bindings/ruby/lib/core/exceptions.rb b/proton-c/bindings/ruby/lib/core/exceptions.rb
index adef927..f88b3c8 100644
--- a/proton-c/bindings/ruby/lib/core/exceptions.rb
+++ b/proton-c/bindings/ruby/lib/core/exceptions.rb
@@ -1,4 +1,3 @@
-#--
 # 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
@@ -15,117 +14,113 @@
 # KIND, either express or implied.  See the License for the
 # specific language governing permissions and limitations
 # under the License.
-#++
-
-module Qpid
-
-  module Proton
-
-    module Error
-
-      NONE = 0
-      EOS = Cproton::PN_EOS
-      ERROR = Cproton::PN_ERR
-      OVERFLOW = Cproton::PN_OVERFLOW
-      UNDERFLOW = Cproton::PN_UNDERFLOW
-      STATE = Cproton::PN_STATE_ERR
-      ARGUMENT = Cproton::PN_ARG_ERR
-      TIMEOUT = Cproton::PN_TIMEOUT
-      INTERRUPTED = Cproton::PN_INTR
-      INPROGRESS = Cproton::PN_INPROGRESS
-
-    end
-
-    # Represents a generic error at the messaging level.
-    #
-    class ProtonError < RuntimeError
-    end
-
-    # Represents an end-of-stream error while messaging.
-    #
-    class EOSError < ProtonError
-    end
-
-    # Represents a data overflow exception while messaging.
-    #
-    class OverflowError < ProtonError
-    end
-
-    # Represents a data underflow exception while messaging.
-    #
-    class UnderflowError < ProtonError
-    end
-
-    # Represents an invalid, missing or illegal argument while messaging.
-    #
-    class ArgumentError < ProtonError
-    end
-
-    # Represents that the client has got into an unexpected state during
-    # messaging.
-    #
-    class StateError < ProtonError
-    end
-
-    # Represents a timeout during messaging.
-    #
-    class TimeoutError < ProtonError
-    end
-
-    # Represents an interrupting during a blocking I/O operation.
-    #
-    class InterruptedError < ProtonError
-    end
-
-    class InProgressError < ProtonError
-    end
-
-    # Raised by instances of Transport.
-    #
-    class TransportError < ProtonError
-    end
-
-    # Raised by instances of SASL
-    #
-    class SASLError < TransportError
-    end
-
-    # Raised by Session.
-    #
-    class SessionError < ProtonError
-    end
-
-    # Raised when an attempt is made to change an attribute that is read-only.
-    #
-    class AttributeError < ProtonError
-    end
-
-    # Raised by link components.
-    #
-    class LinkError < ProtonError
-    end
-
-    class SSLError < TransportError
-    end
-
-    class SSLUnavailableError < SSLError
-    end
-
-    # Raised when a message is rejected.
-    #
-    class Reject < ProtonError
-    end
-
-    # Raised when a message is released.
-    #
-    class Release < ProtonError
-    end
-
-    # Raised when a message is aborted.
-    #
-    class Aborted < ProtonError
-    end
 
+
+module Qpid::Proton
+
+  module Error
+
+    NONE = 0
+    EOS = Cproton::PN_EOS
+    ERROR = Cproton::PN_ERR
+    OVERFLOW = Cproton::PN_OVERFLOW
+    UNDERFLOW = Cproton::PN_UNDERFLOW
+    STATE = Cproton::PN_STATE_ERR
+    ARGUMENT = Cproton::PN_ARG_ERR
+    TIMEOUT = Cproton::PN_TIMEOUT
+    INTERRUPTED = Cproton::PN_INTR
+    INPROGRESS = Cproton::PN_INPROGRESS
+
+  end
+
+  # Represents a generic error at the messaging level.
+  #
+  class ProtonError < RuntimeError
+  end
+
+  # Represents an end-of-stream error while messaging.
+  #
+  class EOSError < ProtonError
+  end
+
+  # Represents a data overflow exception while messaging.
+  #
+  class OverflowError < ProtonError
+  end
+
+  # Represents a data underflow exception while messaging.
+  #
+  class UnderflowError < ProtonError
+  end
+
+  # Represents an invalid, missing or illegal argument while messaging.
+  #
+  class ArgumentError < ProtonError
+  end
+
+  # Represents that the client has got into an unexpected state during
+  # messaging.
+  #
+  class StateError < ProtonError
+  end
+
+  # Represents a timeout during messaging.
+  #
+  class TimeoutError < ProtonError
+  end
+
+  # Represents an interrupting during a blocking I/O operation.
+  #
+  class InterruptedError < ProtonError
+  end
+
+  class InProgressError < ProtonError
+  end
+
+  # Raised by instances of Transport.
+  #
+  class TransportError < ProtonError
+  end
+
+  # Raised by instances of SASL
+  #
+  class SASLError < TransportError
+  end
+
+  # Raised by Session.
+  #
+  class SessionError < ProtonError
+  end
+
+  # Raised when an attempt is made to change an attribute that is read-only.
+  #
+  class AttributeError < ProtonError
+  end
+
+  # Raised by link components.
+  #
+  class LinkError < ProtonError
+  end
+
+  class SSLError < TransportError
+  end
+
+  class SSLUnavailableError < SSLError
+  end
+
+  # Raised when a message is rejected.
+  #
+  class Reject < ProtonError
+  end
+
+  # Raised when a message is released.
+  #
+  class Release < ProtonError
+  end
+
+  # Raised when a message is aborted.
+  #
+  class Aborted < ProtonError
   end
 
 end

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/7c004d3e/proton-c/bindings/ruby/lib/core/link.rb
----------------------------------------------------------------------
diff --git a/proton-c/bindings/ruby/lib/core/link.rb b/proton-c/bindings/ruby/lib/core/link.rb
index e525aa9..f8999cd 100644
--- a/proton-c/bindings/ruby/lib/core/link.rb
+++ b/proton-c/bindings/ruby/lib/core/link.rb
@@ -1,4 +1,3 @@
-#--
 # 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
@@ -15,7 +14,7 @@
 # KIND, either express or implied.  See the License for the
 # specific language governing permissions and limitations
 # under the License.
-#++
+
 
 module Qpid::Proton
 

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/7c004d3e/proton-c/bindings/ruby/lib/core/listener.rb
----------------------------------------------------------------------
diff --git a/proton-c/bindings/ruby/lib/core/listener.rb b/proton-c/bindings/ruby/lib/core/listener.rb
index 3feb44b..e69e88a 100644
--- a/proton-c/bindings/ruby/lib/core/listener.rb
+++ b/proton-c/bindings/ruby/lib/core/listener.rb
@@ -1,4 +1,3 @@
-#--
 # 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
@@ -15,7 +14,7 @@
 # KIND, either express or implied.  See the License for the
 # specific language governing permissions and limitations
 # under the License.
-#++
+
 
 module Qpid::Proton
   # A listener for incoming connections.

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/7c004d3e/proton-c/bindings/ruby/lib/core/message.rb
----------------------------------------------------------------------
diff --git a/proton-c/bindings/ruby/lib/core/message.rb b/proton-c/bindings/ruby/lib/core/message.rb
index a39ab09..0f0c072 100644
--- a/proton-c/bindings/ruby/lib/core/message.rb
+++ b/proton-c/bindings/ruby/lib/core/message.rb
@@ -1,4 +1,3 @@
-#--
 # 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
@@ -15,7 +14,7 @@
 # KIND, either express or implied.  See the License for the
 # specific language governing permissions and limitations
 # under the License.
-#++
+
 
 module Qpid::Proton
 

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/7c004d3e/proton-c/bindings/ruby/lib/core/messaging_handler.rb
----------------------------------------------------------------------
diff --git a/proton-c/bindings/ruby/lib/core/messaging_handler.rb b/proton-c/bindings/ruby/lib/core/messaging_handler.rb
index 8ef9a06..7a793df 100644
--- a/proton-c/bindings/ruby/lib/core/messaging_handler.rb
+++ b/proton-c/bindings/ruby/lib/core/messaging_handler.rb
@@ -1,4 +1,3 @@
-#--
 # 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
@@ -15,7 +14,7 @@
 # KIND, either express or implied.  See the License for the
 # specific language governing permissions and limitations
 # under the License.
-#++
+
 
 module Qpid::Proton
 

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/7c004d3e/proton-c/bindings/ruby/lib/core/receiver.rb
----------------------------------------------------------------------
diff --git a/proton-c/bindings/ruby/lib/core/receiver.rb b/proton-c/bindings/ruby/lib/core/receiver.rb
index df767e2..a78e5b5 100644
--- a/proton-c/bindings/ruby/lib/core/receiver.rb
+++ b/proton-c/bindings/ruby/lib/core/receiver.rb
@@ -1,4 +1,3 @@
-#--
 # 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
@@ -15,7 +14,7 @@
 # KIND, either express or implied.  See the License for the
 # specific language governing permissions and limitations
 # under the License.
-#++
+
 
 module Qpid::Proton
 

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/7c004d3e/proton-c/bindings/ruby/lib/core/sasl.rb
----------------------------------------------------------------------
diff --git a/proton-c/bindings/ruby/lib/core/sasl.rb b/proton-c/bindings/ruby/lib/core/sasl.rb
index 965c889..3787637 100644
--- a/proton-c/bindings/ruby/lib/core/sasl.rb
+++ b/proton-c/bindings/ruby/lib/core/sasl.rb
@@ -1,4 +1,3 @@
-#--
 # 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
@@ -15,7 +14,7 @@
 # KIND, either express or implied.  See the License for the
 # specific language governing permissions and limitations
 # under the License.
-#++
+
 
 module Qpid::Proton
 

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/7c004d3e/proton-c/bindings/ruby/lib/core/sender.rb
----------------------------------------------------------------------
diff --git a/proton-c/bindings/ruby/lib/core/sender.rb b/proton-c/bindings/ruby/lib/core/sender.rb
index 2f45356..bef3460 100644
--- a/proton-c/bindings/ruby/lib/core/sender.rb
+++ b/proton-c/bindings/ruby/lib/core/sender.rb
@@ -1,4 +1,3 @@
-#--
 # 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
@@ -15,7 +14,7 @@
 # KIND, either express or implied.  See the License for the
 # specific language governing permissions and limitations
 # under the License.
-#++
+
 
 module Qpid::Proton
 

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/7c004d3e/proton-c/bindings/ruby/lib/core/session.rb
----------------------------------------------------------------------
diff --git a/proton-c/bindings/ruby/lib/core/session.rb b/proton-c/bindings/ruby/lib/core/session.rb
index 6bed0ba..bdc128f 100644
--- a/proton-c/bindings/ruby/lib/core/session.rb
+++ b/proton-c/bindings/ruby/lib/core/session.rb
@@ -1,4 +1,3 @@
-#--
 # 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
@@ -15,7 +14,7 @@
 # KIND, either express or implied.  See the License for the
 # specific language governing permissions and limitations
 # under the License.
-#++
+
 
 module Qpid::Proton
 

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/7c004d3e/proton-c/bindings/ruby/lib/core/ssl.rb
----------------------------------------------------------------------
diff --git a/proton-c/bindings/ruby/lib/core/ssl.rb b/proton-c/bindings/ruby/lib/core/ssl.rb
index 0b16075..2db1c1c 100644
--- a/proton-c/bindings/ruby/lib/core/ssl.rb
+++ b/proton-c/bindings/ruby/lib/core/ssl.rb
@@ -1,4 +1,3 @@
-#--
 # 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
@@ -15,7 +14,7 @@
 # KIND, either express or implied.  See the License for the
 # specific language governing permissions and limitations
 # under the License.
-#++
+
 
 module Qpid::Proton
 

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/7c004d3e/proton-c/bindings/ruby/lib/core/ssl_details.rb
----------------------------------------------------------------------
diff --git a/proton-c/bindings/ruby/lib/core/ssl_details.rb b/proton-c/bindings/ruby/lib/core/ssl_details.rb
index 5367c80..3f1984a 100644
--- a/proton-c/bindings/ruby/lib/core/ssl_details.rb
+++ b/proton-c/bindings/ruby/lib/core/ssl_details.rb
@@ -1,4 +1,3 @@
-#--
 # 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
@@ -15,7 +14,7 @@
 # KIND, either express or implied.  See the License for the
 # specific language governing permissions and limitations
 # under the License.
-#++
+
 
 module Qpid::Proton
 

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/7c004d3e/proton-c/bindings/ruby/lib/core/ssl_domain.rb
----------------------------------------------------------------------
diff --git a/proton-c/bindings/ruby/lib/core/ssl_domain.rb b/proton-c/bindings/ruby/lib/core/ssl_domain.rb
index 26b4e9d..2a3940d 100644
--- a/proton-c/bindings/ruby/lib/core/ssl_domain.rb
+++ b/proton-c/bindings/ruby/lib/core/ssl_domain.rb
@@ -1,4 +1,3 @@
-#--
 # 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
@@ -15,7 +14,7 @@
 # KIND, either express or implied.  See the License for the
 # specific language governing permissions and limitations
 # under the License.
-#++
+
 
 module Qpid::Proton
 

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/7c004d3e/proton-c/bindings/ruby/lib/core/terminus.rb
----------------------------------------------------------------------
diff --git a/proton-c/bindings/ruby/lib/core/terminus.rb b/proton-c/bindings/ruby/lib/core/terminus.rb
index b4927d8..b3d7c05 100644
--- a/proton-c/bindings/ruby/lib/core/terminus.rb
+++ b/proton-c/bindings/ruby/lib/core/terminus.rb
@@ -1,4 +1,3 @@
-#--
 # 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
@@ -15,7 +14,7 @@
 # KIND, either express or implied.  See the License for the
 # specific language governing permissions and limitations
 # under the License.
-#++
+
 
 module Qpid::Proton
 

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/7c004d3e/proton-c/bindings/ruby/lib/core/tracker.rb
----------------------------------------------------------------------
diff --git a/proton-c/bindings/ruby/lib/core/tracker.rb b/proton-c/bindings/ruby/lib/core/tracker.rb
index fbecd61..7363e3a 100644
--- a/proton-c/bindings/ruby/lib/core/tracker.rb
+++ b/proton-c/bindings/ruby/lib/core/tracker.rb
@@ -1,4 +1,3 @@
-#--
 # 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
@@ -15,7 +14,7 @@
 # KIND, either express or implied.  See the License for the
 # specific language governing permissions and limitations
 # under the License.
-#++
+
 
 module Qpid::Proton
 
@@ -24,7 +23,7 @@ module Qpid::Proton
     # @return [Sender] The parent {Sender} link.
     def sender() link; end
 
-    # If {#state} == {#MODIFIED} this method returns additional information
+    # If {#state} == {MODIFIED} this method returns additional information
     # about re-delivery from the receiver's call to {Delivery#release}
     #
     # @return [Hash] See {Delivery#release} options for the meaning of hash entries.

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/7c004d3e/proton-c/bindings/ruby/lib/core/transfer.rb
----------------------------------------------------------------------
diff --git a/proton-c/bindings/ruby/lib/core/transfer.rb b/proton-c/bindings/ruby/lib/core/transfer.rb
index 4d640f0..db2a03e 100644
--- a/proton-c/bindings/ruby/lib/core/transfer.rb
+++ b/proton-c/bindings/ruby/lib/core/transfer.rb
@@ -1,4 +1,3 @@
-#--
 # 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
@@ -15,7 +14,7 @@
 # KIND, either express or implied.  See the License for the
 # specific language governing permissions and limitations
 # under the License.
-#++
+
 
 module Qpid::Proton
 

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/7c004d3e/proton-c/bindings/ruby/lib/core/transport.rb
----------------------------------------------------------------------
diff --git a/proton-c/bindings/ruby/lib/core/transport.rb b/proton-c/bindings/ruby/lib/core/transport.rb
index 9b12be3..4398966 100644
--- a/proton-c/bindings/ruby/lib/core/transport.rb
+++ b/proton-c/bindings/ruby/lib/core/transport.rb
@@ -1,4 +1,3 @@
-#--
 # 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
@@ -15,7 +14,7 @@
 # KIND, either express or implied.  See the License for the
 # specific language governing permissions and limitations
 # under the License.
-#++
+
 
 module Qpid::Proton
 

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/7c004d3e/proton-c/bindings/ruby/lib/core/uri.rb
----------------------------------------------------------------------
diff --git a/proton-c/bindings/ruby/lib/core/uri.rb b/proton-c/bindings/ruby/lib/core/uri.rb
index e9c5add..e347849 100644
--- a/proton-c/bindings/ruby/lib/core/uri.rb
+++ b/proton-c/bindings/ruby/lib/core/uri.rb
@@ -1,4 +1,3 @@
-#--
 # 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
@@ -15,7 +14,7 @@
 # KIND, either express or implied.  See the License for the
 # specific language governing permissions and limitations
 # under the License.
-#++
+
 
 require 'uri'
 

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/7c004d3e/proton-c/bindings/ruby/lib/core/url.rb
----------------------------------------------------------------------
diff --git a/proton-c/bindings/ruby/lib/core/url.rb b/proton-c/bindings/ruby/lib/core/url.rb
index 88545e3..48f295c 100644
--- a/proton-c/bindings/ruby/lib/core/url.rb
+++ b/proton-c/bindings/ruby/lib/core/url.rb
@@ -1,4 +1,3 @@
-#--
 # 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
@@ -15,7 +14,7 @@
 # KIND, either express or implied.  See the License for the
 # specific language governing permissions and limitations
 # under the License.
-#++
+
 
 module Qpid::Proton
 

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/7c004d3e/proton-c/bindings/ruby/lib/handler/adapter.rb
----------------------------------------------------------------------
diff --git a/proton-c/bindings/ruby/lib/handler/adapter.rb b/proton-c/bindings/ruby/lib/handler/adapter.rb
index 2d9bdc8..8fe9bc5 100644
--- a/proton-c/bindings/ruby/lib/handler/adapter.rb
+++ b/proton-c/bindings/ruby/lib/handler/adapter.rb
@@ -1,4 +1,3 @@
-#--
 # 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
@@ -15,7 +14,7 @@
 # KIND, either express or implied.  See the License for the
 # specific language governing permissions and limitations
 # under the License.
-#++
+
 
 # @private
 module Qpid::Proton::Handler

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/7c004d3e/proton-c/bindings/ruby/lib/messenger/messenger.rb
----------------------------------------------------------------------
diff --git a/proton-c/bindings/ruby/lib/messenger/messenger.rb b/proton-c/bindings/ruby/lib/messenger/messenger.rb
index 65e0ae8..0c39429 100644
--- a/proton-c/bindings/ruby/lib/messenger/messenger.rb
+++ b/proton-c/bindings/ruby/lib/messenger/messenger.rb
@@ -1,4 +1,3 @@
-# --
 # 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
@@ -15,7 +14,7 @@
 # KIND, either express or implied.  See the License for the
 # specific language governing permissions and limitations
 # under the License.
-# ++
+
 
 module Qpid::Proton::Messenger
   # @deprecated use {Qpid::Proton::Container}

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/7c004d3e/proton-c/bindings/ruby/lib/messenger/subscription.rb
----------------------------------------------------------------------
diff --git a/proton-c/bindings/ruby/lib/messenger/subscription.rb b/proton-c/bindings/ruby/lib/messenger/subscription.rb
index 6d4973e..49fb50e 100644
--- a/proton-c/bindings/ruby/lib/messenger/subscription.rb
+++ b/proton-c/bindings/ruby/lib/messenger/subscription.rb
@@ -1,4 +1,3 @@
-#--
 # 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
@@ -15,7 +14,7 @@
 # KIND, either express or implied.  See the License for the
 # specific language governing permissions and limitations
 # under the License.
-#++
+
 
 module Qpid::Proton::Messenger
 

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/7c004d3e/proton-c/bindings/ruby/lib/messenger/tracker.rb
----------------------------------------------------------------------
diff --git a/proton-c/bindings/ruby/lib/messenger/tracker.rb b/proton-c/bindings/ruby/lib/messenger/tracker.rb
index 55507e5..5fb98e5 100644
--- a/proton-c/bindings/ruby/lib/messenger/tracker.rb
+++ b/proton-c/bindings/ruby/lib/messenger/tracker.rb
@@ -1,4 +1,3 @@
-#--
 # 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
@@ -15,7 +14,7 @@
 # KIND, either express or implied.  See the License for the
 # specific language governing permissions and limitations
 # under the License.
-#++
+
 
 module Qpid::Proton::Messenger
 

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/7c004d3e/proton-c/bindings/ruby/lib/messenger/tracker_status.rb
----------------------------------------------------------------------
diff --git a/proton-c/bindings/ruby/lib/messenger/tracker_status.rb b/proton-c/bindings/ruby/lib/messenger/tracker_status.rb
index 6eea9ce..ab77683 100644
--- a/proton-c/bindings/ruby/lib/messenger/tracker_status.rb
+++ b/proton-c/bindings/ruby/lib/messenger/tracker_status.rb
@@ -1,4 +1,3 @@
-#--
 # 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
@@ -15,7 +14,7 @@
 # KIND, either express or implied.  See the License for the
 # specific language governing permissions and limitations
 # under the License.
-#++
+
 
 module Qpid::Proton::Messenger
 

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/7c004d3e/proton-c/bindings/ruby/lib/qpid_proton.rb
----------------------------------------------------------------------
diff --git a/proton-c/bindings/ruby/lib/qpid_proton.rb b/proton-c/bindings/ruby/lib/qpid_proton.rb
index 36c14a1..6164fde 100644
--- a/proton-c/bindings/ruby/lib/qpid_proton.rb
+++ b/proton-c/bindings/ruby/lib/qpid_proton.rb
@@ -1,4 +1,3 @@
-#--
 # 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
@@ -15,7 +14,7 @@
 # KIND, either express or implied.  See the License for the
 # specific language governing permissions and limitations
 # under the License.
-#++
+
 
 require "cproton"
 require "date"
@@ -37,7 +36,7 @@ module Qpid
   end
 
   # Proton is a ruby API for sending and receiving AMQP messages in clients or servers.
-  # {overveiw}[README.rdoc]
+  # See the {overview}[../file.README.html] for more.
   module Proton
   end
 end

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/7c004d3e/proton-c/bindings/ruby/lib/reactor/container.rb
----------------------------------------------------------------------
diff --git a/proton-c/bindings/ruby/lib/reactor/container.rb b/proton-c/bindings/ruby/lib/reactor/container.rb
index 9c6b13d..8ce5ea6 100644
--- a/proton-c/bindings/ruby/lib/reactor/container.rb
+++ b/proton-c/bindings/ruby/lib/reactor/container.rb
@@ -1,4 +1,3 @@
-#--
 # 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
@@ -15,7 +14,7 @@
 # KIND, either express or implied.  See the License for the
 # specific language governing permissions and limitations
 # under the License.
-#++
+
 
 module Qpid::Proton::Reactor
 

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/7c004d3e/proton-c/bindings/ruby/lib/types/array.rb
----------------------------------------------------------------------
diff --git a/proton-c/bindings/ruby/lib/types/array.rb b/proton-c/bindings/ruby/lib/types/array.rb
index f5c6b50..88eb26b 100644
--- a/proton-c/bindings/ruby/lib/types/array.rb
+++ b/proton-c/bindings/ruby/lib/types/array.rb
@@ -1,4 +1,3 @@
-#--
 # 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
@@ -15,7 +14,7 @@
 # KIND, either express or implied.  See the License for the
 # specific language governing permissions and limitations
 # under the License.
-#++
+
 
 #--
 # Patch the Array class to provide methods for adding its contents

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/7c004d3e/proton-c/bindings/ruby/lib/types/described.rb
----------------------------------------------------------------------
diff --git a/proton-c/bindings/ruby/lib/types/described.rb b/proton-c/bindings/ruby/lib/types/described.rb
index 7c09d3f..fb880ba 100644
--- a/proton-c/bindings/ruby/lib/types/described.rb
+++ b/proton-c/bindings/ruby/lib/types/described.rb
@@ -1,4 +1,3 @@
-#--
 # 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
@@ -15,7 +14,7 @@
 # KIND, either express or implied.  See the License for the
 # specific language governing permissions and limitations
 # under the License.
-#++
+
 
 module Qpid::Proton::Types
 

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/7c004d3e/proton-c/bindings/ruby/lib/types/hash.rb
----------------------------------------------------------------------
diff --git a/proton-c/bindings/ruby/lib/types/hash.rb b/proton-c/bindings/ruby/lib/types/hash.rb
index e6836d5..9415f86 100644
--- a/proton-c/bindings/ruby/lib/types/hash.rb
+++ b/proton-c/bindings/ruby/lib/types/hash.rb
@@ -1,4 +1,3 @@
-#--
 # 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
@@ -15,7 +14,7 @@
 # KIND, either express or implied.  See the License for the
 # specific language governing permissions and limitations
 # under the License.
-#++
+
 
 #--
 # Patch the Hash class to provide methods for adding its contents

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/7c004d3e/proton-c/bindings/ruby/lib/types/strings.rb
----------------------------------------------------------------------
diff --git a/proton-c/bindings/ruby/lib/types/strings.rb b/proton-c/bindings/ruby/lib/types/strings.rb
index ffbea3c..3edbd80 100644
--- a/proton-c/bindings/ruby/lib/types/strings.rb
+++ b/proton-c/bindings/ruby/lib/types/strings.rb
@@ -1,4 +1,3 @@
-#--
 # 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
@@ -15,7 +14,7 @@
 # KIND, either express or implied.  See the License for the
 # specific language governing permissions and limitations
 # under the License.
-#++
+
 
 module Qpid::Proton::Types
 

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/7c004d3e/proton-c/bindings/ruby/lib/util/error_handler.rb
----------------------------------------------------------------------
diff --git a/proton-c/bindings/ruby/lib/util/error_handler.rb b/proton-c/bindings/ruby/lib/util/error_handler.rb
index da51214..58545fb 100644
--- a/proton-c/bindings/ruby/lib/util/error_handler.rb
+++ b/proton-c/bindings/ruby/lib/util/error_handler.rb
@@ -1,4 +1,3 @@
-#--
 # 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
@@ -15,7 +14,7 @@
 # KIND, either express or implied.  See the License for the
 # specific language governing permissions and limitations
 # under the License.
-#++
+
 
 module Qpid::Proton::Util
 

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/7c004d3e/proton-c/bindings/ruby/lib/util/swig_helper.rb
----------------------------------------------------------------------
diff --git a/proton-c/bindings/ruby/lib/util/swig_helper.rb b/proton-c/bindings/ruby/lib/util/swig_helper.rb
index 5567235..1013df8 100644
--- a/proton-c/bindings/ruby/lib/util/swig_helper.rb
+++ b/proton-c/bindings/ruby/lib/util/swig_helper.rb
@@ -1,4 +1,3 @@
-#--
 # 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
@@ -15,7 +14,7 @@
 # KIND, either express or implied.  See the License for the
 # specific language governing permissions and limitations
 # under the License.
-#++
+
 
 module Qpid::Proton::Util
 

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/7c004d3e/proton-c/bindings/ruby/lib/util/timeout.rb
----------------------------------------------------------------------
diff --git a/proton-c/bindings/ruby/lib/util/timeout.rb b/proton-c/bindings/ruby/lib/util/timeout.rb
index f4647f5..5e299dd 100644
--- a/proton-c/bindings/ruby/lib/util/timeout.rb
+++ b/proton-c/bindings/ruby/lib/util/timeout.rb
@@ -1,4 +1,3 @@
-#--
 # 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
@@ -15,7 +14,7 @@
 # KIND, either express or implied.  See the License for the
 # specific language governing permissions and limitations
 # under the License.
-#++
+
 
 module Qpid::Proton::Util
 

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/7c004d3e/proton-c/bindings/ruby/lib/util/version.rb
----------------------------------------------------------------------
diff --git a/proton-c/bindings/ruby/lib/util/version.rb b/proton-c/bindings/ruby/lib/util/version.rb
index f9962ba..f4571a3 100644
--- a/proton-c/bindings/ruby/lib/util/version.rb
+++ b/proton-c/bindings/ruby/lib/util/version.rb
@@ -1,4 +1,3 @@
-#--
 # 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
@@ -15,7 +14,7 @@
 # KIND, either express or implied.  See the License for the
 # specific language governing permissions and limitations
 # under the License.
-#++
+
 
 module Qpid::Proton::Util
 

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/7c004d3e/proton-c/bindings/ruby/lib/util/wrapper.rb
----------------------------------------------------------------------
diff --git a/proton-c/bindings/ruby/lib/util/wrapper.rb b/proton-c/bindings/ruby/lib/util/wrapper.rb
index 8537e4b..c6e0e72 100644
--- a/proton-c/bindings/ruby/lib/util/wrapper.rb
+++ b/proton-c/bindings/ruby/lib/util/wrapper.rb
@@ -1,4 +1,3 @@
-#--
 # 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
@@ -15,7 +14,7 @@
 # KIND, either express or implied.  See the License for the
 # specific language governing permissions and limitations
 # under the License.
-#++
+
 
 module Qpid::Proton::Util
 

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/7c004d3e/proton-c/bindings/ruby/spec/data_spec.rb
----------------------------------------------------------------------
diff --git a/proton-c/bindings/ruby/spec/data_spec.rb b/proton-c/bindings/ruby/spec/data_spec.rb
index 3123f61..f4041e4 100644
--- a/proton-c/bindings/ruby/spec/data_spec.rb
+++ b/proton-c/bindings/ruby/spec/data_spec.rb
@@ -1,4 +1,3 @@
-# --
 # 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
@@ -15,7 +14,7 @@
 # KIND, either express or implied.  See the License for the
 # specific language governing permissions and limitations
 # under the License.
-# ++
+
 
 
 require "spec_helper"

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/7c004d3e/proton-c/bindings/ruby/spec/exception_handling_spec.rb
----------------------------------------------------------------------
diff --git a/proton-c/bindings/ruby/spec/exception_handling_spec.rb b/proton-c/bindings/ruby/spec/exception_handling_spec.rb
index a78dcd9..7470e37 100644
--- a/proton-c/bindings/ruby/spec/exception_handling_spec.rb
+++ b/proton-c/bindings/ruby/spec/exception_handling_spec.rb
@@ -1,4 +1,3 @@
-# --
 # 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
@@ -15,7 +14,7 @@
 # KIND, either express or implied.  See the License for the
 # specific language governing permissions and limitations
 # under the License.
-# ++
+
 
 require "spec_helper"
 

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/7c004d3e/proton-c/bindings/ruby/spec/message_spec.rb
----------------------------------------------------------------------
diff --git a/proton-c/bindings/ruby/spec/message_spec.rb b/proton-c/bindings/ruby/spec/message_spec.rb
index 6486d24..2951f9c 100644
--- a/proton-c/bindings/ruby/spec/message_spec.rb
+++ b/proton-c/bindings/ruby/spec/message_spec.rb
@@ -1,4 +1,3 @@
-# --
 # 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
@@ -15,7 +14,7 @@
 # KIND, either express or implied.  See the License for the
 # specific language governing permissions and limitations
 # under the License.
-# ++
+
 
 require "spec_helper"
 

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/7c004d3e/proton-c/bindings/ruby/tests/old_examples/broker.rb
----------------------------------------------------------------------
diff --git a/proton-c/bindings/ruby/tests/old_examples/broker.rb b/proton-c/bindings/ruby/tests/old_examples/broker.rb
index e7cc9b3..d76dfba 100644
--- a/proton-c/bindings/ruby/tests/old_examples/broker.rb
+++ b/proton-c/bindings/ruby/tests/old_examples/broker.rb
@@ -1,4 +1,3 @@
-#--
 # 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
@@ -15,7 +14,7 @@
 # KIND, either express or implied.  See the License for the
 # specific language governing permissions and limitations
 # under the License.
-#++
+
 
 require 'qpid_proton'
 require 'optparse'

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/7c004d3e/proton-c/bindings/ruby/tests/old_examples/client.rb
----------------------------------------------------------------------
diff --git a/proton-c/bindings/ruby/tests/old_examples/client.rb b/proton-c/bindings/ruby/tests/old_examples/client.rb
index 8c38f38..ff22e6b 100644
--- a/proton-c/bindings/ruby/tests/old_examples/client.rb
+++ b/proton-c/bindings/ruby/tests/old_examples/client.rb
@@ -1,4 +1,3 @@
-#--
 # 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
@@ -15,7 +14,7 @@
 # KIND, either express or implied.  See the License for the
 # specific language governing permissions and limitations
 # under the License.
-#++
+
 
 require 'qpid_proton'
 require 'optparse'

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/7c004d3e/proton-c/bindings/ruby/tests/old_examples/direct_recv.rb
----------------------------------------------------------------------
diff --git a/proton-c/bindings/ruby/tests/old_examples/direct_recv.rb b/proton-c/bindings/ruby/tests/old_examples/direct_recv.rb
index ff3366a..7281845 100644
--- a/proton-c/bindings/ruby/tests/old_examples/direct_recv.rb
+++ b/proton-c/bindings/ruby/tests/old_examples/direct_recv.rb
@@ -1,4 +1,3 @@
-#--
 # 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
@@ -15,7 +14,7 @@
 # KIND, either express or implied.  See the License for the
 # specific language governing permissions and limitations
 # under the License.
-#++
+
 
 require 'qpid_proton'
 require 'optparse'

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/7c004d3e/proton-c/bindings/ruby/tests/old_examples/direct_send.rb
----------------------------------------------------------------------
diff --git a/proton-c/bindings/ruby/tests/old_examples/direct_send.rb b/proton-c/bindings/ruby/tests/old_examples/direct_send.rb
index c507b46..1a7a71a 100644
--- a/proton-c/bindings/ruby/tests/old_examples/direct_send.rb
+++ b/proton-c/bindings/ruby/tests/old_examples/direct_send.rb
@@ -1,4 +1,3 @@
-#--
 # 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
@@ -15,7 +14,7 @@
 # KIND, either express or implied.  See the License for the
 # specific language governing permissions and limitations
 # under the License.
-#++
+
 
 require 'qpid_proton'
 require 'optparse'

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/7c004d3e/proton-c/bindings/ruby/tests/old_examples/helloworld.rb
----------------------------------------------------------------------
diff --git a/proton-c/bindings/ruby/tests/old_examples/helloworld.rb b/proton-c/bindings/ruby/tests/old_examples/helloworld.rb
index 9b02e8a..65b9ccc 100644
--- a/proton-c/bindings/ruby/tests/old_examples/helloworld.rb
+++ b/proton-c/bindings/ruby/tests/old_examples/helloworld.rb
@@ -1,4 +1,3 @@
-#--
 # 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
@@ -15,7 +14,7 @@
 # KIND, either express or implied.  See the License for the
 # specific language governing permissions and limitations
 # under the License.
-#++
+
 
 require 'qpid_proton'
 require 'optparse'

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/7c004d3e/proton-c/bindings/ruby/tests/old_examples/helloworld_direct.rb
----------------------------------------------------------------------
diff --git a/proton-c/bindings/ruby/tests/old_examples/helloworld_direct.rb b/proton-c/bindings/ruby/tests/old_examples/helloworld_direct.rb
index e98cc1f..f329723 100644
--- a/proton-c/bindings/ruby/tests/old_examples/helloworld_direct.rb
+++ b/proton-c/bindings/ruby/tests/old_examples/helloworld_direct.rb
@@ -1,4 +1,3 @@
-#--
 # 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
@@ -15,7 +14,7 @@
 # KIND, either express or implied.  See the License for the
 # specific language governing permissions and limitations
 # under the License.
-#++
+
 
 require 'qpid_proton'
 require 'optparse'

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/7c004d3e/proton-c/bindings/ruby/tests/old_examples/lib/debugging.rb
----------------------------------------------------------------------
diff --git a/proton-c/bindings/ruby/tests/old_examples/lib/debugging.rb b/proton-c/bindings/ruby/tests/old_examples/lib/debugging.rb
index 5065d51..4f7414e 100644
--- a/proton-c/bindings/ruby/tests/old_examples/lib/debugging.rb
+++ b/proton-c/bindings/ruby/tests/old_examples/lib/debugging.rb
@@ -1,4 +1,3 @@
-#--
 # 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
@@ -15,7 +14,7 @@
 # KIND, either express or implied.  See the License for the
 # specific language governing permissions and limitations
 # under the License.
-#++
+
 
 module Debugging
 

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/7c004d3e/proton-c/bindings/ruby/tests/old_examples/lib/driver.rb
----------------------------------------------------------------------
diff --git a/proton-c/bindings/ruby/tests/old_examples/lib/driver.rb b/proton-c/bindings/ruby/tests/old_examples/lib/driver.rb
index 4e223d0..129f499 100644
--- a/proton-c/bindings/ruby/tests/old_examples/lib/driver.rb
+++ b/proton-c/bindings/ruby/tests/old_examples/lib/driver.rb
@@ -1,4 +1,3 @@
-#--
 # 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
@@ -15,7 +14,7 @@
 # KIND, either express or implied.  See the License for the
 # specific language governing permissions and limitations
 # under the License.
-#++
+
 
 class Driver
 

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/7c004d3e/proton-c/bindings/ruby/tests/old_examples/lib/qpid_examples.rb
----------------------------------------------------------------------
diff --git a/proton-c/bindings/ruby/tests/old_examples/lib/qpid_examples.rb b/proton-c/bindings/ruby/tests/old_examples/lib/qpid_examples.rb
index 665812d..0a369a6 100644
--- a/proton-c/bindings/ruby/tests/old_examples/lib/qpid_examples.rb
+++ b/proton-c/bindings/ruby/tests/old_examples/lib/qpid_examples.rb
@@ -1,4 +1,3 @@
-#--
 # 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
@@ -15,7 +14,7 @@
 # KIND, either express or implied.  See the License for the
 # specific language governing permissions and limitations
 # under the License.
-#++
+
 
 require "qpid_proton"
 

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/7c004d3e/proton-c/bindings/ruby/tests/old_examples/lib/selectable.rb
----------------------------------------------------------------------
diff --git a/proton-c/bindings/ruby/tests/old_examples/lib/selectable.rb b/proton-c/bindings/ruby/tests/old_examples/lib/selectable.rb
index 779ea24..4634743 100644
--- a/proton-c/bindings/ruby/tests/old_examples/lib/selectable.rb
+++ b/proton-c/bindings/ruby/tests/old_examples/lib/selectable.rb
@@ -1,4 +1,3 @@
-#--
 # 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
@@ -15,7 +14,7 @@
 # KIND, either express or implied.  See the License for the
 # specific language governing permissions and limitations
 # under the License.
-#++
+
 
 class Selectable
 

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/7c004d3e/proton-c/bindings/ruby/tests/old_examples/lib/send_and_receive.rb
----------------------------------------------------------------------
diff --git a/proton-c/bindings/ruby/tests/old_examples/lib/send_and_receive.rb b/proton-c/bindings/ruby/tests/old_examples/lib/send_and_receive.rb
index 9fd7417..3b1cf4f 100644
--- a/proton-c/bindings/ruby/tests/old_examples/lib/send_and_receive.rb
+++ b/proton-c/bindings/ruby/tests/old_examples/lib/send_and_receive.rb
@@ -1,4 +1,3 @@
-#--
 # 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
@@ -15,7 +14,7 @@
 # KIND, either express or implied.  See the License for the
 # specific language governing permissions and limitations
 # under the License.
-#++
+
 
 class ExampleSend < Qpid::Proton::Handler::MessagingHandler
 

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/7c004d3e/proton-c/bindings/ruby/tests/old_examples/server.rb
----------------------------------------------------------------------
diff --git a/proton-c/bindings/ruby/tests/old_examples/server.rb b/proton-c/bindings/ruby/tests/old_examples/server.rb
index 9373272..265a63d 100644
--- a/proton-c/bindings/ruby/tests/old_examples/server.rb
+++ b/proton-c/bindings/ruby/tests/old_examples/server.rb
@@ -1,4 +1,3 @@
-#--
 # 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
@@ -15,7 +14,7 @@
 # KIND, either express or implied.  See the License for the
 # specific language governing permissions and limitations
 # under the License.
-#++
+
 
 require 'qpid_proton'
 require 'optparse'

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/7c004d3e/proton-c/bindings/ruby/tests/old_examples/simple_recv.rb
----------------------------------------------------------------------
diff --git a/proton-c/bindings/ruby/tests/old_examples/simple_recv.rb b/proton-c/bindings/ruby/tests/old_examples/simple_recv.rb
index 136e332..21feedd 100644
--- a/proton-c/bindings/ruby/tests/old_examples/simple_recv.rb
+++ b/proton-c/bindings/ruby/tests/old_examples/simple_recv.rb
@@ -1,4 +1,3 @@
-#--
 # 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
@@ -15,7 +14,7 @@
 # KIND, either express or implied.  See the License for the
 # specific language governing permissions and limitations
 # under the License.
-#++
+
 
 require 'qpid_proton'
 require 'optparse'

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/7c004d3e/proton-c/bindings/ruby/tests/old_examples/simple_send.rb
----------------------------------------------------------------------
diff --git a/proton-c/bindings/ruby/tests/old_examples/simple_send.rb b/proton-c/bindings/ruby/tests/old_examples/simple_send.rb
index 5e5d0a6..0b84c4c 100644
--- a/proton-c/bindings/ruby/tests/old_examples/simple_send.rb
+++ b/proton-c/bindings/ruby/tests/old_examples/simple_send.rb
@@ -1,4 +1,3 @@
-#--
 # 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
@@ -15,7 +14,7 @@
 # KIND, either express or implied.  See the License for the
 # specific language governing permissions and limitations
 # under the License.
-#++
+
 
 require 'qpid_proton'
 require 'optparse'

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/7c004d3e/proton-c/bindings/ruby/tests/test_adapter.rb
----------------------------------------------------------------------
diff --git a/proton-c/bindings/ruby/tests/test_adapter.rb b/proton-c/bindings/ruby/tests/test_adapter.rb
index 77aee76..c90f788 100644
--- a/proton-c/bindings/ruby/tests/test_adapter.rb
+++ b/proton-c/bindings/ruby/tests/test_adapter.rb
@@ -1,4 +1,3 @@
-#--
 # 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
@@ -15,7 +14,7 @@
 # KIND, either express or implied.  See the License for the
 # specific language governing permissions and limitations
 # under the License.
-#++
+
 
 require 'minitest/autorun'
 require 'qpid_proton'

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/7c004d3e/proton-c/bindings/ruby/tests/test_connection_driver.rb
----------------------------------------------------------------------
diff --git a/proton-c/bindings/ruby/tests/test_connection_driver.rb b/proton-c/bindings/ruby/tests/test_connection_driver.rb
index f12076f..3617dce 100644
--- a/proton-c/bindings/ruby/tests/test_connection_driver.rb
+++ b/proton-c/bindings/ruby/tests/test_connection_driver.rb
@@ -1,4 +1,3 @@
-#--
 # 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
@@ -14,7 +13,7 @@
 # KIND, either express or implied.  See the License for the
 # specific language governing permissions and limitations
 # under the License.
-#++
+
 
 require 'test_tools'
 

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/7c004d3e/proton-c/bindings/ruby/tests/test_container.rb
----------------------------------------------------------------------
diff --git a/proton-c/bindings/ruby/tests/test_container.rb b/proton-c/bindings/ruby/tests/test_container.rb
index be74be8..bfa40b1 100644
--- a/proton-c/bindings/ruby/tests/test_container.rb
+++ b/proton-c/bindings/ruby/tests/test_container.rb
@@ -1,4 +1,3 @@
-#--
 # 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
@@ -15,7 +14,7 @@
 # KIND, either express or implied.  See the License for the
 # specific language governing permissions and limitations
 # under the License.
-#++
+
 
 require 'test_tools'
 require 'minitest/unit'


---------------------------------------------------------------------
To unsubscribe, e-mail: commits-unsubscribe@qpid.apache.org
For additional commands, e-mail: commits-help@qpid.apache.org