You are viewing a plain text version of this content. The canonical link for it is here.
Posted to dev@tomcat.apache.org by co...@apache.org on 2001/06/24 22:44:49 UTC

cvs commit: jakarta-tomcat-connectors/jk/java/org/apache/ajp Ajp14.java Ajp14Packet.java

costin      01/06/24 13:44:49

  Added:       jk/java/org/apache/ajp Ajp14.java Ajp14Packet.java
  Log:
  Moved Ajp14 and Ajp14Packet to the common dir.
  
  Did the changes to make it compile ( it will not work right now, there
  are few more fixes - to wrap AjpRequest into a Request in the interceptor )
  
  Another change that is needed is to move the code from Ajp13, Ajp13Packet
  ( so Ajp14 is independent ) and make sure Ajp14(Packet) works with mod_jk
  sending ajp13 requests.  After that we can remove Ajp13/Ajp13Packet
  and do all the work in Ajp14.
  
  Revision  Changes    Path
  1.1                  jakarta-tomcat-connectors/jk/java/org/apache/ajp/Ajp14.java
  
  Index: Ajp14.java
  ===================================================================
  /*
   * ====================================================================
   *
   * The Apache Software License, Version 1.1
   *
   * Copyright (c) 1999 The Apache Software Foundation.  All rights
   * reserved.
   *
   * Redistribution and use in source and binary forms, with or without
   * modification, are permitted provided that the following conditions
   * are met:
   *
   * 1. Redistributions of source code must retain the above copyright
   *    notice, this list of conditions and the following disclaimer.
   *
   * 2. Redistributions in binary form must reproduce the above copyright
   *    notice, this list of conditions and the following disclaimer in
   *    the documentation and/or other materials provided with the
   *    distribution.
   *
   * 3. The end-user documentation included with the redistribution, if
   *    any, must include the following acknowlegement:
   *       "This product includes software developed by the
   *        Apache Software Foundation (http://www.apache.org/)."
   *    Alternately, this acknowlegement may appear in the software itself,
   *    if and wherever such third-party acknowlegements normally appear.
   *
   * 4. The names "The Jakarta Project", "Tomcat", and "Apache Software
   *    Foundation" must not be used to endorse or promote products derived
   *    from this software without prior written permission. For written
   *    permission, please contact apache@apache.org.
   *
   * 5. Products derived from this software may not be called "Apache"
   *    nor may "Apache" appear in their names without prior written
   *    permission of the Apache Group.
   *
   * THIS SOFTWARE IS PROVIDED ``AS IS'' AND ANY EXPRESSED OR IMPLIED
   * WARRANTIES, INCLUDING, BUT NOT LIMITED TO, THE IMPLIED WARRANTIES
   * OF MERCHANTABILITY AND FITNESS FOR A PARTICULAR PURPOSE ARE
   * DISCLAIMED.  IN NO EVENT SHALL THE APACHE SOFTWARE FOUNDATION OR
   * ITS CONTRIBUTORS BE LIABLE FOR ANY DIRECT, INDIRECT, INCIDENTAL,
   * SPECIAL, EXEMPLARY, OR CONSEQUENTIAL DAMAGES (INCLUDING, BUT NOT
   * LIMITED TO, PROCUREMENT OF SUBSTITUTE GOODS OR SERVICES; LOSS OF
   * USE, DATA, OR PROFITS; OR BUSINESS INTERRUPTION) HOWEVER CAUSED AND
   * ON ANY THEORY OF LIABILITY, WHETHER IN CONTRACT, STRICT LIABILITY,
   * OR TORT (INCLUDING NEGLIGENCE OR OTHERWISE) ARISING IN ANY WAY OUT
   * OF THE USE OF THIS SOFTWARE, EVEN IF ADVISED OF THE POSSIBILITY OF
   * SUCH DAMAGE.
   * ====================================================================
   *
   * This software consists of voluntary contributions made by many
   * individuals on behalf of the Apache Software Foundation.  For more
   * information on the Apache Software Foundation, please see
   * <http://www.apache.org/>.
   *
   * [Additional notices, if required by prior licensing conditions]
   *
   */
  
  package org.apache.ajp;
  
  import java.io.IOException;
  import java.io.UnsupportedEncodingException;
  import java.io.InputStream;
  import java.io.OutputStream;
  import java.net.Socket;
  import java.util.Enumeration;
  import java.security.*;
  
  import org.apache.tomcat.util.http.MimeHeaders;
  import org.apache.tomcat.util.buf.MessageBytes;
  import org.apache.tomcat.util.http.HttpMessages;
  import org.apache.tomcat.util.buf.HexUtils;
  
  
  /**
   * Represents a single, persistent connection between the web server and
   * the servlet container.  Uses the Apache JServ Protocol version 1.3 for
   * communication.  Because this protocal does not multiplex requests, this
   * connection can only be associated with a single request-handling cycle
   * at a time.<P>
   *
   * This class contains knowledge about how an individual packet is laid out
   * (via the internal <CODE>Ajp14Packet</CODE> class), and also about the
   * stages of communicaton between the server and the servlet container.  It
   * translates from Tomcat's internal servlet support methods
   * (e.g. doWrite) to the correct packets to send to the web server.
   *
   * @see Ajp14Interceptor 
   *
   * @author Henri Gomez [hgomez@slib.fr]
   * @author Dan Milstein [danmil@shore.net]
   * @author Keith Wannamaker [Keith@Wannamaker.org]
   */
  public class Ajp14 extends Ajp13
  {
      // Original AJP13 commands    
      // Prefix codes for message types from server to container
      public static final byte JK_AJP13_FORWARD_REQUEST   = 2;
      public static final byte JK_AJP13_SHUTDOWN          = 7;
  	
      // Prefix codes for message types from container to server
      public static final byte JK_AJP13_SEND_BODY_CHUNK   = 3;
      public static final byte JK_AJP13_SEND_HEADERS      = 4;
      public static final byte JK_AJP13_END_RESPONSE      = 5;
      public static final byte JK_AJP13_GET_BODY_CHUNK    = 6;
      
  
  
      // New AJP14 commands
      
      // Initial Login Phase (web server -> servlet engine)
      public static final byte JK_AJP14_LOGINIT_CMD			= 0x10;
      
      // Second Login Phase (servlet engine -> web server), md5 seed is received
      public static final byte JK_AJP14_LOGSEED_CMD			= 0x11;
      
      // Third Login Phase (web server -> servlet engine), md5 of seed + secret is sent
      public static final byte JK_AJP14_LOGCOMP_CMD			= 0x12;
      
      // Login Accepted (servlet engine -> web server)
      public static final byte JK_AJP14_LOGOK_CMD         	= 0x13;
  
      // Login Rejected (servlet engine -> web server), will be logged
  	public static final byte JK_AJP14_LOGNOK_CMD        	= 0x14;
      
      // Context Query (web server -> servlet engine), which URI are handled by servlet engine ?
      public static final byte JK_AJP14_CONTEXT_QRY_CMD		= 0x15;
      
      // Context Info (servlet engine -> web server), URI handled response
      public static final byte JK_AJP14_CONTEXT_INFO_CMD		= 0x16;
      
      // Context Update (servlet engine -> web server), status of context changed
      public static final byte JK_AJP14_CONTEXT_UPDATE_CMD	= 0x17;
      
      // Servlet Engine Status (web server -> servlet engine), what's the status of the servlet engine ?
      public static final byte JK_AJP14_STATUS_CMD			= 0x18;
      
      // Secure Shutdown command (web server -> servlet engine), please servlet stop yourself.
      public static final byte JK_AJP14_SHUTDOWN_CMD			= 0x19;
      
      // Secure Shutdown command Accepted (servlet engine -> web server)
      public static final byte JK_AJP14_SHUTOK_CMD			= 0x1A;
      
      // Secure Shutdown Rejected (servlet engine -> web server)
      public static final byte JK_AJP14_SHUTNOK_CMD           = 0x1B;
      
      // Context Status (web server -> servlet engine), what's the status of the context ?
      public static final byte JK_AJP14_CONTEXT_STATE_CMD     = 0x1C;
      
      // Context Status Reply (servlet engine -> web server), status of context
      public static final byte JK_AJP14_CONTEXT_STATE_REP_CMD = 0x1D;
      
      // Unknown Packet Reply (web server <-> servlet engine), when a packet couldn't be decoded
      public static final byte JK_AJP14_UNKNOW_PACKET_CMD     = 0x1E;
  
  
      // -------------------- Other constants -------------------- 
  
      // Entropy Packet Size
      public static final int	 AJP14_ENTROPY_SEED_LEN 		= 32;
      public static final int	 AJP14_COMPUTED_KEY_LEN 		= 32;
      
      // web-server want context info after login
      public static final int	 AJP14_CONTEXT_INFO_NEG			= 0x80000000;
      
      // web-server want context updates
      public static final int	 AJP14_CONTEXT_UPDATE_NEG		= 0x40000000;
      
      // web-server want compressed stream
      public static final int  AJP14_GZIP_STREAM_NEG			= 0x20000000;
      
      // web-server want crypted DES56 stream with secret key
      public static final int  AJP14_DES56_STREAM_NEG      	= 0x10000000;
      
      // Extended info on server SSL vars
      public static final int  AJP14_SSL_VSERVER_NEG			= 0x08000000;
      
      // Extended info on client SSL vars
      public static final int  AJP14_SSL_VCLIENT_NEG			= 0x04000000;
      
      // Extended info on crypto SSL vars
      public static final int	 AJP14_SSL_VCRYPTO_NEG			= 0x02000000;
      
      // Extended info on misc SSL vars
      public static final int  AJP14_SSL_VMISC_NEG         	= 0x01000000;
      
      // mask of protocol supported
      public static final int  AJP14_PROTO_SUPPORT_AJPXX_NEG  = 0x00FF0000;
      
      // communication could use AJP14
      public static final int  AJP14_PROTO_SUPPORT_AJP14_NEG  = 0x00010000;
      
      // communication could use AJP15
      public static final int  AJP14_PROTO_SUPPORT_AJP15_NEG  = 0x00020000;
      
      // communication could use AJP16
      public static final int  AJP14_PROTO_SUPPORT_AJP16_NEG  = 0x00040000;
      
      // Some failure codes
      public static final int  AJP14_BAD_KEY_ERR				 = 0xFFFFFFFF;
      public static final int  AJP14_ENGINE_DOWN_ERR           = 0xFFFFFFFE;
      public static final int  AJP14_RETRY_LATER_ERR           = 0xFFFFFFFD;
      public static final int  AJP14_SHUT_AUTHOR_FAILED_ERR    = 0xFFFFFFFC;
      
      // Some status codes
      public static final byte AJP14_CONTEXT_DOWN       		 = 0x01;
      public static final byte AJP14_CONTEXT_UP         		 = 0x02;
      public static final byte AJP14_CONTEXT_OK         		 = 0x03;
      
      // AJP14 new header
      public static final byte SC_A_SSL_KEY_SIZE  = 11;
  
      // ============ Instance Properties ====================
  
      // AJP14 
      boolean logged = false;
      int	    webserverNegociation	= 0;
      String  webserverName;
      String  seed="seed";// will use random
      String  password;
      String  containerSignature="Ajp14-based container";
  
      public Ajp14() 
      {
          super();
  	setSeed("myveryrandomentropy");
  	setPassword("myverysecretkey");
      }
  
      public void setContainerSignature( String s ) {
  	containerSignature=s;
      }
      
      public void initBuf()
      {	
  	outBuf = new Ajp14Packet( MAX_PACKET_SIZE );
  	inBuf  = new Ajp14Packet( MAX_PACKET_SIZE );
  	hBuf   = new Ajp14Packet( MAX_PACKET_SIZE );
      }
  
      // -------------------- Parameters --------------------
      
      /**
       * Set the original entropy seed
       */
      public void setSeed(String pseed) 
      {
  	String[] credentials = new String[1];
  	credentials[0] = pseed;
  	seed = digest(credentials, "md5");
      }
  
      /**
       * Get the original entropy seed
       */
      public String getSeed()
      {
  	return seed;
      }
  
      /**
       * Set the secret password
       */
      public void setPassword(String ppwd) 
      {
  	password = ppwd;
      }
      
      /**
       * Get the secret password
       */
      public String getPassword()
      {
  	return password;
      }
  
      // -------------------- Main dispatch --------------------
      
      /**
       * Read a new packet from the web server and decode it.  If it's a
       * forwarded request, store its properties in the passed-in Request
       * object.
       *
       * @param req An empty (newly-recycled) request object.
       * 
       * @return 200 in case of a successful read of a forwarded request, 500
       * if there were errors in the reading of the request, and -2 if the
       * server is asking the container to shut itself down.  
       */
      public int receiveNextRequest(AjpRequest req) throws IOException 
      {
  	// XXX The return values are awful.
  	int err = receive(hBuf);
  	if(err < 0) {
  	    if(debug >0 ) log( "Error receiving message ");
  	    return 500;
  	}
  	
  	int type = (int)hBuf.getByte();
  	if( debug > 0 ) log( "Received " + type + " " + MSG_NAME[type]);
  	
  	switch(type) {
  	    
  	case JK_AJP13_FORWARD_REQUEST:
  		if (logged)
  	    	return decodeRequest(req, hBuf);
  	    else {
  			log("can't handle forward request until logged");
  			return 200;
  		}
  
  	case JK_AJP13_SHUTDOWN:
  		if (logged)
  	    	return -2;
  		else {
  			log("can't handle AJP13 shutdown command until logged");
  			return 200;
  		}
  
  	case JK_AJP14_LOGINIT_CMD :
  		if (! logged)
  			return handleLogInit(hBuf);
  		else {
  			log("shouldn't handle logint command when logged");
  			return 200;
  		}
  
  	case JK_AJP14_LOGCOMP_CMD :
  		if (! logged)
  			return handleLogComp(hBuf);
  		else {
  			log("shouldn't handle logcomp command when logged");
  			return 200;
  		}
  
  	case JK_AJP14_CONTEXT_QRY_CMD :
  		if (logged)
  			return handleContextQuery(hBuf);
  		else {
  			log("can't handle contextquery command until logged");
  			return 200;
  		}
  
  	case JK_AJP14_STATUS_CMD :
  		if (logged)
  			return handleStatus(hBuf);
  		else {
  			log("can't handle status command until logged");
  			return 200;
  		}
  
  	case JK_AJP14_SHUTDOWN_CMD :
  		if (logged)
  			return handleShutdown(hBuf);
  		else {
  			log("can't handle AJP14 shutdown command until logged");
  			return 200;
  		}
  
  	case JK_AJP14_CONTEXT_STATE_CMD :
  		if (logged)
  			return handleContextState(hBuf);
  		else {
  			log("can't handle contextstate command until logged");
  			return 200;
  		}
  
  	case JK_AJP14_UNKNOW_PACKET_CMD :
  		if (logged)
  			return handleUnknowPacket(hBuf);
  		else {
  			log("can't handle unknown packet command until logged");
  			return 200;
  		}
  	}
  	log("unknown command " + type + " received");
  	return 200; // XXX This is actually an error condition 
      }
  
      //-------------------- Implementation for various protocol commands --------------------
      
      /**
       * Handle the Initial Login Message from Web-Server
       *
       * Get the requested Negociation Flags
       * Get also the Web-Server Name
       * 
  	 * Send Login Seed (MD5 of seed)
  	 */
      private int handleLogInit( Ajp13Packet msg ) throws IOException
      {
  	webserverNegociation = msg.getLongInt();
  	webserverName 		 = msg.getString();
  	log("in handleLogInit with nego " +
  	    decodeNegociation(webserverNegociation) + " from webserver " + webserverName);
  	
  	outBuf.reset();
          outBuf.appendByte(JK_AJP14_LOGSEED_CMD);
  	String[] credentials = new String[1];
  	credentials[0] = getSeed();
          outBuf.appendXBytes(getSeed().getBytes(), 0, AJP14_ENTROPY_SEED_LEN);
  	log("in handleLogInit: sent entropy " + getSeed());
          outBuf.end();
          send(outBuf);
  	return 304;
      }
      
      /**
       * Handle the Second Phase of Login (accreditation)
       * 
       * Get the MD5 digest of entropy + secret password
       * If the authentification is valid send back LogOk
       * If the authentification failed send back LogNok
       */
      private int handleLogComp( Ajp13Packet msg ) throws IOException
      {
  	// log("in handleLogComp :");
  	
  	byte [] rdigest = new byte[AJP14_ENTROPY_SEED_LEN];
  	
  	if (msg.getXBytes(rdigest, AJP14_ENTROPY_SEED_LEN) < 0)
  	    return 200;
  	
  	String[] credentials = new String[2];
  	credentials[0] = getSeed();
  	credentials[1] = getPassword();
  	String computed = digest(credentials, "md5");
  	String received = new String(rdigest);
  	
  	// XXX temp workaround, to test the rest of the connector.
  	
  	if ( ! computed.equalsIgnoreCase(received)) {
  	    log("in handleLogComp : authentification failure received=" +
  		received + " awaited=" + computed);
  	}
  	
  	if (false ) { // ! computed.equalsIgnoreCase(received)) {
  	    log("in handleLogComp : authentification failure received=" +
  		received + " awaited=" + computed);
  	    
  	    // we should have here a security mecanism which could maintain
  	    // a list of remote IP which failed too many times
  	    // so we could reject them quickly at next connect
  	    outBuf.reset();
  	    outBuf.appendByte(JK_AJP14_LOGNOK_CMD);
  	    outBuf.appendLongInt(AJP14_BAD_KEY_ERR);
  	    outBuf.end();
  	    send(outBuf);
  	    return 200;
  	} else {
  	    logged = true;		// logged we can go process requests
  	    outBuf.reset();
  	    outBuf.appendByte(JK_AJP14_LOGOK_CMD);
  	    outBuf.appendLongInt(getProtocolFlags(webserverNegociation));
  	    outBuf.appendString( containerSignature );
  	    outBuf.end(); 
  	    send(outBuf);
  	}
  	
  	return (304);
      }
  
      private int handleContextQuery( Ajp13Packet msg ) throws IOException
      {
  	log("in handleContextQuery :");
  	return (304);
      }
      
      private int handleStatus( Ajp13Packet msg ) throws IOException
      {
  	log("in handleStatus :");
  	return (304);
      }
  
      private int handleShutdown( Ajp13Packet msg ) throws IOException
      {
  	log("in handleShutdown :");
  	return (304);
      }
      
      private int handleContextState( Ajp13Packet msg ) throws IOException
      {
  	log("in handleContextState :");
  	return (304);
      }
      
      private int handleUnknowPacket( Ajp13Packet msg ) throws IOException
      {
  	log("in handleUnknowPacket :");
  	return (304);
      }
  
      int decodeMoreHeaders(AjpRequest req, byte attribute, Ajp13Packet msg)
      {
  	if (attribute == SC_A_SSL_KEY_SIZE) {
  	    req.setAttribute("javax.servlet.request.key_size", Integer.toString(msg.getInt()));
  	    return 200;
  	}
  	return 500; // Error
      }
  
      // ========= Internal Packet-Handling Methods =================
  
      /**
       * Read in a packet from the web server and store it in the passed-in
       * <CODE>Ajp13Packet</CODE> object.
       *
       * @param msg The object into which to store the incoming packet -- any
       * current contents will be overwritten.
       *
       * @return The number of bytes read on a successful read or -1 if there 
       * was an error.
       **/
      public int receive(Ajp13Packet msg) throws IOException {
  	// XXX If the length in the packet header doesn't agree with the
  	// actual number of bytes read, it should probably return an error
  	// value.  Also, callers of this method never use the length
  	// returned -- should probably return true/false instead.
  	byte b[] = msg.getBuff();
  
  	if( debug > 5 ) log( "Reading head " );
  	int rd = in.read( b, 0, H_SIZE );
  	if(rd <= 0) {
  	    if( debug > 5 ) log( "Error reading " + rd );
  	    return rd; 
  	}
  	if( debug > 5 ) log( "Read " + rd );
  	
  	int len = msg.checkIn();
  	
  	// XXX check if enough space - it's assert()-ed !!!
  
   	int total_read = 0;
    	while (total_read < len) {
  	    rd = in.read( b, 4 + total_read, len - total_read);
              if (rd == -1) {
   		log( "Incomplete read, deal with it " + len + " " + rd);
                  break;
  		// XXX log
  		// XXX Return an error code?
  	    }
       	    total_read += rd;
  	}
  	return total_read;
      }
  
      /**
       * Send a packet to the web server.  Works for any type of message.
       *
       * @param msg A packet with accumulated data to send to the server --
       * this method will write out the length in the header.  
       */
      protected void send( Ajp13Packet msg ) throws IOException {
  	msg.end(); // Write the packet header
  	byte b[] = msg.getBuff();
  	int len  = msg.getLen();
  	out.write( b, 0, len );
      }
  	
      /**
       * Close the socket connection to the web server.  In general, sockets
       * are maintained across many requests, so this will not be called
       * after finish().  
       *
       * @see Ajp14Interceptor#processConnection
       */
      public void close() throws IOException {
  	if(null != out) {        
  	    out.close();
  	}
  	if(null !=in) {
  	    in.close();
  	}
  
  	logged = false;	// no more logged now 
      }
  
      // -------------------- Utils --------------------
      /**
       * Compute the Protocol Negociation Flags
       * 
       * Depending the protocol fatures implemented on servet-engine,
       * we'll drop requested features which could be asked by web-server
       *
       * Hopefully this functions could be overrided by decendants (AJP15/AJP16...)
       */
      private int getProtocolFlags(int wanted)
      {
  	wanted &= ~(AJP14_CONTEXT_UPDATE_NEG	| // no real-time context update yet 
  		    AJP14_GZIP_STREAM_NEG   	| // no gzip compression yet
  		    AJP14_DES56_STREAM_NEG  	| // no DES56 cyphering yet
  		    AJP14_SSL_VSERVER_NEG	| // no Extended info on server SSL vars yet
  		    AJP14_SSL_VCLIENT_NEG	| // no Extended info on client SSL vars yet
  		    AJP14_SSL_VCRYPTO_NEG	| // no Extended info on crypto SSL vars yet
  		    AJP14_SSL_VMISC_NEG		| // no Extended info on misc SSL vars yet
  		    AJP14_PROTO_SUPPORT_AJPXX_NEG); // Reset AJP protocol mask
  	
  	return (wanted | AJP14_PROTO_SUPPORT_AJP14_NEG);	// Only strict AJP14 supported
      }
  
      /**
       * Compute a digest (MD5 in AJP14) for an array of String
       */
      public final String digest(String[] credentials, String algorithm) {
          try {
              // Obtain a new message digest with MD5 encryption
              MessageDigest md = (MessageDigest)MessageDigest.getInstance(algorithm).clone();
              // encode the credentials items
  	    for (int i = 0; i < credentials.length; i++) {
  		if( debug > 0 ) log("Credentials : " + i + " " + credentials[i]);
  		if( credentials[i] != null  )
  		    md.update(credentials[i].getBytes());
  	    }
              // obtain the byte array from the digest
              byte[] dig = md.digest();
  	    return HexUtils.convert(dig);
          } catch (Exception ex) {
              ex.printStackTrace();
              return null;
          }
      }
  
      // -------------------- Debugging --------------------
      // Very usefull for develoment
  
      /**
       * Display Negociation field in human form 
       */
      private String decodeNegociation(int nego)
      {
  	StringBuffer buf = new StringBuffer(128);
  	
  	if ((nego & AJP14_CONTEXT_INFO_NEG) != 0) 
  	    buf.append(" CONTEXT-INFO");
  	
  	if ((nego & AJP14_CONTEXT_UPDATE_NEG) != 0)
  	    buf.append(" CONTEXT-UPDATE");
  	
  	if ((nego & AJP14_GZIP_STREAM_NEG) != 0)
  	    buf.append(" GZIP-STREAM");
  	
  	if ((nego & AJP14_DES56_STREAM_NEG) != 0)
  	    buf.append(" DES56-STREAM");
  	
  	if ((nego & AJP14_SSL_VSERVER_NEG) != 0)
  	    buf.append(" SSL-VSERVER");
  	
  	if ((nego & AJP14_SSL_VCLIENT_NEG) != 0)
  	    buf.append(" SSL-VCLIENT");
  	
  	if ((nego & AJP14_SSL_VCRYPTO_NEG) != 0)
  	    buf.append(" SSL-VCRYPTO");
  	
  	if ((nego & AJP14_SSL_VMISC_NEG) != 0)
  	    buf.append(" SSL-VMISC");
  	
  	if ((nego & AJP14_PROTO_SUPPORT_AJP14_NEG) != 0)
  	    buf.append(" AJP14");
  	
  	if ((nego & AJP14_PROTO_SUPPORT_AJP15_NEG) != 0)
  	    buf.append(" AJP15");
  	
  	if ((nego & AJP14_PROTO_SUPPORT_AJP16_NEG) != 0)
  	    buf.append(" AJP16");
  	
  	return (buf.toString());
      }
      
      
      // Debugging names
      public final String MSG_NAME[]={
  	null, // 0
  	null, // 1
  	"JK_AJP13_FORWARD_REQUEST", // 2
  	"JK_AJP13_SEND_BODY_CHUNK", // 3
  	"JK_AJP13_SEND_HEADERS", // 4
  	"JK_AJP13_END_RESPONSE", // 5
  	"JK_AJP13_GET_BODY_CHUNK", // 6
  	"JK_AJP13_SHUTDOWN", // 7
  	null, null, null, null, // 8, 9, A, B
  	null, null, null, null,
  	"JK_AJP14_LOGINIT_CMD", // 0x10
  	"JK_AJP14_LOGSEED_CMD", // 0x11
  	"JK_AJP14_LOGCOMP_CMD", // 0x12
  	"JK_AJP14_LOGOK_CMD", // 0x13
  	"JK_AJP14_LOGNOK_CMD", // 0x14
  	"JK_AJP14_CONTEXT_QRY_CMD", // 0x15
  	"JK_AJP14_CONTEXT_INFO_CMD", // 0x16
  	"JK_AJP14_CONTEXT_UPDATE_CMD", // 0x17
  	"JK_AJP14_STATUS_CMD", // 0x18
  	"JK_AJP14_SHUTDOWN_CMD", // 0x19
  	"JK_AJP14_SHUTOK_CMD", // 0x1A
  	"JK_AJP14_SHUTNOK_CMD", // 0x1B
  	"JK_AJP14_CONTEXT_STATE_CMD ", // 0x1C
  	"JK_AJP14_CONTEXT_STATE_REP_CMD ", // 0x1D
  	"JK_AJP14_UNKNOW_PACKET_CMD " // 0x1E,
      };
  
      
      private static int debug=10;
      void log(String s) {
  	System.out.println("Ajp14: " + s );
      }
   }
  
  
  
  1.1                  jakarta-tomcat-connectors/jk/java/org/apache/ajp/Ajp14Packet.java
  
  Index: Ajp14Packet.java
  ===================================================================
  /*
   * ====================================================================
   *
   * The Apache Software License, Version 1.1
   *
   * Copyright (c) 1999 The Apache Software Foundation.  All rights
   * reserved.
   *
   * Redistribution and use in source and binary forms, with or without
   * modification, are permitted provided that the following conditions
   * are met:
   *
   * 1. Redistributions of source code must retain the above copyright
   *    notice, this list of conditions and the following disclaimer.
   *
   * 2. Redistributions in binary form must reproduce the above copyright
   *    notice, this list of conditions and the following disclaimer in
   *    the documentation and/or other materials provided with the
   *    distribution.
   *
   * 3. The end-user documentation included with the redistribution, if
   *    any, must include the following acknowlegement:
   *       "This product includes software developed by the
   *        Apache Software Foundation (http://www.apache.org/)."
   *    Alternately, this acknowlegement may appear in the software itself,
   *    if and wherever such third-party acknowlegements normally appear.
   *
   * 4. The names "The Jakarta Project", "Tomcat", and "Apache Software
   *    Foundation" must not be used to endorse or promote products derived
   *    from this software without prior written permission. For written
   *    permission, please contact apache@apache.org.
   *
   * 5. Products derived from this software may not be called "Apache"
   *    nor may "Apache" appear in their names without prior written
   *    permission of the Apache Group.
   *
   * THIS SOFTWARE IS PROVIDED ``AS IS'' AND ANY EXPRESSED OR IMPLIED
   * WARRANTIES, INCLUDING, BUT NOT LIMITED TO, THE IMPLIED WARRANTIES
   * OF MERCHANTABILITY AND FITNESS FOR A PARTICULAR PURPOSE ARE
   * DISCLAIMED.  IN NO EVENT SHALL THE APACHE SOFTWARE FOUNDATION OR
   * ITS CONTRIBUTORS BE LIABLE FOR ANY DIRECT, INDIRECT, INCIDENTAL,
   * SPECIAL, EXEMPLARY, OR CONSEQUENTIAL DAMAGES (INCLUDING, BUT NOT
   * LIMITED TO, PROCUREMENT OF SUBSTITUTE GOODS OR SERVICES; LOSS OF
   * USE, DATA, OR PROFITS; OR BUSINESS INTERRUPTION) HOWEVER CAUSED AND
   * ON ANY THEORY OF LIABILITY, WHETHER IN CONTRACT, STRICT LIABILITY,
   * OR TORT (INCLUDING NEGLIGENCE OR OTHERWISE) ARISING IN ANY WAY OUT
   * OF THE USE OF THIS SOFTWARE, EVEN IF ADVISED OF THE POSSIBILITY OF
   * SUCH DAMAGE.
   * ====================================================================
   *
   * This software consists of voluntary contributions made by many
   * individuals on behalf of the Apache Software Foundation.  For more
   * information on the Apache Software Foundation, please see
   * <http://www.apache.org/>.
   *
   * [Additional notices, if required by prior licensing conditions]
   *
   */
  
  package org.apache.ajp;
  
  import java.io.IOException;
  import java.io.UnsupportedEncodingException;
  import java.io.InputStream;
  import java.io.OutputStream;
  import java.net.Socket;
  import java.util.Enumeration;
  import java.security.*;
  
  import org.apache.tomcat.util.http.MimeHeaders;
  import org.apache.tomcat.util.buf.MessageBytes;
  import org.apache.tomcat.util.http.HttpMessages;
  import org.apache.tomcat.util.buf.HexUtils;
  
  
  /**
   * A single packet for communication between the web server and the
   * container.  Designed to be reused many times with no creation of
   * garbage.  Understands the format of data types for these packets.
   * Can be used (somewhat confusingly) for both incoming and outgoing
   * packets.  
   *
   * @see Ajp14/Ajp13Packet 
   *
   * @author Henri Gomez [hgomez@slib.fr]
   * @author Dan Milstein [danmil@shore.net]
   * @author Keith Wannamaker [Keith@Wannamaker.org]
   */
  
  public class Ajp14Packet extends Ajp13Packet {
  
  	/**
  	 * Create a new packet with an internal buffer of given size.
  	 */
  	public Ajp14Packet( int size ) {
  		super(size);
  	}
  
  	public Ajp14Packet( byte b[] ) {
  		super(b);
  	}
  
  // 	public Ajp14Packet( OutputBuffer ob ) {
  // 		super(ob);
  // 	}
  	
  	/** 
  	 * Parse the packet header for a packet sent from the web server to
  	 * the container.  Set the read position to immediately after
  	 * the header.
  	 *
  	 * @return The length of the packet payload, as encoded in the
  	 * header, or -1 if the packet doesn't have a valid header.  
  	 */
  	public int checkIn() {
  	    pos = 0;
  	    int mark = getInt();
  	    len      = getInt();
  	    
  	    if( mark != 0x1235 ) {
  		// XXX Logging
  		System.out.println("BAD packet " + mark);
  		dump( "In: " );
  		return -1;
  	    }
  	    return len;
  	}
  	
  	/**
  	 * Prepare this packet for accumulating a message from the container to
  	 * the web server.  Set the write position to just after the header
  	 * (but leave the length unwritten, because it is as yet unknown).  
  	 */
  	public void reset() {
  	    len = 4;
  	    pos = 4;
  	    buff[0] = (byte)0x12;
  	    buff[1] = (byte)0x35;
  	}
  }