| Package | Description | 
|---|---|
| org.apache.hadoop.hbase | |
| org.apache.hadoop.hbase.client | Provides HBase Client | 
| org.apache.hadoop.hbase.master | |
| org.apache.hadoop.hbase.master.assignment | |
| org.apache.hadoop.hbase.master.procedure | |
| org.apache.hadoop.hbase.master.webapp | |
| org.apache.hadoop.hbase.replication.regionserver | |
| org.apache.hadoop.hbase.thrift2 | Provides an HBase Thrift
service. | 
| Modifier and Type | Field and Description | 
|---|---|
| private HRegionLocation[] | RegionLocations. locations | 
| Modifier and Type | Method and Description | 
|---|---|
| HRegionLocation | RegionLocations. getDefaultRegionLocation() | 
| HRegionLocation | RegionLocations. getRegionLocation()Returns the first not-null region location in the list | 
| static HRegionLocation | MetaTableAccessor. getRegionLocation(Connection connection,
                 byte[] regionName)Returns the HRegionLocation from meta for the given region | 
| static HRegionLocation | MetaTableAccessor. getRegionLocation(Connection connection,
                 RegionInfo regionInfo)Returns the HRegionLocation from meta for the given region | 
| HRegionLocation | RegionLocations. getRegionLocation(int replicaId) | 
| private static HRegionLocation | AsyncMetaTableAccessor. getRegionLocation(Result r,
                 RegionInfo regionInfo,
                 int replicaId)Returns the HRegionLocation parsed from the given meta row Result
 for the given regionInfo and replicaId. | 
| private static HRegionLocation | MetaTableAccessor. getRegionLocation(Result r,
                 RegionInfo regionInfo,
                 int replicaId)Returns the HRegionLocation parsed from the given meta row Result
 for the given regionInfo and replicaId. | 
| HRegionLocation | RegionLocations. getRegionLocationByRegionName(byte[] regionName)Returns the region location from the list for matching regionName, which can
 be regionName or encodedRegionName | 
| HRegionLocation[] | RegionLocations. getRegionLocations() | 
| private HRegionLocation | RegionLocations. selectRegionLocation(HRegionLocation oldLocation,
                    HRegionLocation location,
                    boolean checkForEquals,
                    boolean force) | 
| Modifier and Type | Method and Description | 
|---|---|
| static CompletableFuture<Optional<HRegionLocation>> | AsyncMetaTableAccessor. getRegionLocation(AsyncTable<?> metaTable,
                 byte[] regionName)Returns the HRegionLocation from meta for the given region | 
| static CompletableFuture<Optional<HRegionLocation>> | AsyncMetaTableAccessor. getRegionLocationWithEncodedName(AsyncTable<?> metaTable,
                                byte[] encodedRegionName)Returns the HRegionLocation from meta for the given encoded region name | 
| static CompletableFuture<List<HRegionLocation>> | AsyncMetaTableAccessor. getTableHRegionLocations(AsyncTable<AdvancedScanResultConsumer> metaTable,
                        TableName tableName)Used to get all region locations for the specific table. | 
| Iterator<HRegionLocation> | RegionLocations. iterator() | 
| Modifier and Type | Method and Description | 
|---|---|
| int | HRegionLocation. compareTo(HRegionLocation o) | 
| RegionLocations | RegionLocations. remove(HRegionLocation location)Removes the given location from the list | 
| private HRegionLocation | RegionLocations. selectRegionLocation(HRegionLocation oldLocation,
                    HRegionLocation location,
                    boolean checkForEquals,
                    boolean force) | 
| RegionLocations | RegionLocations. updateLocation(HRegionLocation location,
              boolean checkForEquals,
              boolean force)Updates the location with new only if the new location has a higher
 seqNum than the old one or force is true. | 
