public static class MiniHBaseCluster.MiniHBaseClusterRegionServer extends org.apache.hadoop.hbase.regionserver.HRegionServer
| Modifier and Type | Field and Description | 
|---|---|
(package private) static Set<org.apache.hadoop.hbase.ServerName> | 
killedServers
List of RegionServers killed so far. 
 | 
private Thread | 
shutdownThread  | 
private org.apache.hadoop.hbase.security.User | 
user  | 
ABORT_TIMEOUT, ABORT_TIMEOUT_TASK, cacheConfig, cacheFlusher, clusterConnection, clusterId, clusterStatusTracker, compactSplitThread, conf, configurationManager, csm, executorService, fs, fsOk, fsUtilizationChore, hMemManager, infoServer, leases, lock, MASTER_HOSTNAME_KEY, metaTableLocator, movedRegions, msgInterval, numRegionsToReport, onlineRegions, regionFavoredNodesMap, REGIONSERVER, regionsInTransitionInRS, replicationSinkHandler, replicationSourceHandler, rpcServices, secureBulkLoadManager, serverName, sleeper, startcode, tableDescriptors, TEST_SKIP_REPORTING_TRANSITION, threadWakeFrequency, useThisHostnameInstead, walFactory, walFs, walRoller, zooKeeper| Constructor and Description | 
|---|
MiniHBaseClusterRegionServer(org.apache.hadoop.conf.Configuration conf)  | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
abort(String reason,
     Throwable cause)  | 
private void | 
abortRegionServer(String reason,
                 Throwable cause)  | 
protected void | 
handleReportForDutyResponse(org.apache.hadoop.hbase.shaded.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse c)  | 
protected void | 
kill()  | 
void | 
run()  | 
private void | 
runRegionServer()  | 
abort, addRegion, addToMovedRegions, canCreateBaseZNode, canUpdateTableDescriptor, checkFileSystem, cleanMovedRegions, clearRegionBlockCache, closeAllRegions, closeAndOfflineRegionForSplitOrMerge, closeRegion, configureInfoServer, constructRegionServer, convertThrowableToIOE, createClusterConnection, createConnection, createRegionLoad, createRegionServerStatusStub, createRegionServerStatusStub, createRpcServices, execRegionServerService, getCacheConfig, getChoreService, getClusterConnection, getClusterId, getCompactionPressure, getCompactionRequestor, getCompactSplitThread, getConfiguration, getConfigurationManager, getConnection, getCoordinatedStateManager, getDumpServlet, getEventLoopGroupConfig, getExecutorService, getFavoredNodesForRegion, getFileSystem, getFlushPressure, getFlushRequester, getFlushThroughputController, getFsTableDescriptors, getHeapMemoryManager, getInfoServer, getLastSequenceId, getLeases, getMasterAddressTracker, getMetaTableLocator, getMetaTableObserver, getMetrics, getMostLoadedRegions, getNonceManager, getNumberOfOnlineRegions, getOnlineRegion, getOnlineRegionsLocalContext, getOnlineTables, getProcessName, getRegion, getRegion, getRegionBlockLocations, getRegionByEncodedName, getRegionByEncodedName, getRegions, getRegions, getRegionServerAccounting, getRegionServerCoprocessorHost, getRegionServerCoprocessors, getRegionServerMetrics, getRegionServerRpcQuotaManager, getRegionServerSpaceQuotaManager, getRegionsInTransitionInRS, getReplicationSourceService, getRootDir, getRpcServer, getRSRpcServices, getSecureBulkLoadManager, getServerName, getStartcode, getTableDescriptors, getThreadWakeFrequency, getUseThisHostnameInstead, getWAL, getWALFileSystem, getWalRoller, getWALRootDir, getWALs, getZooKeeper, initializeMemStoreChunkCreator, isAborted, isClusterUp, isOnline, isStopped, isStopping, login, main, movedRegionCleanerPeriod, onConfigurationChange, postOpenDeployTasks, regionLock, registerService, removeRegion, reportRegionSizesForQuotas, reportRegionStateTransition, sendShutdownInterrupt, setupClusterConnection, stop, stop, stopServiceThreads, toString, tryRegionServerReport, unassign, updateConfiguration, updateRegionFavoredNodesMapping, waitForMasterActive, waitForServerOnline, walRollRequestFinishedprivate Thread shutdownThread
private org.apache.hadoop.hbase.security.User user
static Set<org.apache.hadoop.hbase.ServerName> killedServers
public MiniHBaseClusterRegionServer(org.apache.hadoop.conf.Configuration conf) throws IOException, InterruptedException
IOExceptionInterruptedExceptionprotected void handleReportForDutyResponse(org.apache.hadoop.hbase.shaded.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse c) throws IOException
handleReportForDutyResponse in class org.apache.hadoop.hbase.regionserver.HRegionServerIOExceptionpublic void run()
private void runRegionServer()
protected void kill()
kill in class org.apache.hadoop.hbase.regionserver.HRegionServerpublic void abort(String reason, Throwable cause)
abort in interface org.apache.hadoop.hbase.Abortableabort in class org.apache.hadoop.hbase.regionserver.HRegionServerprivate void abortRegionServer(String reason, Throwable cause)
Copyright © 2007–2019 The Apache Software Foundation. All rights reserved.