You are viewing a plain text version of this content. The canonical link for it is here.
Posted to dev@tomcat.apache.org by vi...@apache.org on 2016/09/11 06:18:33 UTC

svn commit: r1760227 - /tomcat/trunk/java/org/apache/coyote/http11/Http11InputBuffer.java

Author: violetagg
Date: Sun Sep 11 06:18:33 2016
New Revision: 1760227

URL: http://svn.apache.org/viewvc?rev=1760227&view=rev
Log:
Use ByteBuffer instead of byte array. Use the new method for reading the data -  SocketWrapperBase.read(boolean, ByteBuffer).

Modified:
    tomcat/trunk/java/org/apache/coyote/http11/Http11InputBuffer.java

Modified: tomcat/trunk/java/org/apache/coyote/http11/Http11InputBuffer.java
URL: http://svn.apache.org/viewvc/tomcat/trunk/java/org/apache/coyote/http11/Http11InputBuffer.java?rev=1760227&r1=1760226&r2=1760227&view=diff
==============================================================================
--- tomcat/trunk/java/org/apache/coyote/http11/Http11InputBuffer.java (original)
+++ tomcat/trunk/java/org/apache/coyote/http11/Http11InputBuffer.java Sun Sep 11 06:18:33 2016
@@ -28,6 +28,7 @@ import org.apache.juli.logging.LogFactor
 import org.apache.tomcat.util.buf.ByteChunk;
 import org.apache.tomcat.util.buf.MessageBytes;
 import org.apache.tomcat.util.http.MimeHeaders;
+import org.apache.tomcat.util.net.ApplicationBufferHandler;
 import org.apache.tomcat.util.net.SocketWrapperBase;
 import org.apache.tomcat.util.res.StringManager;
 
@@ -35,7 +36,7 @@ import org.apache.tomcat.util.res.String
  * InputBuffer for HTTP that provides request header parsing as well as transfer
  * encoding.
  */
