You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@hc.apache.org by gg...@apache.org on 2018/08/14 16:55:47 UTC

httpcomponents-core git commit: Use camcel-case.

Repository: httpcomponents-core
Updated Branches:
  refs/heads/4.4.x d956f67e6 -> dbad59e2e


Use camcel-case.

Project: http://git-wip-us.apache.org/repos/asf/httpcomponents-core/repo
Commit: http://git-wip-us.apache.org/repos/asf/httpcomponents-core/commit/dbad59e2
Tree: http://git-wip-us.apache.org/repos/asf/httpcomponents-core/tree/dbad59e2
Diff: http://git-wip-us.apache.org/repos/asf/httpcomponents-core/diff/dbad59e2

Branch: refs/heads/4.4.x
Commit: dbad59e2e05eb9672052218d8e9fa4f9bdd5fb64
Parents: d956f67
Author: Gary Gregory <ga...@gmail.com>
Authored: Tue Aug 14 10:55:42 2018 -0600
Committer: Gary Gregory <ga...@gmail.com>
Committed: Tue Aug 14 10:55:42 2018 -0600

----------------------------------------------------------------------
 .../http/examples/nio/NHttpReverseProxy.java    | 24 +++++++++---------
 .../http/nio/entity/BufferingNHttpEntity.java   |  2 +-
 .../entity/ConsumingNHttpEntityTemplate.java    |  4 +--
 .../apache/http/nio/entity/ContentListener.java |  4 +--
 .../http/nio/entity/NHttpEntityWrapper.java     |  2 +-
 .../http/nio/entity/SkipContentListener.java    |  2 +-
 .../BasicAsyncRequestExecutionHandler.java      |  8 +++---
 .../http/nio/protocol/NullNHttpEntity.java      |  2 +-
 .../http/nio/entity/ConsumingNHttpEntity.java   |  4 +--
 .../nio/entity/EntityAsyncContentProducer.java  |  2 +-
 .../nio/entity/HttpAsyncContentProducer.java    |  4 +--
 .../http/nio/entity/NByteArrayEntity.java       |  2 +-
 .../org/apache/http/nio/entity/NFileEntity.java |  2 +-
 .../apache/http/nio/entity/NStringEntity.java   |  2 +-
 .../http/nio/entity/ProducingNHttpEntity.java   |  4 +--
 .../protocol/AbstractAsyncRequestConsumer.java  |  8 +++---
 .../protocol/AbstractAsyncResponseConsumer.java |  8 +++---
 .../BasicAsyncClientExchangeHandler.java        |  8 +++---
 .../nio/protocol/BasicAsyncRequestConsumer.java |  2 +-
 .../nio/protocol/BasicAsyncRequestProducer.java |  4 +--
 .../protocol/BasicAsyncResponseConsumer.java    |  2 +-
 .../protocol/BasicAsyncResponseProducer.java    |  4 +--
 .../nio/protocol/ErrorResponseProducer.java     |  4 +--
 .../HttpAsyncClientExchangeHandler.java         |  8 +++---
 .../nio/protocol/HttpAsyncRequestConsumer.java  |  4 +--
 .../nio/protocol/HttpAsyncRequestProducer.java  |  4 +--
 .../nio/protocol/HttpAsyncResponseConsumer.java |  4 +--
 .../nio/protocol/HttpAsyncResponseProducer.java |  4 +--
 .../http/nio/protocol/NullRequestConsumer.java  |  2 +-
 .../PipeliningClientExchangeHandler.java        |  8 +++---
 .../apache/http/nio/util/SharedInputBuffer.java | 20 +++++++--------
 .../http/nio/util/SharedOutputBuffer.java       | 26 ++++++++++----------
 .../nio/TestDefaultNHttpClientConnection.java   |  4 +--
 .../nio/TestDefaultNHttpServerConnection.java   |  4 +--
 .../TestHttpAsyncHandlerCancellable.java        |  4 +--
 .../TestHttpAsyncPrematureTermination.java      |  4 +--
 .../nio/integration/TestTruncatedChunks.java    |  2 +-
 .../protocol/TestBasicAsyncRequestConsumer.java |  6 ++---
 .../TestBasicAsyncResponseConsumer.java         |  6 ++---
 39 files changed, 109 insertions(+), 109 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/httpcomponents-core/blob/dbad59e2/httpcore-nio/src/examples/org/apache/http/examples/nio/NHttpReverseProxy.java
