| Modifier and Type | Method and Description | 
|---|---|
| HRegion | RegionCoprocessorEnvironment. getRegion() | 
| Modifier and Type | Method and Description | 
|---|---|
| void | BaseRegionServerObserver. postMerge(ObserverContext<RegionServerCoprocessorEnvironment> c,
         HRegion regionA,
         HRegion regionB,
         HRegion mergedRegion) | 
| void | RegionServerObserver. postMerge(ObserverContext<RegionServerCoprocessorEnvironment> c,
         HRegion regionA,
         HRegion regionB,
         HRegion mergedRegion)called after the regions merge. | 
| void | BaseRegionServerObserver. postMergeCommit(ObserverContext<RegionServerCoprocessorEnvironment> ctx,
               HRegion regionA,
               HRegion regionB,
               HRegion mergedRegion) | 
| void | RegionServerObserver. postMergeCommit(ObserverContext<RegionServerCoprocessorEnvironment> ctx,
               HRegion regionA,
               HRegion regionB,
               HRegion mergedRegion)This will be called after PONR step as part of regions merge transaction. | 
| void | BaseRegionServerObserver. postRollBackMerge(ObserverContext<RegionServerCoprocessorEnvironment> ctx,
                 HRegion regionA,
                 HRegion regionB) | 
| void | RegionServerObserver. postRollBackMerge(ObserverContext<RegionServerCoprocessorEnvironment> ctx,
                 HRegion regionA,
                 HRegion regionB)This will be called after the roll back of the regions merge. | 
| void | BaseRegionObserver. postSplit(ObserverContext<RegionCoprocessorEnvironment> e,
         HRegion l,
         HRegion r) | 
| void | RegionObserver. postSplit(ObserverContext<RegionCoprocessorEnvironment> c,
         HRegion l,
         HRegion r)Deprecated. 
 Use postCompleteSplit() instead | 
| void | BaseRegionServerObserver. preMerge(ObserverContext<RegionServerCoprocessorEnvironment> ctx,
        HRegion regionA,
        HRegion regionB) | 
| void | RegionServerObserver. preMerge(ObserverContext<RegionServerCoprocessorEnvironment> ctx,
        HRegion regionA,
        HRegion regionB)Called before the regions merge. | 
| void | BaseRegionServerObserver. preMergeCommit(ObserverContext<RegionServerCoprocessorEnvironment> ctx,
              HRegion regionA,
              HRegion regionB,
              List<Mutation> metaEntries) | 
| void | RegionServerObserver. preMergeCommit(ObserverContext<RegionServerCoprocessorEnvironment> ctx,
              HRegion regionA,
              HRegion regionB,
              List<Mutation> metaEntries)This will be called before PONR step as part of regions merge transaction. | 
| void | BaseRegionServerObserver. preRollBackMerge(ObserverContext<RegionServerCoprocessorEnvironment> ctx,
                HRegion regionA,
                HRegion regionB) | 
| void | RegionServerObserver. preRollBackMerge(ObserverContext<RegionServerCoprocessorEnvironment> ctx,
                HRegion regionA,
                HRegion regionB)This will be called before the roll back of the regions merge. | 
| Modifier and Type | Field and Description | 
|---|---|
| protected HRegion | RegionSplitPolicy. regionThe region configured for this split policy. | 
| Modifier and Type | Field and Description | 
|---|---|
| protected Map<String,HRegion> | HRegionServer. onlineRegionsMap of regions currently being served by this region server. | 
| protected Map<String,HRegion> | HRegionServer. recoveringRegionsSet of regions currently being in recovering state which means it can accept writes(edits from
 previous failed region server) but not reads. | 
| Modifier and Type | Method and Description | 
|---|---|
| static HRegion | HRegion. createHRegion(HRegionInfo info,
             org.apache.hadoop.fs.Path rootDir,
             org.apache.hadoop.conf.Configuration conf,
             HTableDescriptor hTableDescriptor)Convenience method creating new HRegions. | 
| static HRegion | HRegion. createHRegion(HRegionInfo info,
             org.apache.hadoop.fs.Path rootDir,
             org.apache.hadoop.conf.Configuration conf,
             HTableDescriptor hTableDescriptor,
             HLog hlog) | 
