| Package | Description | 
|---|---|
| org.apache.hadoop.hbase.client | Provides HBase Client | 
| org.apache.hadoop.hbase.coprocessor | Table of Contents | 
| org.apache.hadoop.hbase.procedure.flush | |
| org.apache.hadoop.hbase.regionserver | |
| org.apache.hadoop.hbase.regionserver.compactions | |
| org.apache.hadoop.hbase.regionserver.handler | |
| org.apache.hadoop.hbase.regionserver.snapshot | |
| org.apache.hadoop.hbase.snapshot | |
| org.apache.hadoop.hbase.util | 
| Modifier and Type | Field and Description | 
|---|---|
| private HRegion | ClientSideRegionScanner. region | 
| Modifier and Type | Field and Description | 
|---|---|
| private HRegion | Export.ScanCoprocessor. region | 
| Modifier and Type | Field and Description | 
|---|---|
| (package private) HRegion | FlushTableSubprocedure.RegionFlushTask. region | 
| Modifier and Type | Field and Description | 
|---|---|
| private List<HRegion> | FlushTableSubprocedure. regions | 
| Modifier and Type | Method and Description | 
|---|---|
| private List<HRegion> | RegionServerFlushTableProcedureManager. 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. | 
| Constructor and Description | 
|---|
| RegionFlushTask(HRegion region) | 
| Constructor and Description | 
|---|
| FlushTableSubprocedure(ProcedureMember member,
                      ForeignExceptionDispatcher errorListener,
                      long wakeFrequency,
                      long timeout,
                      List<HRegion> regions,
                      String table,
                      RegionServerFlushTableProcedureManager.FlushTableSubprocedurePool taskManager) | 
| Modifier and Type | Field and Description | 
|---|---|
| private HRegion | RSRpcServices.RegionScannerHolder. r | 
| protected HRegion | FlushPolicy. regionThe region configured for this flush policy. | 
| protected HRegion | RegionSplitPolicy. regionThe region configured for this split policy. | 
| private HRegion | RegionServerServices.PostOpenDeployContext. region | 
| private HRegion | RegionServicesForStores. region | 
| (package private) HRegion | RegionCoprocessorHost. regionThe region | 
| protected HRegion | HStore. region | 
| private HRegion | MetricsRegionWrapperImpl. region | 
| private HRegion | CompactSplit.CompactionRunner. region | 
| private HRegion | MemStoreFlusher.FlushRegionEntry. region | 
| protected HRegion | HRegion.BatchOperation. region | 
| protected HRegion | HRegion.RegionScannerImpl. region | 
| private HRegion | BusyRegionSplitPolicy. region | 
| Modifier and Type | Field and Description | 
|---|---|
| private Consumer<HRegion> | SecureBulkLoadManager. fsCreatedListener | 
| protected Map<String,HRegion> | HRegionServer. onlineRegionsMap of regions currently being served by this region server. | 
| Modifier and Type | Method and Description | 
|---|---|
| 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. | 
| private HRegion | MemStoreFlusher. getBiggestMemStoreOfRegionReplica(SortedMap<Long,HRegion> regionsBySize,
                                 Set<HRegion> excludedRegions) | 
| private HRegion | MemStoreFlusher. getBiggestMemStoreRegion(SortedMap<Long,HRegion> regionsBySize,
                        Set<HRegion> excludedRegions,
                        boolean checkStoreFileCount) | 
| HRegion | HStore. getHRegion() | 
| HRegion | HRegionServer. getOnlineRegion(byte[] regionName) | 
| HRegion | RegionServerServices.PostOpenDeployContext. getRegion() | 
| protected HRegion | HRegionServer. getRegion(byte[] regionName)Protected Utility method for safely obtaining an HRegion handle. | 
| HRegion | RSRpcServices. getRegion(org.apache.hadoop.hbase.shaded.protobuf.generated.HBaseProtos.RegionSpecifier regionSpecifier)Find the HRegion based on a region specifier | 
| HRegion | HRegionServer. getRegion(String encodedRegionName) | 
| protected HRegion | HRegionServer. getRegionByEncodedName(byte[] regionName,
                      String encodedRegionName) | 
