Uses of Interface
org.apache.hadoop.hbase.regionserver.Region
Package
Description
Table of Contents
-
Uses of Region in org.apache.hadoop.hbase
Modifier and TypeMethodDescriptionstatic void
HBaseTestingUtility.closeRegionAndWAL
(Region r) Deprecated.Close both the regionr
and it's underlying WAL.int
Deprecated.int
Deprecated.HBaseTestingUtility.getClosestRowBefore
(Region r, byte[] row, byte[] family) Deprecated.int
HBaseTestingUtility.loadRegion
(Region r, byte[] f) Deprecated.void
HBaseTestingUtility.verifyNumericRows
(Region region, byte[] f, int startRow, int endRow) Deprecated.void
HBaseTestingUtility.verifyNumericRows
(Region region, byte[] f, int startRow, int endRow, boolean present) Deprecated. -
Uses of Region in org.apache.hadoop.hbase.coprocessor
Modifier and TypeMethodDescriptionRegionCoprocessorEnvironment.getRegion()
Returns the region associated with this coprocessorModifier and TypeMethodDescriptionRegionCoprocessorEnvironment.checkBatchQuota
(Region region, int numWrites, int numReads) Check the quota for the current (rpc-context) user.RegionCoprocessorEnvironment.checkBatchQuota
(Region region, OperationQuota.OperationType type) Check the quota for the current (rpc-context) user.private void
MultiRowMutationEndpoint.checkFamily
(Region region, byte[] family) private boolean
MultiRowMutationEndpoint.matches
(Region region, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.Condition condition) -
Uses of Region in org.apache.hadoop.hbase.quotas
Modifier and TypeMethodDescriptionFileSystemUtilizationChore.getLeftoverRegions()
Returns anIterator
over the Regions which were skipped last invocation of the chore.Modifier and TypeMethodDescriptionRegionServerRpcQuotaManager.checkBatchQuota
(Region region, int numWrites, int numReads) Check the quota for the current (rpc-context) user.RegionServerRpcQuotaManager.checkBatchQuota
(Region region, List<org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.Action> actions, boolean hasCondition) RegionServerRpcQuotaManager.checkBatchQuota
(Region region, OperationQuota.OperationType type) RpcQuotaManager.checkBatchQuota
(Region region, int numWrites, int numReads) Check the quota for the current (rpc-context) user.RpcQuotaManager.checkBatchQuota
(Region region, List<org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.Action> actions, boolean hasCondition) Check the quota for the current (rpc-context) user.RpcQuotaManager.checkBatchQuota
(Region region, OperationQuota.OperationType type) Check the quota for the current (rpc-context) user.RegionServerRpcQuotaManager.checkScanQuota
(Region region, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ScanRequest scanRequest, long maxScannerResultSize, long maxBlockBytesScanned, long prevBlockBytesScannedDifference) RpcQuotaManager.checkScanQuota
(Region region, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ScanRequest scanRequest, long maxScannerResultSize, long maxBlockBytesScanned, long prevBlockBytesScannedDifference) Check the quota for the current (rpc-context) user.(package private) long
FileSystemUtilizationChore.computeSize
(Region r) Computes total FileSystem size for the givenRegion
.ActivePolicyEnforcement.getPolicyEnforcement
(Region r) Returns the properSpaceViolationPolicyEnforcement
implementation for the given table.Modifier and TypeMethodDescription(package private) HashSet<RegionInfo>
RegionSizeReportingChore.getOnlineRegionInfos
(List<? extends Region> onlineRegions) (package private) void
FileSystemUtilizationChore.setLeftoverRegions
(Iterator<Region> newLeftovers) Sets a new collection of Regions as leftovers. -
Uses of Region in org.apache.hadoop.hbase.regionserver
Modifier and TypeClassDescriptionclass
Regions store data for a certain region of a table.Modifier and TypeFieldDescriptionprotected final Map<Region,
MemStoreFlusher.FlushRegionEntry> MemStoreFlusher.regionsInQueue
Modifier and TypeMethodDescriptionReturnRegion
instance.RegionCoprocessorHost.RegionEnvironment.getRegion()
Returns the regionstatic Region
HRegion.openHRegion
(Region other, CancelableProgressable reporter) Modifier and TypeMethodDescriptionOnlineRegions.getRegions()
Get all online regions in this RS.OnlineRegions.getRegions
(TableName tableName) Get all online regions of a table in this RS.Modifier and TypeMethodDescriptionRegionCoprocessorHost.RegionEnvironment.checkBatchQuota
(Region region, int numWrites, int numReads) RegionCoprocessorHost.RegionEnvironment.checkBatchQuota
(Region region, OperationQuota.OperationType type) (package private) CacheEvictionStats
HRegionServer.clearRegionBlockCache
(Region region) void
FlushRequestListener.flushRequested
(FlushType type, Region region) Callback which will get called when a flush request is made for a region.void
HeapMemoryManager.HeapMemoryTunerChore.flushRequested
(FlushType type, Region region) private int
MemStoreFlusher.getStoreFileCount
(Region region) private boolean
MemStoreFlusher.isTooManyStoreFiles
(Region region) private void
MemStoreFlusher.notifyFlushRequest
(Region region, boolean emergencyFlush) static Region
HRegion.openHRegion
(Region other, CancelableProgressable reporter) private boolean
MemStoreFlusher.refreshStoreFilesAndReclaimMemory
(Region region) boolean
CompactSplit.requestSplit
(Region r) private void
CompactSplit.requestSplit
(Region r, byte[] midKey) private void
CompactSplit.requestSplit
(Region r, byte[] midKey, User user) ModifierConstructorDescriptionRegionEnvironment
(RegionCoprocessor impl, int priority, int seq, org.apache.hadoop.conf.Configuration conf, Region region, RegionServerServices services, ConcurrentMap<String, Object> sharedData) ConstructorRegionEnvironmentForCoreCoprocessors
(RegionCoprocessor impl, int priority, int seq, org.apache.hadoop.conf.Configuration conf, Region region, RegionServerServices services, ConcurrentMap<String, Object> sharedData) (package private)
SplitRequest
(Region region, byte[] midKey, HRegionServer hrs, User user) -
Uses of Region in org.apache.hadoop.hbase.regionserver.throttle
ModifierConstructorDescriptionStoreHotnessProtector
(Region region, org.apache.hadoop.conf.Configuration conf) -
Uses of Region in org.apache.hadoop.hbase.security.access
Modifier and TypeMethodDescriptionAccessController.getRegion()
private Region
AccessController.getRegion
(RegionCoprocessorEnvironment e) Modifier and TypeMethodDescriptionprivate TableName
AccessController.getTableName
(Region region) (package private) static boolean
PermissionStorage.isAclRegion
(Region region) Returnstrue
if the given region is part of the_acl_
metadata table.(package private) static Map<byte[],
org.apache.hbase.thirdparty.com.google.common.collect.ListMultimap<String, UserPermission>> Loads all of the permission grants stored in a region of the_acl_
table. -
Uses of Region in org.apache.hadoop.hbase.security.visibility
Modifier and TypeMethodDescriptionprotected void
DefaultVisibilityLabelServiceImpl.addSystemLabel
(Region region, Map<String, Integer> labels, Map<String, List<Integer>> userAuths) static Filter
VisibilityUtils.createVisibilityLabelFilter
(Region region, Authorizations authorizations) -
Uses of Region in org.apache.hadoop.hbase.testing
Modifier and TypeMethodDescriptionTestingHBaseCluster.getRegion
(RegionInfo regionInfo) Get the server sideRegion
interface for the specific region.TestingHBaseClusterImpl.getRegion
(RegionInfo regionInfo)