| static HRegion | HRegion. createHRegion(HRegionInfo info,
             org.apache.hadoop.fs.Path rootDir,
             org.apache.hadoop.conf.Configuration conf,
             HTableDescriptor hTableDescriptor,
             HLog hlog,
             boolean initialize)Convenience method creating new HRegions. | 
| static HRegion | HRegion. createHRegion(HRegionInfo info,
             org.apache.hadoop.fs.Path rootDir,
             org.apache.hadoop.conf.Configuration conf,
             HTableDescriptor hTableDescriptor,
             HLog hlog,
             boolean initialize,
             boolean ignoreHLog)Convenience method creating new HRegions. | 
| static HRegion | HRegion. createHRegion(HRegionInfo info,
             org.apache.hadoop.fs.Path rootDir,
             org.apache.hadoop.fs.Path tableDir,
             org.apache.hadoop.conf.Configuration conf,
             HTableDescriptor hTableDescriptor,
             HLog hlog,
             boolean initialize,
             boolean ignoreHLog)Convenience method creating new HRegions. | 
| HRegion | RegionMergeTransaction. execute(Server server,
       RegionServerServices services)Run the transaction. | 
| HRegion | HRegionServer. getFromOnlineRegions(String encodedRegionName) | 
| HRegion | HStore. getHRegion() | 
| HRegion | HRegionServer. getOnlineRegion(byte[] regionName) | 
| protected HRegion | HRegionServer. getRegion(byte[] regionName)Protected utility method for safely obtaining an HRegion handle. | 
| protected HRegion | HRegionServer. getRegion(HBaseProtos.RegionSpecifier regionSpecifier)Find the HRegion based on a region specifier | 
| protected HRegion | HRegionServer. getRegionByEncodedName(byte[] regionName,
                      String encodedRegionName) | 
| protected HRegion | HRegionServer. getRegionByEncodedName(String encodedRegionName) | 
| static HRegion | HRegion. merge(HRegion a,
     HRegion b)Merge two regions whether they are adjacent or not. | 
| static HRegion | HRegion. mergeAdjacent(HRegion srcA,
             HRegion srcB)Merge two HRegions. | 
| protected HRegion | HRegion. openHRegion(CancelableProgressable reporter)Open HRegion. | 
| static HRegion | HRegion. openHRegion(org.apache.hadoop.conf.Configuration conf,
           org.apache.hadoop.fs.FileSystem fs,
           org.apache.hadoop.fs.Path rootDir,
           HRegionInfo info,
           HTableDescriptor htd,
           HLog 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,
           HRegionInfo info,
           HTableDescriptor htd,
           HLog wal,
           RegionServerServices rsServices,
           CancelableProgressable reporter)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,
           org.apache.hadoop.fs.Path tableDir,
           HRegionInfo info,
           HTableDescriptor htd,
           HLog wal,
           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) | 
| static HRegion | HRegion. openHRegion(HRegionInfo info,
           HTableDescriptor htd,
           HLog wal,
           org.apache.hadoop.conf.Configuration conf)Open a Region. | 
| static HRegion | HRegion. openHRegion(HRegionInfo info,
           HTableDescriptor htd,
           HLog wal,
           org.apache.hadoop.conf.Configuration conf,
           RegionServerServices rsServices,
           CancelableProgressable reporter)Open a Region. | 
| static HRegion | HRegion. openHRegion(org.apache.hadoop.fs.Path rootDir,
           HRegionInfo info,
           HTableDescriptor htd,
           HLog wal,
           org.apache.hadoop.conf.Configuration conf)Open a Region. | 
| static HRegion | HRegion. openHRegion(org.apache.hadoop.fs.Path rootDir,
           HRegionInfo info,
           HTableDescriptor htd,
           HLog wal,
           org.apache.hadoop.conf.Configuration conf,
           RegionServerServices rsServices,
           CancelableProgressable reporter)Open a Region. | 
| HRegion | RegionMergeTransaction. stepsAfterPONR(Server server,
              RegionServerServices services,
              HRegion mergedRegion) | 