| Constructor and Description | 
|---|
| RegionLocations(HRegionLocation... locations)Constructs the region location list. | 
| Constructor and Description | 
|---|
| RegionLocations(Collection<HRegionLocation> locations) | 
| Modifier and Type | Field and Description | 
|---|---|
| private HRegionLocation | HTableMultiplexer.FlushWorker. addr | 
| HRegionLocation | AsyncClientScanner.OpenScannerResponse. loc | 
| HRegionLocation | AsyncBatchRpcRetryingCaller.RegionRequest. loc | 
| private HRegionLocation | AsyncScanSingleRegionRpcRetryingCaller. loc | 
| private HRegionLocation | AsyncRpcRetryingCallerFactory.ScanSingleRegionCallerBuilder. loc | 
| protected HRegionLocation | RegionServerCallable. locationSome subclasses want to set their own location. | 
| protected HRegionLocation | RegionAdminServiceCallable. location | 
| Modifier and Type | Field and Description | 
|---|---|
| private Map<HRegionLocation,HTableMultiplexer.FlushWorker> | HTableMultiplexer. serverToFlushWorkerMapDeprecated.  The map between each region server to its flush worker | 
| Modifier and Type | Method and Description | 
|---|---|
| private HRegionLocation | AsyncNonMetaRegionLocator. getCachedLocation(HRegionLocation loc) | 
| private HRegionLocation | AsyncMetaRegionLocator. getCacheLocation(HRegionLocation loc) | 
| protected HRegionLocation | MultiServerCallable. getLocation() | 
| protected HRegionLocation | RegionServerCallable. getLocation() | 
| HRegionLocation | RegionAdminServiceCallable. getLocation(boolean useCache) | 
| protected HRegionLocation | ScannerCallable. getLocationForReplica(RegionLocations locs) | 
| default HRegionLocation | RegionLocator. getRegionLocation(byte[] row)Finds the region on which the given row is being served. | 
| default HRegionLocation | RegionLocator. getRegionLocation(byte[] row,
                 boolean reload)Finds the region on which the given row is being served. | 
| default HRegionLocation | RegionLocator. getRegionLocation(byte[] row,
                 int replicaId)Finds the region with the given replica id on which the given row is being served. | 
| HRegionLocation | RegionLocator. getRegionLocation(byte[] row,
                 int replicaId,
                 boolean reload)Finds the region with the given replica id on which the given row is being served. | 
| HRegionLocation | HRegionLocator. getRegionLocation(byte[] row,
                 int replicaId,
                 boolean reload) | 
| HRegionLocation | ClusterConnection. getRegionLocation(TableName tableName,
                 byte[] row,
                 boolean reload)Find region location hosting passed row | 
| HRegionLocation | ConnectionImplementation. getRegionLocation(TableName tableName,
                 byte[] row,
                 boolean reload) | 
| private HRegionLocation | AsyncRequestFutureImpl. getReplicaLocationOrFail(Action action) | 
| HRegionLocation | ClusterConnection. locateRegion(byte[] regionName)Gets the location of the region of regionName. | 
| HRegionLocation | ConnectionImplementation. locateRegion(byte[] regionName) | 
| HRegionLocation | ClusterConnection. locateRegion(TableName tableName,
            byte[] row)Find the location of the region of tableName that row
 lives in. | 
| HRegionLocation | ConnectionImplementation. locateRegion(TableName tableName,
            byte[] row) | 
| HRegionLocation | ClusterConnection. relocateRegion(TableName tableName,
              byte[] row)Find the location of the region of tableName that row
 lives in, ignoring any value that might be in the cache. | 
| HRegionLocation | ConnectionImplementation. relocateRegion(TableName tableName,
              byte[] row) | 
| Modifier and Type | Method and Description | 
|---|---|
| List<HRegionLocation> | RegionLocator. getAllRegionLocations()Retrieves all of the regions associated with this table. | 
| List<HRegionLocation> | HRegionLocator. getAllRegionLocations() | 
| CompletableFuture<List<HRegionLocation>> | AsyncTableRegionLocatorImpl. getAllRegionLocations() | 
| CompletableFuture<List<HRegionLocation>> | AsyncTableRegionLocator. getAllRegionLocations()Retrieves all of the regions associated with this table. | 
| private Pair<List<byte[]>,List<HRegionLocation>> | HTable. getKeysAndRegionsInRange(byte[] startKey,
                        byte[] endKey,
                        boolean includeEndKey)Get the corresponding start keys and regions for an arbitrary range of
 keys. | 
| private Pair<List<byte[]>,List<HRegionLocation>> | HTable. getKeysAndRegionsInRange(byte[] startKey,
                        byte[] endKey,
                        boolean includeEndKey,
                        boolean reload)Get the corresponding start keys and regions for an arbitrary range of
 keys. | 
