public class OOMERegionServer extends org.apache.hadoop.hbase.regionserver.HRegionServer
put(byte[], Put)
is called, we add keep around
a reference to the batch. Use this class to test OOME extremes. Needs to be started manually as
in
${HBASE_HOME}/bin/hbase ./bin/hbase org.apache.hadoop.hbase.OOMERegionServer start
.Thread.State, Thread.UncaughtExceptionHandler
Modifier and Type | Field and Description |
---|---|
private List<org.apache.hadoop.hbase.client.Put> |
retainer |
ABORT_TIMEOUT, ABORT_TIMEOUT_TASK, clusterConnection, clusterId, clusterStatusTracker, compactedFileDischarger, conf, configurationManager, executorService, infoServer, metricsRegionServerImpl, msgInterval, nonceManager, online, REGIONSERVER, rpcServices, RS_HOSTNAME_DISABLE_MASTER_REVERSEDNS_KEY, serverName, sleeper, startcode, tableDescriptors, TEST_SKIP_REPORTING_TRANSITION, UNSAFE_RS_HOSTNAME_DISABLE_MASTER_REVERSEDNS_KEY, useThisHostnameInstead, zooKeeper
MAX_PRIORITY, MIN_PRIORITY, NORM_PRIORITY
Constructor and Description |
---|
OOMERegionServer(org.apache.hadoop.hbase.HBaseConfiguration conf) |
Modifier and Type | Method and Description |
---|---|
static void |
main(String[] args) |
void |
put(byte[] regionName,
org.apache.hadoop.hbase.client.Put put) |
abort, addRegion, buildRegionSpaceUseReportRequest, cacheTableDescriptor, canCreateBaseZNode, canUpdateTableDescriptor, checkFileSystem, clearRegionBlockCache, closeRegion, configureInfoServer, constructRegionServer, convertRegionSize, createClusterConnection, createConnection, createRegionLoad, createRegionLoad, createRegionServerStatusStub, createRpcServices, dumpRowLocks, execRegionServerService, executeProcedure, finishRegionProcedure, getAccessChecker, getActiveMaster, getBackupMasters, getBlockCache, getBrokenStoreFileCleaner, getChoreService, getClusterConnection, getClusterId, getCompactedHFilesDischarger, getCompactionPressure, getCompactionRequestor, getCompactSplitThread, getConfiguration, getConfigurationManager, getConnection, getCoordinatedStateManager, getCopyOfOnlineRegionsSortedByOffHeapSize, getCopyOfOnlineRegionsSortedByOnHeapSize, getDataRootDir, getDumpServlet, getEventLoopGroupConfig, getExecutorService, getFavoredNodesForRegion, getFileSystem, getFlushPressure, getFlushRequester, getFlushThroughputController, getHeapMemoryManager, getInfoServer, getLastSequenceId, getLeaseManager, getMasterAddressTracker, getMemStoreFlusher, getMetaRegionLocationCache, getMetrics, getMobFileCache, getMovedRegion, getNamedQueueRecorder, getNonceManager, getNumberOfOnlineRegions, getOnlineRegion, getOnlineRegions, getOnlineRegionsLocalContext, getOnlineTables, getProcessName, getRegion, getRegion, getRegionByEncodedName, getRegions, getRegions, getRegionServerAccounting, getRegionServerCoprocessorHost, getRegionServerCoprocessors, getRegionServerRpcQuotaManager, getRegionServers, getRegionServerSpaceQuotaManager, getRegionsInTransitionInRS, getReplicationSinkService, getReplicationSourceService, getRetryPauseTime, getRpcServer, getRSRpcServices, getSecureBulkLoadManager, getServerName, getStartcode, getTableDescriptors, getUseThisHostnameInstead, getWAL, getWalFactory, getWALFileSystem, getWalGroupsReplicationStatus, getWalRoller, getWALRootDir, getWALs, getZKPermissionWatcher, getZooKeeper, handleReportForDutyResponse, initializeMemStoreChunkCreator, isAborted, isClusterUp, isDataFileSystemOk, isOnline, isShutDown, isStopped, isStopping, kill, login, movedRegionCacheExpiredTime, onConfigurationChange, postOpenDeployTasks, regionLock, registerService, remoteProcedureComplete, removeFromMovedRegions, removeRegion, reportFileArchivalForQuotas, reportProcedureDone, reportRegionSizesForQuotas, reportRegionStateTransition, run, setAbortRequested, setupClusterConnection, shutdownChore, stop, stop, stopServiceThreads, submitRegionProcedure, toString, tryRegionServerReport, unassign, updateConfiguration, updateRegionFavoredNodesMapping, waitForMasterActive, waitForServerOnline, walRollRequestFinished
activeCount, checkAccess, clone, countStackFrames, currentThread, destroy, dumpStack, enumerate, getAllStackTraces, getContextClassLoader, getDefaultUncaughtExceptionHandler, getId, getName, getPriority, getStackTrace, getState, getThreadGroup, getUncaughtExceptionHandler, holdsLock, interrupt, interrupted, isAlive, isDaemon, isInterrupted, join, join, join, resume, setContextClassLoader, setDaemon, setDefaultUncaughtExceptionHandler, setName, setPriority, setUncaughtExceptionHandler, sleep, sleep, start, stop, stop, suspend, yield
public OOMERegionServer(org.apache.hadoop.hbase.HBaseConfiguration conf) throws IOException, InterruptedException
IOException
InterruptedException
public void put(byte[] regionName, org.apache.hadoop.hbase.client.Put put) throws IOException
IOException
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.