| HRegion | RegionMergeTransaction. stepsBeforePONR(Server server,
               RegionServerServices services,
               boolean testing) | 
| Modifier and Type | Method and Description | 
|---|---|
| PairOfSameType<HRegion> | SplitTransaction. execute(Server server,
       RegionServerServices services)Run the transaction. | 
| List<HRegion> | HRegionServer. getOnlineRegions(TableName tableName)Gets the online regions of the specified table. | 
| Collection<HRegion> | HRegionServer. getOnlineRegionsLocalContext()For tests, web ui and metrics. | 
| Map<String,HRegion> | HRegionServer. getRecoveringRegions() | 
| Map<String,HRegion> | RegionServerServices. getRecoveringRegions() | 
| PairOfSameType<HRegion> | SplitTransaction. stepsAfterPONR(Server server,
              RegionServerServices services,
              PairOfSameType<HRegion> regions) | 
| PairOfSameType<HRegion> | SplitTransaction. stepsBeforePONR(Server server,
               RegionServerServices services,
               boolean testing) | 
| Modifier and Type | Method and Description | 
|---|---|
| static void | HRegion. addRegionToMETA(HRegion meta,
               HRegion r)Inserts a new region's meta information into the passed
  metaregion. | 
| protected long | HRegionServer. addScanner(RegionScanner s,
          HRegion r) | 
| void | HRegionServer. addToOnlineRegions(HRegion region) | 
| protected Result | HRegionServer. append(HRegion region,
      ClientProtos.MutationProto m,
      CellScanner cellScanner,
      long nonceGroup)Execute an append mutation. | 
| static void | HRegion. closeHRegion(HRegion r)This will do the necessary cleanup a call to
  createHRegion(HRegionInfo, Path, Configuration, HTableDescriptor)requires. | 
| protected void | ConstantSizeRegionSplitPolicy. configureForRegion(HRegion region) | 
| protected void | KeyPrefixRegionSplitPolicy. configureForRegion(HRegion region) | 
| protected void | RegionSplitPolicy. configureForRegion(HRegion region)Upon construction, this method will be called with the region
 to be governed. | 
| protected void | DelimitedKeyPrefixRegionSplitPolicy. configureForRegion(HRegion region) | 
| protected void | IncreasingToUpperBoundRegionSplitPolicy. configureForRegion(HRegion region) | 
| static RegionSplitPolicy | RegionSplitPolicy. create(HRegion region,
      org.apache.hadoop.conf.Configuration conf)Create the RegionSplitPolicy configured for the given table. | 
| protected void | HRegionServer. doBatchOp(ClientProtos.RegionActionResult.Builder builder,
         HRegion region,
         List<ClientProtos.Action> mutations,
         CellScanner cells)Execute a list of Put/Delete mutations. | 
| protected OperationStatus[] | HRegionServer. doReplayBatchOp(HRegion region,
               List<HLogSplitter.MutationReplay> mutations)Execute a list of Put/Delete mutations. | 
| protected Result | HRegionServer. increment(HRegion region,
         ClientProtos.MutationProto mutation,
         CellScanner cells,
         long nonceGroup)Execute an increment mutation. | 
| static HRegion | HRegion. merge(HRegion a,
     HRegion b)Merge two regions whether they are adjacent or not. | 
| static HRegion | HRegion. mergeAdjacent(HRegion srcA,
             HRegion srcB)Merge two HRegions. | 
| protected void | HRegionServer. mutateRows(HRegion region,
          List<ClientProtos.Action> actions,
          CellScanner cellScanner)Mutate a list of rows atomically. | 
| static HRegion | HRegion. openHRegion(HRegion other,
           CancelableProgressable reporter)Useful when reopening a closed region (normally for unit tests) | 
| void | BaseRowProcessor. postBatchMutate(HRegion region) | 
| void | RowProcessor. postBatchMutate(HRegion region)The hook to be executed after the process() and applying the Mutations to region. | 
| void | RegionServerCoprocessorHost. postMerge(HRegion regionA,
         HRegion regionB,
         HRegion mergedRegion) | 