| (package private) CompletableFuture<HRegionLocation> | RawAsyncHBaseAdmin. getRegionLocation(byte[] regionNameOrEncodedRegionName)Get the region location for the passed region name. | 
| default CompletableFuture<HRegionLocation> | AsyncTableRegionLocator. getRegionLocation(byte[] row)Finds the region on which the given row is being served. | 
| default CompletableFuture<HRegionLocation> | AsyncTableRegionLocator. getRegionLocation(byte[] row,
                 boolean reload)Finds the region on which the given row is being served. | 
| default CompletableFuture<HRegionLocation> | AsyncTableRegionLocator. getRegionLocation(byte[] row,
                 int replicaId)Finds the region with the given  replicaIdon which the given row is being served. | 
| CompletableFuture<HRegionLocation> | AsyncTableRegionLocatorImpl. getRegionLocation(byte[] row,
                 int replicaId,
                 boolean reload) | 
| CompletableFuture<HRegionLocation> | AsyncTableRegionLocator. getRegionLocation(byte[] row,
                 int replicaId,
                 boolean reload)Finds the region with the given  replicaIdon which the given row is being served. | 
| (package private) CompletableFuture<HRegionLocation> | AsyncRegionLocator. getRegionLocation(TableName tableName,
                 byte[] row,
                 int replicaId,
                 RegionLocateType type,
                 boolean reload,
                 long timeoutNs) | 
| (package private) CompletableFuture<HRegionLocation> | AsyncRegionLocator. getRegionLocation(TableName tableName,
                 byte[] row,
                 int replicaId,
                 RegionLocateType type,
                 long timeoutNs) | 
| (package private) CompletableFuture<HRegionLocation> | AsyncRegionLocator. getRegionLocation(TableName tableName,
                 byte[] row,
                 RegionLocateType type,
                 boolean reload,
                 long timeoutNs) | 
| (package private) CompletableFuture<HRegionLocation> | AsyncRegionLocator. getRegionLocation(TableName tableName,
                 byte[] row,
                 RegionLocateType type,
                 long timeoutNs) | 
| default List<HRegionLocation> | RegionLocator. getRegionLocations(byte[] row)Find all the replicas for the region on which the given row is being served. | 
| default CompletableFuture<List<HRegionLocation>> | AsyncTableRegionLocator. getRegionLocations(byte[] row)Find all the replicas for the region on which the given row is being served. | 
| List<HRegionLocation> | RegionLocator. getRegionLocations(byte[] row,
                  boolean reload)Find all the replicas for the region on which the given row is being served. | 
| List<HRegionLocation> | HRegionLocator. getRegionLocations(byte[] row,
                  boolean reload) | 
| CompletableFuture<List<HRegionLocation>> | AsyncTableRegionLocatorImpl. getRegionLocations(byte[] row,
                  boolean reload) | 
| CompletableFuture<List<HRegionLocation>> | AsyncTableRegionLocator. getRegionLocations(byte[] row,
                  boolean reload)Find all the replicas for the region on which the given row is being served. | 
| private CompletableFuture<List<HRegionLocation>> | RawAsyncHBaseAdmin. getTableHRegionLocations(TableName tableName)List all region locations for the specific table. | 
| List<HRegionLocation> | ClusterConnection. locateRegions(TableName tableName)Gets the locations of all regions in the specified table, tableName. | 
| List<HRegionLocation> | ConnectionImplementation. locateRegions(TableName tableName) | 
| List<HRegionLocation> | ClusterConnection. locateRegions(TableName tableName,
             boolean useCache,
             boolean offlined)Gets the locations of all regions in the specified table, tableName. | 
| List<HRegionLocation> | ConnectionImplementation. locateRegions(TableName tableName,
             boolean useCache,
             boolean offlined) | 
| private List<HRegionLocation> | ReversedScannerCallable. locateRegionsInRange(byte[] startKey,
                    byte[] endKey,
                    boolean reload)Get the corresponding regions for an arbitrary range of keys. | 
| Modifier and Type | Method and Description | 
|---|---|
| void | AsyncBatchRpcRetryingCaller.ServerRequest. addAction(HRegionLocation loc,
         Action action) | 