| HRegion | HRegionServer. getRegionByEncodedName(String encodedRegionName) | 
| (package private) 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 the
  HConstants.REGION_IMPLconfiguration property. | 
| 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,
           org.apache.hadoop.fs.Path tableDir,
           RegionInfo info,
           TableDescriptor htd,
           WAL 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,
           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(HRegion other,
           CancelableProgressable reporter)Useful when reopening a closed region (normally for unit tests) | 
| 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. 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) | 
| Modifier and Type | Method and Description | 
|---|---|
| (package private) SortedMap<Long,HRegion> | HRegionServer. getCopyOfOnlineRegionsSortedByOffHeapSize() | 
| (package private) SortedMap<Long,HRegion> | HRegionServer. getCopyOfOnlineRegionsSortedByOnHeapSize() | 
| Collection<HRegion> | HRegionServer. getOnlineRegionsLocalContext()For tests, web ui and metrics. | 
| List<HRegion> | HRegionServer. getRegions() | 
| private List<HRegion> | 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 specifiers | 
| List<HRegion> | HRegionServer. getRegions(TableName tableName)Gets the online regions of the specified table. | 
| Modifier and Type | Method and Description | 
|---|---|
| void | MutableOnlineRegions. addRegion(HRegion r)Add to online regions. | 
| void | HRegionServer. addRegion(HRegion region) | 
| private RSRpcServices.RegionScannerHolder | RSRpcServices. addScanner(String scannerName,
          RegionScanner s,
          Shipper shipper,
          HRegion r,
          boolean needCursor) | 
| private Result | RSRpcServices. append(HRegion region,
      OperationQuota quota,
      org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MutationProto mutation,
      CellScanner cellScanner,
      long nonceGroup,
      ActivePolicyEnforcement spaceQuota)Execute an append mutation. | 
| private boolean | RSRpcServices. checkAndRowMutate(HRegion region,
                 List<org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.Action> actions,
                 CellScanner cellScanner,
                 byte[] row,
                 byte[] family,
                 byte[] qualifier,
                 CompareOperator op,
                 ByteArrayComparable comparator,
                 TimeRange timeRange,
                 org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.RegionActionResult.Builder builder,
                 ActivePolicyEnforcement spaceQuotaEnforcement)Mutate a list of rows atomically. | 
| 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) | 
| protected void | DelimitedKeyPrefixRegionSplitPolicy. configureForRegion(HRegion region) | 
| protected void | FlushPolicy. configureForRegion(HRegion region)Upon construction, this method will be called with the region to be governed. | 
| protected void | FlushAllLargeStoresPolicy. configureForRegion(HRegion region) | 
| protected void | IncreasingToUpperBoundRegionSplitPolicy. configureForRegion(HRegion region) | 
| protected void | RegionSplitPolicy. configureForRegion(HRegion region)Upon construction, this method will be called with the region
 to be governed. | 
| protected void | KeyPrefixRegionSplitPolicy. configureForRegion(HRegion region) | 
| protected void | FlushNonSloppyStoresFirstPolicy. configureForRegion(HRegion region) | 
| protected void | ConstantSizeRegionSplitPolicy. configureForRegion(HRegion region) | 
| protected void | BusyRegionSplitPolicy. configureForRegion(HRegion region) | 
| static RegionSplitPolicy | RegionSplitPolicy. create(HRegion region,
      org.apache.hadoop.conf.Configuration conf)Create the RegionSplitPolicy configured for the given table. | 
| static FlushPolicy | FlushPolicyFactory. create(HRegion region,
      org.apache.hadoop.conf.Configuration conf)Create the FlushPolicy 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. 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,
               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,
         ActivePolicyEnforcement spaceQuotaEnforcement,
         boolean atomic)Execute a list of Put/Delete 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<CellScannable> | 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<CellScannable> cellsToReturn,
                         long nonceGroup,
                         RSRpcServices.RegionScannersCloseCallBack closeCallBack,
                         RpcCallContext context,
                         ActivePolicyEnforcement spaceQuotaEnforcement)Run through the regionMutation  rmand per Mutation, do the work, and then when
 done, add an instance of aClientProtos.ResultOrExceptionthat corresponds to each Mutation. | 