| void | RegionServerCoprocessorHost. postMergeCommit(HRegion regionA,
               HRegion regionB,
               HRegion mergedRegion) | 
| void | HRegionServer. postOpenDeployTasks(HRegion r,
                   CatalogTracker ct) | 
| void | RegionServerServices. postOpenDeployTasks(HRegion r,
                   CatalogTracker ct)Tasks to perform after region open to complete deploy of region on
 regionserver | 
| void | BaseRowProcessor. postProcess(HRegion region,
           WALEdit walEdit,
           boolean success) | 
| void | RowProcessor. postProcess(HRegion region,
           WALEdit walEdit,
           boolean success)The hook to be executed after process() and applying the Mutations to region. | 
| void | RegionServerCoprocessorHost. postRollBackMerge(HRegion regionA,
                 HRegion regionB) | 
| void | RegionCoprocessorHost. postSplit(HRegion l,
         HRegion r)Invoked just after a split | 
| void | BaseRowProcessor. preBatchMutate(HRegion region,
              WALEdit walEdit) | 
| void | RowProcessor. preBatchMutate(HRegion region,
              WALEdit walEdit)The hook to be executed after the process() but before applying the Mutations to region. | 
| boolean | RegionServerCoprocessorHost. preMerge(HRegion regionA,
        HRegion regionB) | 
| boolean | RegionServerCoprocessorHost. preMergeCommit(HRegion regionA,
              HRegion regionB,
              List<Mutation> metaEntries) | 
| void | BaseRowProcessor. preProcess(HRegion region,
          WALEdit walEdit) | 
| void | RowProcessor. preProcess(HRegion region,
          WALEdit walEdit)The hook to be executed before process(). | 
| void | RegionServerCoprocessorHost. preRollBackMerge(HRegion regionA,
                HRegion regionB) | 
| void | RowProcessor. process(long now,
       HRegion region,
       List<Mutation> mutations,
       WALEdit walEdit)HRegion handles the locks and MVCC and invokes this method properly. | 
| boolean | HRegionServer. removeFromOnlineRegions(HRegion r,
                       ServerName destination) | 
| CompactionRequest | CompactionRequestor. requestCompaction(HRegion r,
                 Store s,
                 String why,
                 CompactionRequest request) | 
| CompactionRequest | CompactSplitThread. requestCompaction(HRegion r,
                 Store s,
                 String why,
                 CompactionRequest request) | 
| CompactionRequest | CompactionRequestor. requestCompaction(HRegion r,
                 Store s,
                 String why,
                 int pri,
                 CompactionRequest request) | 
| CompactionRequest | CompactSplitThread. requestCompaction(HRegion r,
                 Store s,
                 String why,
                 int priority,
                 CompactionRequest request) | 
| List<CompactionRequest> | CompactionRequestor. requestCompaction(HRegion r,
                 String why) | 
| List<CompactionRequest> | CompactSplitThread. requestCompaction(HRegion r,
                 String why) | 
| List<CompactionRequest> | CompactionRequestor. requestCompaction(HRegion r,
                 String why,
                 int pri,
                 List<Pair<CompactionRequest,Store>> requests) | 
| List<CompactionRequest> | CompactSplitThread. requestCompaction(HRegion r,
                 String why,
                 int p,
                 List<Pair<CompactionRequest,Store>> requests) | 
| List<CompactionRequest> | CompactionRequestor. requestCompaction(HRegion r,
                 String why,
                 List<Pair<CompactionRequest,Store>> requests) | 
| List<CompactionRequest> | CompactSplitThread. requestCompaction(HRegion r,
                 String why,
                 List<Pair<CompactionRequest,Store>> requests) | 
| void | FlushRequester. requestDelayedFlush(HRegion region,
                   long delay)Tell the listener the cache needs to be flushed after a delay | 
| void | FlushRequester. requestFlush(HRegion region)Tell the listener the cache needs to be flushed. | 
| void | CompactSplitThread. requestRegionsMerge(HRegion a,
                   HRegion b,
                   boolean forcible) | 