-public class Http11InputBuffer implements InputBuffer {
+public class Http11InputBuffer implements InputBuffer, ApplicationBufferHandler {
 
     // -------------------------------------------------------------- Constants
 
@@ -127,19 +128,7 @@ public class Http11InputBuffer implement
     /**
      * The read buffer.
      */
-    private byte[] buf;
-
-
-    /**
-     * Last valid byte.
-     */
-    private int lastValid;
-
-
-    /**
-     * Position in the buffer.
-     */
-    private int pos;
+    private ByteBuffer byteBuffer;
 
 
     /**
@@ -318,8 +307,7 @@ public class Http11InputBuffer implement
             activeFilters[i].recycle();
         }
 
-        lastValid = 0;
-        pos = 0;
+        byteBuffer.limit(0).position(0);
         lastActiveFilter = -1;
         parsingHeader = true;
         swallowInput = true;
@@ -344,12 +332,11 @@ public class Http11InputBuffer implement
         request.recycle();
 
         // Copy leftover bytes to the beginning of the buffer
-        if (lastValid - pos > 0 && pos > 0) {
-            System.arraycopy(buf, pos, buf, 0, lastValid - pos);
+        if (byteBuffer.remaining() > 0 && byteBuffer.position() > 0) {
+            byteBuffer.compact();
         }
         // Always reset pos to zero
-        lastValid = lastValid - pos;
-        pos = 0;
+        byteBuffer.limit(byteBuffer.limit() - byteBuffer.position()).position(0);
 
         // Recycle filters
         for (int i = 0; i <= lastActiveFilter; i++) {
@@ -396,7 +383,7 @@ public class Http11InputBuffer implement
             do {
 
                 // Read new bytes if needed
-                if (pos >= lastValid) {
+                if (byteBuffer.position() >= byteBuffer.limit()) {
                     if (keptAlive) {
                         // Haven't read any request data yet so use the keep-alive
                         // timeout.
@@ -411,10 +398,10 @@ public class Http11InputBuffer implement
                     // Switch to the socket timeout.
                     wrapper.setReadTimeout(wrapper.getEndpoint().getSoTimeout());
                 }
-                if (!keptAlive && pos == 0 && lastValid >= CLIENT_PREFACE_START.length - 1) {
+                if (!keptAlive && byteBuffer.position() == 0 && byteBuffer.limit() >= CLIENT_PREFACE_START.length - 1) {
                     boolean prefaceMatch = true;
                     for (int i = 0; i < CLIENT_PREFACE_START.length && prefaceMatch; i++) {
-                        if (CLIENT_PREFACE_START[i] != buf[i]) {
+                        if (CLIENT_PREFACE_START[i] != byteBuffer.get(i)) {
                             prefaceMatch = false;
                         }
                     }
@@ -429,15 +416,15 @@ public class Http11InputBuffer implement
                 if (request.getStartTime() < 0) {
                     request.setStartTime(System.currentTimeMillis());
                 }
-                chr = buf[pos++];
+                chr = byteBuffer.get();
             } while ((chr == Constants.CR) || (chr == Constants.LF));
-            pos--;
+            byteBuffer.position(byteBuffer.position() - 1);
 
-            parsingRequestLineStart = pos;
+            parsingRequestLineStart = byteBuffer.position();
             parsingRequestLinePhase = 2;
             if (log.isDebugEnabled()) {
                 log.debug("Received ["
-                        + new String(buf, pos, lastValid - pos, StandardCharsets.ISO_8859_1) + "]");
+                        + new String(byteBuffer.array(), byteBuffer.position(), byteBuffer.remaining(), StandardCharsets.ISO_8859_1) + "]");
             }
         }
         if (parsingRequestLinePhase == 2) {
@@ -448,20 +435,22 @@ public class Http11InputBuffer implement
             boolean space = false;
             while (!space) {
                 // Read new bytes if needed
-                if (pos >= lastValid) {
+                if (byteBuffer.position() >= byteBuffer.limit()) {
                     if (!fill(false)) // request line parsing
                         return false;
                 }
                 // Spec says method name is a token followed by a single SP but
                 // also be tolerant of multiple SP and/or HT.
-                if (buf[pos] == Constants.SP || buf[pos] == Constants.HT) {
+                int pos = byteBuffer.position();
+                byte chr = byteBuffer.get();
+                if (chr == Constants.SP || chr == Constants.HT) {
                     space = true;
-                    request.method().setBytes(buf, parsingRequestLineStart,
+                    request.method().setBytes(byteBuffer.array(), parsingRequestLineStart,
                             pos - parsingRequestLineStart);
-                } else if (!HTTP_TOKEN_CHAR[buf[pos]]) {
+                } else if (!HTTP_TOKEN_CHAR[chr]) {
+                    byteBuffer.position(byteBuffer.position() - 1);
                     throw new IllegalArgumentException(sm.getString("iib.invalidmethod"));
                 }
-                pos++;
             }
             parsingRequestLinePhase = 3;
         }
@@ -470,17 +459,17 @@ public class Http11InputBuffer implement
             boolean space = true;
             while (space) {
                 // Read new bytes if needed
-                if (pos >= lastValid) {
+                if (byteBuffer.position() >= byteBuffer.limit()) {
                     if (!fill(false)) // request line parsing
                         return false;
                 }
-                if (buf[pos] == Constants.SP || buf[pos] == Constants.HT) {
-                    pos++;
-                } else {
+                byte chr = byteBuffer.get();
+                if (!(chr == Constants.SP || chr == Constants.HT)) {
                     space = false;
+                    byteBuffer.position(byteBuffer.position() - 1);
                 }
             }
-            parsingRequestLineStart = pos;
+            parsingRequestLineStart = byteBuffer.position();
             parsingRequestLinePhase = 4;
         }
         if (parsingRequestLinePhase == 4) {
@@ -493,30 +482,31 @@ public class Http11InputBuffer implement
             boolean space = false;
             while (!space) {
                 // Read new bytes if needed
-                if (pos >= lastValid) {
+                if (byteBuffer.position() >= byteBuffer.limit()) {
                     if (!fill(false)) // request line parsing
                         return false;
                 }
-                if (buf[pos] == Constants.SP || buf[pos] == Constants.HT) {
+                int pos = byteBuffer.position();
+                byte chr = byteBuffer.get();
+                if (chr == Constants.SP || chr == Constants.HT) {
                     space = true;
                     end = pos;
-                } else if ((buf[pos] == Constants.CR) || (buf[pos] == Constants.LF)) {
+                } else if (chr == Constants.CR || chr == Constants.LF) {
                     // HTTP/0.9 style request
                     parsingRequestLineEol = true;
                     space = true;
                     end = pos;
-                } else if ((buf[pos] == Constants.QUESTION) && (parsingRequestLineQPos == -1)) {
+                } else if (chr == Constants.QUESTION && parsingRequestLineQPos == -1) {
                     parsingRequestLineQPos = pos;
                 }
-                pos++;
             }
             if (parsingRequestLineQPos >= 0) {
-                request.queryString().setBytes(buf, parsingRequestLineQPos + 1,
+                request.queryString().setBytes(byteBuffer.array(), parsingRequestLineQPos + 1,
                         end - parsingRequestLineQPos - 1);
-                request.requestURI().setBytes(buf, parsingRequestLineStart,
+                request.requestURI().setBytes(byteBuffer.array(), parsingRequestLineStart,
                         parsingRequestLineQPos - parsingRequestLineStart);
             } else {
-                request.requestURI().setBytes(buf, parsingRequestLineStart,
+                request.requestURI().setBytes(byteBuffer.array(), parsingRequestLineStart,
                         end - parsingRequestLineStart);
             }
             parsingRequestLinePhase = 5;
@@ -526,17 +516,17 @@ public class Http11InputBuffer implement
             boolean space = true;
             while (space) {
                 // Read new bytes if needed
-                if (pos >= lastValid) {
+                if (byteBuffer.position() >= byteBuffer.limit()) {
                     if (!fill(false)) // request line parsing
                         return false;
                 }
-                if (buf[pos] == Constants.SP || buf[pos] == Constants.HT) {
-                    pos++;
-                } else {
+                byte chr = byteBuffer.get();
+                if (!(chr == Constants.SP || chr == Constants.HT)) {
                     space = false;
+                    byteBuffer.position(byteBuffer.position() - 1);
                 }
             }
-            parsingRequestLineStart = pos;
+            parsingRequestLineStart = byteBuffer.position();
             parsingRequestLinePhase = 6;
 
             // Mark the current buffer position
@@ -549,23 +539,25 @@ public class Http11InputBuffer implement
             //
             while (!parsingRequestLineEol) {
                 // Read new bytes if needed
-                if (pos >= lastValid) {
+                if (byteBuffer.position() >= byteBuffer.limit()) {
                     if (!fill(false)) // request line parsing
                         return false;
                 }
 
-                if (buf[pos] == Constants.CR) {
+                int pos = byteBuffer.position();
+                byte chr = byteBuffer.get();
+                if (chr == Constants.CR) {
                     end = pos;
-                } else if (buf[pos] == Constants.LF) {
-                    if (end == 0)
+                } else if (chr == Constants.LF) {
+                    if (end == 0) {
                         end = pos;
+                    }
                     parsingRequestLineEol = true;
                 }
-                pos++;
             }
 
             if ((end - parsingRequestLineStart) > 0) {
-                request.protocol().setBytes(buf, parsingRequestLineStart,
+                request.protocol().setBytes(byteBuffer.array(), parsingRequestLineStart,
                         end - parsingRequestLineStart);
             } else {
                 request.protocol().setString("");
@@ -601,13 +593,13 @@ public class Http11InputBuffer implement
             // limitation to enforce the meaning of headerBufferSize
             // From the way how buf is allocated and how blank lines are being
             // read, it should be enough to check (1) only.
-            if (pos > headerBufferSize || buf.length - pos < socketReadBufferSize) {
+            if (byteBuffer.position() > headerBufferSize || byteBuffer.capacity() - byteBuffer.position() < socketReadBufferSize) {
                 throw new IllegalArgumentException(sm.getString("iib.requestheadertoolarge.error"));
             }
         } while (status == HeaderParseStatus.HAVE_MORE_HEADERS);
         if (status == HeaderParseStatus.DONE) {
             parsingHeader = false;
-            end = pos;
+            end = byteBuffer.position();
             return true;
         } else {
             return false;
@@ -629,7 +621,7 @@ public class Http11InputBuffer implement
 
         if (swallowInput && (lastActiveFilter != -1)) {
             int extraBytes = (int) activeFilters[lastActiveFilter].end();
-            pos = pos - extraBytes;
+            byteBuffer.position(byteBuffer.position() - extraBytes);
         }
     }
 
@@ -639,7 +631,7 @@ public class Http11InputBuffer implement
      * correspond).
      */
     int available(boolean read) {
-        int available = lastValid - pos;
+        int available = byteBuffer.remaining();
         if ((available == 0) && (lastActiveFilter >= 0)) {
             for (int i = 0; (available == 0) && (i <= lastActiveFilter); i++) {
                 available = activeFilters[i].available();
@@ -651,7 +643,7 @@ public class Http11InputBuffer implement
 
         try {
             fill(false);
-            available = lastValid - pos;
+            available = byteBuffer.remaining();
         } catch (IOException ioe) {
             if (log.isDebugEnabled()) {
                 log.debug(sm.getString("iib.available.readFail"), ioe);
@@ -671,7 +663,7 @@ public class Http11InputBuffer implement
      * faking non-blocking reads with the blocking IO connector.
      */
     boolean isFinished() {
-        if (lastValid > pos) {
+        if (byteBuffer.limit() > byteBuffer.position()) {
             // Data to read in the buffer so not finished
             return false;
         }
@@ -697,9 +689,9 @@ public class Http11InputBuffer implement
     }
 
     ByteBuffer getLeftover() {
-        int available = lastValid - pos;
+        int available = byteBuffer.remaining();
         if (available > 0) {
-            return ByteBuffer.wrap(buf, pos, available);
+            return ByteBuffer.wrap(byteBuffer.array(), byteBuffer.position(), available);
         } else {
             return null;
         }
@@ -709,11 +701,13 @@ public class Http11InputBuffer implement
     void init(SocketWrapperBase<?> socketWrapper) {
 
         wrapper = socketWrapper;
+        wrapper.setAppReadBufHandler(this);
 
         int bufLength = headerBufferSize +
                 wrapper.getSocketBufferHandler().getReadBuffer().capacity();
-        if (buf == null || buf.length < bufLength) {
-            buf = new byte[bufLength];
+        if (byteBuffer == null || byteBuffer.capacity() < bufLength) {
+            byteBuffer = ByteBuffer.allocate(bufLength);
+            byteBuffer.position(0).limit(0);
         }
     }
 
@@ -730,16 +724,21 @@ public class Http11InputBuffer implement
     private boolean fill(boolean block) throws IOException {
 
         if (parsingHeader) {
-            if (lastValid >= headerBufferSize) {
+            if (byteBuffer.limit() >= headerBufferSize) {
                 throw new IllegalArgumentException(sm.getString("iib.requestheadertoolarge.error"));
             }
         } else {
-            lastValid = pos = end;
+            byteBuffer.limit(end).position(end);
         }
 
-        int nRead = wrapper.read(block, buf, pos, buf.length - pos);
+        int oldPosition = byteBuffer.position();
+        if (byteBuffer.position() < byteBuffer.limit()) {
+            byteBuffer.position(byteBuffer.limit());
+        }
+        byteBuffer.limit(byteBuffer.capacity());
+        int nRead = wrapper.read(block, byteBuffer);
+        byteBuffer.limit(byteBuffer.position()).position(oldPosition);
         if (nRead > 0) {
-            lastValid = pos + nRead;
             return true;
         } else if (nRead == -1) {
             throw new EOFException(sm.getString("iib.eof.error"));
@@ -766,31 +765,29 @@ public class Http11InputBuffer implement
         while (headerParsePos == HeaderParsePosition.HEADER_START) {
 
             // Read new bytes if needed
-            if (pos >= lastValid) {
+            if (byteBuffer.position() >= byteBuffer.limit()) {
                 if (!fill(false)) {// parse header
                     headerParsePos = HeaderParsePosition.HEADER_START;
                     return HeaderParseStatus.NEED_MORE_DATA;
                 }
             }
 
-            chr = buf[pos];
+            chr = byteBuffer.get();
 
             if (chr == Constants.CR) {
                 // Skip
             } else if (chr == Constants.LF) {
-                pos++;
                 return HeaderParseStatus.DONE;
             } else {
+                byteBuffer.position(byteBuffer.position() - 1);
                 break;
             }
 
-            pos++;
-
         }
 
         if (headerParsePos == HeaderParsePosition.HEADER_START) {
             // Mark the current buffer position
-            headerData.start = pos;
+            headerData.start = byteBuffer.position();
             headerParsePos = HeaderParsePosition.HEADER_NAME;
         }
 
@@ -802,18 +799,19 @@ public class Http11InputBuffer implement
         while (headerParsePos == HeaderParsePosition.HEADER_NAME) {
 
             // Read new bytes if needed
-            if (pos >= lastValid) {
+            if (byteBuffer.position() >= byteBuffer.limit()) {
                 if (!fill(false)) { // parse header
                     return HeaderParseStatus.NEED_MORE_DATA;
                 }
             }
 
-            chr = buf[pos];
+            int pos = byteBuffer.position();
+            chr = byteBuffer.get();
             if (chr == Constants.COLON) {
                 headerParsePos = HeaderParsePosition.HEADER_VALUE_START;
-                headerData.headerValue = headers.addValue(buf, headerData.start,
+                headerData.headerValue = headers.addValue(byteBuffer.array(), headerData.start,
                         pos - headerData.start);
-                pos++;
+                pos = byteBuffer.position();
                 // Mark the current buffer position
                 headerData.start = pos;
                 headerData.realPos = pos;
@@ -823,14 +821,14 @@ public class Http11InputBuffer implement
                 // If a non-token header is detected, skip the line and
                 // ignore the header
                 headerData.lastSignificantChar = pos;
+                byteBuffer.position(byteBuffer.position() - 1);
                 return skipLine();
             }
 
             // chr is next byte of header name. Convert to lowercase.
             if ((chr >= Constants.A) && (chr <= Constants.Z)) {
-                buf[pos] = (byte) (chr - Constants.LC_OFFSET);
+                byteBuffer.put(pos, (byte) (chr - Constants.LC_OFFSET));
             }
-            pos++;
         }
 
         // Skip the line and ignore the header
@@ -850,18 +848,17 @@ public class Http11InputBuffer implement
                 // Skipping spaces
                 while (true) {
                     // Read new bytes if needed
-                    if (pos >= lastValid) {
+                    if (byteBuffer.position() >= byteBuffer.limit()) {
                         if (!fill(false)) {// parse header
                             // HEADER_VALUE_START
                             return HeaderParseStatus.NEED_MORE_DATA;
                         }
                     }
 
-                    chr = buf[pos];
-                    if (chr == Constants.SP || chr == Constants.HT) {
-                        pos++;
-                    } else {
+                    chr = byteBuffer.get();
+                    if (!(chr == Constants.SP || chr == Constants.HT)) {
                         headerParsePos = HeaderParsePosition.HEADER_VALUE;
+                        byteBuffer.position(byteBuffer.position() - 1);
                         break;
                     }
                 }
@@ -873,28 +870,26 @@ public class Http11InputBuffer implement
                 while (!eol) {
 
                     // Read new bytes if needed
-                    if (pos >= lastValid) {
+                    if (byteBuffer.position() >= byteBuffer.limit()) {
                         if (!fill(false)) {// parse header
                             // HEADER_VALUE
                             return HeaderParseStatus.NEED_MORE_DATA;
                         }
                     }
 
-                    chr = buf[pos];
+                    chr = byteBuffer.get();
                     if (chr == Constants.CR) {
                         // Skip
                     } else if (chr == Constants.LF) {
                         eol = true;
                     } else if (chr == Constants.SP || chr == Constants.HT) {
-                        buf[headerData.realPos] = chr;
+                        byteBuffer.put(headerData.realPos, chr);
                         headerData.realPos++;
                     } else {
-                        buf[headerData.realPos] = chr;
+                        byteBuffer.put(headerData.realPos, chr);
                         headerData.realPos++;
                         headerData.lastSignificantChar = headerData.realPos;
                     }
-
-                    pos++;
                 }
 
                 // Ignore whitespaces at the end of the line
@@ -905,14 +900,14 @@ public class Http11InputBuffer implement
                 headerParsePos = HeaderParsePosition.HEADER_MULTI_LINE;
             }
             // Read new bytes if needed
-            if (pos >= lastValid) {
+            if (byteBuffer.position() >= byteBuffer.limit()) {
                 if (!fill(false)) {// parse header
                     // HEADER_MULTI_LINE
                     return HeaderParseStatus.NEED_MORE_DATA;
                 }
             }
 
-            chr = buf[pos];
+            chr = byteBuffer.get(byteBuffer.position());
             if (headerParsePos == HeaderParsePosition.HEADER_MULTI_LINE) {
                 if ((chr != Constants.SP) && (chr != Constants.HT)) {
                     headerParsePos = HeaderParsePosition.HEADER_START;
@@ -920,14 +915,14 @@ public class Http11InputBuffer implement
                 } else {
                     // Copying one extra space in the buffer (since there must
                     // be at least one space inserted between the lines)
-                    buf[headerData.realPos] = chr;
+                    byteBuffer.put(headerData.realPos, chr);
                     headerData.realPos++;
                     headerParsePos = HeaderParsePosition.HEADER_VALUE_START;
                 }
             }
         }
         // Set the header value
-        headerData.headerValue.setBytes(buf, headerData.start,
+        headerData.headerValue.setBytes(byteBuffer.array(), headerData.start,
                 headerData.lastSignificantChar - headerData.start);
         headerData.recycle();
         return HeaderParseStatus.HAVE_MORE_HEADERS;
@@ -942,25 +937,25 @@ public class Http11InputBuffer implement
         while (!eol) {
 
             // Read new bytes if needed
-            if (pos >= lastValid) {
+            if (byteBuffer.position() >= byteBuffer.limit()) {
                 if (!fill(false)) {
                     return HeaderParseStatus.NEED_MORE_DATA;
                 }
             }
 
-            if (buf[pos] == Constants.CR) {
+            int pos = byteBuffer.position();
+            byte chr = byteBuffer.get();
+            if (chr == Constants.CR) {
                 // Skip
-            } else if (buf[pos] == Constants.LF) {
+            } else if (chr == Constants.LF) {
                 eol = true;
             } else {
                 headerData.lastSignificantChar = pos;
             }
-
-            pos++;
         }
         if (log.isDebugEnabled()) {
             log.debug(sm.getString("iib.invalidheader",
-                    new String(buf, headerData.start,
+                    new String(byteBuffer.array(), headerData.start,
                             headerData.lastSignificantChar - headerData.start + 1,
                             StandardCharsets.ISO_8859_1)));
         }
@@ -1065,18 +1060,36 @@ public class Http11InputBuffer implement
         @Override
         public int doRead(ByteChunk chunk) throws IOException {
 
-            if (pos >= lastValid) {
+            if (byteBuffer.position() >= byteBuffer.limit()) {
                 // The application is reading the HTTP request body which is
                 // always a blocking operation.
                 if (!fill(true))
                     return -1;
             }
 
-            int length = lastValid - pos;
-            chunk.setBytes(buf, pos, length);
-            pos = lastValid;
+            int length = byteBuffer.remaining();
+            chunk.setBytes(byteBuffer.array(), byteBuffer.position(), length);
+            byteBuffer.position(byteBuffer.limit());
 
             return length;
         }
     }
+
+
+    @Override
+    public ByteBuffer getByteBuffer() {
+        return byteBuffer;
+    }
+
+
+    @Override
+    public void expand(int size) {
+        if (byteBuffer.capacity() >= size) {
+            byteBuffer.limit(size);
+        }
+        ByteBuffer temp = ByteBuffer.allocate(size);
+        temp.put(byteBuffer);
+        byteBuffer = temp;
+        temp = null;
+    }
 }



---------------------------------------------------------------------
To unsubscribe, e-mail: dev-unsubscribe@tomcat.apache.org
For additional commands, e-mail: dev-help@tomcat.apache.org