| private void | AsyncNonMetaRegionLocator. addLocationToCache(HRegionLocation loc) | 
| private void | AsyncMetaRegionLocator. addLocationToCache(HRegionLocation loc) | 
| void | MetaCache. cacheLocation(TableName tableName,
             ServerName source,
             HRegionLocation location)Put a newly discovered HRegionLocation into the cache. | 
| private void | ConnectionImplementation. cacheLocation(TableName tableName,
             ServerName source,
             HRegionLocation location)Put a newly discovered HRegionLocation into the cache. | 
| CompletableFuture<T> | AsyncSingleRequestRpcRetryingCaller.Callable. call(HBaseRpcController controller,
    HRegionLocation loc,
    org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ClientService.Interface stub) | 
| private static <REQ,PREQ,PRESP,RESP> | RawAsyncTableImpl. call(HBaseRpcController controller,
    HRegionLocation loc,
    org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ClientService.Interface stub,
    REQ req,
    RawAsyncTableImpl.Converter<PREQ,byte[],REQ> reqConvert,
    RawAsyncTableImpl.RpcCall<PRESP,PREQ> rpcCall,
    RawAsyncTableImpl.Converter<RESP,HBaseRpcController,PRESP> respConverter) | 
| private void | AsyncSingleRequestRpcRetryingCaller. call(HRegionLocation loc) | 
| private CompletableFuture<AsyncClientScanner.OpenScannerResponse> | AsyncClientScanner. callOpenScanner(HBaseRpcController controller,
               HRegionLocation loc,
               org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ClientService.Interface stub) | 
| RequestController.ReturnCode | SimpleRequestController.SubmittedSizeChecker. canTakeOperation(HRegionLocation loc,
                long heapSizeOfRow) | 
| RequestController.ReturnCode | SimpleRequestController.TaskCountChecker. canTakeOperation(HRegionLocation loc,
                long heapSizeOfRow)1) check the regions is allowed. | 
| RequestController.ReturnCode | SimpleRequestController.RequestRowsChecker. canTakeOperation(HRegionLocation loc,
                long heapSizeOfRow) | 
| RequestController.ReturnCode | SimpleRequestController.RequestHeapSizeChecker. canTakeOperation(HRegionLocation loc,
                long heapSizeOfRow) | 
| RequestController.ReturnCode | SimpleRequestController.RowChecker. canTakeOperation(HRegionLocation loc,
                long heapSizeOfRow) | 
| RequestController.ReturnCode | RequestController.Checker. canTakeRow(HRegionLocation loc,
          Row row)Checks the data whether it is valid to submit. | 
| (package private) static boolean | AsyncRegionLocatorHelper. canUpdateOnError(HRegionLocation loc,
                HRegionLocation oldLoc) | 
| void | MetaCache. clearCache(HRegionLocation location) | 
| (package private) static RegionLocations | AsyncRegionLocatorHelper. createRegionLocations(HRegionLocation loc) | 
| void | ClusterConnection. deleteCachedRegionLocation(HRegionLocation location)Deletes cached locations for the specific region. | 
| void | ConnectionImplementation. deleteCachedRegionLocation(HRegionLocation location) | 
| private HRegionLocation | AsyncNonMetaRegionLocator. getCachedLocation(HRegionLocation loc) | 
| private HRegionLocation | AsyncMetaRegionLocator. getCacheLocation(HRegionLocation loc) | 
| (package private) LinkedBlockingQueue<HTableMultiplexer.PutStatus> | HTableMultiplexer. getQueue(HRegionLocation addr)Deprecated.  | 
| AsyncRpcRetryingCallerFactory.ScanSingleRegionCallerBuilder | AsyncRpcRetryingCallerFactory.ScanSingleRegionCallerBuilder. location(HRegionLocation loc) | 
| private static <REQ,RESP> CompletableFuture<RESP> | RawAsyncTableImpl. mutate(HBaseRpcController controller,
      HRegionLocation loc,
      org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ClientService.Interface stub,
      REQ req,
      RawAsyncTableImpl.Converter<org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MutateRequest,byte[],REQ> reqConvert,
      RawAsyncTableImpl.Converter<RESP,HBaseRpcController,org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MutateResponse> respConverter) | 