| boolean | CompactSplitThread. requestSplit(HRegion r) | 
| void | CompactSplitThread. requestSplit(HRegion r,
            byte[] midKey) | 
| void | CompactSplitThread. requestSystemCompaction(HRegion r,
                       Store s,
                       String why) | 
| void | CompactSplitThread. requestSystemCompaction(HRegion r,
                       String why) | 
| HRegion | RegionMergeTransaction. stepsAfterPONR(Server server,
              RegionServerServices services,
              HRegion mergedRegion) | 
| Modifier and Type | Method and Description | 
|---|---|
| PairOfSameType<HRegion> | SplitTransaction. stepsAfterPONR(Server server,
              RegionServerServices services,
              PairOfSameType<HRegion> regions) | 
| Constructor and Description | 
|---|
| HStore(HRegion region,
      HColumnDescriptor family,
      org.apache.hadoop.conf.Configuration confParam)Constructor | 
| MetricsRegionWrapperImpl(HRegion region) | 
| RegionCoprocessorHost(HRegion region,
                     RegionServerServices rsServices,
                     org.apache.hadoop.conf.Configuration conf)Constructor | 
| RegionMergeTransaction(HRegion a,
                      HRegion b,
                      boolean forcible)Constructor | 
| SplitTransaction(HRegion r,
                byte[] splitrow)Constructor | 
| Constructor and Description | 
|---|
| FlushSnapshotSubprocedure(ProcedureMember member,
                         ForeignExceptionDispatcher errorListener,
                         long wakeFrequency,
                         long timeout,
                         List<HRegion> regions,
                         HBaseProtos.SnapshotDescription snapshot,
                         org.apache.hadoop.hbase.regionserver.snapshot.RegionServerSnapshotManager.SnapshotSubprocedurePool taskManager) | 
| Modifier and Type | Method and Description | 
|---|---|
| HRegion | AccessController. getRegion() | 
| Modifier and Type | Method and Description | 
|---|---|
| void | AccessController. postMerge(ObserverContext<RegionServerCoprocessorEnvironment> c,
         HRegion regionA,
         HRegion regionB,
         HRegion mergedRegion) | 
| void | AccessController. postMergeCommit(ObserverContext<RegionServerCoprocessorEnvironment> ctx,
               HRegion regionA,
               HRegion regionB,
               HRegion mergedRegion) | 
| void | AccessController. postRollBackMerge(ObserverContext<RegionServerCoprocessorEnvironment> ctx,
                 HRegion regionA,
                 HRegion regionB) | 
| void | AccessController. preMerge(ObserverContext<RegionServerCoprocessorEnvironment> ctx,
        HRegion regionA,
        HRegion regionB) | 
| void | AccessController. preMergeCommit(ObserverContext<RegionServerCoprocessorEnvironment> ctx,
              HRegion regionA,
              HRegion regionB,
              List<Mutation> metaEntries) | 
| void | AccessController. preRollBackMerge(ObserverContext<RegionServerCoprocessorEnvironment> ctx,
                HRegion regionA,
                HRegion regionB) | 
| Modifier and Type | Method and Description | 
|---|---|
| protected void | DefaultVisibilityLabelServiceImpl. addSystemLabel(HRegion region,
              Map<String,Integer> labels,
              Map<String,List<Integer>> userAuths) | 
| static Filter | VisibilityUtils. createVisibilityLabelFilter(HRegion region,
                           Authorizations authorizations) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | SnapshotManifest. addRegion(HRegion region)Creates a 'manifest' for the specified region, by reading directly from the HRegion object. | 
| Modifier and Type | Method and Description | 
|---|---|
| static HRegion | HBaseFsckRepair. createHDFSRegionDir(org.apache.hadoop.conf.Configuration conf,
                   HRegionInfo hri,
                   HTableDescriptor htd)Creates, flushes, and closes a new region. | 
| HRegion | MetaUtils. getMetaRegion() | 
| Modifier and Type | Method and Description | 
|---|---|
| void | ModifyRegionUtils.RegionFillTask. fillRegion(HRegion region) | 
Copyright © 2014 The Apache Software Foundation. All rights reserved.