Return-Path: X-Original-To: apmail-hbase-commits-archive@www.apache.org Delivered-To: apmail-hbase-commits-archive@www.apache.org Received: from mail.apache.org (hermes.apache.org [140.211.11.3]) by minotaur.apache.org (Postfix) with SMTP id 3DFC618A2E for ; Fri, 18 Dec 2015 16:42:45 +0000 (UTC) Received: (qmail 73584 invoked by uid 500); 18 Dec 2015 16:42:38 -0000 Delivered-To: apmail-hbase-commits-archive@hbase.apache.org Received: (qmail 73507 invoked by uid 500); 18 Dec 2015 16:42:38 -0000 Mailing-List: contact commits-help@hbase.apache.org; run by ezmlm Precedence: bulk List-Help: List-Unsubscribe: List-Post: List-Id: Reply-To: dev@hbase.apache.org Delivered-To: mailing list commits@hbase.apache.org Received: (qmail 70602 invoked by uid 99); 18 Dec 2015 16:42:35 -0000 Received: from git1-us-west.apache.org (HELO git1-us-west.apache.org) (140.211.11.23) by apache.org (qpsmtpd/0.29) with ESMTP; Fri, 18 Dec 2015 16:42:35 +0000 Received: by git1-us-west.apache.org (ASF Mail Server at git1-us-west.apache.org, from userid 33) id CD7CBE698A; Fri, 18 Dec 2015 16:42:35 +0000 (UTC) Content-Type: text/plain; charset="us-ascii" MIME-Version: 1.0 Content-Transfer-Encoding: 7bit From: misty@apache.org To: commits@hbase.apache.org Date: Fri, 18 Dec 2015 16:43:16 -0000 Message-Id: <29f7dfc5642c4f288e0550f2c0cdb18c@git.apache.org> In-Reply-To: <2b06700c24844cf38cd4158783c0e9ba@git.apache.org> References: <2b06700c24844cf38cd4158783c0e9ba@git.apache.org> X-Mailer: ASF-Git Admin Mailer Subject: [43/48] hbase-site git commit: Published site at 4bfeccb87a94cfe232ea8fc9a6f40ff5b8d3b1c5. http://git-wip-us.apache.org/repos/asf/hbase-site/blob/d917c66a/devapidocs/org/apache/hadoop/hbase/ipc/RpcServer.Connection.html ---------------------------------------------------------------------- diff --git a/devapidocs/org/apache/hadoop/hbase/ipc/RpcServer.Connection.html b/devapidocs/org/apache/hadoop/hbase/ipc/RpcServer.Connection.html index e527cc5..7bdd47e 100644 --- a/devapidocs/org/apache/hadoop/hbase/ipc/RpcServer.Connection.html +++ b/devapidocs/org/apache/hadoop/hbase/ipc/RpcServer.Connection.html @@ -99,7 +99,7 @@

-
public class RpcServer.Connection
+
public class RpcServer.Connection
 extends Object
