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 CE9FB200B50 for ; Thu, 14 Jul 2016 21:46:32 +0200 (CEST) Received: by cust-asf.ponee.io (Postfix) id CD37F160A8E; Thu, 14 Jul 2016 19:46:32 +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 CE1FC160A86 for ; Thu, 14 Jul 2016 21:46:30 +0200 (CEST) Received: (qmail 59562 invoked by uid 500); 14 Jul 2016 19:46:26 -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 57979 invoked by uid 99); 14 Jul 2016 19:46:25 -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, 14 Jul 2016 19:46:25 +0000 Received: by git1-us-west.apache.org (ASF Mail Server at git1-us-west.apache.org, from userid 33) id 82F3DED103; Thu, 14 Jul 2016 19:46:25 +0000 (UTC) Content-Type: text/plain; charset="us-ascii" MIME-Version: 1.0 Content-Transfer-Encoding: 7bit From: busbey@apache.org To: commits@hbase.apache.org Date: Thu, 14 Jul 2016 19:46:47 -0000 Message-Id: In-Reply-To: <588ce14c0d8544b2906deffa43a1c0cc@git.apache.org> References: <588ce14c0d8544b2906deffa43a1c0cc@git.apache.org> X-Mailer: ASF-Git Admin Mailer Subject: [24/52] [partial] hbase-site git commit: Published site at a55af38689fbe273e716ebbf6191e9515986dbf3. archived-at: Thu, 14 Jul 2016 19:46:33 -0000 http://git-wip-us.apache.org/repos/asf/hbase-site/blob/975096b1/devapidocs/org/apache/hadoop/hbase/regionserver/HRegionServer.html ---------------------------------------------------------------------- diff --git a/devapidocs/org/apache/hadoop/hbase/regionserver/HRegionServer.html b/devapidocs/org/apache/hadoop/hbase/regionserver/HRegionServer.html index 9e8e91b..b34a6e1 100644 --- a/devapidocs/org/apache/hadoop/hbase/regionserver/HRegionServer.html +++ b/devapidocs/org/apache/hadoop/hbase/regionserver/HRegionServer.html @@ -2199,7 +2199,7 @@ implements
  • UNSPECIFIED_REGION

    -
    private static final byte[] UNSPECIFIED_REGION
    +
    private static final byte[] UNSPECIFIED_REGION
  • @@ -2208,7 +2208,7 @@ implements
  • movedRegions

    -
    protected Map<String,HRegionServer.MovedRegionInfo> movedRegions
    +
    protected Map<String,HRegionServer.MovedRegionInfo> movedRegions
  • @@ -2217,7 +2217,7 @@ implements
  • TIMEOUT_REGION_MOVED

    -
    private static final int TIMEOUT_REGION_MOVED
    +
    private static final int TIMEOUT_REGION_MOVED
    See Also:
    Constant Field Values
  • @@ -2803,7 +2803,7 @@ implements
  • putUpWebUI

    -
    private int putUpWebUI()
    +
    private int putUpWebUI()
                     throws IOException
    Puts up the webui.
    Returns:
    Returns final port -- maybe different from what we started with.
    @@ -2817,7 +2817,7 @@ implements
  • isHealthy

    -
    private boolean isHealthy()
    +
    private boolean isHealthy()
  • @@ -2826,7 +2826,7 @@ implements
  • getWAL

    -
    public WAL getWAL(HRegionInfo regionInfo)
    +
    public WAL getWAL(HRegionInfo regionInfo)
                throws IOException
    Specified by:
    @@ -2843,7 +2843,7 @@ implements
  • getConnection

    -
    public Connection getConnection()
    +
    public Connection getConnection()
    Description copied from interface: Server
    Returns a reference to the servers' connection. @@ -2861,7 +2861,7 @@ implements
  • getClusterConnection

    -
    public ClusterConnection getClusterConnection()
    +
    public ClusterConnection getClusterConnection()
    Description copied from interface: Server
    Returns a reference to the servers' cluster connection. Prefer Server.getConnection(). @@ -2879,7 +2879,7 @@ implements
  • getMetaTableLocator

    -
    public MetaTableLocator getMetaTableLocator()
    +
    public MetaTableLocator getMetaTableLocator()
    Description copied from interface: Server
    Returns instance of MetaTableLocator running inside this server. This MetaServerLocator is started and stopped by server, clients @@ -2896,7 +2896,7 @@ implements
  • stop

    -
    public void stop(String msg)
    +
    public void stop(String msg)
    Description copied from interface: Stoppable
    Stop this service. Implementers should favor logging errors over throwing RuntimeExceptions.
    @@ -2912,7 +2912,7 @@ implements
  • waitForServerOnline

    -
    public void waitForServerOnline()
    +
    public void waitForServerOnline()
  • @@ -2921,7 +2921,7 @@ implements
  • postOpenDeployTasks

    -
    public void postOpenDeployTasks(Region r)
    +
    public void postOpenDeployTasks(Region r)
                              throws org.apache.zookeeper.KeeperException,
                                     IOException
    Description copied from interface: RegionServerServices
    @@ -2942,7 +2942,7 @@ implements
  • postOpenDeployTasks

    -
    public void postOpenDeployTasks(RegionServerServices.PostOpenDeployContext context)
    +
    public void postOpenDeployTasks(RegionServerServices.PostOpenDeployContext context)
                              throws org.apache.zookeeper.KeeperException,
                                     IOException
    Description copied from interface: RegionServerServices
    @@ -2963,7 +2963,7 @@ implements
  • reportRegionStateTransition

    -
    public boolean reportRegionStateTransition(org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionStateTransition.TransitionCode code,
    +
    public boolean reportRegionStateTransition(org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionStateTransition.TransitionCode code,
                                       HRegionInfo... hris)
    Description copied from interface: RegionServerServices
    Notify master that a handler requests to change a region state
    @@ -2979,7 +2979,7 @@ implements
  • reportRegionStateTransition

    -
    public boolean reportRegionStateTransition(org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionStateTransition.TransitionCode code,
    +
    public boolean reportRegionStateTransition(org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionStateTransition.TransitionCode code,
                                       long openSeqNum,
                                       HRegionInfo... hris)
    Description copied from interface: RegionServerServices
    @@ -2996,7 +2996,7 @@ implements
  • reportRegionStateTransition

    -
    public boolean reportRegionStateTransition(RegionServerServices.RegionStateTransitionContext context)
    +
    public boolean reportRegionStateTransition(RegionServerServices.RegionStateTransitionContext context)
    Description copied from interface: RegionServerServices
    Notify master that a handler requests to change a region state
    @@ -3011,7 +3011,7 @@ implements
  • triggerFlushInPrimaryRegion

    -
    void triggerFlushInPrimaryRegion(HRegion region)
    +
    void triggerFlushInPrimaryRegion(HRegion region)
    Trigger a flush in the primary region replica if this region is a secondary replica. Does not block this thread. See RegionReplicaFlushHandler for details.
  • @@ -3022,7 +3022,7 @@ implements
  • getRpcServer

    -
    public RpcServerInterface getRpcServer()
    +
    public RpcServerInterface getRpcServer()
    Description copied from interface: RegionServerServices
    Returns a reference to the region server's RPC server
    @@ -3037,7 +3037,7 @@ implements
  • getRSRpcServices

    -
    public RSRpcServices getRSRpcServices()
    +
    public RSRpcServices getRSRpcServices()
  • @@ -3046,7 +3046,7 @@ implements
  • abort

    -
    public void abort(String reason,
    +
    public void abort(String reason,
              Throwable cause)
    Cause the server to exit without closing the regions it is serving, the log it is using and without notifying the master. Used unit testing and on @@ -3063,7 +3063,7 @@ implements
  • abort

    -
    public void abort(String reason)
    +
    public void abort(String reason)
    See Also:
    abort(String, Throwable)
  • @@ -3073,7 +3073,7 @@ implements
  • isAborted

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

    -
    protected void kill()
    +
    protected void kill()
  • @@ -3097,7 +3097,7 @@ implements
  • sendShutdownInterrupt

    -
    protected void sendShutdownInterrupt()
    +
    protected void sendShutdownInterrupt()
    Called on stop/abort before closing the cluster connection and meta locator.
  • @@ -3107,7 +3107,7 @@ implements
  • stopServiceThreads

    -
    protected void stopServiceThreads()
    +
    protected void stopServiceThreads()
    Wait on all threads to finish. Presumption is that all closes and stops have already been called.
  • @@ -3118,7 +3118,7 @@ implements
  • getReplicationSourceService

    -
    ReplicationSourceService getReplicationSourceService()
    +
    ReplicationSourceService getReplicationSourceService()
    Returns:
    Return the object that implements the replication source service.
  • @@ -3129,7 +3129,7 @@ implements
  • getReplicationSinkService

    -
    ReplicationSinkService getReplicationSinkService()
    +
    ReplicationSinkService getReplicationSinkService()
    Returns:
    Return the object that implements the replication sink service.
  • @@ -3140,7 +3140,7 @@ implements
  • createRegionServerStatusStub

    -
    protected ServerName createRegionServerStatusStub()
    +
    protected ServerName createRegionServerStatusStub()
    Get the current master from ZooKeeper and open the RPC connection to it. To get a fresh connection, the current rssStub must be null. Method will block until a master is available. You can break from this @@ -3154,7 +3154,7 @@ implements
  • keepLooping

    -
    private boolean keepLooping()
    +
    private boolean keepLooping()
    Returns:
    True if we should break loop because cluster is going down or this server has been stopped or hdfs has gone bad.
  • @@ -3165,7 +3165,7 @@ implements
  • reportForDuty

    -
    private org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse reportForDuty()
    +
    private org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse reportForDuty()
                                                                                                                    throws IOException
    Throws:
    IOException
    @@ -3177,7 +3177,7 @@ implements
  • getLastSequenceId

    -
    public org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionStoreSequenceIds getLastSequenceId(byte[] encodedRegionName)
    +
    public org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionStoreSequenceIds getLastSequenceId(byte[] encodedRegionName)
    Specified by:
    getLastSequenceId in interface LastSequenceId
    @@ -3192,7 +3192,7 @@ implements
  • closeAllRegions

    -
    protected void closeAllRegions(boolean abort)
    +
    protected void closeAllRegions(boolean abort)
    Closes all regions. Called on our way out. Assumes that its not possible for new regions to be added to onlineRegions while this method runs.
    @@ -3204,7 +3204,7 @@ implements
  • closeMetaTableRegions

    -
    void closeMetaTableRegions(boolean abort)
    +
    void closeMetaTableRegions(boolean abort)
    Close meta region if we carry it
    Parameters:
    abort - Whether we're running an abort.
  • @@ -3215,7 +3215,7 @@ implements
  • closeUserRegions

    -
    void closeUserRegions(boolean abort)
    +
    void closeUserRegions(boolean abort)
    Schedule closes on all user regions. Should be safe calling multiple times because it wont' close regions that are already closed or that are closing.
    @@ -3228,7 +3228,7 @@ implements
  • getInfoServer

    -
    public InfoServer getInfoServer()
    +
    public InfoServer getInfoServer()
    Returns:
    the info server
  • @@ -3238,7 +3238,7 @@ implements
  • isStopped

    -
    public boolean isStopped()
    +
    public boolean isStopped()
    Specified by:
    isStopped in interface Stoppable
    @@ -3251,7 +3251,7 @@ implements
  • isStopping

    -
    public boolean isStopping()
    +
    public boolean isStopping()
    Specified by:
    isStopping in interface RegionServerServices
    @@ -3264,7 +3264,7 @@ implements
  • getRecoveringRegions

    -
    public Map<String,RegiongetRecoveringRegions()
    +
    public Map<String,RegiongetRecoveringRegions()
    Specified by:
    getRecoveringRegions in interface RegionServerServices
    @@ -3277,7 +3277,7 @@ implements
  • getConfiguration

    -
    public org.apache.hadoop.conf.Configuration getConfiguration()
    +
    public org.apache.hadoop.conf.Configuration getConfiguration()
    Description copied from interface: Server
    Gets the configuration object for this server.
    @@ -3292,7 +3292,7 @@ implements
  • getWriteLock

    -
    ReentrantReadWriteLock.WriteLock getWriteLock()
    +
    ReentrantReadWriteLock.WriteLock getWriteLock()
    Returns:
    the write lock for the server
  • @@ -3302,7 +3302,7 @@ implements
  • getNumberOfOnlineRegions

    -
    public int getNumberOfOnlineRegions()
    +
    public int getNumberOfOnlineRegions()
  • @@ -3311,7 +3311,7 @@ implements
  • isOnlineRegionsEmpty

    -
    boolean isOnlineRegionsEmpty()
    +
    boolean isOnlineRegionsEmpty()
  • @@ -3320,7 +3320,7 @@ implements
  • getOnlineRegionsLocalContext

    -
    public Collection<RegiongetOnlineRegionsLocalContext()
    +
    public Collection<RegiongetOnlineRegionsLocalContext()
    For tests, web ui and metrics. This method will only work if HRegionServer is in the same JVM as client; HRegion cannot be serialized to cross an rpc.
    @@ -3332,7 +3332,7 @@ implements
  • addToOnlineRegions

    -
    public void addToOnlineRegions(Region region)
    +
    public void addToOnlineRegions(Region region)
    Description copied from interface: OnlineRegions
    Add to online regions.
    @@ -3347,7 +3347,7 @@ implements
  • getCopyOfOnlineRegionsSortedBySize

    -
    SortedMap<Long,RegiongetCopyOfOnlineRegionsSortedBySize()
    +
    SortedMap<Long,RegiongetCopyOfOnlineRegionsSortedBySize()
    Returns:
    A new Map of online regions sorted by region size with the first entry being the biggest. If two regions are the same size, then the last one found wins; i.e. this method may NOT return all regions.
    @@ -3359,7 +3359,7 @@ implements
  • getStartcode

    -
    public long getStartcode()
    +
    public long getStartcode()
    Returns:
    time stamp in millis of when this region server was started
  • @@ -3369,7 +3369,7 @@ implements
  • getFlushRequester

    -
    public FlushRequester getFlushRequester()
    +
    public FlushRequester getFlushRequester()
    Specified by:
    getFlushRequester in interface RegionServerServices
    @@ -3382,7 +3382,7 @@ implements
  • getMostLoadedRegions

    -
    protected HRegionInfo[] getMostLoadedRegions()
    +
    protected HRegionInfo[] getMostLoadedRegions()
    Get the top N most loaded regions this server is serving so we can tell the master which regions it can reallocate if we're overloaded. TODO: actually calculate which regions are most loaded. (Right now, we're just grabbing @@ -3395,7 +3395,7 @@ implements
  • getLeases

    -
    public Leases getLeases()
    +
    public Leases getLeases()
    Specified by:
    getLeases in interface RegionServerServices
    @@ -3408,7 +3408,7 @@ implements
  • getRootDir

    -
    protected org.apache.hadoop.fs.Path getRootDir()
    +
    protected org.apache.hadoop.fs.Path getRootDir()
    Returns:
    Return the rootDir.
  • @@ -3418,7 +3418,7 @@ implements
  • getFileSystem

    -
    public org.apache.hadoop.fs.FileSystem getFileSystem()
    +
    public org.apache.hadoop.fs.FileSystem getFileSystem()
    Specified by:
    getFileSystem in interface RegionServerServices
    @@ -3431,7 +3431,7 @@ implements
  • toString

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

    -
    public int getThreadWakeFrequency()
    +
    public int getThreadWakeFrequency()
    Interval at which threads should run
    Returns:
    the interval
  • @@ -3455,7 +3455,7 @@ implements
  • getZooKeeper

    -
    public ZooKeeperWatcher getZooKeeper()
    +
    public ZooKeeperWatcher getZooKeeper()
    Description copied from interface: Server
    Gets the ZooKeeper instance for this server.
    @@ -3470,7 +3470,7 @@ implements
  • getCoordinatedStateManager

    -
    public BaseCoordinatedStateManager getCoordinatedStateManager()
    +
    public BaseCoordinatedStateManager getCoordinatedStateManager()
    Description copied from interface: Server
    Get CoordinatedStateManager instance for this server.
    @@ -3485,7 +3485,7 @@ implements
  • getServerName

    -
    public ServerName getServerName()
    +
    public ServerName getServerName()
    Specified by:
    getServerName in interface Server
    @@ -3498,7 +3498,7 @@ implements
  • getCompactionRequester

    -
    public CompactionRequestor getCompactionRequester()
    +
    public CompactionRequestor getCompactionRequester()
    Specified by:
    getCompactionRequester in interface RegionServerServices
    @@ -3511,7 +3511,7 @@ implements
  • getRegionServerCoprocessorHost

    -
    public RegionServerCoprocessorHost getRegionServerCoprocessorHost()
    +
    public RegionServerCoprocessorHost getRegionServerCoprocessorHost()
  • @@ -3520,7 +3520,7 @@ implements
  • getRegionsInTransitionInRS

    -
    public ConcurrentMap<byte[],BooleangetRegionsInTransitionInRS()
    +
    public ConcurrentMap<byte[],BooleangetRegionsInTransitionInRS()
    Description copied from interface: RegionServerServices
    Get the regions that are currently being opened or closed in the RS
    @@ -3535,7 +3535,7 @@ implements
  • getExecutorService

    -
    public ExecutorService getExecutorService()
    +
    public ExecutorService getExecutorService()
    Specified by:
    getExecutorService in interface RegionServerServices
    @@ -3548,7 +3548,7 @@ implements
  • getChoreService

    -
    public ChoreService getChoreService()
    +
    public ChoreService getChoreService()
    Specified by:
    getChoreService in interface Server
    @@ -3561,7 +3561,7 @@ implements
  • getRegionServerQuotaManager

    -
    public RegionServerQuotaManager getRegionServerQuotaManager()
    +
    public RegionServerQuotaManager getRegionServerQuotaManager()
    Specified by:
    getRegionServerQuotaManager in interface RegionServerServices
    @@ -3574,7 +3574,7 @@ implements
  • createNewReplicationInstance

    -
    private static void createNewReplicationInstance(org.apache.hadoop.conf.Configuration conf,
    +
    private static void createNewReplicationInstance(org.apache.hadoop.conf.Configuration conf,
                                     HRegionServer server,
                                     org.apache.hadoop.fs.FileSystem fs,
                                     org.apache.hadoop.fs.Path logDir,
    @@ -3591,7 +3591,7 @@ implements 
     
  • newReplicationInstance

    -
    private static ReplicationService newReplicationInstance(String classname,
    +
    private static ReplicationService newReplicationInstance(String classname,
                                             org.apache.hadoop.conf.Configuration conf,
                                             HRegionServer server,
                                             org.apache.hadoop.fs.FileSystem fs,
    @@ -3608,7 +3608,7 @@ implements 
     
  • constructRegionServer

    -
    public static HRegionServer constructRegionServer(Class<? extends HRegionServer> regionServerClass,
    +
    public static HRegionServer constructRegionServer(Class<? extends HRegionServer> regionServerClass,
                                       org.apache.hadoop.conf.Configuration conf2,
                                       CoordinatedStateManager cp)
    Utility for constructing an instance of the passed HRegionServer class.
    @@ -3622,7 +3622,7 @@ implements
  • main

    -
    public static void main(String[] args)
    +
    public static void main(String[] args)
                      throws Exception
    Throws:
    Exception
    See Also:
    HRegionServerCommandLine
    @@ -3634,7 +3634,7 @@ implements
  • getOnlineRegions

    -
    public List<RegiongetOnlineRegions(TableName tableName)
    +
    public List<RegiongetOnlineRegions(TableName tableName)
    Gets the online regions of the specified table. This method looks at the in-memory onlineRegions. It does not go to hbase:meta. Only returns online regions. If a region on this table has been @@ -3654,7 +3654,7 @@ implements
  • getOnlineRegions

    -
    public List<RegiongetOnlineRegions()
    +
    public List<RegiongetOnlineRegions()
    Description copied from interface: OnlineRegions
    Get all online regions in this RS.
    @@ -3669,7 +3669,7 @@ implements
  • getOnlineTables

    -
    public Set<TableNamegetOnlineTables()
    +
    public Set<TableNamegetOnlineTables()
    Gets the online tables in this RS. This method looks at the in-memory onlineRegions.
    @@ -3684,7 +3684,7 @@ implements
  • getRegionServerCoprocessors

    -
    public String[] getRegionServerCoprocessors()
    +
    public String[] getRegionServerCoprocessors()
  • @@ -3693,7 +3693,7 @@ implements
  • closeRegionIgnoreErrors

    -
    private void closeRegionIgnoreErrors(HRegionInfo region,
    +
    private void closeRegionIgnoreErrors(HRegionInfo region,
                                boolean abort)
    Try to close the region, logs a warning on failure but continues.
    Parameters:
    region - Region to close
    @@ -3705,7 +3705,7 @@ implements
  • closeRegion

    -
    protected boolean closeRegion(String encodedName,
    +
    protected boolean closeRegion(String encodedName,
                       boolean abort,
                       ServerName sn)
                            throws NotServingRegionException
    @@ -3732,7 +3732,7 @@ implements
  • getOnlineRegion

    -
    public Region getOnlineRegion(byte[] regionName)
    +
    public Region getOnlineRegion(byte[] regionName)
    Parameters:
    regionName -
    Returns:
    HRegion for the passed binary regionName or null if named region is not member of the online regions.
    @@ -3744,7 +3744,7 @@ implements
  • getRegionBlockLocations

    -
    public InetSocketAddress[] getRegionBlockLocations(String encodedRegionName)
    +
    public InetSocketAddress[] getRegionBlockLocations(String encodedRegionName)
  • @@ -3753,7 +3753,7 @@ implements
  • getFromOnlineRegions

    -
    public Region getFromOnlineRegions(String encodedRegionName)
    +
    public Region getFromOnlineRegions(String encodedRegionName)
    Description copied from interface: OnlineRegions
    Return Region instance. Only works if caller is in same context, in same JVM. Region is not @@ -3771,7 +3771,7 @@ implements
  • removeFromOnlineRegions

    -
    public boolean removeFromOnlineRegions(Region r,
    +
    public boolean removeFromOnlineRegions(Region r,
                                   ServerName destination)
    Description copied from interface: OnlineRegions
    This method removes Region corresponding to hri from the Map of onlineRegions.
    @@ -3788,7 +3788,7 @@ implements
  • getRegion

    -
    protected Region getRegion(byte[] regionName)
    +
    protected Region getRegion(byte[] regionName)
                         throws NotServingRegionException
    Protected utility method for safely obtaining an HRegion handle.
    Parameters:
    regionName - Name of online HRegion to return
    @@ -3803,7 +3803,7 @@ implements
  • getRegionByEncodedName

    -
    public Region getRegionByEncodedName(String encodedRegionName)
    +
    public Region getRegionByEncodedName(String encodedRegionName)
                                   throws NotServingRegionException
    Throws:
    NotServingRegionException
    @@ -3815,7 +3815,7 @@ implements
  • getRegionByEncodedName

    -
    protected Region getRegionByEncodedName(byte[] regionName,
    +
    protected Region getRegionByEncodedName(byte[] regionName,
                                 String encodedRegionName)
                                      throws NotServingRegionException
    Throws:
    @@ -3828,7 +3828,7 @@ implements
  • cleanup

    -
    private Throwable cleanup(Throwable t,
    +
    private Throwable cleanup(Throwable t,
                     String msg)
  • @@ -3838,7 +3838,7 @@ implements
  • convertThrowableToIOE

    -
    protected IOException convertThrowableToIOE(Throwable t,
    +
    protected IOException convertThrowableToIOE(Throwable t,
                                     String msg)
  • @@ -3848,7 +3848,7 @@ implements
  • checkFileSystem

    -
    public boolean checkFileSystem()
    +
    public boolean checkFileSystem()
    Checks to see if the file system is still accessible. If not, sets abortRequested and stopRequested
    Returns:
    false if file system is not available
    @@ -3860,7 +3860,7 @@ implements
  • updateRegionFavoredNodesMapping

    -
    public void updateRegionFavoredNodesMapping(String encodedRegionName,
    +
    public void updateRegionFavoredNodesMapping(String encodedRegionName,
                                        List<org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerName> favoredNodes)
    Description copied from interface: FavoredNodesForRegion
    Used to update the favo