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 6A78A18F14 for ; Thu, 21 Jan 2016 17:22:27 +0000 (UTC) Received: (qmail 11252 invoked by uid 500); 21 Jan 2016 17:22:21 -0000 Delivered-To: apmail-hbase-commits-archive@hbase.apache.org Received: (qmail 11177 invoked by uid 500); 21 Jan 2016 17:22:21 -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 10183 invoked by uid 99); 21 Jan 2016 17:22:21 -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; Thu, 21 Jan 2016 17:22:21 +0000 Received: by git1-us-west.apache.org (ASF Mail Server at git1-us-west.apache.org, from userid 33) id 22301DFF94; Thu, 21 Jan 2016 17:22:21 +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: Thu, 21 Jan 2016 17:22:39 -0000 Message-Id: In-Reply-To: <260fbf76833c437ea038951881d40890@git.apache.org> References: <260fbf76833c437ea038951881d40890@git.apache.org> X-Mailer: ASF-Git Admin Mailer Subject: [20/51] [partial] hbase-site git commit: Published site at 4bf6f8379d7f85413b914dddf607d016780d40ce. http://git-wip-us.apache.org/repos/asf/hbase-site/blob/75eda567/devapidocs/org/apache/hadoop/hbase/ipc/RpcClientImpl.Connection.html ---------------------------------------------------------------------- diff --git a/devapidocs/org/apache/hadoop/hbase/ipc/RpcClientImpl.Connection.html b/devapidocs/org/apache/hadoop/hbase/ipc/RpcClientImpl.Connection.html index ae0775b..a3cc241 100644 --- a/devapidocs/org/apache/hadoop/hbase/ipc/RpcClientImpl.Connection.html +++ b/devapidocs/org/apache/hadoop/hbase/ipc/RpcClientImpl.Connection.html @@ -301,14 +301,18 @@ extends disposeSasl()  +private void +doNotify()  + + InetSocketAddress getRemoteAddress()  - + private org.apache.hadoop.hbase.protobuf.generated.RPCProtos.UserInformation getUserInfo(org.apache.hadoop.security.UserGroupInformation ugi)  - + private void handleConnectionFailure(int curRetries, int maxRetries, @@ -320,7 +324,7 @@ extends + private void handleSaslConnectionFailure(int currRetries, int maxRetries, @@ -332,62 +336,62 @@ extends + private boolean isFatalConnectionException(org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse e)  - + protected boolean markClosed(IOException e)  - + protected void readResponse()  - + void run()  - + protected void setupConnection()  - + protected void setupIOstreams()  - + private boolean setupSaslConnection(InputStream in2, OutputStream out2)  - + private boolean shouldAuthenticateOverKrb()  - + protected void tracedWriteRequest(Call call, int priority, org.apache.htrace.Span span)  - + protected boolean waitForWork()  - + private void writeConnectionHeader()
Write the connection header.
- + private void writeConnectionHeaderPreamble(OutputStream outStream)
Write the RPC header: <MAGIC WORD -- 'HBas'> <ONEBYTE_VERSION> <ONEBYTE_AUTH_TYPE>
- + private void writeRequest(Call call, int priority, @@ -816,7 +820,7 @@ extends
  • writeConnectionHeader

    -
    private void writeConnectionHeader()
    +
    private void writeConnectionHeader()
                                 throws IOException
    Write the connection header.
    Throws:
    @@ -829,7 +833,7 @@ extends
  • close

    -
    protected void close()
    +
    protected void close()
    Close the connection.
  • @@ -839,7 +843,7 @@ extends
  • tracedWriteRequest

    -
    protected void tracedWriteRequest(Call call,
    +
    protected void tracedWriteRequest(Call call,
                           int priority,
                           org.apache.htrace.Span span)
                                throws IOException
    @@ -853,7 +857,7 @@ extends
  • writeRequest

    -
    private void writeRequest(Call call,
    +
    private void writeRequest(Call call,
                     int priority,
                     org.apache.htrace.Span span)
                        throws IOException
    @@ -864,13 +868,22 @@ extends IOException
    See Also:
    readResponse()
  • + + + +
      +
    • +

      doNotify

      +
      private void doNotify()
      +
    • +
    @@ -879,7 +892,7 @@ extends
  • isFatalConnectionException

    -
    private boolean isFatalConnectionException(org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse e)
    +
    private boolean isFatalConnectionException(org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse e)
    Returns:
    True if the exception is a fatal connection exception.
  • @@ -889,7 +902,7 @@ extends
  • createRemoteException

    -
    private org.apache.hadoop.ipc.RemoteException createRemoteException(org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse e)
    +
    private org.apache.hadoop.ipc.RemoteException createRemoteException(org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse e)
    Parameters:
    e - exception to be wrapped
    Returns:
    RemoteException made from passed e
  • @@ -900,7 +913,7 @@ extends
  • markClosed

    -
    protected boolean markClosed(IOException e)
    +
    protected boolean markClosed(IOException e)
  • @@ -909,7 +922,7 @@ extends
  • cleanupCalls

    -
    protected void cleanupCalls(boolean allCalls)
    +
    protected void cleanupCalls(boolean allCalls)
    Cleanup the calls older than a given timeout, in milli seconds.
    Parameters:
    allCalls - true for all calls, false for only the calls in timeout
  • http://git-wip-us.apache.org/repos/asf/hbase-site/blob/75eda567/devapidocs/org/apache/hadoop/hbase/ipc/RpcClientImpl.html ---------------------------------------------------------------------- diff --git a/devapidocs/org/apache/hadoop/hbase/ipc/RpcClientImpl.html b/devapidocs/org/apache/hadoop/hbase/ipc/RpcClientImpl.html index 7bae775..92e9dea 100644 --- a/devapidocs/org/apache/hadoop/hbase/ipc/RpcClientImpl.html +++ b/devapidocs/org/apache/hadoop/hbase/ipc/RpcClientImpl.html @@ -413,7 +413,7 @@ extends
  • RpcClientImpl

    -
    RpcClientImpl(org.apache.hadoop.conf.Configuration conf,
    +
    RpcClientImpl(org.apache.hadoop.conf.Configuration conf,
                  String clusterId,
                  SocketFactory factory)
    Used in test only. Construct an IPC cluster client whose values are of the @@ -427,7 +427,7 @@ extends
  • RpcClientImpl

    -
    RpcClientImpl(org.apache.hadoop.conf.Configuration conf,
    +
    RpcClientImpl(org.apache.hadoop.conf.Configuration conf,
                  String clusterId,
                  SocketFactory factory,
                  SocketAddress localAddr,
    @@ -442,7 +442,7 @@ extends 
     
  • RpcClientImpl

    -
    RpcClientImpl(org.apache.hadoop.conf.Configuration conf,
    +
    RpcClientImpl(org.apache.hadoop.conf.Configuration conf,
                  String clusterId)
    Used in test only. Construct an IPC client for the cluster clusterId with the default SocketFactory
    @@ -454,7 +454,7 @@ extends
  • RpcClientImpl

    -
    public RpcClientImpl(org.apache.hadoop.conf.Configuration conf,
    +
    public RpcClientImpl(org.apache.hadoop.conf.Configuration conf,
                  String clusterId,
                  SocketAddress localAddr,
                  MetricsConnection metrics)
    @@ -494,7 +494,7 @@ extends
  • close

    -
    public void close()
    +
    public void close()
    Stop all threads related to this client. No further calls may be made using this client.
  • @@ -505,7 +505,7 @@ extends
  • call

    -
    protected Pair<com.google.protobuf.Message,CellScannercall(PayloadCarryingRpcController pcrc,
    +
    protected Pair<com.google.protobuf.Message,CellScannercall(PayloadCarryingRpcController pcrc,
                                                      com.google.protobuf.Descriptors.MethodDescriptor md,
                                                      com.google.protobuf.Message param,
                                                      com.google.protobuf.Message returnType,
    @@ -537,7 +537,7 @@ extends 
     
  • cancelConnections

    -
    public void cancelConnections(ServerName sn)
    +
    public void cancelConnections(ServerName sn)
    Interrupt the connections to the given ip:port server. This should be called if the server is known as actually dead. This will not prevent current operation to be retried, and, depending on their own behavior, they may retry on the same server. This can be a feature, @@ -553,7 +553,7 @@ extends
  • getConnection

    -
    protected RpcClientImpl.Connection getConnection(User ticket,
    +
    protected RpcClientImpl.Connection getConnection(User ticket,
                                          Call call,
                                          InetSocketAddress addr)
                                               throws IOException
    http://git-wip-us.apache.org/repos/asf/hbase-site/blob/75eda567/devapidocs/org/apache/hadoop/hbase/ipc/RpcServer.BlockingServiceAndInterface.html ---------------------------------------------------------------------- diff --git a/devapidocs/org/apache/hadoop/hbase/ipc/RpcServer.BlockingServiceAndInterface.html b/devapidocs/org/apache/hadoop/hbase/ipc/RpcServer.BlockingServiceAndInterface.html index b456bae..e221010 100644 --- a/devapidocs/org/apache/hadoop/hbase/ipc/RpcServer.BlockingServiceAndInterface.html +++ b/devapidocs/org/apache/hadoop/hbase/ipc/RpcServer.BlockingServiceAndInterface.html @@ -99,7 +99,7 @@

    -
    public static class RpcServer.BlockingServiceAndInterface
    +
    public static class RpcServer.BlockingServiceAndInterface
     extends Object
    Datastructure for passing a BlockingService and its associated class of protobuf service interface. For example, a server that fielded what is defined @@ -200,7 +200,7 @@ extends
  • service

    -
    private final com.google.protobuf.BlockingService service
    +
    private final com.google.protobuf.BlockingService service
  • @@ -209,7 +209,7 @@ extends
  • serviceInterface

    -
    private final Class<?> serviceInterface
    +
    private final Class<?> serviceInterface
  • @@ -226,7 +226,7 @@ extends
  • RpcServer.BlockingServiceAndInterface

    -
    public RpcServer.BlockingServiceAndInterface(com.google.protobuf.BlockingService service,
    +
    public RpcServer.BlockingServiceAndInterface(com.google.protobuf.BlockingService service,
                                          Class<?> serviceInterface)
  • @@ -244,7 +244,7 @@ extends
  • getServiceInterface

    -
    public Class<?> getServiceInterface()
    +
    public Class<?> getServiceInterface()
  • @@ -253,7 +253,7 @@ extends
  • getBlockingService

    -
    public com.google.protobuf.BlockingService getBlockingService()
    +
    public com.google.protobuf.BlockingService getBlockingService()
  • http://git-wip-us.apache.org/repos/asf/hbase-site/blob/75eda567/devapidocs/org/apache/hadoop/hbase/ipc/RpcServer.Call.html ---------------------------------------------------------------------- diff --git a/devapidocs/org/apache/hadoop/hbase/ipc/RpcServer.Call.html b/devapidocs/org/apache/hadoop/hbase/ipc/RpcServer.Call.html index e231ba6..fcac6d0 100644 --- a/devapidocs/org/apache/hadoop/hbase/ipc/RpcServer.Call.html +++ b/devapidocs/org/apache/hadoop/hbase/ipc/RpcServer.Call.html @@ -640,7 +640,7 @@ implements
  • RpcServer.Call

    -
    RpcServer.Call(int id,
    +
    RpcServer.Call(int id,
                   com.google.protobuf.BlockingService service,
                   com.google.protobuf.Descriptors.MethodDescriptor md,
                   org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader header,
    @@ -667,7 +667,7 @@ implements 
     
  • done

    -
    void done()
    +
    void done()
    Call is done. Execution happened and we returned results to client. It is now safe to cleanup.
  • @@ -678,7 +678,7 @@ implements
  • toString

    -
    public String toString()
    +
    public String toString()
    Overrides:
    toString in class Object
    @@ -691,7 +691,7 @@ implements
  • getHeader

    -
    protected org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader getHeader()
    +
    protected org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader getHeader()
  • @@ -700,7 +700,7 @@ implements
  • toShortString

    -
    String toShortString()
    +
    String toShortString()
  • @@ -709,7 +709,7 @@ implements
  • toTraceString

    -
    String toTraceString()
    +
    String toTraceString()
  • @@ -718,7 +718,7 @@ implements
  • setSaslTokenResponse

    -
    protected void setSaslTokenResponse(ByteBuffer response)
    +
    protected void setSaslTokenResponse(ByteBuffer response)
  • @@ -727,7 +727,7 @@ implements
  • setResponse

    -
    protected void setResponse(Object m,
    +
    protected void setResponse(Object m,
                    CellScanner cells,
                    Throwable t,
                    String errorMsg)
    @@ -739,7 +739,7 @@ implements
  • wrapWithSasl

    -
    private BufferChain wrapWithSasl(BufferChain bc)
    +
    private BufferChain wrapWithSasl(BufferChain bc)
                               throws IOException
    Throws:
    IOException
    @@ -751,7 +751,7 @@ implements
  • endDelay

    -
    public void endDelay(Object result)
    +
    public void endDelay(Object result)
                   throws IOException
    Description copied from interface: Delayable
    Signal that the RPC server is now allowed to send the response.
    @@ -771,7 +771,7 @@ implements
  • endDelay

    -
    public void endDelay()
    +
    public void endDelay()
                   throws IOException
    Description copied from interface: Delayable
    Signal the end of a delayed RPC, without specifying the return value. Use @@ -789,7 +789,7 @@ implements
  • startDelay

    -
    public void startDelay(boolean delayReturnValue)
    +
    public void startDelay(boolean delayReturnValue)
    Description copied from interface: Delayable
    Signal that the call response should be delayed, thus freeing the RPC server to handle different requests.
    @@ -807,7 +807,7 @@ implements
  • endDelayThrowing

    -
    public void endDelayThrowing(Throwable t)
    +
    public void endDelayThrowing(Throwable t)
                           throws IOException
    Description copied from interface: Delayable
    End the call, throwing and exception to the caller. This works regardless @@ -826,7 +826,7 @@ implements
  • isDelayed

    -
    public boolean isDelayed()
    +
    public boolean isDelayed()
    Specified by:
    isDelayed in interface Delayable
    @@ -839,7 +839,7 @@ implements
  • isReturnValueDelayed

    -
    public boolean isReturnValueDelayed()
    +
    public boolean isReturnValueDelayed()
    Specified by:
    isReturnValueDelayed in interface Delayable
    @@ -852,7 +852,7 @@ implements
  • isClientCellBlockSupported

    -
    public boolean isClientCellBlockSupported()
    +
    public boolean isClientCellBlockSupported()
    Description copied from interface: RpcCallContext
    If the client connected and specified a codec to use, then we will use this codec making cellblocks to return. If the client did not specify a codec, we assume it does not support @@ -871,7 +871,7 @@ implements
  • disconnectSince

    -
    public long disconnectSince()
    +
    public long disconnectSince()
    Description copied from interface: RpcCallContext
    Check if the caller who made this IPC call has disconnected. If called from outside the context of IPC, this does nothing.
    @@ -888,7 +888,7 @@ implements
  • getSize

    -
    public long getSize()
    +
    public long getSize()
  • @@ -897,7 +897,7 @@ implements
  • getResponseCellSize

    -
    public long getResponseCellSize()
    +
    public long getResponseCellSize()
    Description copied from interface: RpcCallContext
    The size of response cells that have been accumulated so far. This along with the corresponding increment call is used to ensure that multi's or @@ -914,7 +914,7 @@ implements
  • incrementResponseCellSize

    -
    public void incrementResponseCellSize(long cellSize)
    +
    public void incrementResponseCellSize(long cellSize)
    Description copied from interface: RpcCallContext
    Add on the given amount to the retained cell size. @@ -933,7 +933,7 @@ implements
  • getResponseBlockSize

    -
    public long getResponseBlockSize()
    +
    public long getResponseBlockSize()
    Specified by:
    getResponseBlockSize in interface RpcCallContext
    @@ -946,7 +946,7 @@ implements
  • incrementResponseBlockSize

    -
    public void incrementResponseBlockSize(long blockSize)
    +
    public void incrementResponseBlockSize(long blockSize)
    Specified by:
    incrementResponseBlockSize in interface RpcCallContext
    @@ -959,7 +959,7 @@ implements
  • sendResponseIfReady

    -
    public void sendResponseIfReady()
    +
    public void sendResponseIfReady()
                              throws IOException
    If we have a response, and delay is not set, then respond immediately. Otherwise, do not respond to client. This is @@ -974,7 +974,7 @@ implements
  • getRemoteUser

    -
    public org.apache.hadoop.security.UserGroupInformation getRemoteUser()
    +
    public org.apache.hadoop.security.UserGroupInformation getRemoteUser()
  • @@ -983,7 +983,7 @@ implements
  • getRequestUser

    -
    public User getRequestUser()
    +
    public User getRequestUser()
    Description copied from interface: RpcCallContext
    Returns the user credentials associated with the current RPC request or null if no credentials were provided.
    @@ -999,7 +999,7 @@ implements
  • getRequestUserName

    -
    public String getRequestUserName()
    +
    public String getRequestUserName()
    Specified by:
    getRequestUserName in interface RpcCallContext
    @@ -1012,7 +1012,7 @@ implements
  • getRemoteAddress

    -
    public InetAddress getRemoteAddress()
    +
    public InetAddress getRemoteAddress()
    Specified by:
    getRemoteAddress in interface RpcCallContext
    @@ -1025,7 +1025,7 @@ implements
  • getClientVersionInfo

    -
    public org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.VersionInfo getClientVersionInfo()
    +
    public org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.VersionInfo getClientVersionInfo()
    Specified by:
    getClientVersionInfo in interface RpcCallContext
    @@ -1038,7 +1038,7 @@ implements
  • setCallBack

    -
    public void setCallBack(RpcCallback callback)
    +
    public void setCallBack(RpcCallback callback)
    Description copied from interface: RpcCallContext
    Sets a callback which has to be executed at the end of this RPC call. Such a callback is an optional one for any Rpc call.
    @@ -1054,7 +1054,7 @@ implements
  • isRetryImmediatelySupported

    -
    public boolean isRetryImmediatelySupported()
    +
    public boolean isRetryImmediatelySupported()
    Specified by:
    isRetryImmediatelySupported in interface RpcCallContext
    http://git-wip-us.apache.org/repos/asf/hbase-site/blob/75eda567/devapidocs/org/apache/hadoop/hbase/ipc/RpcServer.CallQueueTooBigException.html ---------------------------------------------------------------------- diff --git a/devapidocs/org/apache/hadoop/hbase/ipc/RpcServer.CallQueueTooBigException.html b/devapidocs/org/apache/hadoop/hbase/ipc/RpcServer.CallQueueTooBigException.html index 4b839d4..c4de61a 100644 --- a/devapidocs/org/apache/hadoop/hbase/ipc/RpcServer.CallQueueTooBigException.html +++ b/devapidocs/org/apache/hadoop/hbase/ipc/RpcServer.CallQueueTooBigException.html @@ -118,7 +118,7 @@


    -
    public static class RpcServer.CallQueueTooBigException
    +
    public static class RpcServer.CallQueueTooBigException
     extends IOException
    See Also:
    Serialized Form
  • @@ -184,7 +184,7 @@ extends
  • RpcServer.CallQueueTooBigException

    -
    RpcServer.CallQueueTooBigException()
    +
    RpcServer.CallQueueTooBigException()