| private void | HRegion. doProcessRowWithTimeout(RowProcessor<?,?> processor,
                       long now,
                       HRegion region,
                       List<Mutation> mutations,
                       WALEdit walEdit,
                       long timeout) | 
| private OperationStatus[] | RSRpcServices. doReplayBatchOp(HRegion region,
               List<WALSplitter.MutationReplay> mutations,
               long replaySeqId)Execute a list of Put/Delete mutations. | 
| private 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,
           boolean forceFlushAllStores,
           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) | 
| private static long | MemStoreFlusher. getMemStoreHeapSize(HRegion r) | 
| private static long | MemStoreFlusher. getMemStoreOffHeapSize(HRegion r) | 
| private Result | RSRpcServices. increment(HRegion region,
         OperationQuota quota,
         org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MutationProto mutation,
         CellScanner cells,
         long nonceGroup,
         ActivePolicyEnforcement spaceQuota)Execute an increment mutation. | 
| protected void | HRegion.RegionScannerImpl. initializeKVHeap(List<KeyValueScanner> scanners,
                List<KeyValueScanner> joinedScanners,
                HRegion region) | 
| protected void | ReversedRegionScannerImpl. initializeKVHeap(List<KeyValueScanner> scanners,
                List<KeyValueScanner> joinedScanners,
                HRegion region) | 
| static HRegion | HRegion. openHRegion(HRegion other,
           CancelableProgressable reporter)Useful when reopening a closed region (normally for unit tests) | 
| void | RowProcessor. postBatchMutate(HRegion region)Deprecated.  The hook to be executed after the process() and applying the Mutations to region. | 
| void | BaseRowProcessor. postBatchMutate(HRegion region) | 
| void | RowProcessor. postProcess(HRegion region,
           WALEdit walEdit,
           boolean success)Deprecated.  The hook to be executed after process() and applying the Mutations to region. | 
| void | BaseRowProcessor. postProcess(HRegion region,
           WALEdit walEdit,
           boolean success) | 
| void | RowProcessor. preBatchMutate(HRegion region,
              WALEdit walEdit)Deprecated.  The hook to be executed after the process() but before applying the Mutations to region. | 
| void | BaseRowProcessor. preBatchMutate(HRegion region,
              WALEdit walEdit) | 
| String | SecureBulkLoadManager. prepareBulkLoad(HRegion region,
               org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.PrepareBulkLoadRequest request) | 
| void | RowProcessor. preProcess(HRegion region,
          WALEdit walEdit)Deprecated.  The hook to be executed before process(). | 
| void | BaseRowProcessor. preProcess(HRegion region,
          WALEdit walEdit) | 
| void | RowProcessor. process(long now,
       HRegion region,
       List<Mutation> mutations,
       WALEdit walEdit)Deprecated.  HRegion handles the locks and MVCC and invokes this method properly. | 
| boolean | MutableOnlineRegions. removeRegion(HRegion r,
            ServerName destination)Removes the given Region from the list of onlineRegions. | 
| boolean | HRegionServer. removeRegion(HRegion r,
            ServerName destination) | 
| void | CompactSplit. requestCompaction(HRegion region,
                 HStore store,
                 String why,
                 int priority,
                 CompactionLifeCycleTracker tracker,
                 User user) | 
| void | CompactSplit. requestCompaction(HRegion region,
                 String why,
                 int priority,
                 CompactionLifeCycleTracker tracker,
                 User user) | 
| private void | CompactSplit. requestCompactionInternal(HRegion region,
                         HStore store,
                         String why,
                         int priority,
                         boolean selectNow,
                         CompactionLifeCycleTracker tracker,
                         CompactSplit.CompactionCompleteTracker completeTracker,
                         User user) | 
| private void | CompactSplit. requestCompactionInternal(HRegion region,
                         String why,
                         int priority,
                         boolean selectNow,
                         CompactionLifeCycleTracker tracker,
                         CompactSplit.CompactionCompleteTracker completeTracker,
                         User user) | 
