Package org.apache.hadoop.hbase
Class SingleProcessHBaseCluster.MiniHBaseClusterRegionServer
java.lang.Object
java.lang.Thread
org.apache.hadoop.hbase.HBaseServerBase<org.apache.hadoop.hbase.regionserver.RSRpcServices>
org.apache.hadoop.hbase.regionserver.HRegionServer
org.apache.hadoop.hbase.SingleProcessHBaseCluster.MiniHBaseClusterRegionServer
- All Implemented Interfaces:
Runnable,org.apache.hadoop.hbase.Abortable,org.apache.hadoop.hbase.client.ConnectionRegistryEndpoint,org.apache.hadoop.hbase.conf.ConfigurationObserver,org.apache.hadoop.hbase.regionserver.FavoredNodesForRegion,org.apache.hadoop.hbase.regionserver.LastSequenceId,org.apache.hadoop.hbase.regionserver.MutableOnlineRegions,org.apache.hadoop.hbase.regionserver.OnlineRegions,org.apache.hadoop.hbase.regionserver.RegionServerServices,org.apache.hadoop.hbase.Server,org.apache.hadoop.hbase.Stoppable
- Direct Known Subclasses:
TestClientClusterMetrics.MyRegionServer,TestClientOperationTimeout.DelayedRegionServer,TestClientScannerTimeouts.RegionServerWithScanTimeout,TestCustomPriorityRpcControllerFactory.PriorityRegionServer,TestLocalHBaseCluster.MyHRegionServer,TestMasterMetrics.MyRegionServer,TestMetaShutdownHandler.MyRegionServer,TestRegionReplicaReplicationError.RSForTest,TestRegionReplicationForFlushMarker.RSForTest,TestRegionReplicationSinkCallbackAndFlushConcurrently.RSForTest,TestRegionServerReportForDuty.MyRegionServer,TestRegionServerScan.MyRegionServer,TestRSKilledWhenInitializing.RegisterAndDieRegionServer,TestScannerLeaseCount.MockedQuotaManagerRegionServer,TestScannerRPCScanMetrics.RegionServerWithScanMetrics,TestScannerTimeoutHandling.RegionServerWithScanTimeout,TestWakeUpUnexpectedProcedure.RSForTest
- Enclosing class:
- SingleProcessHBaseCluster
public static class SingleProcessHBaseCluster.MiniHBaseClusterRegionServer
extends org.apache.hadoop.hbase.regionserver.HRegionServer
Subclass so can get at protected methods (none at moment). Also, creates a FileSystem instance
per instantiation. Adds a shutdown own FileSystem on the way out. Shuts down own Filesystem
only, not All filesystems as the FileSystem system exit hook does.
-
Nested Class Summary
Nested classes/interfaces inherited from class java.lang.Thread
Thread.State, Thread.UncaughtExceptionHandlerNested classes/interfaces inherited from interface org.apache.hadoop.hbase.regionserver.RegionServerServices
org.apache.hadoop.hbase.regionserver.RegionServerServices.PostOpenDeployContext, org.apache.hadoop.hbase.regionserver.RegionServerServices.RegionStateTransitionContext -
Field Summary
FieldsModifier and TypeFieldDescription(package private) static Set<org.apache.hadoop.hbase.ServerName>List of RegionServers killed so far.private Threadprivate org.apache.hadoop.hbase.security.UserFields inherited from class org.apache.hadoop.hbase.regionserver.HRegionServer
REGIONSERVER, TEST_SKIP_REPORTING_TRANSITIONFields inherited from class org.apache.hadoop.hbase.HBaseServerBase
abortRequested, asyncClusterConnection, choreService, clusterStatusTracker, conf, configurationManager, csm, dataFs, dataRootDir, eventLoopGroupConfig, executorService, infoServer, metaRegionLocationCache, msgInterval, namedQueueRecorder, rpcServices, serverName, sleeper, startcode, stopped, tableDescriptors, userProvider, useThisHostnameInstead, walFs, walRootDir, zooKeeperFields inherited from class java.lang.Thread
MAX_PRIORITY, MIN_PRIORITY, NORM_PRIORITY -
Constructor Summary
Constructors -
Method Summary
Modifier and TypeMethodDescriptionvoidprivate voidabortRegionServer(String reason, Throwable cause) protected voidhandleReportForDutyResponse(org.apache.hadoop.hbase.shaded.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse c) protected voidkill()voidrun()private voidMethods inherited from class org.apache.hadoop.hbase.regionserver.HRegionServer
addRegion, cacheTableDescriptor, canCreateBaseZNode, canUpdateTableDescriptor, closeRegion, clusterMode, configureInfoServer, createNamedQueueRecord, createRegionLoad, createRegionServerStatusStub, createRpcServices, dumpRowLocks, finishRegionProcedure, getActiveMaster, getBackupMasters, getBlockCache, getBootstrapNodes, getBrokenStoreFileCleaner, getClusterId, getCompactedHFilesDischarger, getCompactionPressure, getCompactionRequestor, getCompactSplitThread, getCoprocessorHost, getDumpServlet, getFavoredNodesForRegion, getFlushPressure, getFlushRequester, getFlushThroughputController, getHeapMemoryManager, getLastSequenceId, getLeaseManager, getMasterAddressTracker, getMemStoreFlusher, getMetaLocations, getMetrics, getMobFileCache, getMovedRegion, getNonceManager, getNumberOfOnlineRegions, getOnlineRegion, getOnlineRegions, getOnlineRegionsLocalContext, getOnlineTables, getProcessName, getRegion, getRegion, getRegionByEncodedName, getRegionReplicationBufferManager, getRegions, getRegions, getRegionServerAccounting, getRegionServerCoprocessorHost, getRegionServerCoprocessors, getRegionServerRpcQuotaManager, getRegionServerSpaceQuotaManager, getRegionsInTransitionInRS, getReplicationSinkService, getReplicationSourceService, getRetryPauseTime, getRSMobFileCleanerChore, getRSRpcServices, getSecureBulkLoadManager, getUseThisHostnameInstead, getWAL, getWalFactory, getWalGroupsReplicationStatus, getWalRoller, getWALs, isClusterUp, isOnline, isStopping, login, main, movedRegionCacheExpiredTime, onConfigurationChange, postOpenDeployTasks, regionLock, registerService, remoteProcedureComplete, removeRegion, reportFileArchivalForQuotas, reportRegionSizesForQuotas, reportRegionStateTransition, stop, stop, stopChores, stopServiceThreads, tryRegionServerReport, unassign, updateRegionFavoredNodesMapping, waitForServerOnline, walRollRequestFinishedMethods inherited from class org.apache.hadoop.hbase.HBaseServerBase
closeClusterConnection, closeTableDescriptors, closeZooKeeper, createConnection, getAccessChecker, getAsyncClusterConnection, getChoreService, getConfiguration, getConfigurationManager, getCoordinatedStateManager, getDataRootDir, getEventLoopGroupConfig, getExecutorService, getFileSystem, getInfoServer, getMetaRegionLocationCache, getMsgInterval, getNamedQueueRecorder, getRpcServer, getRpcServices, getServerName, getStartcode, getTableDescriptors, getWALFileSystem, getWALRootDir, getZKPermissionWatcher, getZooKeeper, initializeFileSystem, initializeMemStoreChunkCreator, installShutdownHook, isAborted, isShutdownHookInstalled, isStopped, setAbortRequested, setupClusterConnection, shutdownChore, stopChoreService, stopExecutorService, stopInfoServer, toString, updateConfigurationMethods inherited from class java.lang.Thread
activeCount, checkAccess, clone, countStackFrames, currentThread, dumpStack, enumerate, getAllStackTraces, getContextClassLoader, getDefaultUncaughtExceptionHandler, getId, getName, getPriority, getStackTrace, getState, getThreadGroup, getUncaughtExceptionHandler, holdsLock, interrupt, interrupted, isAlive, isDaemon, isInterrupted, join, join, join, onSpinWait, resume, setContextClassLoader, setDaemon, setDefaultUncaughtExceptionHandler, setName, setPriority, setUncaughtExceptionHandler, sleep, sleep, start, stop, suspend, yieldMethods inherited from class java.lang.Object
equals, finalize, getClass, hashCode, notify, notifyAll, wait, wait, waitMethods inherited from interface org.apache.hadoop.hbase.Abortable
abort, isAbortedMethods inherited from interface org.apache.hadoop.hbase.regionserver.RegionServerServices
getAccessChecker, getExecutorService, getRpcServer, getTableDescriptors, getZKPermissionWatcherMethods inherited from interface org.apache.hadoop.hbase.Server
createConnection, getAsyncClusterConnection, getAsyncConnection, getChoreService, getConfiguration, getConnection, getCoordinatedStateManager, getFileSystem, getServerName, getZooKeeperMethods inherited from interface org.apache.hadoop.hbase.Stoppable
isStopped
-
Field Details
-
shutdownThread
-
user
-
killedServers
List of RegionServers killed so far. ServerName also comprises startCode of a server, so any restarted instances of the same server will have different ServerName and will not coincide with past dead ones. So there's no need to cleanup this list.
-
-
Constructor Details
-
MiniHBaseClusterRegionServer
public MiniHBaseClusterRegionServer(org.apache.hadoop.conf.Configuration conf) throws IOException, InterruptedException - Throws:
IOExceptionInterruptedException
-
-
Method Details
-
handleReportForDutyResponse
protected void handleReportForDutyResponse(org.apache.hadoop.hbase.shaded.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse c) throws IOException - Overrides:
handleReportForDutyResponsein classorg.apache.hadoop.hbase.regionserver.HRegionServer- Throws:
IOException
-
run
-
runRegionServer
-
kill
- Overrides:
killin classorg.apache.hadoop.hbase.regionserver.HRegionServer
-
abort
- Specified by:
abortin interfaceorg.apache.hadoop.hbase.Abortable- Overrides:
abortin classorg.apache.hadoop.hbase.regionserver.HRegionServer
-
abortRegionServer
-