Reads calls from a connection and queues them for handling.
@@ -454,7 +454,7 @@ extends
  • connectionPreambleRead

    -
    private boolean connectionPreambleRead
    +
    private boolean connectionPreambleRead
  • @@ -463,7 +463,7 @@ extends
  • connectionHeaderRead

    -
    private boolean connectionHeaderRead
    +
    private boolean connectionHeaderRead
  • @@ -472,7 +472,7 @@ extends
  • channel

    -
    protected SocketChannel channel
    +
    protected SocketChannel channel
  • @@ -481,7 +481,7 @@ extends
  • data

    -
    private ByteBuffer data
    +
    private ByteBuffer data
  • @@ -490,7 +490,7 @@ extends
  • dataLengthBuffer

    -
    private ByteBuffer dataLengthBuffer
    +
    private ByteBuffer dataLengthBuffer
  • @@ -499,7 +499,7 @@ extends
  • responseQueue

    -
    protected final ConcurrentLinkedDeque<RpcServer.Call> responseQueue
    +
    protected final ConcurrentLinkedDeque<RpcServer.Call> responseQueue
  • @@ -508,7 +508,7 @@ extends
  • responseWriteLock

    -
    private final Lock responseWriteLock
    +
    private final Lock responseWriteLock
  • @@ -517,7 +517,7 @@ extends
  • rpcCount

    -
    private Counter rpcCount
    +
    private Counter rpcCount
  • @@ -526,7 +526,7 @@ extends
  • lastContact

    -
    private long lastContact
    +
    private long lastContact
  • @@ -535,7 +535,7 @@ extends
  • addr

    -
    private InetAddress addr
    +
    private InetAddress addr
  • @@ -544,7 +544,7 @@ extends
  • socket

    -
    protected Socket socket
    +
    protected Socket socket
  • @@ -553,7 +553,7 @@ extends
  • hostAddress

    -
    protected String hostAddress
    +
    protected String hostAddress
  • @@ -562,7 +562,7 @@ extends
  • remotePort

    -
    protected int remotePort
    +
    protected int remotePort
  • @@ -571,7 +571,7 @@ extends
  • connectionHeader

    -
    org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader connectionHeader
    +
    org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader connectionHeader
  • @@ -580,7 +580,7 @@ extends
  • codec

    -
    private Codec codec
    +
    private Codec codec
    Codec the client asked use.
  • @@ -590,7 +590,7 @@ extends
  • compressionCodec

    -
    private org.apache.hadoop.io.compress.CompressionCodec compressionCodec
    +
    private org.apache.hadoop.io.compress.CompressionCodec compressionCodec
    Compression codec the client asked us use.
  • @@ -600,7 +600,7 @@ extends
  • service

    -
    com.google.protobuf.BlockingService service
    +
    com.google.protobuf.BlockingService service
  • @@ -609,7 +609,7 @@ extends
  • authMethod

    -
    private AuthMethod authMethod
    +
    private AuthMethod authMethod
  • @@ -618,7 +618,7 @@ extends
  • saslContextEstablished

    -
    private boolean saslContextEstablished
    +
    private boolean saslContextEstablished
  • @@ -627,7 +627,7 @@ extends
  • skipInitialSaslHandshake

    -
    private boolean skipInitialSaslHandshake
    +
    private boolean skipInitialSaslHandshake
  • @@ -636,7 +636,7 @@ extends
  • unwrappedData

    -
    private ByteBuffer unwrappedData
    +
    private ByteBuffer unwrappedData
  • @@ -645,7 +645,7 @@ extends
  • unwrappedDataLengthBuffer

    -
    private ByteBuffer unwrappedDataLengthBuffer
    +
    private ByteBuffer unwrappedDataLengthBuffer
  • @@ -654,7 +654,7 @@ extends
  • useSasl

    -
    boolean useSasl
    +
    boolean useSasl
  • @@ -663,7 +663,7 @@ extends
  • saslServer

    -
    SaslServer saslServer
    +
    SaslServer saslServer
  • @@ -672,7 +672,7 @@ extends
  • useWrap

    -
    private boolean useWrap
    +
    private boolean useWrap
  • @@ -681,7 +681,7 @@ extends
  • AUTHORIZATION_FAILED_CALLID

    -
    private static final int AUTHORIZATION_FAILED_CALLID
    +
    private static final int AUTHORIZATION_FAILED_CALLID
    See Also:
    Constant Field Values
  • @@ -691,7 +691,7 @@ extends
  • authFailedCall

    -
    private final RpcServer.Call authFailedCall
    +
    private final RpcServer.Call authFailedCall
  • @@ -700,7 +700,7 @@ extends
  • authFailedResponse

    -
    private ByteArrayOutputStream authFailedResponse
    +
    private ByteArrayOutputStream authFailedResponse
  • @@ -709,7 +709,7 @@ extends
  • SASL_CALLID

    -
    private static final int SASL_CALLID
    +
    private static final int SASL_CALLID
    See Also:
    Constant Field Values
  • @@ -719,7 +719,7 @@ extends
  • saslCall

    -
    private final RpcServer.Call saslCall
    +
    private final RpcServer.Call saslCall
  • @@ -728,7 +728,7 @@ extends
  • authenticatedWithFallback

    -
    private boolean authenticatedWithFallback
    +
    private boolean authenticatedWithFallback
  • @@ -737,7 +737,7 @@ extends
  • retryImmediatelySupported

    -
    private boolean retryImmediatelySupported
    +
    private boolean retryImmediatelySupported
  • @@ -746,7 +746,7 @@ extends
  • attemptingUser

    -
    public org.apache.hadoop.security.UserGroupInformation attemptingUser
    +
    public org.apache.hadoop.security.UserGroupInformation attemptingUser
  • @@ -755,7 +755,7 @@ extends
  • user

    -
    protected User user
    +
    protected User user
  • @@ -764,7 +764,7 @@ extends
  • ugi

    -
    protected org.apache.hadoop.security.UserGroupInformation ugi
    +
    protected org.apache.hadoop.security.UserGroupInformation ugi
  • @@ -781,7 +781,7 @@ extends
  • RpcServer.Connection

    -
    public RpcServer.Connection(SocketChannel channel,
    +
    public RpcServer.Connection(SocketChannel channel,
                         long lastContact)
  • @@ -799,7 +799,7 @@ extends
  • toString

    -
    public String toString()
    +
    public String toString()
    Overrides:
    toString in class Object
    @@ -812,7 +812,7 @@ extends
  • getHostAddress

    -
    public String getHostAddress()
    +
    public String getHostAddress()
  • @@ -821,7 +821,7 @@ extends
  • getHostInetAddress

    -
    public InetAddress getHostInetAddress()
    +
    public InetAddress getHostInetAddress()
  • @@ -830,7 +830,7 @@ extends
  • getRemotePort

    -
    public int getRemotePort()
    +
    public int getRemotePort()
  • @@ -839,7 +839,7 @@ extends
  • setLastContact

    -
    public void setLastContact(long lastContact)
    +
    public void setLastContact(long lastContact)
  • @@ -848,7 +848,7 @@ extends
  • getVersionInfo

    -
    public org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.VersionInfo getVersionInfo()
    +
    public org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.VersionInfo getVersionInfo()
  • @@ -857,7 +857,7 @@ extends
  • isIdle

    -
    private boolean isIdle()
    +
    private boolean isIdle()
  • @@ -866,7 +866,7 @@ extends
  • decRpcCount

    -
    protected void decRpcCount()
    +
    protected void decRpcCount()
  • @@ -875,7 +875,7 @@ extends
  • incRpcCount

    -
    protected void incRpcCount()
    +
    protected void incRpcCount()
  • @@ -884,7 +884,7 @@ extends
  • timedOut

    -
    protected boolean timedOut(long currentTime)
    +
    protected boolean timedOut(long currentTime)
  • @@ -893,7 +893,7 @@ extends
  • getAuthorizedUgi

    -
    private org.apache.hadoop.security.UserGroupInformation getAuthorizedUgi(String authorizedId)
    +
    private org.apache.hadoop.security.UserGroupInformation getAuthorizedUgi(String authorizedId)
                                                                       throws IOException
    Throws:
    IOException
    @@ -905,7 +905,7 @@ extends
  • saslReadAndProcess

    -
    private void saslReadAndProcess(byte[] saslToken)
    +
    private void saslReadAndProcess(byte[] saslToken)
                              throws IOException,
                                     InterruptedException
    Throws:
    @@ -919,7 +919,7 @@ extends
  • doRawSaslReply

    -
    private void doRawSaslReply(SaslStatus status,
    +
    private void doRawSaslReply(SaslStatus status,
                       org.apache.hadoop.io.Writable rv,
                       String errorClass,
                       String error)
    @@ -935,7 +935,7 @@ extends 
     
  • disposeSasl

    -
    private void disposeSasl()
    +
    private void disposeSasl()
  • @@ -944,7 +944,7 @@ extends
  • readPreamble

    -
    private int readPreamble()
    +
    private int readPreamble()
                       throws IOException
    Throws:
    IOException
    @@ -956,7 +956,7 @@ extends
  • read4Bytes

    -
    private int read4Bytes()
    +
    private int read4Bytes()
                     throws IOException
    Throws:
    IOException
    @@ -968,7 +968,7 @@ extends
  • readAndProcess

    -
    public int readAndProcess()
    +
    public int readAndProcess()
                        throws IOException,
                               InterruptedException
    Read off the wire. If there is not enough data to read, update the connection state with @@ -985,7 +985,7 @@ extends
  • process

    -
    private void process()
    +
    private void process()
                   throws IOException,
                          InterruptedException
    Process the data buffer and clean the connection state for the next call.
    @@ -1000,7 +1000,7 @@ extends
  • getFatalConnectionString

    -
    private String getFatalConnectionString(int version,
    +
    private String getFatalConnectionString(int version,
                                   byte authByte)
  • @@ -1010,7 +1010,7 @@ extends
  • doBadPreambleHandling

    -
    private int doBadPreambleHandling(String msg)
    +
    private int doBadPreambleHandling(String msg)
                                throws IOException
    Throws:
    IOException
    @@ -1022,7 +1022,7 @@ extends
  • doBadPreambleHandling

    -
    private int doBadPreambleHandling(String msg,
    +
    private int doBadPreambleHandling(String msg,
                             Exception e)
                                throws IOException
    Throws:
    @@ -1035,7 +1035,7 @@ extends
  • processConnectionHeader

    -
    private void processConnectionHeader(byte[] buf)
    +
    private void processConnectionHeader(byte[] buf)
                                   throws IOException
    Throws:
    IOException
    @@ -1047,7 +1047,7 @@ extends
  • setupCellBlockCodecs

    -
    private void setupCellBlockCodecs(org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader header)
    +
    private void setupCellBlockCodecs(org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader header)
                                throws FatalConnectionException
    Set up cell block codecs
    Throws:
    @@ -1060,7 +1060,7 @@ extends
  • processUnwrappedData

    -
    private void processUnwrappedData(byte[] inBuf)
    +
    private void processUnwrappedData(byte[] inBuf)
                                throws IOException,
                                       InterruptedException
    Throws:
    @@ -1074,7 +1074,7 @@ extends
  • processOneRpc

    -
    private void processOneRpc(byte[] buf)
    +
    private void processOneRpc(byte[] buf)
                         throws IOException,
                                InterruptedException
    Throws:
    @@ -1088,7 +1088,7 @@ extends
  • processRequest

    -
    protected void processRequest(byte[] buf)
    +
    protected void processRequest(byte[] buf)
                            throws IOException,
                                   InterruptedException
    Parameters:
    buf - Has the request header and the request param and optionally encoded data buffer @@ -1104,7 +1104,7 @@ extends
  • authorizeConnection

    -
    private boolean authorizeConnection()
    +
    private boolean authorizeConnection()
                                  throws IOException
    Throws:
    IOException
    @@ -1116,7 +1116,7 @@ extends
  • close

    -
    protected void close()
    +
    protected void close()
  • @@ -1125,7 +1125,7 @@ extends
  • createUser

    -
    private org.apache.hadoop.security.UserGroupInformation createUser(org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader head)
    +
    private org.apache.hadoop.security.UserGroupInformation createUser(org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader head)
  • http://git-wip-us.apache.org/repos/asf/hbase-site/blob/d917c66a/devapidocs/org/apache/hadoop/hbase/ipc/RpcServer.Listener.Reader.html ---------------------------------------------------------------------- diff --git a/devapidocs/org/apache/hadoop/hbase/ipc/RpcServer.Listener.Reader.html b/devapidocs/org/apache/hadoop/hbase/ipc/RpcServer.Listener.Reader.html index e01f0e6..2a3ee2a 100644 --- a/devapidocs/org/apache/hadoop/hbase/ipc/RpcServer.Listener.Reader.html +++ b/devapidocs/org/apache/hadoop/hbase/ipc/RpcServer.Listener.Reader.html @@ -103,7 +103,7 @@


    -
    private class RpcServer.Listener.Reader
    +
    private class RpcServer.Listener.Reader
     extends Object
     implements Runnable
  • @@ -215,7 +215,7 @@ implements
  • adding

    -
    private volatile boolean adding
    +
    private volatile boolean adding
  • @@ -224,7 +224,7 @@ implements
  • readSelector

    -
    private final Selector readSelector
    +
    private final Selector readSelector
  • @@ -241,7 +241,7 @@ implements
  • RpcServer.Listener.Reader

    -
    RpcServer.Listener.Reader()
    +
    RpcServer.Listener.Reader()
                         throws IOException
    Throws:
    IOException
    @@ -261,7 +261,7 @@ implements
  • run

    -
    public void run()
    +
    public void run()
    Specified by:
    run in interface Runnable
    @@ -274,7 +274,7 @@ implements
  • doRunLoop

    -
    private void doRunLoop()
    +
    private void doRunLoop()
  • @@ -283,7 +283,7 @@ implements
  • startAdd

    -
    public void startAdd()
    +
    public void startAdd()
    This gets reader into the state that waits for the new channel to be registered with readSelector. If it was waiting in select() the thread will be woken up, otherwise whenever select() is called @@ -297,7 +297,7 @@ implements
  • registerChannel

    -
    public SelectionKey registerChannel(SocketChannel channel)
    +
    public SelectionKey registerChannel(SocketChannel channel)
                                  throws IOException
    Throws:
    IOException
    @@ -309,7 +309,7 @@ implements
  • finishAdd

    -
    public void finishAdd()
    +
    public void finishAdd()
  • http://git-wip-us.apache.org/repos/asf/hbase-site/blob/d917c66a/devapidocs/org/apache/hadoop/hbase/ipc/RpcServer.Listener.html ---------------------------------------------------------------------- diff --git a/devapidocs/org/apache/hadoop/hbase/ipc/RpcServer.Listener.html b/devapidocs/org/apache/hadoop/hbase/ipc/RpcServer.Listener.html index 7d1a45d..54cd479 100644 --- a/devapidocs/org/apache/hadoop/hbase/ipc/RpcServer.Listener.html +++ b/devapidocs/org/apache/hadoop/hbase/ipc/RpcServer.Listener.html @@ -108,7 +108,7 @@


    -
    private class RpcServer.Listener
    +
    private class RpcServer.Listener
     extends Thread
    Listens on the socket. Creates jobs for the handler threads
  • @@ -300,7 +300,7 @@ extends
  • acceptChannel

    -
    private ServerSocketChannel acceptChannel
    +
    private ServerSocketChannel acceptChannel
  • @@ -309,7 +309,7 @@ extends
  • selector

    -
    private Selector selector
    +
    private Selector selector
  • @@ -318,7 +318,7 @@ extends
  • readers

    -
    private RpcServer.Listener.Reader[] readers
    +
    private RpcServer.Listener.Reader[] readers
  • @@ -327,7 +327,7 @@ extends
  • currentReader

    -
    private int currentReader
    +
    private int currentReader
  • @@ -336,7 +336,7 @@ extends
  • rand

    -
    private Random rand
    +
    private Random rand
  • @@ -345,7 +345,7 @@ extends
  • lastCleanupRunTime

    -
    private long lastCleanupRunTime
    +
    private long lastCleanupRunTime
  • @@ -354,7 +354,7 @@ extends
  • cleanupInterval

    -
    private long cleanupInterval
    +
    private long cleanupInterval
  • @@ -363,7 +363,7 @@ extends
  • backlogLength

    -
    private int backlogLength
    +
    private int backlogLength
  • @@ -372,7 +372,7 @@ extends
  • readPool

    -
    private ExecutorService readPool
    +
    private ExecutorService readPool
  • @@ -389,7 +389,7 @@ extends
  • RpcServer.Listener

    -
    public RpcServer.Listener(String name)
    +
    public RpcServer.Listener(String name)
                        throws IOException
    Throws:
    IOException
    @@ -409,7 +409,7 @@ extends
  • cleanupConnections

    -
    private void cleanupConnections(boolean force)
    +
    private void cleanupConnections(boolean force)
    cleanup connections from connectionList. Choose a random range to scan and also have a limit on the number of the connections that will be cleanedup per run. The criteria for cleanup is the time @@ -424,7 +424,7 @@ extends
  • run

    -
    public void run()
    +
    public void run()
    Specified by:
    run in interface Runnable
    @@ -439,7 +439,7 @@ extends
  • closeCurrentConnection

    -
    private void closeCurrentConnection(SelectionKey key,
    +
    private void closeCurrentConnection(SelectionKey key,
                               Throwable e)
  • @@ -449,7 +449,7 @@ extends
  • getAddress

    -
    InetSocketAddress getAddress()
    +
    InetSocketAddress getAddress()
  • @@ -458,7 +458,7 @@ extends
  • doAccept

    -
    void doAccept(SelectionKey key)
    +
    void doAccept(SelectionKey key)
             throws IOException,
                    OutOfMemoryError
    Throws:
    @@ -472,7 +472,7 @@ extends
  • doRead

    -
    void doRead(SelectionKey key)
    +
    void doRead(SelectionKey key)
           throws InterruptedException
    Throws:
    InterruptedException
    @@ -484,7 +484,7 @@ extends
  • doStop

    -
    void doStop()
    +
    void doStop()
  • @@ -493,7 +493,7 @@ extends
  • getReader

    -
    RpcServer.Listener.Reader getReader()
    +
    RpcServer.Listener.Reader getReader()
  • http://git-wip-us.apache.org/repos/asf/hbase-site/blob/d917c66a/devapidocs/org/apache/hadoop/hbase/ipc/RpcServer.Responder.html ---------------------------------------------------------------------- diff --git a/devapidocs/org/apache/hadoop/hbase/ipc/RpcServer.Responder.html b/devapidocs/org/apache/hadoop/hbase/ipc/RpcServer.Responder.html index 8d1dab2..352e34d 100644 --- a/devapidocs/org/apache/hadoop/hbase/ipc/RpcServer.Responder.html +++ b/devapidocs/org/apache/hadoop/hbase/ipc/RpcServer.Responder.html @@ -108,7 +108,7 @@


    -
    protected class RpcServer.Responder
    +
    protected class RpcServer.Responder
     extends Thread
  • @@ -273,7 +273,7 @@ extends
  • writeSelector

    -
    private final Selector writeSelector
    +
    private final Selector writeSelector
  • @@ -282,7 +282,7 @@ extends
  • writingCons

    -
    private final Set<RpcServer.Connection> writingCons
    +
    private final Set<RpcServer.Connection> writingCons
  • @@ -299,7 +299,7 @@ extends
  • RpcServer.Responder

    -
    RpcServer.Responder()
    +
    RpcServer.Responder()
                   throws IOException
    Throws:
    IOException
    @@ -319,7 +319,7 @@ extends
  • run

    -
    public void run()
    +
    public void run()
    Specified by:
    run in interface Runnable
    @@ -334,7 +334,7 @@ extends
  • registerWrites

    -
    private void registerWrites()
    +
    private void registerWrites()
    Take the list of the connections that want to write, and register them in the selector.
  • @@ -345,7 +345,7 @@ extends
  • registerForWrite

    -
    public void registerForWrite(RpcServer.Connection c)
    +
    public void registerForWrite(RpcServer.Connection c)
    Add a connection to the list that want to write,
  • @@ -355,7 +355,7 @@ extends
  • doRunLoop

    -
    private void doRunLoop()
    +
    private void doRunLoop()
  • @@ -364,7 +364,7 @@ extends
  • purge

    -
    private long purge(long lastPurgeTime)
    +
    private long purge(long lastPurgeTime)
    If there were some calls that have not been sent out for a long time, we close the connection.
    Returns:
    the time of the purge.
    @@ -376,7 +376,7 @@ extends
  • doAsyncWrite

    -
    private void doAsyncWrite(SelectionKey key)
    +
    private void doAsyncWrite(SelectionKey key)
                        throws IOException
    Throws:
    IOException
    @@ -388,7 +388,7 @@ extends
  • processResponse

    -
    private boolean processResponse(RpcServer.Call call)
    +
    private boolean processResponse(RpcServer.Call call)
                              throws IOException
    Process the response for this call. You need to have the lock on RpcServer.Connection.responseWriteLock
    @@ -404,7 +404,7 @@ extends
  • processAllResponses

    -
    private boolean processAllResponses(RpcServer.Connection connection)
    +
    private boolean processAllResponses(RpcServer.Connection connection)
                                  throws IOException
    Process all the responses for this connection
    Returns:
    true if all the calls were processed or that someone else is doing it. @@ -420,7 +420,7 @@ extends
  • doRespond

    -
    void doRespond(RpcServer.Call call)
    +
    void doRespond(RpcServer.Call call)
              throws IOException
    Throws:
    IOException