| private <RES,RESP> CompletableFuture<RESP> | RawAsyncTableImpl. mutateRow(HBaseRpcController controller,
         HRegionLocation loc,
         org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ClientService.Interface stub,
         RowMutations mutation,
         RawAsyncTableImpl.Converter<org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MultiRequest,byte[],RowMutations> reqConvert,
         Function<RES,RESP> respConverter) | 
| private <REQ,RESP> CompletableFuture<RESP> | RawAsyncTableImpl. noncedMutate(long nonceGroup,
            long nonce,
            HBaseRpcController controller,
            HRegionLocation loc,
            org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ClientService.Interface stub,
            REQ req,
            RawAsyncTableImpl.NoncedConverter<org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MutateRequest,byte[],REQ> reqConvert,
            RawAsyncTableImpl.Converter<RESP,HBaseRpcController,org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MutateResponse> respConverter) | 
| void | SimpleRequestController.SubmittedSizeChecker. notifyFinal(RequestController.ReturnCode code,
           HRegionLocation loc,
           long heapSizeOfRow) | 
| void | SimpleRequestController.TaskCountChecker. notifyFinal(RequestController.ReturnCode code,
           HRegionLocation loc,
           long heapSizeOfRow) | 
| void | SimpleRequestController.RequestRowsChecker. notifyFinal(RequestController.ReturnCode code,
           HRegionLocation loc,
           long heapSizeOfRow) | 
| void | SimpleRequestController.RequestHeapSizeChecker. notifyFinal(RequestController.ReturnCode code,
           HRegionLocation loc,
           long heapSizeOfRow) | 
| void | SimpleRequestController.RowChecker. notifyFinal(RequestController.ReturnCode code,
           HRegionLocation loc,
           long heapSizeOfRow)Add the final ReturnCode to the checker. | 
| void | CatalogReplicaLoadBalanceSimpleSelector. onError(HRegionLocation loc)When a client runs into RegionNotServingException, it will call this method to
 update Selector's internal state. | 
| void | CatalogReplicaLoadBalanceSelector. onError(HRegionLocation loc)This method is called when input location is stale, i.e, when clients run into
 org.apache.hadoop.hbase.NotServingRegionException. | 
| private <S,R> void | RawAsyncTableImpl. onLocateComplete(Function<com.google.protobuf.RpcChannel,S> stubMaker,
                ServiceCaller<S,R> callable,
                AsyncTable.CoprocessorCallback<R> callback,
                List<HRegionLocation> locs,
                byte[] endKey,
                boolean endKeyInclusive,
                AtomicBoolean locateFinished,
                AtomicInteger unfinishedRequest,
                HRegionLocation loc,
                Throwable error) | 
| private void | AsyncNonMetaRegionLocator. removeLocationFromCache(HRegionLocation loc) | 
| private void | AsyncMetaRegionLocator. removeLocationFromCache(HRegionLocation loc) | 
| (package private) static RegionLocations | AsyncRegionLocatorHelper. replaceRegionLocation(RegionLocations oldLocs,
                     HRegionLocation loc)Create a new  RegionLocationsbased on the givenoldLocs, and replace the
 location for the givenreplicaIdwith the givenloc. | 
| (package private) boolean | HTableMultiplexer.FlushWorker. resubmitFailedPut(HTableMultiplexer.PutStatus ps,
                 HRegionLocation oldLoc) | 
| private CompletableFuture<com.google.protobuf.Message> | RegionCoprocessorRpcChannelImpl. rpcCall(com.google.protobuf.Descriptors.MethodDescriptor method,
       com.google.protobuf.Message request,
       com.google.protobuf.Message responsePrototype,
       HBaseRpcController controller,
       HRegionLocation loc,
       org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ClientService.Interface stub) | 
| protected void | RegionServerCallable. setLocation(HRegionLocation location) | 
| (package private) void | AsyncNonMetaRegionLocator. updateCachedLocationOnError(HRegionLocation loc,
                           Throwable exception) | 
| (package private) void | AsyncRegionLocator. updateCachedLocationOnError(HRegionLocation loc,
                           Throwable exception) | 
| (package private) void | AsyncMetaRegionLocator. updateCachedLocationOnError(HRegionLocation loc,
                           Throwable exception) | 
