Uses of Class
org.apache.hadoop.hbase.regionserver.HRegion
Package
Description
Provides HBase Client
Provides implementations of
HFile
and HFile
BlockCache
.Provides
BucketCache
, an implementation of
BlockCache
.-
Uses of HRegion in org.apache.hadoop.hbase
Modifier and TypeMethodDescriptionHBaseTestingUtility.createLocalHRegion
(RegionInfo info, org.apache.hadoop.conf.Configuration conf, TableDescriptor desc, WAL wal) Deprecated.Create an HRegion that writes to the local tmp dirs with specified walHBaseTestingUtility.createLocalHRegion
(RegionInfo info, TableDescriptor desc) Deprecated.Create an HRegion that writes to the local tmp dirs.HBaseTestingUtility.createLocalHRegion
(TableDescriptor desc, byte[] startKey, byte[] endKey) Deprecated.Create an HRegion that writes to the local tmp dirsHBaseTestingUtility.createLocalHRegion
(TableName tableName, byte[] startKey, byte[] stopKey, org.apache.hadoop.conf.Configuration conf, boolean isReadOnly, Durability durability, WAL wal, byte[]... families) Deprecated.Return a region on which you must callHBaseTestingUtility.closeRegionAndWAL(HRegion)
when done.HBaseTestingUtility.createLocalHRegionWithInMemoryFlags
(TableName tableName, byte[] startKey, byte[] stopKey, org.apache.hadoop.conf.Configuration conf, boolean isReadOnly, Durability durability, WAL wal, boolean[] compactedMemStore, byte[]... families) Deprecated.static HRegion
HBaseTestingUtility.createRegionAndWAL
(RegionInfo info, org.apache.hadoop.fs.Path rootDir, org.apache.hadoop.conf.Configuration conf, TableDescriptor htd) Deprecated.Create a region with it's own WAL.static HRegion
HBaseTestingUtility.createRegionAndWAL
(RegionInfo info, org.apache.hadoop.fs.Path rootDir, org.apache.hadoop.conf.Configuration conf, TableDescriptor htd, boolean initialize) Deprecated.Create a region with it's own WAL.static HRegion
HBaseTestingUtility.createRegionAndWAL
(RegionInfo info, org.apache.hadoop.fs.Path rootDir, org.apache.hadoop.conf.Configuration conf, TableDescriptor htd, BlockCache blockCache) Deprecated.Create a region with it's own WAL.static HRegion
HBaseTestingUtility.createRegionAndWAL
(RegionInfo info, org.apache.hadoop.fs.Path rootDir, org.apache.hadoop.conf.Configuration conf, TableDescriptor htd, MobFileCache mobFileCache) Deprecated.Create a region with it's own WAL.HBaseTestingUtility.createTestRegion
(String tableName, ColumnFamilyDescriptor cd) Deprecated.HBaseTestingUtility.createTestRegion
(String tableName, ColumnFamilyDescriptor cd, BlockCache blockCache) Deprecated.HBaseTestingUtility.getSplittableRegion
(TableName tableName, int maxAttempts) Deprecated.Retrieves a splittable region randomly from tableNameModifier and TypeMethodDescriptionMiniHBaseCluster.findRegionsForTable
(TableName tableName) Deprecated.MiniHBaseCluster.getRegions
(byte[] tableName) Deprecated.MiniHBaseCluster.getRegions
(TableName tableName) Deprecated.MockRegionServerServices.getRegions()
MockRegionServerServices.getRegions
(TableName tableName) Modifier and TypeMethodDescriptionvoid
static void
HBaseTestingUtility.closeRegionAndWAL
(HRegion r) Deprecated.Close both the HRegionr
and it's underlying WAL.private void
MiniHBaseCluster.executeFlush
(HRegion region) Deprecated.int
HBaseTestingUtility.loadRegion
(HRegion r, byte[] f) Deprecated.int
HBaseTestingUtility.loadRegion
(HRegion r, byte[] f, boolean flush) Deprecated.Load region with rows from 'aaa' to 'zzz'.boolean
MockRegionServerServices.removeRegion
(HRegion r, ServerName destination) void
HBaseTestingUtility.verifyNumericRows
(HRegion region, byte[] f, int startRow, int endRow) Deprecated.void
HBaseTestingUtility.verifyNumericRows
(HRegion region, byte[] f, int startRow, int endRow, boolean present) Deprecated. -
Uses of HRegion in org.apache.hadoop.hbase.client
-
Uses of HRegion in org.apache.hadoop.hbase.io.hfile
Modifier and TypeMethodDescriptionstatic BlockCache
BlockCacheFactory.createBlockCache
(org.apache.hadoop.conf.Configuration conf, Map<String, HRegion> onlineRegions) private static BucketCache
BlockCacheFactory.createBucketCache
(org.apache.hadoop.conf.Configuration c, Map<String, HRegion> onlineRegions) BlockCacheUtil.listAllFilesNames
(Map<String, HRegion> onlineRegions) -
Uses of HRegion in org.apache.hadoop.hbase.io.hfile.bucket
-
Uses of HRegion in org.apache.hadoop.hbase.master.region
Modifier and TypeFieldDescription(package private) final HRegion
MasterRegion.region
private final HRegion
MasterRegionFlusherAndCompactor.region
Modifier and TypeMethodDescriptionprivate static HRegion
MasterRegion.bootstrap
(org.apache.hadoop.conf.Configuration conf, TableDescriptor td, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.fs.Path rootDir, org.apache.hadoop.fs.FileSystem walFs, org.apache.hadoop.fs.Path walRootDir, WALFactory walFactory, MasterRegionWALRoller walRoller, String serverName, boolean touchInitializingFlag) private static HRegion
MasterRegion.open
(org.apache.hadoop.conf.Configuration conf, TableDescriptor td, RegionInfo regionInfo, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.fs.Path rootDir, org.apache.hadoop.fs.FileSystem walFs, org.apache.hadoop.fs.Path walRootDir, WALFactory walFactory, MasterRegionWALRoller walRoller, String serverName) ModifierConstructorDescriptionprivate
MasterRegion
(Server server, HRegion region, WALFactory walFactory, MasterRegionFlusherAndCompactor flusherAndCompactor, MasterRegionWALRoller walRoller) (package private)
MasterRegionFlusherAndCompactor
(org.apache.hadoop.conf.Configuration conf, Abortable abortable, HRegion region, long flushSize, long flushPerChanges, long flushIntervalMs, int compactMin, org.apache.hadoop.fs.Path globalArchivePath, String archivedHFileSuffix) -
Uses of HRegion in org.apache.hadoop.hbase.procedure.flush
Modifier and TypeFieldDescription(package private) HRegion
FlushTableSubprocedure.RegionFlushTask.region
Modifier and TypeMethodDescriptionRegionServerFlushTableProcedureManager.getRegionsToFlush
(String table) Get the list of regions to flush for the table on this server It is possible that if a region moves somewhere between the calls we'll miss the region.ModifierConstructorDescription(package private)
RegionFlushTask
(HRegion region, List<byte[]> families) ModifierConstructorDescriptionFlushTableSubprocedure
(ProcedureMember member, ForeignExceptionDispatcher errorListener, long wakeFrequency, long timeout, List<HRegion> regions, String table, List<String> families, RegionServerFlushTableProcedureManager.FlushTableSubprocedurePool taskManager) -
Uses of HRegion in org.apache.hadoop.hbase.regionserver
Modifier and TypeFieldDescriptionprivate final HRegion
RSRpcServices.RegionScannerHolder.r
private HRegion
BusyRegionSplitPolicy.region
private final HRegion
CompactSplit.CompactionRunner.region
protected HRegion
FlushPolicy.region
The region configured for this flush policy.protected final HRegion
HRegion.BatchOperation.region
private final HRegion
HStore.region
private final HRegion
MemStoreFlusher.FlushRegionEntry.region
private final HRegion
MetricsRegionWrapperImpl.region
(package private) HRegion
RegionCoprocessorHost.region
The regionprotected final HRegion
RegionScannerImpl.region
private final HRegion
RegionServerServices.PostOpenDeployContext.region
private final HRegion
RegionServicesForStores.region
protected HRegion
RegionSplitPolicy.region
The region configured for this split policy.Modifier and TypeFieldDescriptionSecureBulkLoadManager.fsCreatedListener
HRegionServer.onlineRegions
Map of regions currently being served by this region server.Modifier and TypeMethodDescriptionstatic HRegion
HRegion.createHRegion
(org.apache.hadoop.conf.Configuration conf, RegionInfo regionInfo, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.fs.Path tableDir, TableDescriptor tableDesc) Create a region under the given table directory.static HRegion
HRegion.createHRegion
(RegionInfo info, org.apache.hadoop.fs.Path rootDir, org.apache.hadoop.conf.Configuration conf, TableDescriptor hTableDescriptor, WAL wal) static HRegion
HRegion.createHRegion
(RegionInfo info, org.apache.hadoop.fs.Path rootDir, org.apache.hadoop.conf.Configuration conf, TableDescriptor hTableDescriptor, WAL wal, boolean initialize) Convenience method creating new HRegions.static HRegion
HRegion.createHRegion
(RegionInfo info, org.apache.hadoop.fs.Path rootDir, org.apache.hadoop.conf.Configuration conf, TableDescriptor hTableDescriptor, WAL wal, boolean initialize, RegionServerServices rsRpcServices) Convenience method creating new HRegions.private HRegion
MemStoreFlusher.getBiggestMemStoreOfRegionReplica
(SortedMap<Long, Collection<HRegion>> regionsBySize, Set<HRegion> excludedRegions) private HRegion
MemStoreFlusher.getBiggestMemStoreRegion
(SortedMap<Long, Collection<HRegion>> regionsBySize, Set<HRegion> excludedRegions, boolean checkStoreFileCount) HStore.getHRegion()
HRegionServer.getOnlineRegion
(byte[] regionName) protected HRegion
HRegionServer.getRegion
(byte[] regionName) Protected Utility method for safely obtaining an HRegion handle.RegionServerServices.PostOpenDeployContext.getRegion()
RSRpcServices.getRegion
(org.apache.hadoop.hbase.shaded.protobuf.generated.HBaseProtos.RegionSpecifier regionSpecifier) Find the HRegion based on a region specifierprivate HRegion
HRegionServer.getRegionByEncodedName
(byte[] regionName, String encodedRegionName) HRegionServer.getRegionByEncodedName
(String encodedRegionName) static HRegion
HRegion.newHRegion
(org.apache.hadoop.fs.Path tableDir, WAL wal, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.conf.Configuration conf, RegionInfo regionInfo, TableDescriptor htd, RegionServerServices rsServices) A utility method to create new instances of HRegion based on theHConstants.REGION_IMPL
configuration property.static HRegion
HRegion.openHRegion
(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.fs.Path rootDir, RegionInfo info, TableDescriptor htd, WAL wal) Open a Region.static HRegion
HRegion.openHRegion
(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.fs.Path rootDir, RegionInfo info, TableDescriptor htd, WAL wal, RegionServerServices rsServices, CancelableProgressable reporter) Open a Region.static HRegion
HRegion.openHRegion
(org.apache.hadoop.fs.Path rootDir, RegionInfo info, TableDescriptor htd, WAL wal, org.apache.hadoop.conf.Configuration conf) Open a Region.static HRegion
HRegion.openHRegion
(org.apache.hadoop.fs.Path rootDir, RegionInfo info, TableDescriptor htd, WAL wal, org.apache.hadoop.conf.Configuration conf, RegionServerServices rsServices, CancelableProgressable reporter) Open a Region.static HRegion
HRegion.openHRegion
(RegionInfo info, TableDescriptor htd, WAL wal, org.apache.hadoop.conf.Configuration conf) Open a Region.static HRegion
HRegion.openHRegion
(RegionInfo info, TableDescriptor htd, WAL wal, org.apache.hadoop.conf.Configuration conf, RegionServerServices rsServices, CancelableProgressable reporter) Open a Region.static HRegion
HRegion.openHRegion
(HRegion other, CancelableProgressable reporter) Useful when reopening a closed region (normally for unit tests)private HRegion
HRegion.openHRegion
(CancelableProgressable reporter) Open HRegion.static HRegion
HRegion.openHRegionFromTableDir
(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.fs.Path tableDir, RegionInfo info, TableDescriptor htd, WAL wal, RegionServerServices rsServices, CancelableProgressable reporter) Open a Region.static HRegion
HRegion.openReadOnlyFileSystemHRegion
(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.fs.Path tableDir, RegionInfo info, TableDescriptor htd) Open a Region on a read-only file-system (like hdfs snapshots)static HRegion
HRegion.warmupHRegion
(RegionInfo info, TableDescriptor htd, WAL wal, org.apache.hadoop.conf.Configuration conf, RegionServerServices rsServices, CancelableProgressable reporter) Modifier and TypeMethodDescription(package private) SortedMap<Long,
Collection<HRegion>> HRegionServer.getCopyOfOnlineRegionsSortedByOffHeapSize()
(package private) SortedMap<Long,
Collection<HRegion>> HRegionServer.getCopyOfOnlineRegionsSortedByOnHeapSize()
HRegionServer.getOnlineRegions()
HRegionServer.getOnlineRegionsLocalContext()
For tests, web ui and metrics.HRegionServer.getRegions()
HRegionServer.getRegions
(TableName tableName) Gets the online regions of the specified table.RegionServerServices.getRegions()
RegionServerServices.getRegions
(TableName tableName) RSRpcServices.getRegions
(List<org.apache.hadoop.hbase.shaded.protobuf.generated.HBaseProtos.RegionSpecifier> regionSpecifiers, CacheEvictionStatsBuilder stats) Find the List of HRegions based on a list of region specifiersModifier and TypeMethodDescriptionprivate void
HRegionServer.addRegion
(SortedMap<Long, Collection<HRegion>> sortedRegions, HRegion region, long size) void
void
Add to online regions.RSRpcServices.addScanner
(String scannerName, RegionScanner s, Shipper shipper, HRegion r, boolean needCursor, boolean fullRegionScan) private Result
RSRpcServices.append
(HRegion region, OperationQuota quota, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MutationProto mutation, CellScanner cellScanner, long nonceGroup, ActivePolicyEnforcement spaceQuota, RpcCallContext context) Execute an append mutation.MetricsRegionServerWrapperImpl.RegionMetricAggregate.calculateReadWriteDeltas
(HRegion r, Map<String, ArrayList<Long>> requestsCountCache) private CheckAndMutateResult
RSRpcServices.checkAndMutate
(HRegion region, List<org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.Action> actions, CellScanner cellScanner, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.Condition condition, long nonceGroup, ActivePolicyEnforcement spaceQuotaEnforcement) private CheckAndMutateResult
RSRpcServices.checkAndMutate
(HRegion region, OperationQuota quota, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MutationProto mutation, CellScanner cellScanner, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.Condition condition, long nonceGroup, ActivePolicyEnforcement spaceQuota, RpcCallContext context) private void
RSRpcServices.checkCellSizeLimit
(HRegion r, Mutation m) void
SecureBulkLoadManager.cleanupBulkLoad
(HRegion region, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.CleanupBulkLoadRequest request) private void
RSRpcServices.closeScanner
(HRegion region, RegionScanner scanner, String scannerName, RpcCallContext context, boolean isError) protected void
BusyRegionSplitPolicy.configureForRegion
(HRegion region) protected void
ConstantSizeRegionSplitPolicy.configureForRegion
(HRegion region) protected void
DelimitedKeyPrefixRegionSplitPolicy.configureForRegion
(HRegion region) Deprecated.protected void
FlushAllLargeStoresPolicy.configureForRegion
(HRegion region) protected void
FlushNonSloppyStoresFirstPolicy.configureForRegion
(HRegion region) protected void
FlushPolicy.configureForRegion
(HRegion region) Upon construction, this method will be called with the region to be governed.protected void
IncreasingToUpperBoundRegionSplitPolicy.configureForRegion
(HRegion region) protected void
KeyPrefixRegionSplitPolicy.configureForRegion
(HRegion region) Deprecated.protected void
RegionSplitPolicy.configureForRegion
(HRegion region) Upon construction, this method will be called with the region to be governed.static FlushPolicy
Create the FlushPolicy configured for the given table.static RegionSplitPolicy
Create the RegionSplitPolicy configured for the given table.(package private) org.apache.hadoop.hbase.shaded.protobuf.generated.ClusterStatusProtos.RegionLoad
HRegionServer.createRegionLoad
(HRegion r, org.apache.hadoop.hbase.shaded.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder regionLoadBldr, org.apache.hadoop.hbase.shaded.protobuf.generated.HBaseProtos.RegionSpecifier.Builder regionSpecifier) private void
RSRpcServices.delete
(HRegion region, OperationQuota quota, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MutationProto mutation, CellScanner cellScanner, ActivePolicyEnforcement spaceQuota) private void
RSRpcServices.doAtomicBatchOp
(org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.RegionActionResult.Builder builder, HRegion region, OperationQuota quota, List<org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.Action> mutations, CellScanner cells, long nonceGroup, ActivePolicyEnforcement spaceQuotaEnforcement) private void
RSRpcServices.doBatchOp
(org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.RegionActionResult.Builder builder, HRegion region, OperationQuota quota, List<org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.Action> mutations, CellScanner cells, long nonceGroup, ActivePolicyEnforcement spaceQuotaEnforcement, boolean atomic) Execute a list of mutations.private void
RSRpcServices.doNonAtomicBatchOp
(org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.RegionActionResult.Builder builder, HRegion region, OperationQuota quota, List<org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.Action> mutations, CellScanner cells, ActivePolicyEnforcement spaceQuotaEnforcement) private List<ExtendedCellScannable>
RSRpcServices.doNonAtomicRegionMutation
(HRegion region, OperationQuota quota, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.RegionAction actions, CellScanner cellScanner, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.RegionActionResult.Builder builder, List<ExtendedCellScannable> cellsToReturn, long nonceGroup, RSRpcServices.RegionScannersCloseCallBack closeCallBack, RpcCallContext context, ActivePolicyEnforcement spaceQuotaEnforcement) Run through the regionMutationrm
and per Mutation, do the work, and then when done, add an instance of aClientProtos.ResultOrException
that corresponds to each Mutation.private OperationStatus[]
RSRpcServices.doReplayBatchOp
(HRegion region, List<WALSplitUtil.MutationReplay> mutations, long replaySeqId) Deprecated.Since 3.0.0, will be removed in 4.0.0.private org.apache.hbase.thirdparty.com.google.protobuf.Message
RSRpcServices.execServiceOnRegion
(HRegion region, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.CoprocessorServiceCall serviceCall) private boolean
MemStoreFlusher.flushRegion
(HRegion region, boolean emergencyFlush, List<byte[]> families, FlushLifeCycleTracker tracker) Flush a region.private Result
RSRpcServices.get
(Get get, HRegion region, RSRpcServices.RegionScannersCloseCallBack closeCallBack, RpcCallContext context) private static long
MemStoreFlusher.getMemStoreDataSize
(HRegion r) Returns Return memstore data size or null ifr
is nullprivate static long
MemStoreFlusher.getMemStoreHeapSize
(HRegion r) Returns Return memstore heap size or null ifr
is nullprivate static long
MemStoreFlusher.getMemStoreOffHeapSize
(HRegion r) Returns Return memstore offheap size or null ifr
is nullprivate static boolean
private Result
RSRpcServices.increment
(HRegion region, OperationQuota quota, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MutationProto mutation, CellScanner cells, long nonceGroup, ActivePolicyEnforcement spaceQuota, RpcCallContext context) Execute an increment mutation.protected void
RegionScannerImpl.initializeKVHeap
(List<KeyValueScanner> scanners, List<KeyValueScanner> joinedScanners, HRegion region) protected void
ReversedRegionScannerImpl.initializeKVHeap
(List<KeyValueScanner> scanners, List<KeyValueScanner> joinedScanners, HRegion region) private boolean
RSRpcServices.isFullRegionScan
(Scan scan, HRegion region) private Pair<String,
RSRpcServices.RegionScannerHolder> RSRpcServices.newRegionScanner
(org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ScanRequest request, HRegion region, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ScanResponse.Builder builder) static HRegion
HRegion.openHRegion
(HRegion other, CancelableProgressable reporter) Useful when reopening a closed region (normally for unit tests)SecureBulkLoadManager.prepareBulkLoad
(HRegion region, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.PrepareBulkLoadRequest request) private void
RSRpcServices.put
(HRegion region, OperationQuota quota, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MutationProto mutation, CellScanner cellScanner, ActivePolicyEnforcement spaceQuota) private void
RSRpcServices.rejectIfInStandByState
(HRegion region) boolean
HRegionServer.removeRegion
(HRegion r, ServerName destination) boolean
MutableOnlineRegions.removeRegion
(HRegion r, ServerName destination) Removes the given Region from the list of onlineRegions.void
CompactSplit.requestCompaction
(HRegion region, String why, int priority, CompactionLifeCycleTracker tracker, User user) void
CompactSplit.requestCompaction
(HRegion region, HStore store, String why, int priority, CompactionLifeCycleTracker tracker, User user) private void
CompactSplit.requestCompactionInternal
(HRegion region, String why, int priority, boolean selectNow, CompactionLifeCycleTracker tracker, CompactSplit.CompactionCompleteTracker completeTracker, User user) protected void
CompactSplit.requestCompactionInternal
(HRegion region, HStore store, String why, int priority, boolean selectNow, CompactionLifeCycleTracker tracker, CompactSplit.CompactionCompleteTracker completeTracker, User user) boolean
FlushRequester.requestDelayedFlush
(HRegion region, long delay) Tell the listener the cache needs to be flushed after a delayboolean
MemStoreFlusher.requestDelayedFlush
(HRegion r, long delay) boolean
FlushRequester.requestFlush
(HRegion region, List<byte[]> families, FlushLifeCycleTracker tracker) Tell the listener the cache needs to be flushed.boolean
FlushRequester.requestFlush
(HRegion region, FlushLifeCycleTracker tracker) Tell the listener the cache needs to be flushed.boolean
MemStoreFlusher.requestFlush
(HRegion r, List<byte[]> families, FlushLifeCycleTracker tracker) boolean
MemStoreFlusher.requestFlush
(HRegion r, FlushLifeCycleTracker tracker) void
CompactSplit.requestSystemCompaction
(HRegion region, String why) void
CompactSplit.requestSystemCompaction
(HRegion region, HStore store, String why) void
CompactSplit.requestSystemCompaction
(HRegion region, HStore store, String why, boolean giveUpIfRequestedOrCompacting) SecureBulkLoadManager.secureBulkLoadHFiles
(HRegion region, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.BulkLoadHFileRequest request) SecureBulkLoadManager.secureBulkLoadHFiles
(HRegion region, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.BulkLoadHFileRequest request, List<String> clusterIds) private Optional<CompactionContext>
CompactSplit.selectCompaction
(HRegion region, HStore store, int priority, CompactionLifeCycleTracker tracker, CompactSplit.CompactionCompleteTracker completeTracker, User user) protected void
FlushLargeStoresPolicy.setFlushSizeLowerBounds
(HRegion region) private boolean
RSRpcServices.shouldRejectRequestsFromClient
(HRegion region) private void
HRegionServer.triggerFlushInPrimaryRegion
(HRegion region) Trigger a flush in the primary region replica if this region is a secondary replica.void
MetricsRegionServer.updateAppend
(HRegion region, long time, long blockBytesScanned) void
MetricsRegionServer.updateCheckAndDelete
(HRegion region, long t) void
MetricsRegionServer.updateCheckAndMutate
(HRegion region, long time, long blockBytesScanned) void
MetricsRegionServer.updateCheckAndPut
(HRegion region, long t) void
MetricsRegionServer.updateDelete
(HRegion region, long t) void
MetricsRegionServer.updateDeleteBatch
(HRegion region, long t) void
void
MetricsRegionServer.updateIncrement
(HRegion region, long time, long blockBytesScanned) private void
RSRpcServices.updateMutationMetrics
(HRegion region, long starttime, boolean batchContainsPuts, boolean batchContainsDelete) void
void
MetricsRegionServer.updatePutBatch
(HRegion region, long t) void
MetricsRegionServer.updateReadQueryMeter
(HRegion region, long count) void
MetricsRegionServer.updateScan
(HRegion region, long time, long responseCellSize, long blockBytesScanned) void
MetricsRegionServer.updateWriteQueryMeter
(HRegion region) void
MetricsRegionServer.updateWriteQueryMeter
(HRegion region, long count) Modifier and TypeMethodDescriptionprivate void
HRegionServer.addRegion
(SortedMap<Long, Collection<HRegion>> sortedRegions, HRegion region, long size) private HRegion
MemStoreFlusher.getBiggestMemStoreOfRegionReplica
(SortedMap<Long, Collection<HRegion>> regionsBySize, Set<HRegion> excludedRegions) private HRegion
MemStoreFlusher.getBiggestMemStoreOfRegionReplica
(SortedMap<Long, Collection<HRegion>> regionsBySize, Set<HRegion> excludedRegions) private HRegion
MemStoreFlusher.getBiggestMemStoreRegion
(SortedMap<Long, Collection<HRegion>> regionsBySize, Set<HRegion> excludedRegions, boolean checkStoreFileCount) private HRegion
MemStoreFlusher.getBiggestMemStoreRegion
(SortedMap<Long, Collection<HRegion>> regionsBySize, Set<HRegion> excludedRegions, boolean checkStoreFileCount) (package private) void
SecureBulkLoadManager.setFsCreatedListener
(Consumer<HRegion> fsCreatedListener) ModifierConstructorDescriptionBatchOperation
(HRegion region, T[] operations) CompactionRunner
(HStore store, HRegion region, CompactionContext compaction, CompactionLifeCycleTracker tracker, CompactSplit.CompactionCompleteTracker completeTracker, ThreadPoolExecutor parent, User user) (package private)
FlushRegionEntry
(HRegion r, List<byte[]> families, FlushLifeCycleTracker tracker) HMobStore
(HRegion region, ColumnFamilyDescriptor family, org.apache.hadoop.conf.Configuration confParam, boolean warmup) protected
HStore
(HRegion region, ColumnFamilyDescriptor family, org.apache.hadoop.conf.Configuration confParam, boolean warmup) ConstructorMetricsRegionWrapperImpl
(HRegion region) MutationBatchOperation
(HRegion region, Mutation[] operations, boolean atomic, long nonceGroup, long nonce) PostOpenDeployContext
(HRegion region, long openProcId, long masterSystemTime, long initiatingMasterActiveTime) RegionCoprocessorHost
(HRegion region, RegionServerServices rsServices, org.apache.hadoop.conf.Configuration conf) Constructor(package private)
RegionScannerHolder
(RegionScanner s, HRegion r, RpcCallback closeCallBack, RpcCallback shippedCallback, boolean needCursor, boolean fullRegionScan, String clientIPAndPort, String userName) (package private)
RegionScannerImpl
(Scan scan, List<KeyValueScanner> additionalScanners, HRegion region, long nonceGroup, long nonce) RegionServicesForStores
(HRegion region, RegionServerServices rsServices) ReplayBatchOperation
(HRegion region, WALSplitUtil.MutationReplay[] operations, long origLogSeqNum) Deprecated.(package private)
ReversedRegionScannerImpl
(Scan scan, List<KeyValueScanner> additionalScanners, HRegion region, long nonceGroup, long nonce) -
Uses of HRegion in org.apache.hadoop.hbase.regionserver.compactions
Modifier and TypeMethodDescriptionvoid
CompactionRequester.requestCompaction
(HRegion region, String why, int priority, CompactionLifeCycleTracker tracker, User user) Request compaction on all the stores of the given region.void
CompactionRequester.requestCompaction
(HRegion region, HStore store, String why, int priority, CompactionLifeCycleTracker tracker, User user) Request compaction on the given store.void
CompactionRequester.requestSystemCompaction
(HRegion region, HStore store, String why, boolean giveUpIfRequestedOrCompacting) Request system compaction on the given store. -
Uses of HRegion in org.apache.hadoop.hbase.regionserver.handler
Modifier and TypeFieldDescriptionprivate final HRegion
OpenRegionHandler.PostOpenDeployTasksThread.region
private final HRegion
RegionReplicaFlushHandler.region
Modifier and TypeMethodDescriptionprivate HRegion
OpenRegionHandler.openRegion()
Deprecated.Returns Instance of HRegion if successful open else null.Modifier and TypeMethodDescriptionprivate void
OpenRegionHandler.cleanupFailedOpen
(HRegion region) Deprecated.private void
OpenRegionHandler.doCleanUpOnFailedOpen
(HRegion region) Deprecated.(package private) void
RegionReplicaFlushHandler.triggerFlushInPrimaryRegion
(HRegion region) private boolean
OpenRegionHandler.updateMeta
(HRegion r, long masterSystemTime) Deprecated.Update ZK or META.ModifierConstructorDescription(package private)
PostOpenDeployTasksThread
(HRegion region, Server server, RegionServerServices services, AtomicBoolean signaller, long masterSystemTime) RegionReplicaFlushHandler
(Server server, HRegion region) -
Uses of HRegion in org.apache.hadoop.hbase.regionserver.snapshot
Modifier and TypeFieldDescriptionprivate HRegion
FlushSnapshotSubprocedure.RegionSnapshotTask.region
Modifier and TypeMethodDescriptionRegionServerSnapshotManager.getRegionsToSnapshot
(org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotDescription snapshot) Determine if the snapshot should be handled on this server NOTE: This is racy -- the master expects a list of regionservers.ModifierConstructorDescriptionRegionSnapshotTask
(HRegion region, org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotDescription snapshotDesc, boolean skipFlush, ForeignExceptionDispatcher monitor) ModifierConstructorDescriptionFlushSnapshotSubprocedure
(ProcedureMember member, ForeignExceptionDispatcher errorListener, long wakeFrequency, long timeout, List<HRegion> regions, org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotDescription snapshot, RegionServerSnapshotManager.SnapshotSubprocedurePool taskManager) -
Uses of HRegion in org.apache.hadoop.hbase.snapshot
Modifier and TypeMethodDescriptionvoid
Creates a 'manifest' for the specified region, by reading directly from the HRegion object.protected void
SnapshotManifest.addRegion
(HRegion region, SnapshotManifest.RegionVisitor visitor) private void
RestoreSnapshotHelper.cloneRegion
(HRegion region, RegionInfo snapshotRegionInfo, org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotRegionManifest manifest) Clone region directory content from the snapshot info. -
Uses of HRegion in org.apache.hadoop.hbase.util
Modifier and TypeMethodDescriptionstatic HRegion
HBaseFsckRepair.createHDFSRegionDir
(org.apache.hadoop.conf.Configuration conf, RegionInfo hri, TableDescriptor htd) Creates, flushes, and closes a new region.Modifier and TypeMethodDescriptionvoid
ModifyRegionUtils.RegionFillTask.fillRegion
(HRegion region) static boolean
ServerRegionReplicaUtil.isReadOnly
(HRegion region) Returns whether this region replica can accept writes.static boolean
ServerRegionReplicaUtil.shouldReplayRecoveredEdits
(HRegion region) Returns whether to replay the recovered edits to flush the results. -
Uses of HRegion in org.apache.hadoop.hbase.wal
Modifier and TypeFieldDescriptionprivate final HRegion
WALPerformanceEvaluation.WALPutBenchmark.region
Modifier and TypeMethodDescriptionprivate HRegion
WALPerformanceEvaluation.openRegion
(org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.fs.Path dir, TableDescriptor htd, WALFactory wals, long whenToRoll, LogRoller roller) Modifier and TypeMethodDescriptionprivate void
WALPerformanceEvaluation.closeRegion
(HRegion region) ModifierConstructorDescription(package private)
WALPutBenchmark
(HRegion region, TableDescriptor htd, long numIterations, boolean noSync, int syncInterval)