Uses of Class
org.apache.hadoop.hbase.regionserver.HRegion
Packages that use 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
Fields in org.apache.hadoop.hbase with type parameters of type HRegionMethods in org.apache.hadoop.hbase that return HRegionModifier 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 HRegionHBaseTestingUtility.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 HRegionHBaseTestingUtility.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 HRegionHBaseTestingUtility.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 HRegionHBaseTestingUtility.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 tableNameMethods in org.apache.hadoop.hbase that return types with arguments of type HRegionModifier and TypeMethodDescriptionMiniHBaseCluster.findRegionsForTable(TableName tableName) Deprecated.MiniHBaseCluster.getRegions(byte[] tableName) Deprecated.MiniHBaseCluster.getRegions(TableName tableName) Deprecated.MockRegionServerServices.getRegions()MockRegionServerServices.getRegions(TableName tableName) Methods in org.apache.hadoop.hbase with parameters of type HRegionModifier and TypeMethodDescriptionvoidstatic voidHBaseTestingUtility.closeRegionAndWAL(HRegion r) Deprecated.Close both the HRegionrand it's underlying WAL.private voidMiniHBaseCluster.executeFlush(HRegion region) Deprecated.intHBaseTestingUtility.loadRegion(HRegion r, byte[] f) Deprecated.intHBaseTestingUtility.loadRegion(HRegion r, byte[] f, boolean flush) Deprecated.Load region with rows from 'aaa' to 'zzz'.booleanMockRegionServerServices.removeRegion(HRegion r, ServerName destination) voidHBaseTestingUtility.verifyNumericRows(HRegion region, byte[] f, int startRow, int endRow) Deprecated.voidHBaseTestingUtility.verifyNumericRows(HRegion region, byte[] f, int startRow, int endRow, boolean present) Deprecated. -
Uses of HRegion in org.apache.hadoop.hbase.client
Fields in org.apache.hadoop.hbase.client declared as HRegionMethods in org.apache.hadoop.hbase.client that return HRegion -
Uses of HRegion in org.apache.hadoop.hbase.io.hfile
Method parameters in org.apache.hadoop.hbase.io.hfile with type arguments of type HRegionModifier and TypeMethodDescriptionstatic BlockCacheBlockCacheFactory.createBlockCache(org.apache.hadoop.conf.Configuration conf, Map<String, HRegion> onlineRegions) private static BucketCacheBlockCacheFactory.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
Fields in org.apache.hadoop.hbase.io.hfile.bucket with type parameters of type HRegionConstructor parameters in org.apache.hadoop.hbase.io.hfile.bucket with type arguments of type HRegion -
Uses of HRegion in org.apache.hadoop.hbase.master.region
Fields in org.apache.hadoop.hbase.master.region declared as HRegionModifier and TypeFieldDescription(package private) final HRegionMasterRegion.regionprivate final HRegionMasterRegionFlusherAndCompactor.regionMethods in org.apache.hadoop.hbase.master.region that return HRegionModifier and TypeMethodDescriptionprivate static HRegionMasterRegion.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 HRegionMasterRegion.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) Methods in org.apache.hadoop.hbase.master.region with parameters of type HRegionConstructors in org.apache.hadoop.hbase.master.region with parameters of type HRegionModifierConstructorDescriptionprivateMasterRegion(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
Fields in org.apache.hadoop.hbase.procedure.flush declared as HRegionModifier and TypeFieldDescription(package private) HRegionFlushTableSubprocedure.RegionFlushTask.regionFields in org.apache.hadoop.hbase.procedure.flush with type parameters of type HRegionMethods in org.apache.hadoop.hbase.procedure.flush that return types with arguments of type HRegionModifier 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.Constructors in org.apache.hadoop.hbase.procedure.flush with parameters of type HRegionModifierConstructorDescription(package private)RegionFlushTask(HRegion region, List<byte[]> families) Constructor parameters in org.apache.hadoop.hbase.procedure.flush with type arguments of type HRegionModifierConstructorDescriptionFlushTableSubprocedure(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
Fields in org.apache.hadoop.hbase.regionserver declared as HRegionModifier and TypeFieldDescriptionprivate final HRegionRSRpcServices.RegionScannerHolder.rprivate HRegionBusyRegionSplitPolicy.regionprivate final HRegionCompactSplit.CompactionRunner.regionprotected HRegionFlushPolicy.regionThe region configured for this flush policy.protected final HRegionHRegion.BatchOperation.regionprivate final HRegionHStore.regionprivate final HRegionMemStoreFlusher.FlushRegionEntry.regionprivate final HRegionMetricsRegionWrapperImpl.region(package private) HRegionRegionCoprocessorHost.regionThe regionprotected final HRegionRegionScannerImpl.regionprivate final HRegionRegionServerServices.PostOpenDeployContext.regionprivate final HRegionRegionServicesForStores.regionprotected HRegionRegionSplitPolicy.regionThe region configured for this split policy.Fields in org.apache.hadoop.hbase.regionserver with type parameters of type HRegionModifier and TypeFieldDescriptionSecureBulkLoadManager.fsCreatedListenerDataTieringManager.onlineRegionsHRegionServer.onlineRegionsMap of regions currently being served by this region server.Methods in org.apache.hadoop.hbase.regionserver that return HRegionModifier and TypeMethodDescriptionstatic HRegionHRegion.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 HRegionHRegion.createHRegion(RegionInfo info, org.apache.hadoop.fs.Path rootDir, org.apache.hadoop.conf.Configuration conf, TableDescriptor hTableDescriptor, WAL wal) static HRegionHRegion.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 HRegionHRegion.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 HRegionMemStoreFlusher.getBiggestMemStoreOfRegionReplica(SortedMap<Long, Collection<HRegion>> regionsBySize, Set<HRegion> excludedRegions) private HRegionMemStoreFlusher.getBiggestMemStoreRegion(SortedMap<Long, Collection<HRegion>> regionsBySize, Set<HRegion> excludedRegions, boolean checkStoreFileCount) private HRegionDataTieringManager.getHRegion(org.apache.hadoop.fs.Path hFilePath) HStore.getHRegion()HRegionServer.getOnlineRegion(byte[] regionName) protected HRegionHRegionServer.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 HRegionHRegionServer.getRegionByEncodedName(byte[] regionName, String encodedRegionName) HRegionServer.getRegionByEncodedName(String encodedRegionName) static HRegionHRegion.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_IMPLconfiguration property.static HRegionHRegion.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 HRegionHRegion.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 HRegionHRegion.openHRegion(org.apache.hadoop.fs.Path rootDir, RegionInfo info, TableDescriptor htd, WAL wal, org.apache.hadoop.conf.Configuration conf) Open a Region.static HRegionHRegion.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 HRegionHRegion.openHRegion(RegionInfo info, TableDescriptor htd, WAL wal, org.apache.hadoop.conf.Configuration conf) Open a Region.static HRegionHRegion.openHRegion(RegionInfo info, TableDescriptor htd, WAL wal, org.apache.hadoop.conf.Configuration conf, RegionServerServices rsServices, CancelableProgressable reporter) Open a Region.static HRegionHRegion.openHRegion(HRegion other, CancelableProgressable reporter) Useful when reopening a closed region (normally for unit tests)private HRegionHRegion.openHRegion(CancelableProgressable reporter) Open HRegion.static HRegionHRegion.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 HRegionHRegion.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 HRegionHRegion.warmupHRegion(RegionInfo info, TableDescriptor htd, WAL wal, org.apache.hadoop.conf.Configuration conf, RegionServerServices rsServices, CancelableProgressable reporter) Methods in org.apache.hadoop.hbase.regionserver that return types with arguments of type HRegionModifier 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 specifiersMethods in org.apache.hadoop.hbase.regionserver with parameters of type HRegionModifier and TypeMethodDescriptionprivate voidHRegionServer.addRegion(SortedMap<Long, Collection<HRegion>> sortedRegions, HRegion region, long size) voidvoidAdd to online regions.RSRpcServices.addScanner(String scannerName, RegionScanner s, Shipper shipper, HRegion r, boolean needCursor, boolean fullRegionScan) private ResultRSRpcServices.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 CheckAndMutateResultRSRpcServices.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 CheckAndMutateResultRSRpcServices.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 voidRSRpcServices.checkCellSizeLimit(HRegion r, Mutation m) voidSecureBulkLoadManager.cleanupBulkLoad(HRegion region, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.CleanupBulkLoadRequest request) private voidRSRpcServices.closeScanner(HRegion region, RegionScanner scanner, String scannerName, RpcCallContext context, boolean isError) protected voidBusyRegionSplitPolicy.configureForRegion(HRegion region) protected voidConstantSizeRegionSplitPolicy.configureForRegion(HRegion region) protected voidDelimitedKeyPrefixRegionSplitPolicy.configureForRegion(HRegion region) Deprecated.protected voidFlushAllLargeStoresPolicy.configureForRegion(HRegion region) protected voidFlushNonSloppyStoresFirstPolicy.configureForRegion(HRegion region) protected voidFlushPolicy.configureForRegion(HRegion region) Upon construction, this method will be called with the region to be governed.protected voidIncreasingToUpperBoundRegionSplitPolicy.configureForRegion(HRegion region) protected voidKeyPrefixRegionSplitPolicy.configureForRegion(HRegion region) Deprecated.protected voidRegionSplitPolicy.configureForRegion(HRegion region) Upon construction, this method will be called with the region to be governed.static FlushPolicyCreate the FlushPolicy configured for the given table.static RegionSplitPolicyCreate the RegionSplitPolicy configured for the given table.(package private) org.apache.hadoop.hbase.shaded.protobuf.generated.ClusterStatusProtos.RegionLoadHRegionServer.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 voidRSRpcServices.delete(HRegion region, OperationQuota quota, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MutationProto mutation, CellScanner cellScanner, ActivePolicyEnforcement spaceQuota) private voidRSRpcServices.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 voidRSRpcServices.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 voidRSRpcServices.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 regionMutationrmand per Mutation, do the work, and then when done, add an instance of aClientProtos.ResultOrExceptionthat 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.MessageRSRpcServices.execServiceOnRegion(HRegion region, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.CoprocessorServiceCall serviceCall) private booleanMemStoreFlusher.flushRegion(HRegion region, boolean emergencyFlush, List<byte[]> families, FlushLifeCycleTracker tracker) Flush a region.private ResultRSRpcServices.get(Get get, HRegion region, RSRpcServices.RegionScannersCloseCallBack closeCallBack, RpcCallContext context) private static longMemStoreFlusher.getMemStoreDataSize(HRegion r) Returns Return memstore data size or null ifris nullprivate static longMemStoreFlusher.getMemStoreHeapSize(HRegion r) Returns Return memstore heap size or null ifris nullprivate static longMemStoreFlusher.getMemStoreOffHeapSize(HRegion r) Returns Return memstore offheap size or null ifris nullprivate static booleanprivate ResultRSRpcServices.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 voidRegionScannerImpl.initializeKVHeap(List<KeyValueScanner> scanners, List<KeyValueScanner> joinedScanners, HRegion region) protected voidReversedRegionScannerImpl.initializeKVHeap(List<KeyValueScanner> scanners, List<KeyValueScanner> joinedScanners, HRegion region) private booleanRSRpcServices.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 HRegionHRegion.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 voidRSRpcServices.put(HRegion region, OperationQuota quota, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MutationProto mutation, CellScanner cellScanner, ActivePolicyEnforcement spaceQuota) private voidRSRpcServices.rejectIfInStandByState(HRegion region) booleanHRegionServer.removeRegion(HRegion r, ServerName destination) booleanMutableOnlineRegions.removeRegion(HRegion r, ServerName destination) Removes the given Region from the list of onlineRegions.voidCompactSplit.requestCompaction(HRegion region, String why, int priority, CompactionLifeCycleTracker tracker, User user) voidCompactSplit.requestCompaction(HRegion region, HStore store, String why, int priority, CompactionLifeCycleTracker tracker, User user) private voidCompactSplit.requestCompactionInternal(HRegion region, String why, int priority, boolean selectNow, CompactionLifeCycleTracker tracker, CompactSplit.CompactionCompleteTracker completeTracker, User user) protected voidCompactSplit.requestCompactionInternal(HRegion region, HStore store, String why, int priority, boolean selectNow, CompactionLifeCycleTracker tracker, CompactSplit.CompactionCompleteTracker completeTracker, User user) booleanFlushRequester.requestDelayedFlush(HRegion region, long delay) Tell the listener the cache needs to be flushed after a delaybooleanMemStoreFlusher.requestDelayedFlush(HRegion r, long delay) booleanFlushRequester.requestFlush(HRegion region, List<byte[]> families, FlushLifeCycleTracker tracker) Tell the listener the cache needs to be flushed.booleanFlushRequester.requestFlush(HRegion region, FlushLifeCycleTracker tracker) Tell the listener the cache needs to be flushed.booleanMemStoreFlusher.requestFlush(HRegion r, List<byte[]> families, FlushLifeCycleTracker tracker) booleanMemStoreFlusher.requestFlush(HRegion r, FlushLifeCycleTracker tracker) voidCompactSplit.requestSystemCompaction(HRegion region, String why) voidCompactSplit.requestSystemCompaction(HRegion region, HStore store, String why) voidCompactSplit.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 voidFlushLargeStoresPolicy.setFlushSizeLowerBounds(HRegion region) private booleanRSRpcServices.shouldRejectRequestsFromClient(HRegion region) private voidHRegionServer.triggerFlushInPrimaryRegion(HRegion region) Trigger a flush in the primary region replica if this region is a secondary replica.voidMetricsRegionServer.updateAppend(HRegion region, long time, long blockBytesScanned) voidMetricsRegionServer.updateCheckAndDelete(HRegion region, long t) voidMetricsRegionServer.updateCheckAndMutate(HRegion region, long time, long blockBytesScanned) voidMetricsRegionServer.updateCheckAndPut(HRegion region, long t) voidMetricsRegionServer.updateDelete(HRegion region, long t) voidMetricsRegionServer.updateDeleteBatch(HRegion region, long t) voidvoidMetricsRegionServer.updateIncrement(HRegion region, long time, long blockBytesScanned) private voidRSRpcServices.updateMutationMetrics(HRegion region, long starttime, boolean batchContainsPuts, boolean batchContainsDelete) voidvoidMetricsRegionServer.updatePutBatch(HRegion region, long t) voidMetricsRegionServer.updateReadQueryMeter(HRegion region, long count) voidMetricsRegionServer.updateScan(HRegion region, long time, long responseCellSize, long blockBytesScanned) voidMetricsRegionServer.updateWriteQueryMeter(HRegion region) voidMetricsRegionServer.updateWriteQueryMeter(HRegion region, long count) Method parameters in org.apache.hadoop.hbase.regionserver with type arguments of type HRegionModifier and TypeMethodDescriptionprivate voidHRegionServer.addRegion(SortedMap<Long, Collection<HRegion>> sortedRegions, HRegion region, long size) private HRegionMemStoreFlusher.getBiggestMemStoreOfRegionReplica(SortedMap<Long, Collection<HRegion>> regionsBySize, Set<HRegion> excludedRegions) private HRegionMemStoreFlusher.getBiggestMemStoreOfRegionReplica(SortedMap<Long, Collection<HRegion>> regionsBySize, Set<HRegion> excludedRegions) private HRegionMemStoreFlusher.getBiggestMemStoreRegion(SortedMap<Long, Collection<HRegion>> regionsBySize, Set<HRegion> excludedRegions, boolean checkStoreFileCount) private HRegionMemStoreFlusher.getBiggestMemStoreRegion(SortedMap<Long, Collection<HRegion>> regionsBySize, Set<HRegion> excludedRegions, boolean checkStoreFileCount) static booleanDataTieringManager.instantiate(org.apache.hadoop.conf.Configuration conf, Map<String, HRegion> onlineRegions) Initializes the DataTieringManager instance with the provided map of online regions, only if the configuration "hbase.regionserver.datatiering.enable" is enabled.(package private) voidSecureBulkLoadManager.setFsCreatedListener(Consumer<HRegion> fsCreatedListener) Constructors in org.apache.hadoop.hbase.regionserver with parameters of type HRegionModifierConstructorDescriptionBatchOperation(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) protectedHStore(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) Constructor parameters in org.apache.hadoop.hbase.regionserver with type arguments of type HRegion -
Uses of HRegion in org.apache.hadoop.hbase.regionserver.compactions
Methods in org.apache.hadoop.hbase.regionserver.compactions with parameters of type HRegionModifier and TypeMethodDescriptionvoidCompactionRequester.requestCompaction(HRegion region, String why, int priority, CompactionLifeCycleTracker tracker, User user) Request compaction on all the stores of the given region.voidCompactionRequester.requestCompaction(HRegion region, HStore store, String why, int priority, CompactionLifeCycleTracker tracker, User user) Request compaction on the given store.voidCompactionRequester.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
Fields in org.apache.hadoop.hbase.regionserver.handler declared as HRegionModifier and TypeFieldDescriptionprivate final HRegionOpenRegionHandler.PostOpenDeployTasksThread.regionprivate final HRegionRegionReplicaFlushHandler.regionMethods in org.apache.hadoop.hbase.regionserver.handler that return HRegionModifier and TypeMethodDescriptionprivate HRegionOpenRegionHandler.openRegion()Deprecated.Returns Instance of HRegion if successful open else null.Methods in org.apache.hadoop.hbase.regionserver.handler with parameters of type HRegionModifier and TypeMethodDescriptionprivate voidOpenRegionHandler.cleanupFailedOpen(HRegion region) Deprecated.private voidOpenRegionHandler.doCleanUpOnFailedOpen(HRegion region) Deprecated.private booleanRegionReplicaFlushHandler.isTableDisabledOrDropped(IOException error, HRegion region) (package private) voidRegionReplicaFlushHandler.triggerFlushInPrimaryRegion(HRegion region) private booleanOpenRegionHandler.updateMeta(HRegion r, long masterSystemTime) Deprecated.Update ZK or META.Constructors in org.apache.hadoop.hbase.regionserver.handler with parameters of type HRegionModifierConstructorDescription(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
Fields in org.apache.hadoop.hbase.regionserver.snapshot declared as HRegionModifier and TypeFieldDescriptionprivate HRegionFlushSnapshotSubprocedure.RegionSnapshotTask.regionFields in org.apache.hadoop.hbase.regionserver.snapshot with type parameters of type HRegionMethods in org.apache.hadoop.hbase.regionserver.snapshot that return types with arguments of type HRegionModifier 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.Constructors in org.apache.hadoop.hbase.regionserver.snapshot with parameters of type HRegionModifierConstructorDescriptionRegionSnapshotTask(HRegion region, org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotDescription snapshotDesc, boolean skipFlush, ForeignExceptionDispatcher monitor) Constructor parameters in org.apache.hadoop.hbase.regionserver.snapshot with type arguments of type HRegionModifierConstructorDescriptionFlushSnapshotSubprocedure(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
Methods in org.apache.hadoop.hbase.snapshot with parameters of type HRegionModifier and TypeMethodDescriptionvoidCreates a 'manifest' for the specified region, by reading directly from the HRegion object.protected voidSnapshotManifest.addRegion(HRegion region, SnapshotManifest.RegionVisitor visitor) private voidRestoreSnapshotHelper.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
Methods in org.apache.hadoop.hbase.util that return HRegionModifier and TypeMethodDescriptionstatic HRegionHBaseFsckRepair.createHDFSRegionDir(org.apache.hadoop.conf.Configuration conf, RegionInfo hri, TableDescriptor htd) Creates, flushes, and closes a new region.Methods in org.apache.hadoop.hbase.util with parameters of type HRegionModifier and TypeMethodDescriptionvoidModifyRegionUtils.RegionFillTask.fillRegion(HRegion region) static booleanServerRegionReplicaUtil.isReadOnly(HRegion region) Returns whether this region replica can accept writes.static booleanServerRegionReplicaUtil.shouldReplayRecoveredEdits(HRegion region) Returns whether to replay the recovered edits to flush the results. -
Uses of HRegion in org.apache.hadoop.hbase.wal
Fields in org.apache.hadoop.hbase.wal declared as HRegionModifier and TypeFieldDescriptionprivate final HRegionWALPerformanceEvaluation.WALPutBenchmark.regionMethods in org.apache.hadoop.hbase.wal that return HRegionModifier and TypeMethodDescriptionprivate HRegionWALPerformanceEvaluation.openRegion(org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.fs.Path dir, TableDescriptor htd, WALFactory wals, long whenToRoll, LogRoller roller) Methods in org.apache.hadoop.hbase.wal with parameters of type HRegionModifier and TypeMethodDescriptionprivate voidWALPerformanceEvaluation.closeRegion(HRegion region) Constructors in org.apache.hadoop.hbase.wal with parameters of type HRegionModifierConstructorDescription(package private)WALPutBenchmark(HRegion region, TableDescriptor htd, long numIterations, boolean noSync, int syncInterval)