| void | FlushRequester. requestDelayedFlush(HRegion region,
                   long delay,
                   boolean forceFlushAllStores)Tell the listener the cache needs to be flushed after a delay | 
| void | MemStoreFlusher. requestDelayedFlush(HRegion r,
                   long delay,
                   boolean forceFlushAllStores) | 
| void | FlushRequester. requestFlush(HRegion region,
            boolean forceFlushAllStores,
            FlushLifeCycleTracker tracker)Tell the listener the cache needs to be flushed. | 
| void | MemStoreFlusher. requestFlush(HRegion r,
            boolean forceFlushAllStores,
            FlushLifeCycleTracker tracker) | 
| void | CompactSplit. requestSystemCompaction(HRegion region,
                       HStore store,
                       String why) | 
| void | CompactSplit. requestSystemCompaction(HRegion region,
                       String why) | 
| Map<byte[],List<org.apache.hadoop.fs.Path>> | SecureBulkLoadManager. secureBulkLoadHFiles(HRegion region,
                    org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.BulkLoadHFileRequest request) | 
| private Optional<CompactionContext> | CompactSplit. selectCompaction(HRegion region,
                HStore store,
                int priority,
                CompactionLifeCycleTracker tracker,
                CompactSplit.CompactionCompleteTracker completeTracker,
                User user) | 
| protected void | FlushLargeStoresPolicy. setFlushSizeLowerBounds(HRegion region) | 
| (package private) void | HRegionServer. triggerFlushInPrimaryRegion(HRegion region)Trigger a flush in the primary region replica if this region is a secondary replica. | 
| private void | RSRpcServices. updateMutationMetrics(HRegion region,
                     long starttime,
                     boolean batchContainsPuts,
                     boolean batchContainsDelete) | 
| Modifier and Type | Method and Description | 
|---|---|
| private HRegion | MemStoreFlusher. getBiggestMemStoreOfRegionReplica(SortedMap<Long,HRegion> regionsBySize,
                                 Set<HRegion> excludedRegions) | 
| private HRegion | MemStoreFlusher. getBiggestMemStoreOfRegionReplica(SortedMap<Long,HRegion> regionsBySize,
                                 Set<HRegion> excludedRegions) | 
| private HRegion | MemStoreFlusher. getBiggestMemStoreRegion(SortedMap<Long,HRegion> regionsBySize,
                        Set<HRegion> excludedRegions,
                        boolean checkStoreFileCount) | 
| private HRegion | MemStoreFlusher. getBiggestMemStoreRegion(SortedMap<Long,HRegion> regionsBySize,
                        Set<HRegion> excludedRegions,
                        boolean checkStoreFileCount) | 
| (package private) void | SecureBulkLoadManager. setFsCreatedListener(Consumer<HRegion> fsCreatedListener) | 
| Constructor and Description | 
|---|
| BatchOperation(HRegion region,
              T[] operations) | 
| CompactionRunner(HStore store,
                HRegion region,
                CompactionContext compaction,
                CompactionLifeCycleTracker tracker,
                CompactSplit.CompactionCompleteTracker completeTracker,
                ThreadPoolExecutor parent,
                User user) | 
| FlushRegionEntry(HRegion r,
                boolean forceFlushAllStores,
                FlushLifeCycleTracker tracker) | 
| HMobStore(HRegion region,
         ColumnFamilyDescriptor family,
         org.apache.hadoop.conf.Configuration confParam) | 
| HStore(HRegion region,
      ColumnFamilyDescriptor family,
      org.apache.hadoop.conf.Configuration confParam)Constructor | 
| MetricsRegionWrapperImpl(HRegion region) | 
| MutationBatchOperation(HRegion region,
                      Mutation[] operations,
                      boolean atomic,
                      long nonceGroup,
                      long nonce) | 
| PostOpenDeployContext(HRegion region,
                     long masterSystemTime) | 
| RegionCoprocessorHost(HRegion region,
                     RegionServerServices rsServices,
                     org.apache.hadoop.conf.Configuration conf)Constructor | 
