Return-Path: X-Original-To: archive-asf-public-internal@cust-asf2.ponee.io Delivered-To: archive-asf-public-internal@cust-asf2.ponee.io Received: from cust-asf.ponee.io (cust-asf.ponee.io [163.172.22.183]) by cust-asf2.ponee.io (Postfix) with ESMTP id D8F71200CB7 for ; Fri, 30 Jun 2017 17:01:00 +0200 (CEST) Received: by cust-asf.ponee.io (Postfix) id D6DB2160BEB; Fri, 30 Jun 2017 15:01:00 +0000 (UTC) Delivered-To: archive-asf-public@cust-asf.ponee.io Received: from mail.apache.org (hermes.apache.org [140.211.11.3]) by cust-asf.ponee.io (Postfix) with SMTP id 0BEA1160C00 for ; Fri, 30 Jun 2017 17:00:58 +0200 (CEST) Received: (qmail 25997 invoked by uid 500); 30 Jun 2017 15:00:53 -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 25645 invoked by uid 99); 30 Jun 2017 15:00:53 -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, 30 Jun 2017 15:00:53 +0000 Received: by git1-us-west.apache.org (ASF Mail Server at git1-us-west.apache.org, from userid 33) id 189F2E96E1; Fri, 30 Jun 2017 15:00:53 +0000 (UTC) Content-Type: text/plain; charset="us-ascii" MIME-Version: 1.0 Content-Transfer-Encoding: 7bit From: git-site-role@apache.org To: commits@hbase.apache.org Date: Fri, 30 Jun 2017 15:01:19 -0000 Message-Id: <0248f31096c14239a8667b49e34f8637@git.apache.org> In-Reply-To: <6802f6ed0a334890adcc73f75ef88cd2@git.apache.org> References: <6802f6ed0a334890adcc73f75ef88cd2@git.apache.org> X-Mailer: ASF-Git Admin Mailer Subject: [29/32] hbase-site git commit: Published site at 82d554e3783372cc6b05489452c815b57c06f6cd. archived-at: Fri, 30 Jun 2017 15:01:01 -0000 http://git-wip-us.apache.org/repos/asf/hbase-site/blob/1b5f3a4b/devapidocs/org/apache/hadoop/hbase/client/ConnectionImplementation.html ---------------------------------------------------------------------- diff --git a/devapidocs/org/apache/hadoop/hbase/client/ConnectionImplementation.html b/devapidocs/org/apache/hadoop/hbase/client/ConnectionImplementation.html index 0fdb3bf..e0614ca 100644 --- a/devapidocs/org/apache/hadoop/hbase/client/ConnectionImplementation.html +++ b/devapidocs/org/apache/hadoop/hbase/client/ConnectionImplementation.html @@ -1186,7 +1186,7 @@ implements
  • stubs

    -
    private final ConcurrentMap<String,Object> stubs
    +
    private final ConcurrentMap<String,Object> stubs
  • @@ -1195,7 +1195,7 @@ implements
  • keepAliveZookeeper

    -
    private ZooKeeperKeepAliveConnection keepAliveZookeeper
    +
    private ZooKeeperKeepAliveConnection keepAliveZookeeper
  • @@ -1204,7 +1204,7 @@ implements
  • keepAliveZookeeperUserCount

    -
    private AtomicInteger keepAliveZookeeperUserCount
    +
    private AtomicInteger keepAliveZookeeperUserCount
  • @@ -1213,7 +1213,7 @@ implements
  • masterServiceState

    -
    final ConnectionImplementation.MasterServiceState masterServiceState
    +
    final ConnectionImplementation.MasterServiceState masterServiceState
  • @@ -1981,7 +1981,7 @@ public boolean 
  • cacheLocation

    -
    public void cacheLocation(TableName tableName,
    +
    public void cacheLocation(TableName tableName,
                               RegionLocations location)
    Put a newly discovered HRegionLocation into the cache.
    @@ -1999,7 +1999,7 @@ public boolean 
  • getCachedLocation

    -
    RegionLocations getCachedLocation(TableName tableName,
    +
    RegionLocations getCachedLocation(TableName tableName,
                                       byte[] row)
    Search the cache for a location that fits our table and row key. Return null if no suitable region is located.
    @@ -2015,7 +2015,7 @@ public boolean 
  • clearRegionCache

    -
    public void clearRegionCache(TableName tableName,
    +
    public void clearRegionCache(TableName tableName,
                                  byte[] row)
  • @@ -2025,7 +2025,7 @@ public boolean 
  • clearCaches

    -
    public void clearCaches(ServerName serverName)
    +
    public void clearCaches(ServerName serverName)
    Description copied from interface: ClusterConnection
    Clear any caches that pertain to server name sn.
    @@ -2042,7 +2042,7 @@ public boolean 
  • clearRegionCache

    -
    public void clearRegionCache()
    +
    public void clearRegionCache()
    Description copied from interface: ClusterConnection
    Allows flushing the region cache.
    @@ -2057,7 +2057,7 @@ public boolean 
  • clearRegionCache

    -
    public void clearRegionCache(TableName tableName)
    +
    public void clearRegionCache(TableName tableName)
    Description copied from interface: ClusterConnection
    Allows flushing the region cache of all locations that pertain to tableName
    @@ -2076,7 +2076,7 @@ public boolean 
  • cacheLocation

    -
    private void cacheLocation(TableName tableName,
    +
    private void cacheLocation(TableName tableName,
                                ServerName source,
                                HRegionLocation location)
    Put a newly discovered HRegionLocation into the cache.
    @@ -2094,7 +2094,7 @@ public boolean 
  • getAdmin

    -
    public org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterface getAdmin(ServerName serverName)
    +
    public org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterface getAdmin(ServerName serverName)
                                                                                                           throws IOException
    Description copied from interface: ClusterConnection
    Establishes a connection to the region server at the specified address.
    @@ -2114,7 +2114,7 @@ public boolean 
  • getClient

    -
    public org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ClientService.BlockingInterface getClient(ServerName serverName)
    +
    public org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ClientService.BlockingInterface getClient(ServerName serverName)
                                                                                                              throws IOException
    Description copied from interface: ClusterConnection
    Establishes a connection to the region server at the specified address, and returns @@ -2135,7 +2135,7 @@ public boolean 
  • getKeepAliveZooKeeperWatcher

    -
    ZooKeeperKeepAliveConnection getKeepAliveZooKeeperWatcher()
    +
    ZooKeeperKeepAliveConnection getKeepAliveZooKeeperWatcher()
                                                        throws IOException
    Retrieve a shared ZooKeeperWatcher. You must close it it once you've have finished with it.
    @@ -2152,7 +2152,7 @@ public boolean 
  • releaseZooKeeperWatcher

    -
    void releaseZooKeeperWatcher(ZooKeeperWatcher zkw)
    +
    void releaseZooKeeperWatcher(ZooKeeperWatcher zkw)
  • @@ -2161,7 +2161,7 @@ public boolean 
  • closeZooKeeperWatcher

    -
    private void closeZooKeeperWatcher()
    +
    private void closeZooKeeperWatcher()
  • @@ -2170,7 +2170,7 @@ public boolean 
  • getMaster

    -
    public org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface getMaster()
    +
    public org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface getMaster()
                                                                                                              throws MasterNotRunningException
    Description copied from interface: ClusterConnection
    Returns a MasterKeepAliveConnection to the active master
    @@ -2188,7 +2188,7 @@ public boolean 
  • resetMasterServiceState

    -
    private void resetMasterServiceState(ConnectionImplementation.MasterServiceState mss)
    +
    private void resetMasterServiceState(ConnectionImplementation.MasterServiceState mss)
  • @@ -2197,7 +2197,7 @@ public boolean 
  • getKeepAliveMasterService

    -
    public MasterKeepAliveConnection getKeepAliveMasterService()
    +
    public MasterKeepAliveConnection getKeepAliveMasterService()
                                                         throws MasterNotRunningException
    Description copied from interface: ClusterConnection
    This function allows HBaseAdmin and potentially others to get a shared MasterService @@ -2218,7 +2218,7 @@ public boolean 
  • release

    -
    private static void release(ConnectionImplementation.MasterServiceState mss)
    +
    private static void release(ConnectionImplementation.MasterServiceState mss)
  • @@ -2227,7 +2227,7 @@ public boolean 
  • isKeepAliveMasterConnectedAndRunning

    -
    private boolean isKeepAliveMasterConnectedAndRunning(ConnectionImplementation.MasterServiceState mss)
    +
    private boolean isKeepAliveMasterConnectedAndRunning(ConnectionImplementation.MasterServiceState mss)
  • @@ -2236,7 +2236,7 @@ public boolean 
  • releaseMaster

    -
    void releaseMaster(ConnectionImplementation.MasterServiceState mss)
    +
    void releaseMaster(ConnectionImplementation.MasterServiceState mss)
  • @@ -2245,7 +2245,7 @@ public boolean 
  • closeMasterService

    -
    private void closeMasterService(ConnectionImplementation.MasterServiceState mss)
    +
    private void closeMasterService(ConnectionImplementation.MasterServiceState mss)
  • @@ -2254,7 +2254,7 @@ public boolean 
  • closeMaster

    -
    private void closeMaster()
    +
    private void closeMaster()
    Immediate close of the shared master. Can be by the delayed close or when closing the connection itself.
  • @@ -2265,7 +2265,7 @@ public boolean 
  • updateCachedLocation

    -
    void updateCachedLocation(HRegionInfo hri,
    +
    void updateCachedLocation(HRegionInfo hri,
                               ServerName source,
                               ServerName serverName,
                               long seqNum)
    @@ -2277,7 +2277,7 @@ public boolean 
  • deleteCachedRegionLocation

    -
    public void deleteCachedRegionLocation(HRegionLocation location)
    +
    public void deleteCachedRegionLocation(HRegionLocation location)
    Description copied from interface: ClusterConnection
    Deletes cached locations for the specific region.
    @@ -2294,7 +2294,7 @@ public boolean 
  • updateCachedLocations

    -
    public void updateCachedLocations(TableName tableName,
    +
    public void updateCachedLocations(TableName tableName,
                                       byte[] regionName,
                                       byte[] rowkey,
                                       Object exception,
    @@ -2321,7 +2321,7 @@ public boolean 
     
  • getAsyncProcess

    -
    public AsyncProcess getAsyncProcess()
    +
    public AsyncProcess getAsyncProcess()
    Specified by:
    getAsyncProcess in interface ClusterConnection
    @@ -2336,7 +2336,7 @@ public boolean 
  • getStatisticsTracker

    -
    public ServerStatisticTracker getStatisticsTracker()
    +
    public ServerStatisticTracker getStatisticsTracker()
    Specified by:
    getStatisticsTracker in interface ClusterConnection
    @@ -2351,7 +2351,7 @@ public boolean 
  • getBackoffPolicy

    -
    public ClientBackoffPolicy getBackoffPolicy()
    +
    public ClientBackoffPolicy getBackoffPolicy()
    Specified by:
    getBackoffPolicy in interface ClusterConnection
    @@ -2366,7 +2366,7 @@ public boolean 
  • getNumberOfCachedRegionLocations

    -
    int getNumberOfCachedRegionLocations(TableName tableName)
    +
    int getNumberOfCachedRegionLocations(TableName tableName)
  • @@ -2375,7 +2375,7 @@ public boolean 
  • abort

    -
    public void abort(String msg,
    +
    public void abort(String msg,
                       Throwable t)
    Description copied from interface: Abortable
    Abort the server or client.
    @@ -2394,7 +2394,7 @@ public boolean 
  • isClosed

    -
    public boolean isClosed()
    +
    public boolean isClosed()
    Description copied from interface: Connection
    Returns whether the connection is closed or not.
    @@ -2411,7 +2411,7 @@ public boolean 
  • isAborted

    -
    public boolean isAborted()
    +
    public boolean isAborted()
    Description copied from interface: Abortable
    Check if the server or client was aborted.
    @@ -2428,7 +2428,7 @@ public boolean 
  • getCurrentNrHRS

    -
    public int getCurrentNrHRS()
    +
    public int getCurrentNrHRS()
                         throws IOException
    Specified by:
    @@ -2446,7 +2446,7 @@ public boolean 
  • close

    -
    public void close()
    +
    public void close()
    Specified by:
    close in interface Closeable
    @@ -2463,7 +2463,7 @@ public boolean 
  • finalize

    -
    protected void finalize()
    +
    protected void finalize()
                      throws Throwable
    Close the connection for good. On the off chance that someone is unable to close the connection, perhaps because it bailed out prematurely, the method @@ -2485,7 +2485,7 @@ public boolean 
  • getNonceGenerator

    -
    public NonceGenerator getNonceGenerator()
    +
    public NonceGenerator getNonceGenerator()
    Specified by:
    getNonceGenerator in interface ClusterConnection
    @@ -2500,7 +2500,7 @@ public boolean 
  • getTableState

    -
    public TableState getTableState(TableName tableName)
    +
    public TableState getTableState(TableName tableName)
                              throws IOException
    Description copied from interface: ClusterConnection
    Retrieve TableState, represent current table state.
    @@ -2522,7 +2522,7 @@ public boolean 
  • getNewRpcRetryingCallerFactory

    -
    public RpcRetryingCallerFactory getNewRpcRetryingCallerFactory(org.apache.hadoop.conf.Configuration conf)
    +
    public RpcRetryingCallerFactory getNewRpcRetryingCallerFactory(org.apache.hadoop.conf.Configuration conf)
    Description copied from interface: ClusterConnection
    Returns a new RpcRetryingCallerFactory from the given Configuration. This RpcRetryingCallerFactory lets the users create RpcRetryingCallers which can be @@ -2543,7 +2543,7 @@ public boolean 
  • hasCellBlockSupport

    -
    public boolean hasCellBlockSupport()
    +
    public boolean hasCellBlockSupport()
    Specified by:
    hasCellBlockSupport in interface ClusterConnection
    @@ -2559,7 +2559,7 @@ public boolean 
  • getConnectionConfiguration

    -
    public ConnectionConfiguration getConnectionConfiguration()
    +
    public ConnectionConfiguration getConnectionConfiguration()
    Specified by:
    getConnectionConfiguration in interface ClusterConnection
    @@ -2574,7 +2574,7 @@ public boolean 
  • getRpcRetryingCallerFactory

    -
    public RpcRetryingCallerFactory getRpcRetryingCallerFactory()
    +
    public RpcRetryingCallerFactory getRpcRetryingCallerFactory()
    Specified by:
    getRpcRetryingCallerFactory in interface ClusterConnection
    @@ -2589,7 +2589,7 @@ public boolean 
  • getRpcControllerFactory

    -
    public RpcControllerFactory getRpcControllerFactory()
    +
    public RpcControllerFactory getRpcControllerFactory()
    Specified by:
    getRpcControllerFactory in interface ClusterConnection
    http://git-wip-us.apache.org/repos/asf/hbase-site/blob/1b5f3a4b/devapidocs/org/apache/hadoop/hbase/procedure2/store/wal/ProcedureWALFormatReader.WalProcedureMap.html ---------------------------------------------------------------------- diff --git a/devapidocs/org/apache/hadoop/hbase/procedure2/store/wal/ProcedureWALFormatReader.WalProcedureMap.html b/devapidocs/org/apache/hadoop/hbase/procedure2/store/wal/ProcedureWALFormatReader.WalProcedureMap.html index f6eae9a..7424458 100644 --- a/devapidocs/org/apache/hadoop/hbase/procedure2/store/wal/ProcedureWALFormatReader.WalProcedureMap.html +++ b/devapidocs/org/apache/hadoop/hbase/procedure2/store/wal/ProcedureWALFormatReader.WalProcedureMap.html @@ -438,7 +438,7 @@ extends
  • remove

    -
    public boolean remove(long procId)
    +
    public boolean remove(long procId)
  • @@ -447,7 +447,7 @@ extends
  • trackProcIds

    -
    private void trackProcIds(long procId)
    +
    private void trackProcIds(long procId)
  • @@ -456,7 +456,7 @@ extends
  • getMinProcId

    -
    public long getMinProcId()
    +
    public long getMinProcId()
  • @@ -465,7 +465,7 @@ extends
  • getMaxProcId

    -
    public long getMaxProcId()
    +
    public long getMaxProcId()
  • @@ -474,7 +474,7 @@ extends
  • contains

    -
    public boolean contains(long procId)
    +
    public boolean contains(long procId)
  • @@ -483,7 +483,7 @@ extends
  • isEmpty

    -
    public boolean isEmpty()
    +
    public boolean isEmpty()
  • @@ -492,7 +492,7 @@ extends
  • clear

    -
    public void clear()
    +
    public void clear()
  • @@ -501,7 +501,7 @@ extends
  • mergeTail

    -
    public void mergeTail(ProcedureWALFormatReader.WalProcedureMap other)
    +
    public void mergeTail(ProcedureWALFormatReader.WalProcedureMap other)
  • @@ -510,7 +510,7 @@ extends
  • fetchReady

    -
    public ProcedureWALFormatReader.EntryIterator fetchReady()
    +
    public ProcedureWALFormatReader.EntryIterator fetchReady()
  • @@ -519,7 +519,7 @@ extends
  • fetchAll

    -
    public ProcedureWALFormatReader.EntryIterator fetchAll()
    +
    public ProcedureWALFormatReader.EntryIterator fetchAll()
  • @@ -528,7 +528,7 @@ extends
  • buildGraph

    -
    private void buildGraph()
    +
    private void buildGraph()
  • @@ -537,7 +537,7 @@ extends
  • getRootProcedure

    -
    private ProcedureWALFormatReader.Entry getRootProcedure(ProcedureWALFormatReader.Entry entry)
    +
    private ProcedureWALFormatReader.Entry getRootProcedure(ProcedureWALFormatReader.Entry entry)
  • @@ -546,7 +546,7 @@ extends
  • checkReadyToRun

    -
    private boolean checkReadyToRun(ProcedureWALFormatReader.Entry rootEntry)
    +
    private boolean checkReadyToRun(ProcedureWALFormatReader.Entry rootEntry)
  • @@ -555,7 +555,7 @@ extends
  • unlinkFromReplayList

    -
    private void unlinkFromReplayList(ProcedureWALFormatReader.Entry entry)
    +
    private void unlinkFromReplayList(ProcedureWALFormatReader.Entry entry)
  • @@ -564,7 +564,7 @@ extends
  • addToReplayList

    -
    private void addToReplayList(ProcedureWALFormatReader.Entry entry)
    +
    private void addToReplayList(ProcedureWALFormatReader.Entry entry)
  • @@ -573,7 +573,7 @@ extends
  • unlinkFromLinkList

    -
    private void unlinkFromLinkList(ProcedureWALFormatReader.Entry entry)
    +
    private void unlinkFromLinkList(ProcedureWALFormatReader.Entry entry)
  • @@ -582,7 +582,7 @@ extends
  • addToLinkList

    -
    private ProcedureWALFormatReader.Entry addToLinkList(ProcedureWALFormatReader.Entry entry,
    +
    private ProcedureWALFormatReader.Entry addToLinkList(ProcedureWALFormatReader.Entry entry,
                                                          ProcedureWALFormatReader.Entry linkHead)
  • @@ -592,7 +592,7 @@ extends
  • findLinkListTail

    -
    private ProcedureWALFormatReader.Entry findLinkListTail(ProcedureWALFormatReader.Entry linkHead)
    +
    private ProcedureWALFormatReader.Entry findLinkListTail(ProcedureWALFormatReader.Entry linkHead)
  • @@ -601,7 +601,7 @@ extends
  • addToMap

    -
    private ProcedureWALFormatReader.Entry addToMap(long procId,
    +
    private ProcedureWALFormatReader.Entry addToMap(long procId,
                                                     boolean hasParent)
  • @@ -611,7 +611,7 @@ extends
  • removeFromMap

    -
    private ProcedureWALFormatReader.Entry removeFromMap(long procId)
    +
    private ProcedureWALFormatReader.Entry removeFromMap(long procId)
  • @@ -620,7 +620,7 @@ extends
  • getProcedure

    -
    private ProcedureWALFormatReader.Entry getProcedure(long procId)
    +
    private ProcedureWALFormatReader.Entry getProcedure(long procId)
  • @@ -629,7 +629,7 @@ extends
  • getProcedure

    -
    private ProcedureWALFormatReader.Entry getProcedure(int slotIndex,
    +
    private ProcedureWALFormatReader.Entry getProcedure(int slotIndex,
                                                         long procId)
  • @@ -639,7 +639,7 @@ extends
  • getMapSlot

    -
    private int getMapSlot(long procId)
    +
    private int getMapSlot(long procId)