| (package private) static void | AsyncRegionLocatorHelper. updateCachedLocationOnError(HRegionLocation loc,
                           Throwable exception,
                           Function<HRegionLocation,HRegionLocation> cachedLocationSupplier,
                           Consumer<HRegionLocation> addToCache,
                           Consumer<HRegionLocation> removeFromCache,
                           MetricsConnection metrics) | 
| private static <REQ> CompletableFuture<Void> | RawAsyncTableImpl. voidMutate(HBaseRpcController controller,
          HRegionLocation loc,
          org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ClientService.Interface stub,
          REQ req,
          RawAsyncTableImpl.Converter<org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MutateRequest,byte[],REQ> reqConvert) | 
| Modifier and Type | Method and Description | 
|---|---|
| private boolean | RawAsyncHBaseAdmin. compareRegionsWithSplitKeys(List<HRegionLocation> locations,
                           byte[][] splitKeys) | 
| private void | HTableMultiplexer.HTableMultiplexerStatus. initialize(Map<HRegionLocation,HTableMultiplexer.FlushWorker> serverToFlushWorkerMap)Deprecated.  | 
| private <S,R> void | RawAsyncTableImpl. onLocateComplete(Function<com.google.protobuf.RpcChannel,S> stubMaker,
                ServiceCaller<S,R> callable,
                AsyncTable.CoprocessorCallback<R> callback,
                List<HRegionLocation> locs,
                byte[] endKey,
                boolean endKeyInclusive,
                AtomicBoolean locateFinished,
                AtomicInteger unfinishedRequest,
                HRegionLocation loc,
                Throwable error) | 
| private static void | ZKConnectionRegistry. tryComplete(org.apache.commons.lang3.mutable.MutableInt remaining,
           Collection<HRegionLocation> locs,
           CompletableFuture<RegionLocations> future) | 
| (package private) static void | AsyncRegionLocatorHelper. updateCachedLocationOnError(HRegionLocation loc,
                           Throwable exception,
                           Function<HRegionLocation,HRegionLocation> cachedLocationSupplier,
                           Consumer<HRegionLocation> addToCache,
                           Consumer<HRegionLocation> removeFromCache,
                           MetricsConnection metrics) | 
| (package private) static void | AsyncRegionLocatorHelper. updateCachedLocationOnError(HRegionLocation loc,
                           Throwable exception,
                           Function<HRegionLocation,HRegionLocation> cachedLocationSupplier,
                           Consumer<HRegionLocation> addToCache,
                           Consumer<HRegionLocation> removeFromCache,
                           MetricsConnection metrics) | 
| (package private) static void | AsyncRegionLocatorHelper. updateCachedLocationOnError(HRegionLocation loc,
                           Throwable exception,
                           Function<HRegionLocation,HRegionLocation> cachedLocationSupplier,
                           Consumer<HRegionLocation> addToCache,
                           Consumer<HRegionLocation> removeFromCache,
                           MetricsConnection metrics) | 
| (package private) static void | AsyncRegionLocatorHelper. updateCachedLocationOnError(HRegionLocation loc,
                           Throwable exception,
                           Function<HRegionLocation,HRegionLocation> cachedLocationSupplier,
                           Consumer<HRegionLocation> addToCache,
                           Consumer<HRegionLocation> removeFromCache,
                           MetricsConnection metrics) | 
| Constructor and Description | 
|---|
| AsyncScanSingleRegionRpcRetryingCaller(org.apache.hbase.thirdparty.io.netty.util.Timer retryTimer,
                                      AsyncConnectionImpl conn,
                                      Scan scan,
                                      ScanMetrics scanMetrics,
                                      long scannerId,
                                      ScanResultCache resultCache,
                                      AdvancedScanResultConsumer consumer,
                                      org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ClientService.Interface stub,
                                      HRegionLocation loc,
                                      boolean isRegionServerRemote,
                                      int priority,
                                      long scannerLeaseTimeoutPeriodNs,
                                      long pauseNs,
                                      long pauseForCQTBENs,
                                      int maxAttempts,
                                      long scanTimeoutNs,
                                      long rpcTimeoutNs,
                                      int startLogErrorsCnt) | 