| RegionScannerHolder(String scannerName,
                   RegionScanner s,
                   HRegion r,
                   RpcCallback closeCallBack,
                   RpcCallback shippedCallback,
                   boolean needCursor) | 
| RegionScannerImpl(Scan scan,
                 List<KeyValueScanner> additionalScanners,
                 HRegion region) | 
| RegionScannerImpl(Scan scan,
                 List<KeyValueScanner> additionalScanners,
                 HRegion region,
                 long nonceGroup,
                 long nonce) | 
| RegionServicesForStores(HRegion region,
                       RegionServerServices rsServices) | 
| ReplayBatchOperation(HRegion region,
                    WALSplitter.MutationReplay[] operations,
                    long origLogSeqNum) | 
| ReversedRegionScannerImpl(Scan scan,
                         List<KeyValueScanner> additionalScanners,
                         HRegion region) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | CompactionRequester. requestCompaction(HRegion region,
                 HStore store,
                 String why,
                 int priority,
                 CompactionLifeCycleTracker tracker,
                 User user)Request compaction on the given store. | 
| void | CompactionRequester. requestCompaction(HRegion region,
                 String why,
                 int priority,
                 CompactionLifeCycleTracker tracker,
                 User user)Request compaction on all the stores of the given region. | 
| Modifier and Type | Field and Description | 
|---|---|
| private HRegion | OpenRegionHandler.PostOpenDeployTasksThread. region | 
| private HRegion | RegionReplicaFlushHandler. region | 
| Modifier and Type | Method and Description | 
|---|---|
| (package private) HRegion | OpenRegionHandler. openRegion() | 
| Modifier and Type | Method and Description | 
|---|---|
| (package private) void | OpenRegionHandler. cleanupFailedOpen(HRegion region) | 
| private void | OpenRegionHandler. doCleanUpOnFailedOpen(HRegion region) | 
| (package private) void | RegionReplicaFlushHandler. triggerFlushInPrimaryRegion(HRegion region) | 
| (package private) boolean | OpenRegionHandler. updateMeta(HRegion r,
          long masterSystemTime)Update ZK or META. | 
| Constructor and Description | 
|---|
| PostOpenDeployTasksThread(HRegion region,
                         Server server,
                         RegionServerServices services,
                         AtomicBoolean signaller,
                         long masterSystemTime) | 
| RegionReplicaFlushHandler(Server server,
                         ClusterConnection connection,
                         RpcRetryingCallerFactory rpcRetryingCallerFactory,
                         RpcControllerFactory rpcControllerFactory,
                         int operationTimeout,
                         HRegion region) | 
| Modifier and Type | Field and Description | 
|---|---|
| private HRegion | FlushSnapshotSubprocedure.RegionSnapshotTask. region | 
| Modifier and Type | Field and Description | 
|---|---|
| private List<HRegion> | FlushSnapshotSubprocedure. regions | 
| Modifier and Type | Method and Description | 
|---|---|
| private List<HRegion> | RegionServerSnapshotManager. 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. | 
| Constructor and Description | 
|---|
| RegionSnapshotTask(HRegion region,
                  org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotDescription snapshotDesc,
                  boolean skipFlush,
                  ForeignExceptionDispatcher monitor) | 
| Constructor and Description | 
|---|
| FlushSnapshotSubprocedure(ProcedureMember member,
                         ForeignExceptionDispatcher errorListener,
                         long wakeFrequency,
                         long timeout,
                         List<HRegion> regions,
                         org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotDescription snapshot,
                         RegionServerSnapshotManager.SnapshotSubprocedurePool taskManager) | 
| 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. | 
| 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. | 
| Modifier and Type | Method and Description | 
|---|---|
| static HRegion | HBaseFsckRepair. createHDFSRegionDir(org.apache.hadoop.conf.Configuration conf,
                   RegionInfo hri,
                   TableDescriptor htd)Creates, flushes, and closes a new region. | 
| Modifier and Type | Method and Description | 
|---|---|
| void | 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. | 
Copyright © 2007–2019 The Apache Software Foundation. All rights reserved.