----------------------------------------------------------------------
diff --git a/httpcore-nio/src/examples/org/apache/http/examples/nio/NHttpReverseProxy.java b/httpcore-nio/src/examples/org/apache/http/examples/nio/NHttpReverseProxy.java
index 663875c..6d97484 100644
--- a/httpcore-nio/src/examples/org/apache/http/examples/nio/NHttpReverseProxy.java
+++ b/httpcore-nio/src/examples/org/apache/http/examples/nio/NHttpReverseProxy.java
@@ -458,9 +458,9 @@ public class NHttpReverseProxy {
         }
 
         public void consumeContent(
-                final ContentDecoder decoder, final IOControl ioctrl) throws IOException {
+                final ContentDecoder decoder, final IOControl ioControl) throws IOException {
             synchronized (this.httpExchange) {
-                this.httpExchange.setClientIOControl(ioctrl);
+                this.httpExchange.setClientIOControl(ioControl);
                 // Receive data from the client
                 final ByteBuffer buf = this.httpExchange.getInBuffer();
                 final int n = decoder.read(buf);
@@ -471,7 +471,7 @@ public class NHttpReverseProxy {
                 // If the buffer is full, suspend client input until there is free
                 // space in the buffer
                 if (!buf.hasRemaining()) {
-                    ioctrl.suspendInput();
+                    ioControl.suspendInput();
                     System.out.println("[client->proxy] " + this.httpExchange.getId() + " suspend client input");
                 }
                 // If there is some content in the input buffer make sure origin
@@ -550,9 +550,9 @@ public class NHttpReverseProxy {
         }
 
         public void produceContent(
-                final ContentEncoder encoder, final IOControl ioctrl) throws IOException {
+                final ContentEncoder encoder, final IOControl ioControl) throws IOException {
             synchronized (this.httpExchange) {
-                this.httpExchange.setOriginIOControl(ioctrl);
+                this.httpExchange.setOriginIOControl(ioControl);
                 // Send data to the origin server
                 final ByteBuffer buf = this.httpExchange.getInBuffer();
                 buf.flip();
@@ -574,7 +574,7 @@ public class NHttpReverseProxy {
                     } else {
                         // Input buffer is empty. Wait until the client fills up
                         // the buffer
-                        ioctrl.suspendOutput();
+                        ioControl.suspendOutput();
                         System.out.println("[proxy->origin] " + this.httpExchange.getId() + " suspend origin output");
                     }
                 }
@@ -627,9 +627,9 @@ public class NHttpReverseProxy {
         }
 
         public void consumeContent(
-                final ContentDecoder decoder, final IOControl ioctrl) throws IOException {
+                final ContentDecoder decoder, final IOControl ioControl) throws IOException {
             synchronized (this.httpExchange) {
-                this.httpExchange.setOriginIOControl(ioctrl);
+                this.httpExchange.setOriginIOControl(ioControl);
                 // Receive data from the origin
                 final ByteBuffer buf = this.httpExchange.getOutBuffer();
                 final int n = decoder.read(buf);
@@ -640,7 +640,7 @@ public class NHttpReverseProxy {
                 // If the buffer is full, suspend origin input until there is free
                 // space in the buffer
                 if (!buf.hasRemaining()) {
-                    ioctrl.suspendInput();
+                    ioControl.suspendInput();
                     System.out.println("[proxy<-origin] " + this.httpExchange.getId() + " suspend origin input");
                 }
                 // If there is some content in the input buffer make sure client
@@ -741,9 +741,9 @@ public class NHttpReverseProxy {
         }
 
         public void produceContent(
-                final ContentEncoder encoder, final IOControl ioctrl) throws IOException {
+                final ContentEncoder encoder, final IOControl ioControl) throws IOException {
             synchronized (this.httpExchange) {
-                this.httpExchange.setClientIOControl(ioctrl);
+                this.httpExchange.setClientIOControl(ioControl);
                 // Send data to the client
                 final ByteBuffer buf = this.httpExchange.getOutBuffer();
                 buf.flip();
@@ -765,7 +765,7 @@ public class NHttpReverseProxy {
                     } else {
                         // Input buffer is empty. Wait until the origin fills up
                         // the buffer
-                        ioctrl.suspendOutput();
+                        ioControl.suspendOutput();
                         System.out.println("[client<-proxy] " + this.httpExchange.getId() + " suspend client output");
                     }
                 }

http://git-wip-us.apache.org/repos/asf/httpcomponents-core/blob/dbad59e2/httpcore-nio/src/main/java-deprecated/org/apache/http/nio/entity/BufferingNHttpEntity.java
----------------------------------------------------------------------
diff --git a/httpcore-nio/src/main/java-deprecated/org/apache/http/nio/entity/BufferingNHttpEntity.java b/httpcore-nio/src/main/java-deprecated/org/apache/http/nio/entity/BufferingNHttpEntity.java
index 5c7aa9a..58ce212 100644
--- a/httpcore-nio/src/main/java-deprecated/org/apache/http/nio/entity/BufferingNHttpEntity.java
+++ b/httpcore-nio/src/main/java-deprecated/org/apache/http/nio/entity/BufferingNHttpEntity.java
@@ -72,7 +72,7 @@ public class BufferingNHttpEntity extends HttpEntityWrapper implements
     @Override
     public void consumeContent(
             final ContentDecoder decoder,
-            final IOControl ioctrl) throws IOException {
+            final IOControl ioControl) throws IOException {
         this.buffer.consumeContent(decoder);
         if (decoder.isCompleted()) {
             this.finished = true;

http://git-wip-us.apache.org/repos/asf/httpcomponents-core/blob/dbad59e2/httpcore-nio/src/main/java-deprecated/org/apache/http/nio/entity/ConsumingNHttpEntityTemplate.java
----------------------------------------------------------------------
diff --git a/httpcore-nio/src/main/java-deprecated/org/apache/http/nio/entity/ConsumingNHttpEntityTemplate.java b/httpcore-nio/src/main/java-deprecated/org/apache/http/nio/entity/ConsumingNHttpEntityTemplate.java
index d7310d1..52f30c9 100644
--- a/httpcore-nio/src/main/java-deprecated/org/apache/http/nio/entity/ConsumingNHttpEntityTemplate.java
+++ b/httpcore-nio/src/main/java-deprecated/org/apache/http/nio/entity/ConsumingNHttpEntityTemplate.java
@@ -81,8 +81,8 @@ public class ConsumingNHttpEntityTemplate
     @Override
     public void consumeContent(
             final ContentDecoder decoder,
-            final IOControl ioctrl) throws IOException {
-        this.contentListener.contentAvailable(decoder, ioctrl);
+            final IOControl ioControl) throws IOException {
+        this.contentListener.contentAvailable(decoder, ioControl);
     }
 
     @Override

http://git-wip-us.apache.org/repos/asf/httpcomponents-core/blob/dbad59e2/httpcore-nio/src/main/java-deprecated/org/apache/http/nio/entity/ContentListener.java
----------------------------------------------------------------------
diff --git a/httpcore-nio/src/main/java-deprecated/org/apache/http/nio/entity/ContentListener.java b/httpcore-nio/src/main/java-deprecated/org/apache/http/nio/entity/ContentListener.java
index 8063bee..d19fce3 100644
--- a/httpcore-nio/src/main/java-deprecated/org/apache/http/nio/entity/ContentListener.java
+++ b/httpcore-nio/src/main/java-deprecated/org/apache/http/nio/entity/ContentListener.java
@@ -46,9 +46,9 @@ public interface ContentListener {
      * Notification that content is available to be read from the decoder.
      *
      * @param decoder content decoder.
-     * @param ioctrl I/O control of the underlying connection.
+     * @param ioControl I/O control of the underlying connection.
      */
-    void contentAvailable(ContentDecoder decoder, IOControl ioctrl)
+    void contentAvailable(ContentDecoder decoder, IOControl ioControl)
         throws IOException;
 
     /**

http://git-wip-us.apache.org/repos/asf/httpcomponents-core/blob/dbad59e2/httpcore-nio/src/main/java-deprecated/org/apache/http/nio/entity/NHttpEntityWrapper.java
----------------------------------------------------------------------
diff --git a/httpcore-nio/src/main/java-deprecated/org/apache/http/nio/entity/NHttpEntityWrapper.java b/httpcore-nio/src/main/java-deprecated/org/apache/http/nio/entity/NHttpEntityWrapper.java
index eab9604..522298a 100644
--- a/httpcore-nio/src/main/java-deprecated/org/apache/http/nio/entity/NHttpEntityWrapper.java
+++ b/httpcore-nio/src/main/java-deprecated/org/apache/http/nio/entity/NHttpEntityWrapper.java
@@ -84,7 +84,7 @@ public class NHttpEntityWrapper
     @Override
     public void produceContent(
             final ContentEncoder encoder,
-            final IOControl ioctrl) throws IOException {
+            final IOControl ioControl) throws IOException {
         final int i = this.channel.read(this.buffer);
         this.buffer.flip();
         encoder.write(this.buffer);

http://git-wip-us.apache.org/repos/asf/httpcomponents-core/blob/dbad59e2/httpcore-nio/src/main/java-deprecated/org/apache/http/nio/entity/SkipContentListener.java
----------------------------------------------------------------------
diff --git a/httpcore-nio/src/main/java-deprecated/org/apache/http/nio/entity/SkipContentListener.java b/httpcore-nio/src/main/java-deprecated/org/apache/http/nio/entity/SkipContentListener.java
index 1f0fc5c..0b95d8a 100644
--- a/httpcore-nio/src/main/java-deprecated/org/apache/http/nio/entity/SkipContentListener.java
+++ b/httpcore-nio/src/main/java-deprecated/org/apache/http/nio/entity/SkipContentListener.java
@@ -56,7 +56,7 @@ public class SkipContentListener implements ContentListener {
     @Override
     public void contentAvailable(
             final ContentDecoder decoder,
-            final IOControl ioctrl) throws IOException {
+            final IOControl ioControl) throws IOException {
         int lastRead;
         do {
             buffer.clear();

http://git-wip-us.apache.org/repos/asf/httpcomponents-core/blob/dbad59e2/httpcore-nio/src/main/java-deprecated/org/apache/http/nio/protocol/BasicAsyncRequestExecutionHandler.java
----------------------------------------------------------------------
diff --git a/httpcore-nio/src/main/java-deprecated/org/apache/http/nio/protocol/BasicAsyncRequestExecutionHandler.java b/httpcore-nio/src/main/java-deprecated/org/apache/http/nio/protocol/BasicAsyncRequestExecutionHandler.java
index 0c25d88..99011a4 100644
--- a/httpcore-nio/src/main/java-deprecated/org/apache/http/nio/protocol/BasicAsyncRequestExecutionHandler.java
+++ b/httpcore-nio/src/main/java-deprecated/org/apache/http/nio/protocol/BasicAsyncRequestExecutionHandler.java
@@ -134,8 +134,8 @@ public class BasicAsyncRequestExecutionHandler<T> implements HttpAsyncRequestExe
 
     @Override
     public void produceContent(
-            final ContentEncoder encoder, final IOControl ioctrl) throws IOException {
-        this.requestProducer.produceContent(encoder, ioctrl);
+            final ContentEncoder encoder, final IOControl ioControl) throws IOException {
+        this.requestProducer.produceContent(encoder, ioControl);
     }
 
     @Override
@@ -160,8 +160,8 @@ public class BasicAsyncRequestExecutionHandler<T> implements HttpAsyncRequestExe
 
     @Override
     public void consumeContent(
-            final ContentDecoder decoder, final IOControl ioctrl) throws IOException {
-        this.responseConsumer.consumeContent(decoder, ioctrl);
+            final ContentDecoder decoder, final IOControl ioControl) throws IOException {
+        this.responseConsumer.consumeContent(decoder, ioControl);
     }
 
     @Override

http://git-wip-us.apache.org/repos/asf/httpcomponents-core/blob/dbad59e2/httpcore-nio/src/main/java-deprecated/org/apache/http/nio/protocol/NullNHttpEntity.java
----------------------------------------------------------------------
diff --git a/httpcore-nio/src/main/java-deprecated/org/apache/http/nio/protocol/NullNHttpEntity.java b/httpcore-nio/src/main/java-deprecated/org/apache/http/nio/protocol/NullNHttpEntity.java
index 772827b..70ad47b 100644
--- a/httpcore-nio/src/main/java-deprecated/org/apache/http/nio/protocol/NullNHttpEntity.java
+++ b/httpcore-nio/src/main/java-deprecated/org/apache/http/nio/protocol/NullNHttpEntity.java
@@ -69,7 +69,7 @@ class NullNHttpEntity extends HttpEntityWrapper implements ConsumingNHttpEntity
     @Override
     public void consumeContent(
             final ContentDecoder decoder,
-            final IOControl ioctrl) throws IOException {
+            final IOControl ioControl) throws IOException {
         int lastRead;
         do {
             buffer.clear();

http://git-wip-us.apache.org/repos/asf/httpcomponents-core/blob/dbad59e2/httpcore-nio/src/main/java/org/apache/http/nio/entity/ConsumingNHttpEntity.java
----------------------------------------------------------------------
diff --git a/httpcore-nio/src/main/java/org/apache/http/nio/entity/ConsumingNHttpEntity.java b/httpcore-nio/src/main/java/org/apache/http/nio/entity/ConsumingNHttpEntity.java
index ff10764..e5a4ed4 100644
--- a/httpcore-nio/src/main/java/org/apache/http/nio/entity/ConsumingNHttpEntity.java
+++ b/httpcore-nio/src/main/java/org/apache/http/nio/entity/ConsumingNHttpEntity.java
@@ -53,9 +53,9 @@ public interface ConsumingNHttpEntity extends HttpEntity {
      * allocate more storage to accommodate all incoming content.
      *
      * @param decoder content decoder.
-     * @param ioctrl I/O control of the underlying connection.
+     * @param ioControl I/O control of the underlying connection.
      */
-    void consumeContent(ContentDecoder decoder, IOControl ioctrl) throws IOException;
+    void consumeContent(ContentDecoder decoder, IOControl ioControl) throws IOException;
 
     /**
      * Notification that any resources allocated for reading can be released.

http://git-wip-us.apache.org/repos/asf/httpcomponents-core/blob/dbad59e2/httpcore-nio/src/main/java/org/apache/http/nio/entity/EntityAsyncContentProducer.java
----------------------------------------------------------------------
diff --git a/httpcore-nio/src/main/java/org/apache/http/nio/entity/EntityAsyncContentProducer.java b/httpcore-nio/src/main/java/org/apache/http/nio/entity/EntityAsyncContentProducer.java
index a1445bb..32575d1 100644
--- a/httpcore-nio/src/main/java/org/apache/http/nio/entity/EntityAsyncContentProducer.java
+++ b/httpcore-nio/src/main/java/org/apache/http/nio/entity/EntityAsyncContentProducer.java
@@ -60,7 +60,7 @@ public class EntityAsyncContentProducer implements HttpAsyncContentProducer {
 
     @Override
     public void produceContent(
-            final ContentEncoder encoder, final IOControl ioctrl) throws IOException {
+            final ContentEncoder encoder, final IOControl ioControl) throws IOException {
         if (this.channel == null) {
             this.channel = Channels.newChannel(this.entity.getContent());
         }

http://git-wip-us.apache.org/repos/asf/httpcomponents-core/blob/dbad59e2/httpcore-nio/src/main/java/org/apache/http/nio/entity/HttpAsyncContentProducer.java
----------------------------------------------------------------------
diff --git a/httpcore-nio/src/main/java/org/apache/http/nio/entity/HttpAsyncContentProducer.java b/httpcore-nio/src/main/java/org/apache/http/nio/entity/HttpAsyncContentProducer.java
index 93bcbdb..600a252 100644
--- a/httpcore-nio/src/main/java/org/apache/http/nio/entity/HttpAsyncContentProducer.java
+++ b/httpcore-nio/src/main/java/org/apache/http/nio/entity/HttpAsyncContentProducer.java
@@ -56,9 +56,9 @@ public interface HttpAsyncContentProducer extends Closeable {
      * to resume output event notifications when more content is made available.
      *
      * @param encoder content encoder.
-     * @param ioctrl I/O control of the underlying connection.
+     * @param ioControl I/O control of the underlying connection.
      */
-    void produceContent(ContentEncoder encoder, IOControl ioctrl) throws IOException;
+    void produceContent(ContentEncoder encoder, IOControl ioControl) throws IOException;
 
     /**
      * Determines whether or not this producer is capable of producing

http://git-wip-us.apache.org/repos/asf/httpcomponents-core/blob/dbad59e2/httpcore-nio/src/main/java/org/apache/http/nio/entity/NByteArrayEntity.java
----------------------------------------------------------------------
diff --git a/httpcore-nio/src/main/java/org/apache/http/nio/entity/NByteArrayEntity.java b/httpcore-nio/src/main/java/org/apache/http/nio/entity/NByteArrayEntity.java
index 79749c0..442c8e9 100644
--- a/httpcore-nio/src/main/java/org/apache/http/nio/entity/NByteArrayEntity.java
+++ b/httpcore-nio/src/main/java/org/apache/http/nio/entity/NByteArrayEntity.java
@@ -131,7 +131,7 @@ public class NByteArrayEntity extends AbstractHttpEntity
     }
 
     @Override
-    public void produceContent(final ContentEncoder encoder, final IOControl ioctrl)
+    public void produceContent(final ContentEncoder encoder, final IOControl ioControl)
             throws IOException {
         encoder.write(this.buf);
         if(!this.buf.hasRemaining()) {

http://git-wip-us.apache.org/repos/asf/httpcomponents-core/blob/dbad59e2/httpcore-nio/src/main/java/org/apache/http/nio/entity/NFileEntity.java
----------------------------------------------------------------------
diff --git a/httpcore-nio/src/main/java/org/apache/http/nio/entity/NFileEntity.java b/httpcore-nio/src/main/java/org/apache/http/nio/entity/NFileEntity.java
index 29d9a22..9f1c9fa 100644
--- a/httpcore-nio/src/main/java/org/apache/http/nio/entity/NFileEntity.java
+++ b/httpcore-nio/src/main/java/org/apache/http/nio/entity/NFileEntity.java
@@ -158,7 +158,7 @@ public class NFileEntity extends AbstractHttpEntity
     }
 
     @Override
-    public void produceContent(final ContentEncoder encoder, final IOControl ioctrl)
+    public void produceContent(final ContentEncoder encoder, final IOControl ioControl)
             throws IOException {
         if (accessfile == null) {
             accessfile = new RandomAccessFile(this.file, "r");

http://git-wip-us.apache.org/repos/asf/httpcomponents-core/blob/dbad59e2/httpcore-nio/src/main/java/org/apache/http/nio/entity/NStringEntity.java
----------------------------------------------------------------------
diff --git a/httpcore-nio/src/main/java/org/apache/http/nio/entity/NStringEntity.java b/httpcore-nio/src/main/java/org/apache/http/nio/entity/NStringEntity.java
index d19ffb1..43b42d7 100644
--- a/httpcore-nio/src/main/java/org/apache/http/nio/entity/NStringEntity.java
+++ b/httpcore-nio/src/main/java/org/apache/http/nio/entity/NStringEntity.java
@@ -171,7 +171,7 @@ public class NStringEntity extends AbstractHttpEntity
 
     @Override
     public void produceContent(
-            final ContentEncoder encoder, final IOControl ioctrl) throws IOException {
+            final ContentEncoder encoder, final IOControl ioControl) throws IOException {
         encoder.write(this.buf);
         if (!this.buf.hasRemaining()) {
             encoder.complete();

http://git-wip-us.apache.org/repos/asf/httpcomponents-core/blob/dbad59e2/httpcore-nio/src/main/java/org/apache/http/nio/entity/ProducingNHttpEntity.java
----------------------------------------------------------------------
diff --git a/httpcore-nio/src/main/java/org/apache/http/nio/entity/ProducingNHttpEntity.java b/httpcore-nio/src/main/java/org/apache/http/nio/entity/ProducingNHttpEntity.java
index 44579f1..dbdf3bb 100644
--- a/httpcore-nio/src/main/java/org/apache/http/nio/entity/ProducingNHttpEntity.java
+++ b/httpcore-nio/src/main/java/org/apache/http/nio/entity/ProducingNHttpEntity.java
@@ -56,9 +56,9 @@ public interface ProducingNHttpEntity extends HttpEntity {
      * Failure to do so could result in the entity never being written.
      *
      * @param encoder content encoder.
-     * @param ioctrl I/O control of the underlying connection.
+     * @param ioControl I/O control of the underlying connection.
      */
-    void produceContent(ContentEncoder encoder, IOControl ioctrl) throws IOException;
+    void produceContent(ContentEncoder encoder, IOControl ioControl) throws IOException;
 
     /**
      * Notification that any resources allocated for writing can be released.

http://git-wip-us.apache.org/repos/asf/httpcomponents-core/blob/dbad59e2/httpcore-nio/src/main/java/org/apache/http/nio/protocol/AbstractAsyncRequestConsumer.java
----------------------------------------------------------------------
diff --git a/httpcore-nio/src/main/java/org/apache/http/nio/protocol/AbstractAsyncRequestConsumer.java b/httpcore-nio/src/main/java/org/apache/http/nio/protocol/AbstractAsyncRequestConsumer.java
index 4057b11..cc765fd 100644
--- a/httpcore-nio/src/main/java/org/apache/http/nio/protocol/AbstractAsyncRequestConsumer.java
+++ b/httpcore-nio/src/main/java/org/apache/http/nio/protocol/AbstractAsyncRequestConsumer.java
@@ -90,11 +90,11 @@ public abstract class AbstractAsyncRequestConsumer<T> implements HttpAsyncReques
      * to find out whether or not the message content has been fully consumed.
      *
      * @param decoder content decoder.
-     * @param ioctrl I/O control of the underlying connection.
+     * @param ioControl I/O control of the underlying connection.
      * @throws IOException in case of an I/O error
      */
     protected abstract void onContentReceived(
-            ContentDecoder decoder, IOControl ioctrl) throws IOException;
+            ContentDecoder decoder, IOControl ioControl) throws IOException;
 
     /**
      * Invoked to generate a result object from the received HTTP request
@@ -141,8 +141,8 @@ public abstract class AbstractAsyncRequestConsumer<T> implements HttpAsyncReques
      */
     @Override
     public final void consumeContent(
-            final ContentDecoder decoder, final IOControl ioctrl) throws IOException {
-        onContentReceived(decoder, ioctrl);
+            final ContentDecoder decoder, final IOControl ioControl) throws IOException {
+        onContentReceived(decoder, ioControl);
     }
 
     /**

http://git-wip-us.apache.org/repos/asf/httpcomponents-core/blob/dbad59e2/httpcore-nio/src/main/java/org/apache/http/nio/protocol/AbstractAsyncResponseConsumer.java
----------------------------------------------------------------------
diff --git a/httpcore-nio/src/main/java/org/apache/http/nio/protocol/AbstractAsyncResponseConsumer.java b/httpcore-nio/src/main/java/org/apache/http/nio/protocol/AbstractAsyncResponseConsumer.java
index 0459fd2..da7deed 100644
--- a/httpcore-nio/src/main/java/org/apache/http/nio/protocol/AbstractAsyncResponseConsumer.java
+++ b/httpcore-nio/src/main/java/org/apache/http/nio/protocol/AbstractAsyncResponseConsumer.java
@@ -78,11 +78,11 @@ public abstract class AbstractAsyncResponseConsumer<T> implements HttpAsyncRespo
      * to find out whether or not the message content has been fully consumed.
      *
      * @param decoder content decoder.
-     * @param ioctrl I/O control of the underlying connection.
+     * @param ioControl I/O control of the underlying connection.
      * @throws IOException in case of an I/O error
      */
     protected abstract void onContentReceived(
-            ContentDecoder decoder, IOControl ioctrl) throws IOException;
+            ContentDecoder decoder, IOControl ioControl) throws IOException;
 
     /**
      * Invoked if the response message encloses a content entity.
@@ -143,8 +143,8 @@ public abstract class AbstractAsyncResponseConsumer<T> implements HttpAsyncRespo
      */
     @Override
     public final void consumeContent(
-            final ContentDecoder decoder, final IOControl ioctrl) throws IOException {
-        onContentReceived(decoder, ioctrl);
+            final ContentDecoder decoder, final IOControl ioControl) throws IOException {
+        onContentReceived(decoder, ioControl);
     }
 
     /**

http://git-wip-us.apache.org/repos/asf/httpcomponents-core/blob/dbad59e2/httpcore-nio/src/main/java/org/apache/http/nio/protocol/BasicAsyncClientExchangeHandler.java
----------------------------------------------------------------------
diff --git a/httpcore-nio/src/main/java/org/apache/http/nio/protocol/BasicAsyncClientExchangeHandler.java b/httpcore-nio/src/main/java/org/apache/http/nio/protocol/BasicAsyncClientExchangeHandler.java
index eb3eabe..f521a36 100644
--- a/httpcore-nio/src/main/java/org/apache/http/nio/protocol/BasicAsyncClientExchangeHandler.java
+++ b/httpcore-nio/src/main/java/org/apache/http/nio/protocol/BasicAsyncClientExchangeHandler.java
@@ -158,8 +158,8 @@ public class BasicAsyncClientExchangeHandler<T> implements HttpAsyncClientExchan
 
     @Override
     public void produceContent(
-            final ContentEncoder encoder, final IOControl ioctrl) throws IOException {
-        this.requestProducer.produceContent(encoder, ioctrl);
+            final ContentEncoder encoder, final IOControl ioControl) throws IOException {
+        this.requestProducer.produceContent(encoder, ioControl);
     }
 
     @Override
@@ -178,8 +178,8 @@ public class BasicAsyncClientExchangeHandler<T> implements HttpAsyncClientExchan
 
     @Override
     public void consumeContent(
-            final ContentDecoder decoder, final IOControl ioctrl) throws IOException {
-        this.responseConsumer.consumeContent(decoder, ioctrl);
+            final ContentDecoder decoder, final IOControl ioControl) throws IOException {
+        this.responseConsumer.consumeContent(decoder, ioControl);
     }
 
     @Override

http://git-wip-us.apache.org/repos/asf/httpcomponents-core/blob/dbad59e2/httpcore-nio/src/main/java/org/apache/http/nio/protocol/BasicAsyncRequestConsumer.java
----------------------------------------------------------------------
diff --git a/httpcore-nio/src/main/java/org/apache/http/nio/protocol/BasicAsyncRequestConsumer.java b/httpcore-nio/src/main/java/org/apache/http/nio/protocol/BasicAsyncRequestConsumer.java
index 9524169..fb60724 100644
--- a/httpcore-nio/src/main/java/org/apache/http/nio/protocol/BasicAsyncRequestConsumer.java
+++ b/httpcore-nio/src/main/java/org/apache/http/nio/protocol/BasicAsyncRequestConsumer.java
@@ -82,7 +82,7 @@ public class BasicAsyncRequestConsumer extends AbstractAsyncRequestConsumer<Http
 
     @Override
     protected void onContentReceived(
-            final ContentDecoder decoder, final IOControl ioctrl) throws IOException {
+            final ContentDecoder decoder, final IOControl ioControl) throws IOException {
         Asserts.notNull(this.buf, "Content buffer");
         this.buf.consumeContent(decoder);
     }

http://git-wip-us.apache.org/repos/asf/httpcomponents-core/blob/dbad59e2/httpcore-nio/src/main/java/org/apache/http/nio/protocol/BasicAsyncRequestProducer.java
----------------------------------------------------------------------
diff --git a/httpcore-nio/src/main/java/org/apache/http/nio/protocol/BasicAsyncRequestProducer.java b/httpcore-nio/src/main/java/org/apache/http/nio/protocol/BasicAsyncRequestProducer.java
index 2c7a5aa..72575ec 100644
--- a/httpcore-nio/src/main/java/org/apache/http/nio/protocol/BasicAsyncRequestProducer.java
+++ b/httpcore-nio/src/main/java/org/apache/http/nio/protocol/BasicAsyncRequestProducer.java
@@ -120,9 +120,9 @@ public class BasicAsyncRequestProducer implements HttpAsyncRequestProducer {
 
     @Override
     public void produceContent(
-            final ContentEncoder encoder, final IOControl ioctrl) throws IOException {
+            final ContentEncoder encoder, final IOControl ioControl) throws IOException {
         if (this.producer != null) {
-            this.producer.produceContent(encoder, ioctrl);
+            this.producer.produceContent(encoder, ioControl);
             if (encoder.isCompleted()) {
                 this.producer.close();
             }

http://git-wip-us.apache.org/repos/asf/httpcomponents-core/blob/dbad59e2/httpcore-nio/src/main/java/org/apache/http/nio/protocol/BasicAsyncResponseConsumer.java
----------------------------------------------------------------------
diff --git a/httpcore-nio/src/main/java/org/apache/http/nio/protocol/BasicAsyncResponseConsumer.java b/httpcore-nio/src/main/java/org/apache/http/nio/protocol/BasicAsyncResponseConsumer.java
index 66fd4e3..60b13bf 100644
--- a/httpcore-nio/src/main/java/org/apache/http/nio/protocol/BasicAsyncResponseConsumer.java
+++ b/httpcore-nio/src/main/java/org/apache/http/nio/protocol/BasicAsyncResponseConsumer.java
@@ -80,7 +80,7 @@ public class BasicAsyncResponseConsumer extends AbstractAsyncResponseConsumer<Ht
 
     @Override
     protected void onContentReceived(
-            final ContentDecoder decoder, final IOControl ioctrl) throws IOException {
+            final ContentDecoder decoder, final IOControl ioControl) throws IOException {
         Asserts.notNull(this.buf, "Content buffer");
         this.buf.consumeContent(decoder);
     }

http://git-wip-us.apache.org/repos/asf/httpcomponents-core/blob/dbad59e2/httpcore-nio/src/main/java/org/apache/http/nio/protocol/BasicAsyncResponseProducer.java
----------------------------------------------------------------------
diff --git a/httpcore-nio/src/main/java/org/apache/http/nio/protocol/BasicAsyncResponseProducer.java b/httpcore-nio/src/main/java/org/apache/http/nio/protocol/BasicAsyncResponseProducer.java
index 8e83c89..6450340 100644
--- a/httpcore-nio/src/main/java/org/apache/http/nio/protocol/BasicAsyncResponseProducer.java
+++ b/httpcore-nio/src/main/java/org/apache/http/nio/protocol/BasicAsyncResponseProducer.java
@@ -104,9 +104,9 @@ public class BasicAsyncResponseProducer implements HttpAsyncResponseProducer {
 
     @Override
     public void produceContent(
-            final ContentEncoder encoder, final IOControl ioctrl) throws IOException {
+            final ContentEncoder encoder, final IOControl ioControl) throws IOException {
         if (this.producer != null) {
-            this.producer.produceContent(encoder, ioctrl);
+            this.producer.produceContent(encoder, ioControl);
             if (encoder.isCompleted()) {
                 this.producer.close();
             }

http://git-wip-us.apache.org/repos/asf/httpcomponents-core/blob/dbad59e2/httpcore-nio/src/main/java/org/apache/http/nio/protocol/ErrorResponseProducer.java
----------------------------------------------------------------------
diff --git a/httpcore-nio/src/main/java/org/apache/http/nio/protocol/ErrorResponseProducer.java b/httpcore-nio/src/main/java/org/apache/http/nio/protocol/ErrorResponseProducer.java
index 6a2df67..d9a9209 100644
--- a/httpcore-nio/src/main/java/org/apache/http/nio/protocol/ErrorResponseProducer.java
+++ b/httpcore-nio/src/main/java/org/apache/http/nio/protocol/ErrorResponseProducer.java
@@ -78,8 +78,8 @@ public class ErrorResponseProducer implements HttpAsyncResponseProducer {
 
     @Override
     public void produceContent(
-            final ContentEncoder encoder, final IOControl ioctrl) throws IOException {
-        this.contentProducer.produceContent(encoder, ioctrl);
+            final ContentEncoder encoder, final IOControl ioControl) throws IOException {
+        this.contentProducer.produceContent(encoder, ioControl);
     }
 
     @Override

http://git-wip-us.apache.org/repos/asf/httpcomponents-core/blob/dbad59e2/httpcore-nio/src/main/java/org/apache/http/nio/protocol/HttpAsyncClientExchangeHandler.java
----------------------------------------------------------------------
diff --git a/httpcore-nio/src/main/java/org/apache/http/nio/protocol/HttpAsyncClientExchangeHandler.java b/httpcore-nio/src/main/java/org/apache/http/nio/protocol/HttpAsyncClientExchangeHandler.java
index d66f356..71f0c74 100644
--- a/httpcore-nio/src/main/java/org/apache/http/nio/protocol/HttpAsyncClientExchangeHandler.java
+++ b/httpcore-nio/src/main/java/org/apache/http/nio/protocol/HttpAsyncClientExchangeHandler.java
@@ -84,10 +84,10 @@ public interface HttpAsyncClientExchangeHandler extends Closeable, Cancellable {
      * to resume output event notifications when more content is made available.
      *
      * @param encoder content encoder.
-     * @param ioctrl I/O control of the underlying connection.
+     * @param ioControl I/O control of the underlying connection.
      * @throws IOException in case of an I/O error
      */
-    void produceContent(ContentEncoder encoder, IOControl ioctrl) throws IOException;
+    void produceContent(ContentEncoder encoder, IOControl ioControl) throws IOException;
 
     /**
      * Invoked to signal that the request has been fully written out.
@@ -121,10 +121,10 @@ public interface HttpAsyncClientExchangeHandler extends Closeable, Cancellable {
      * processing more content.
      *
      * @param decoder content decoder.
-     * @param ioctrl I/O control of the underlying connection.
+     * @param ioControl I/O control of the underlying connection.
      * @throws IOException in case of an I/O error
      */
-    void consumeContent(ContentDecoder decoder, IOControl ioctrl) throws IOException;
+    void consumeContent(ContentDecoder decoder, IOControl ioControl) throws IOException;
 
     /**
      * Invoked to signal that the response has been fully processed.

http://git-wip-us.apache.org/repos/asf/httpcomponents-core/blob/dbad59e2/httpcore-nio/src/main/java/org/apache/http/nio/protocol/HttpAsyncRequestConsumer.java
----------------------------------------------------------------------
diff --git a/httpcore-nio/src/main/java/org/apache/http/nio/protocol/HttpAsyncRequestConsumer.java b/httpcore-nio/src/main/java/org/apache/http/nio/protocol/HttpAsyncRequestConsumer.java
index 2739b62..f23848e 100644
--- a/httpcore-nio/src/main/java/org/apache/http/nio/protocol/HttpAsyncRequestConsumer.java
+++ b/httpcore-nio/src/main/java/org/apache/http/nio/protocol/HttpAsyncRequestConsumer.java
@@ -73,10 +73,10 @@ public interface HttpAsyncRequestConsumer<T> extends Closeable {
      * processing more content.
      *
      * @param decoder content decoder.
-     * @param ioctrl I/O control of the underlying connection.
+     * @param ioControl I/O control of the underlying connection.
      * @throws IOException in case of an I/O error
      */
-    void consumeContent(ContentDecoder decoder, IOControl ioctrl) throws IOException;
+    void consumeContent(ContentDecoder decoder, IOControl ioControl) throws IOException;
 
     /**
      * Invoked to signal that the request has been fully processed.

http://git-wip-us.apache.org/repos/asf/httpcomponents-core/blob/dbad59e2/httpcore-nio/src/main/java/org/apache/http/nio/protocol/HttpAsyncRequestProducer.java
----------------------------------------------------------------------
diff --git a/httpcore-nio/src/main/java/org/apache/http/nio/protocol/HttpAsyncRequestProducer.java b/httpcore-nio/src/main/java/org/apache/http/nio/protocol/HttpAsyncRequestProducer.java
index 3d320ba..3b49f4f 100644
--- a/httpcore-nio/src/main/java/org/apache/http/nio/protocol/HttpAsyncRequestProducer.java
+++ b/httpcore-nio/src/main/java/org/apache/http/nio/protocol/HttpAsyncRequestProducer.java
@@ -85,10 +85,10 @@ public interface HttpAsyncRequestProducer extends Closeable {
      * to resume output event notifications when more content is made available.
      *
      * @param encoder content encoder.
-     * @param ioctrl I/O control of the underlying connection.
+     * @param ioControl I/O control of the underlying connection.
      * @throws IOException in case of an I/O error
      */
-    void produceContent(ContentEncoder encoder, IOControl ioctrl) throws IOException;
+    void produceContent(ContentEncoder encoder, IOControl ioControl) throws IOException;
 
     /**
      * Invoked to signal that the request has been fully written out.

http://git-wip-us.apache.org/repos/asf/httpcomponents-core/blob/dbad59e2/httpcore-nio/src/main/java/org/apache/http/nio/protocol/HttpAsyncResponseConsumer.java
----------------------------------------------------------------------
diff --git a/httpcore-nio/src/main/java/org/apache/http/nio/protocol/HttpAsyncResponseConsumer.java b/httpcore-nio/src/main/java/org/apache/http/nio/protocol/HttpAsyncResponseConsumer.java
index 257bff5..cb165bb 100644
--- a/httpcore-nio/src/main/java/org/apache/http/nio/protocol/HttpAsyncResponseConsumer.java
+++ b/httpcore-nio/src/main/java/org/apache/http/nio/protocol/HttpAsyncResponseConsumer.java
@@ -73,10 +73,10 @@ public interface HttpAsyncResponseConsumer<T> extends Closeable, Cancellable {
      * processing more content.
      *
      * @param decoder content decoder.
-     * @param ioctrl I/O control of the underlying connection.
+     * @param ioControl I/O control of the underlying connection.
      * @throws IOException in case of an I/O error
      */
-    void consumeContent(ContentDecoder decoder, IOControl ioctrl) throws IOException;
+    void consumeContent(ContentDecoder decoder, IOControl ioControl) throws IOException;
 
     /**
      * Invoked to signal that the response has been fully processed.

http://git-wip-us.apache.org/repos/asf/httpcomponents-core/blob/dbad59e2/httpcore-nio/src/main/java/org/apache/http/nio/protocol/HttpAsyncResponseProducer.java
----------------------------------------------------------------------
diff --git a/httpcore-nio/src/main/java/org/apache/http/nio/protocol/HttpAsyncResponseProducer.java b/httpcore-nio/src/main/java/org/apache/http/nio/protocol/HttpAsyncResponseProducer.java
index e66e76a..dcedfc6 100644
--- a/httpcore-nio/src/main/java/org/apache/http/nio/protocol/HttpAsyncResponseProducer.java
+++ b/httpcore-nio/src/main/java/org/apache/http/nio/protocol/HttpAsyncResponseProducer.java
@@ -66,10 +66,10 @@ public interface HttpAsyncResponseProducer extends Closeable {
      * to resume output event notifications when more content is made available.
      *
      * @param encoder content encoder.
-     * @param ioctrl I/O control of the underlying connection.
+     * @param ioControl I/O control of the underlying connection.
      * @throws IOException in case of an I/O error
      */
-    void produceContent(ContentEncoder encoder, IOControl ioctrl) throws IOException;
+    void produceContent(ContentEncoder encoder, IOControl ioControl) throws IOException;
 
     /**
      * Invoked to signal that the response has been fully written out.

http://git-wip-us.apache.org/repos/asf/httpcomponents-core/blob/dbad59e2/httpcore-nio/src/main/java/org/apache/http/nio/protocol/NullRequestConsumer.java
----------------------------------------------------------------------
diff --git a/httpcore-nio/src/main/java/org/apache/http/nio/protocol/NullRequestConsumer.java b/httpcore-nio/src/main/java/org/apache/http/nio/protocol/NullRequestConsumer.java
index 4ade458..00b1b22 100644
--- a/httpcore-nio/src/main/java/org/apache/http/nio/protocol/NullRequestConsumer.java
+++ b/httpcore-nio/src/main/java/org/apache/http/nio/protocol/NullRequestConsumer.java
@@ -51,7 +51,7 @@ class NullRequestConsumer implements HttpAsyncRequestConsumer<Object> {
 
     @Override
     public void consumeContent(
-            final ContentDecoder decoder, final IOControl ioctrl) throws IOException {
+            final ContentDecoder decoder, final IOControl ioControl) throws IOException {
         int lastRead;
         do {
             this.buffer.clear();

http://git-wip-us.apache.org/repos/asf/httpcomponents-core/blob/dbad59e2/httpcore-nio/src/main/java/org/apache/http/nio/protocol/PipeliningClientExchangeHandler.java
----------------------------------------------------------------------
diff --git a/httpcore-nio/src/main/java/org/apache/http/nio/protocol/PipeliningClientExchangeHandler.java b/httpcore-nio/src/main/java/org/apache/http/nio/protocol/PipeliningClientExchangeHandler.java
index 5c21768..096f07b 100644
--- a/httpcore-nio/src/main/java/org/apache/http/nio/protocol/PipeliningClientExchangeHandler.java
+++ b/httpcore-nio/src/main/java/org/apache/http/nio/protocol/PipeliningClientExchangeHandler.java
@@ -191,10 +191,10 @@ public class PipeliningClientExchangeHandler<T> implements HttpAsyncClientExchan
 
     @Override
     public void produceContent(
-            final ContentEncoder encoder, final IOControl ioctrl) throws IOException {
+            final ContentEncoder encoder, final IOControl ioControl) throws IOException {
         final HttpAsyncRequestProducer requestProducer = this.requestProducerRef.get();
         Asserts.check(requestProducer != null, "Inconsistent state: request producer is null");
-        requestProducer.produceContent(encoder, ioctrl);
+        requestProducer.produceContent(encoder, ioControl);
     }
 
     @Override
@@ -225,10 +225,10 @@ public class PipeliningClientExchangeHandler<T> implements HttpAsyncClientExchan
 
     @Override
     public void consumeContent(
-            final ContentDecoder decoder, final IOControl ioctrl) throws IOException {
+            final ContentDecoder decoder, final IOControl ioControl) throws IOException {
         final HttpAsyncResponseConsumer<T> responseConsumer = this.responseConsumerRef.get();
         Asserts.check(responseConsumer != null, "Inconsistent state: response consumer is null");
-        responseConsumer.consumeContent(decoder, ioctrl);
+        responseConsumer.consumeContent(decoder, ioControl);
     }
 
     @Override

http://git-wip-us.apache.org/repos/asf/httpcomponents-core/blob/dbad59e2/httpcore-nio/src/main/java/org/apache/http/nio/util/SharedInputBuffer.java
----------------------------------------------------------------------
diff --git a/httpcore-nio/src/main/java/org/apache/http/nio/util/SharedInputBuffer.java b/httpcore-nio/src/main/java/org/apache/http/nio/util/SharedInputBuffer.java
index 72aa021..9b82739 100644
--- a/httpcore-nio/src/main/java/org/apache/http/nio/util/SharedInputBuffer.java
+++ b/httpcore-nio/src/main/java/org/apache/http/nio/util/SharedInputBuffer.java
@@ -58,7 +58,7 @@ public class SharedInputBuffer extends ExpandableBuffer implements ContentInputB
     private final ReentrantLock lock;
     private final Condition condition;
 
-    private volatile IOControl ioctrl;
+    private volatile IOControl ioControl;
     private volatile boolean shutdown = false;
     private volatile boolean endOfStream = false;
 
@@ -66,9 +66,9 @@ public class SharedInputBuffer extends ExpandableBuffer implements ContentInputB
      * @deprecated (4.3) use {@link SharedInputBuffer#SharedInputBuffer(int, ByteBufferAllocator)}
      */
     @Deprecated
-    public SharedInputBuffer(final int bufferSize, final IOControl ioctrl, final ByteBufferAllocator allocator) {
+    public SharedInputBuffer(final int bufferSize, final IOControl ioControl, final ByteBufferAllocator allocator) {
         super(bufferSize, allocator);
-        this.ioctrl = ioctrl;
+        this.ioControl = ioControl;
         this.lock = new ReentrantLock();
         this.condition = this.lock.newCondition();
     }
@@ -115,14 +115,14 @@ public class SharedInputBuffer extends ExpandableBuffer implements ContentInputB
     /**
      * @since 4.3
      */
-    public int consumeContent(final ContentDecoder decoder, final IOControl ioctrl) throws IOException {
+    public int consumeContent(final ContentDecoder decoder, final IOControl ioControl) throws IOException {
         if (this.shutdown) {
             return -1;
         }
         this.lock.lock();
         try {
-            if (ioctrl != null) {
-                this.ioctrl = ioctrl;
+            if (ioControl != null) {
+                this.ioControl = ioControl;
             }
             setInputMode();
             int totalRead = 0;
@@ -134,8 +134,8 @@ public class SharedInputBuffer extends ExpandableBuffer implements ContentInputB
                 this.endOfStream = true;
             }
             if (!this.buffer.hasRemaining()) {
-                if (this.ioctrl != null) {
-                    this.ioctrl.suspendInput();
+                if (this.ioControl != null) {
+                    this.ioControl.suspendInput();
                 }
             }
             this.condition.signalAll();
@@ -197,8 +197,8 @@ public class SharedInputBuffer extends ExpandableBuffer implements ContentInputB
                     if (this.shutdown) {
                         throw new InterruptedIOException("Input operation aborted");
                     }
-                    if (this.ioctrl != null) {
-                        this.ioctrl.requestInput();
+                    if (this.ioControl != null) {
+                        this.ioControl.requestInput();
                     }
                     this.condition.await();
                 }

http://git-wip-us.apache.org/repos/asf/httpcomponents-core/blob/dbad59e2/httpcore-nio/src/main/java/org/apache/http/nio/util/SharedOutputBuffer.java
----------------------------------------------------------------------
diff --git a/httpcore-nio/src/main/java/org/apache/http/nio/util/SharedOutputBuffer.java b/httpcore-nio/src/main/java/org/apache/http/nio/util/SharedOutputBuffer.java
index 98b8a75..ef1df00 100644
--- a/httpcore-nio/src/main/java/org/apache/http/nio/util/SharedOutputBuffer.java
+++ b/httpcore-nio/src/main/java/org/apache/http/nio/util/SharedOutputBuffer.java
@@ -60,7 +60,7 @@ public class SharedOutputBuffer extends ExpandableBuffer implements ContentOutpu
     private final ReentrantLock lock;
     private final Condition condition;
 
-    private volatile IOControl ioctrl;
+    private volatile IOControl ioControl;
     private volatile boolean shutdown = false;
     private volatile boolean endOfStream = false;
 
@@ -68,10 +68,10 @@ public class SharedOutputBuffer extends ExpandableBuffer implements ContentOutpu
      * @deprecated (4.3) use {@link SharedOutputBuffer#SharedOutputBuffer(int, ByteBufferAllocator)}
      */
     @Deprecated
-    public SharedOutputBuffer(final int bufferSize, final IOControl ioctrl, final ByteBufferAllocator allocator) {
+    public SharedOutputBuffer(final int bufferSize, final IOControl ioControl, final ByteBufferAllocator allocator) {
         super(bufferSize, allocator);
-        Args.notNull(ioctrl, "I/O content control");
-        this.ioctrl = ioctrl;
+        Args.notNull(ioControl, "I/O content control");
+        this.ioControl = ioControl;
         this.lock = new ReentrantLock();
         this.condition = this.lock.newCondition();
     }
@@ -158,14 +158,14 @@ public class SharedOutputBuffer extends ExpandableBuffer implements ContentOutpu
     /**
      * @since 4.3
      */
-    public int produceContent(final ContentEncoder encoder, final IOControl ioctrl) throws IOException {
+    public int produceContent(final ContentEncoder encoder, final IOControl ioControl) throws IOException {
         if (this.shutdown) {
             return -1;
         }
         this.lock.lock();
         try {
-            if (ioctrl != null) {
-                this.ioctrl = ioctrl;
+            if (ioControl != null) {
+                this.ioControl = ioControl;
             }
             setOutputMode();
             int bytesWritten = 0;
@@ -183,8 +183,8 @@ public class SharedOutputBuffer extends ExpandableBuffer implements ContentOutpu
                 }
                 if (!this.endOfStream) {
                     // suspend output events
-                    if (this.ioctrl != null) {
-                        this.ioctrl.suspendOutput();
+                    if (this.ioControl != null) {
+                        this.ioControl.suspendOutput();
                     }
                 }
             }
@@ -274,8 +274,8 @@ public class SharedOutputBuffer extends ExpandableBuffer implements ContentOutpu
                     if (this.shutdown) {
                         throw new InterruptedIOException("Output operation aborted");
                     }
-                    if (this.ioctrl != null) {
-                        this.ioctrl.requestOutput();
+                    if (this.ioControl != null) {
+                        this.ioControl.requestOutput();
                     }
                     this.condition.await();
                 }
@@ -295,8 +295,8 @@ public class SharedOutputBuffer extends ExpandableBuffer implements ContentOutpu
                 return;
             }
             this.endOfStream = true;
-            if (this.ioctrl != null) {
-                this.ioctrl.requestOutput();
+            if (this.ioControl != null) {
+                this.ioControl.requestOutput();
             }
         } finally {
             this.lock.unlock();

http://git-wip-us.apache.org/repos/asf/httpcomponents-core/blob/dbad59e2/httpcore-nio/src/test/java/org/apache/http/impl/nio/TestDefaultNHttpClientConnection.java
----------------------------------------------------------------------
diff --git a/httpcore-nio/src/test/java/org/apache/http/impl/nio/TestDefaultNHttpClientConnection.java b/httpcore-nio/src/test/java/org/apache/http/impl/nio/TestDefaultNHttpClientConnection.java
index 3cb35d2..f404bfb 100644
--- a/httpcore-nio/src/test/java/org/apache/http/impl/nio/TestDefaultNHttpClientConnection.java
+++ b/httpcore-nio/src/test/java/org/apache/http/impl/nio/TestDefaultNHttpClientConnection.java
@@ -159,9 +159,9 @@ public class TestDefaultNHttpClientConnection {
         @Override
         public Void answer(final InvocationOnMock invocation) throws Throwable {
             final Object[] args = invocation.getArguments();
-            final IOControl ioctrl = (IOControl) args[0];
+            final IOControl ioControl = (IOControl) args[0];
             final ContentEncoder encoder = (ContentEncoder) args[1];
-            contentProducer.produceContent(encoder, ioctrl);
+            contentProducer.produceContent(encoder, ioControl);
             return null;
         }
     }

http://git-wip-us.apache.org/repos/asf/httpcomponents-core/blob/dbad59e2/httpcore-nio/src/test/java/org/apache/http/impl/nio/TestDefaultNHttpServerConnection.java
----------------------------------------------------------------------
diff --git a/httpcore-nio/src/test/java/org/apache/http/impl/nio/TestDefaultNHttpServerConnection.java b/httpcore-nio/src/test/java/org/apache/http/impl/nio/TestDefaultNHttpServerConnection.java
index 7887683..334c941 100644
--- a/httpcore-nio/src/test/java/org/apache/http/impl/nio/TestDefaultNHttpServerConnection.java
+++ b/httpcore-nio/src/test/java/org/apache/http/impl/nio/TestDefaultNHttpServerConnection.java
@@ -159,9 +159,9 @@ public class TestDefaultNHttpServerConnection {
         @Override
         public Void answer(final InvocationOnMock invocation) throws Throwable {
             final Object[] args = invocation.getArguments();
-            final IOControl ioctrl = (IOControl) args[0];
+            final IOControl ioControl = (IOControl) args[0];
             final ContentEncoder encoder = (ContentEncoder) args[1];
-            contentProducer.produceContent(encoder, ioctrl);
+            contentProducer.produceContent(encoder, ioControl);
             return null;
         }
     }

http://git-wip-us.apache.org/repos/asf/httpcomponents-core/blob/dbad59e2/httpcore-nio/src/test/java/org/apache/http/nio/integration/TestHttpAsyncHandlerCancellable.java
----------------------------------------------------------------------
diff --git a/httpcore-nio/src/test/java/org/apache/http/nio/integration/TestHttpAsyncHandlerCancellable.java b/httpcore-nio/src/test/java/org/apache/http/nio/integration/TestHttpAsyncHandlerCancellable.java
index 2524888..48cc77f 100644
--- a/httpcore-nio/src/test/java/org/apache/http/nio/integration/TestHttpAsyncHandlerCancellable.java
+++ b/httpcore-nio/src/test/java/org/apache/http/nio/integration/TestHttpAsyncHandlerCancellable.java
@@ -98,9 +98,9 @@ public class TestHttpAsyncHandlerCancellable extends HttpCoreNIOTestBase {
 
             @Override
             public void produceContent(
-                    final ContentEncoder encoder, final IOControl ioctrl) throws IOException {
+                    final ContentEncoder encoder, final IOControl ioControl) throws IOException {
                 // suspend output
-                ioctrl.suspendOutput();
+                ioControl.suspendOutput();
             }
 
             @Override

http://git-wip-us.apache.org/repos/asf/httpcomponents-core/blob/dbad59e2/httpcore-nio/src/test/java/org/apache/http/nio/integration/TestHttpAsyncPrematureTermination.java
----------------------------------------------------------------------
diff --git a/httpcore-nio/src/test/java/org/apache/http/nio/integration/TestHttpAsyncPrematureTermination.java b/httpcore-nio/src/test/java/org/apache/http/nio/integration/TestHttpAsyncPrematureTermination.java
index a99a920..8601682 100644
--- a/httpcore-nio/src/test/java/org/apache/http/nio/integration/TestHttpAsyncPrematureTermination.java
+++ b/httpcore-nio/src/test/java/org/apache/http/nio/integration/TestHttpAsyncPrematureTermination.java
@@ -230,8 +230,8 @@ public class TestHttpAsyncPrematureTermination extends HttpCoreNIOTestBase {
                     @Override
                     public synchronized void produceContent(
                             final ContentEncoder encoder,
-                            final IOControl ioctrl) throws IOException {
-                        ioctrl.shutdown();
+                            final IOControl ioControl) throws IOException {
+                        ioControl.shutdown();
                     }
 
                 });

http://git-wip-us.apache.org/repos/asf/httpcomponents-core/blob/dbad59e2/httpcore-nio/src/test/java/org/apache/http/nio/integration/TestTruncatedChunks.java
----------------------------------------------------------------------
diff --git a/httpcore-nio/src/test/java/org/apache/http/nio/integration/TestTruncatedChunks.java b/httpcore-nio/src/test/java/org/apache/http/nio/integration/TestTruncatedChunks.java
index 8f4c648..797a6a5 100644
--- a/httpcore-nio/src/test/java/org/apache/http/nio/integration/TestTruncatedChunks.java
+++ b/httpcore-nio/src/test/java/org/apache/http/nio/integration/TestTruncatedChunks.java
@@ -211,7 +211,7 @@ public class TestTruncatedChunks extends HttpCoreNIOTestBase {
 
         @Override
         protected void onContentReceived(
-                final ContentDecoder decoder, final IOControl ioctrl) throws IOException {
+                final ContentDecoder decoder, final IOControl ioControl) throws IOException {
             boolean finished = false;
             try {
                 this.buffer.consumeContent(decoder);

http://git-wip-us.apache.org/repos/asf/httpcomponents-core/blob/dbad59e2/httpcore-nio/src/test/java/org/apache/http/nio/protocol/TestBasicAsyncRequestConsumer.java
----------------------------------------------------------------------
diff --git a/httpcore-nio/src/test/java/org/apache/http/nio/protocol/TestBasicAsyncRequestConsumer.java b/httpcore-nio/src/test/java/org/apache/http/nio/protocol/TestBasicAsyncRequestConsumer.java
index 2d2bd68..af496ae 100644
--- a/httpcore-nio/src/test/java/org/apache/http/nio/protocol/TestBasicAsyncRequestConsumer.java
+++ b/httpcore-nio/src/test/java/org/apache/http/nio/protocol/TestBasicAsyncRequestConsumer.java
@@ -50,7 +50,7 @@ public class TestBasicAsyncRequestConsumer {
     @Mock private HttpEntityEnclosingRequest request;
     @Mock private HttpContext context;
     @Mock private ContentDecoder decoder;
-    @Mock private IOControl ioctrl;
+    @Mock private IOControl ioControl;
 
     @Before
     public void setUp() throws Exception {
@@ -68,7 +68,7 @@ public class TestBasicAsyncRequestConsumer {
         when(request.getEntity()).thenReturn(new StringEntity("stuff"));
 
         consumer.requestReceived(request);
-        consumer.consumeContent(decoder, ioctrl);
+        consumer.consumeContent(decoder, ioControl);
         consumer.requestCompleted(context);
 
         verify(consumer).releaseResources();
@@ -88,7 +88,7 @@ public class TestBasicAsyncRequestConsumer {
         when(consumer.buildResult(context)).thenThrow(ooopsie);
 
         consumer.requestReceived(request);
-        consumer.consumeContent(decoder, ioctrl);
+        consumer.consumeContent(decoder, ioControl);
         consumer.requestCompleted(context);
 
         verify(consumer).releaseResources();

http://git-wip-us.apache.org/repos/asf/httpcomponents-core/blob/dbad59e2/httpcore-nio/src/test/java/org/apache/http/nio/protocol/TestBasicAsyncResponseConsumer.java
----------------------------------------------------------------------
diff --git a/httpcore-nio/src/test/java/org/apache/http/nio/protocol/TestBasicAsyncResponseConsumer.java b/httpcore-nio/src/test/java/org/apache/http/nio/protocol/TestBasicAsyncResponseConsumer.java
index 959dd20..e52c4fa 100644
--- a/httpcore-nio/src/test/java/org/apache/http/nio/protocol/TestBasicAsyncResponseConsumer.java
+++ b/httpcore-nio/src/test/java/org/apache/http/nio/protocol/TestBasicAsyncResponseConsumer.java
@@ -50,7 +50,7 @@ public class TestBasicAsyncResponseConsumer {
     @Mock private HttpResponse response;
     @Mock private HttpContext context;
     @Mock private ContentDecoder decoder;
-    @Mock private IOControl ioctrl;
+    @Mock private IOControl ioControl;
 
     @Before
     public void setUp() throws Exception {
@@ -68,7 +68,7 @@ public class TestBasicAsyncResponseConsumer {
         when(response.getEntity()).thenReturn(new StringEntity("stuff"));
 
         consumer.responseReceived(response);
-        consumer.consumeContent(decoder, ioctrl);
+        consumer.consumeContent(decoder, ioControl);
         consumer.responseCompleted(context);
 
         verify(consumer).releaseResources();
@@ -88,7 +88,7 @@ public class TestBasicAsyncResponseConsumer {
         when(consumer.buildResult(context)).thenThrow(ooopsie);
 
         consumer.responseReceived(response);
-        consumer.consumeContent(decoder, ioctrl);
+        consumer.consumeContent(decoder, ioControl);
         consumer.responseCompleted(context);
 
         verify(consumer).releaseResources();