| FlushWorker(org.apache.hadoop.conf.Configuration conf,
           ClusterConnection conn,
           HRegionLocation addr,
           HTableMultiplexer htableMultiplexer,
           int perRegionServerBufferQueueSize,
           ExecutorService pool,
           ScheduledExecutorService executor) | 
| OpenScannerResponse(HRegionLocation loc,
                   boolean isRegionServerRemote,
                   org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ClientService.Interface stub,
                   HBaseRpcController controller,
                   org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ScanResponse resp) | 
| RegionAdminServiceCallable(ClusterConnection connection,
                          RpcControllerFactory rpcControllerFactory,
                          HRegionLocation location,
                          TableName tableName,
                          byte[] row) | 
| RegionAdminServiceCallable(ClusterConnection connection,
                          RpcControllerFactory rpcControllerFactory,
                          HRegionLocation location,
                          TableName tableName,
                          byte[] row,
                          int replicaId) | 
| RegionRequest(HRegionLocation loc) | 
| ReplicaRegionServerCallable(int id,
                           HRegionLocation location) | 
| Constructor and Description | 
|---|
| HTableMultiplexerStatus(Map<HRegionLocation,HTableMultiplexer.FlushWorker> serverToFlushWorkerMap)Deprecated.  | 
| Modifier and Type | Field and Description | 
|---|---|
| private CopyOnWriteArrayMap<Integer,HRegionLocation> | MetaRegionLocationCache. cachedMetaLocationsCached meta region locations indexed by replica ID. | 
| Modifier and Type | Method and Description | 
|---|---|
| private HRegionLocation | MetaRegionLocationCache. getMetaRegionLocation(int replicaId)Gets the HRegionLocation for a given meta replica ID. | 
| Modifier and Type | Method and Description | 
|---|---|
| Optional<List<HRegionLocation>> | MetaRegionLocationCache. getMetaRegionLocations() | 
| Modifier and Type | Method and Description | 
|---|---|
| HRegionLocation | RegionStates. checkReopened(HRegionLocation oldLoc)Check whether the region has been reopened. | 
| private HRegionLocation | RegionStates. createRegionForReopen(RegionStateNode node) | 
| Modifier and Type | Method and Description | 
|---|---|
| List<HRegionLocation> | RegionStates. getRegionsOfTableForReopen(TableName tableName)Get the regions to be reopened when modifying a table. | 
| Modifier and Type | Method and Description | 
|---|---|
| HRegionLocation | RegionStates. checkReopened(HRegionLocation oldLoc)Check whether the region has been reopened. | 
| Modifier and Type | Field and Description | 
|---|---|
| private List<HRegionLocation> | ReopenTableRegionsProcedure. regions | 
| Modifier and Type | Method and Description | 
|---|---|
| private List<HRegionLocation> | ReopenTableRegionsProcedure. getRegionLocationsForReopen(List<HRegionLocation> tableRegionsForReopen) | 
| Modifier and Type | Method and Description | 
|---|---|
| private boolean | ReopenTableRegionsProcedure. canSchedule(MasterProcedureEnv env,
           HRegionLocation loc) | 
| Modifier and Type | Method and Description | 
|---|---|
| private List<HRegionLocation> | ReopenTableRegionsProcedure. getRegionLocationsForReopen(List<HRegionLocation> tableRegionsForReopen) | 
| Constructor and Description | 
|---|
| RegionReplicaInfo(Result result,
                 HRegionLocation location) | 
| Constructor and Description | 
|---|
| RegionReplicaReplayCallable(ClusterConnection connection,
                           RpcControllerFactory rpcControllerFactory,
                           TableName tableName,
                           HRegionLocation location,
                           RegionInfo regionInfo,
                           byte[] row,
                           List<WAL.Entry> entries,
                           AtomicLong skippedEntries) | 
| Modifier and Type | Method and Description | 
|---|---|
| static org.apache.hadoop.hbase.thrift2.generated.THRegionLocation | ThriftUtilities. regionLocationFromHBase(HRegionLocation hrl) | 
| Modifier and Type | Method and Description | 
|---|---|
| static List<org.apache.hadoop.hbase.thrift2.generated.THRegionLocation> | ThriftUtilities. regionLocationsFromHBase(List<HRegionLocation> locations) | 
Copyright © 2007–2021 The Apache Software Foundation. All rights reserved.