| Package | Description | 
|---|---|
| org.apache.hadoop.hbase | |
| org.apache.hadoop.hbase.client | Provides HBase Client | 
| org.apache.hadoop.hbase.client.locking | |
| org.apache.hadoop.hbase.coprocessor | Table of Contents | 
| org.apache.hadoop.hbase.ipc | Tools to help define network clients and servers. | 
| org.apache.hadoop.hbase.master | |
| org.apache.hadoop.hbase.master.region | |
| org.apache.hadoop.hbase.procedure.flush | |
| org.apache.hadoop.hbase.regionserver | |
| org.apache.hadoop.hbase.regionserver.snapshot | |
| org.apache.hadoop.hbase.regionserver.wal | |
| org.apache.hadoop.hbase.replication | Multi Cluster Replication | 
| org.apache.hadoop.hbase.replication.regionserver | |
| org.apache.hadoop.hbase.thrift2.client | |
| org.apache.hadoop.hbase.wal | |
| org.apache.hadoop.hbase.zookeeper | 
| Modifier and Type | Interface and Description | 
|---|---|
| interface  | ServerDefines a curated set of shared functions implemented by HBase servers (Masters
 and RegionServers). | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | SharedConnectionWraps a Connection to make it can't be closed or aborted. | 
| Modifier and Type | Interface and Description | 
|---|---|
| interface  | AdminThe administrative API for HBase. | 
| interface  | ClusterConnectionInternal methods on Connection that should not be used by user code. | 
| interface  | ConnectionA cluster connection encapsulating lower level individual connections to actual servers and
 a connection to zookeeper. | 
| interface  | HbckHbck fixup tool APIs. | 
| Modifier and Type | Class and Description | 
|---|---|
| (package private) class  | ConnectionImplementationMain implementation of  ConnectionandClusterConnectioninterfaces. | 
| (package private) static class  | ConnectionUtils.MasterlessConnectionSome tests shut down the master. | 
| static class  | ConnectionUtils.ShortCircuitingClusterConnectionA ClusterConnection that will short-circuit RPC making direct invocations against the localhost
 if the invocation target is 'this' server; save on network and protobuf invocations. | 
| class  | HBaseAdminHBaseAdmin is no longer a client API. | 
| private static class  | HBaseAdmin.ThrowableAbortableSimple  Abortable, throwing RuntimeException on abort. | 
| class  | HBaseHbckUse  Connection.getHbck()to obtain an instance ofHbckinstead of
 constructing an HBaseHbck directly. | 
| Modifier and Type | Field and Description | 
|---|---|
| private Abortable | EntityLock. abort | 
| Modifier and Type | Method and Description | 
|---|---|
| EntityLock | LockServiceClient. namespaceLock(String namespace,
             String description,
             Abortable abort)LocCreate a new EntityLock object to acquire exclusive lock on a namespace. | 
| EntityLock | LockServiceClient. regionLock(List<RegionInfo> regionInfos,
          String description,
          Abortable abort)Create a new EntityLock object to acquire exclusive lock on multiple regions of same tables. | 
| EntityLock | LockServiceClient. tableLock(TableName tableName,
         boolean exclusive,
         String description,
         Abortable abort)Create a new EntityLock object to acquire an exclusive or shared lock on a table. | 
| Constructor and Description | 
|---|
| EntityLock(org.apache.hadoop.conf.Configuration conf,
          org.apache.hadoop.hbase.shaded.protobuf.generated.LockServiceProtos.LockService.BlockingInterface stub,
          org.apache.hadoop.hbase.shaded.protobuf.generated.LockServiceProtos.LockRequest request,
          Abortable abort)Abortable.abort() is called when the lease of the lock will expire. | 
| Modifier and Type | Field and Description | 
|---|---|
| protected Abortable | CoprocessorHost. abortable | 
| Constructor and Description | 
|---|
| CoprocessorHost(Abortable abortable) | 
| Modifier and Type | Field and Description | 
|---|---|
| private Abortable | RpcExecutor. abortable | 
| private Abortable | SimpleRpcScheduler. abortable | 
| Constructor and Description | 
|---|
| BalancedQueueRpcExecutor(String name,
                        int handlerCount,
                        int maxQueueLength,
                        PriorityFunction priority,
                        org.apache.hadoop.conf.Configuration conf,
                        Abortable abortable) | 
| BalancedQueueRpcExecutor(String name,
                        int handlerCount,
                        String callQueueType,
                        int maxQueueLength,
                        PriorityFunction priority,
                        org.apache.hadoop.conf.Configuration conf,
                        Abortable abortable) | 
| FastPathBalancedQueueRpcExecutor(String name,
                                int handlerCount,
                                int maxQueueLength,
                                PriorityFunction priority,
                                org.apache.hadoop.conf.Configuration conf,
                                Abortable abortable) | 
| FastPathBalancedQueueRpcExecutor(String name,
                                int handlerCount,
                                String callQueueType,
                                int maxQueueLength,
                                PriorityFunction priority,
                                org.apache.hadoop.conf.Configuration conf,
                                Abortable abortable) | 
| MetaRWQueueRpcExecutor(String name,
                      int handlerCount,
                      int maxQueueLength,
                      PriorityFunction priority,
                      org.apache.hadoop.conf.Configuration conf,
                      Abortable abortable) | 
| RpcExecutor(String name,
           int handlerCount,
           int maxQueueLength,
           PriorityFunction priority,
           org.apache.hadoop.conf.Configuration conf,
           Abortable abortable) | 
| RpcExecutor(String name,
           int handlerCount,
           String callQueueType,
           int maxQueueLength,
           PriorityFunction priority,
           org.apache.hadoop.conf.Configuration conf,
           Abortable abortable) | 
| RWQueueRpcExecutor(String name,
                  int handlerCount,
                  int maxQueueLength,
                  PriorityFunction priority,
                  org.apache.hadoop.conf.Configuration conf,
                  Abortable abortable) | 
| SimpleRpcScheduler(org.apache.hadoop.conf.Configuration conf,
                  int handlerCount,
                  int priorityHandlerCount,
                  int replicationHandlerCount,
                  int metaTransitionHandler,
                  PriorityFunction priority,
                  Abortable server,
                  int highPriorityLevel) | 
| Modifier and Type | Interface and Description | 
|---|---|
| interface  | MasterServicesA curated subset of services provided by  HMaster. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | HMasterHMaster is the "master server" for HBase. | 
| static class  | HMasterCommandLine.LocalHMaster | 
| Modifier and Type | Field and Description | 
|---|---|
| private Abortable | DrainingServerTracker. abortable | 
| Constructor and Description | 
|---|
| DrainingServerTracker(ZKWatcher watcher,
                     Abortable abortable,
                     ServerManager serverManager) | 
| SplitOrMergeTracker(ZKWatcher watcher,
                   org.apache.hadoop.conf.Configuration conf,
                   Abortable abortable) | 
| SwitchStateTracker(ZKWatcher watcher,
                  String node,
                  Abortable abortable) | 
| Modifier and Type | Field and Description | 
|---|---|
| private Abortable | MasterRegionFlusherAndCompactor. abortable | 
| Modifier and Type | Method and Description | 
|---|---|
| (package private) static MasterRegionWALRoller | MasterRegionWALRoller. create(String name,
      org.apache.hadoop.conf.Configuration conf,
      Abortable abortable,
      org.apache.hadoop.fs.FileSystem fs,
      org.apache.hadoop.fs.Path walRootDir,
      org.apache.hadoop.fs.Path globalWALRootDir,
      String archivedWALSuffix,
      long rollPeriodMs,
      long flushSize) | 
| Constructor and Description | 
|---|
| 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) | 
| MasterRegionWALRoller(String name,
                     org.apache.hadoop.conf.Configuration conf,
                     Abortable abortable,
                     org.apache.hadoop.fs.FileSystem fs,
                     org.apache.hadoop.fs.Path walRootDir,
                     org.apache.hadoop.fs.Path globalWALRootDir,
                     String archivedWALSuffix) | 
| Modifier and Type | Field and Description | 
|---|---|
| private Abortable | RegionServerFlushTableProcedureManager.FlushTableSubprocedurePool. abortable | 
| Constructor and Description | 
|---|
| FlushTableSubprocedurePool(String name,
                          org.apache.hadoop.conf.Configuration conf,
                          Abortable abortable) | 
| Modifier and Type | Interface and Description | 
|---|---|
| interface  | RegionServerServicesA curated subset of services provided by  HRegionServer. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | HRegionServerHRegionServer makes a set of HRegions available to clients. | 
| Modifier and Type | Method and Description | 
|---|---|
| RpcScheduler | RpcSchedulerFactory. create(org.apache.hadoop.conf.Configuration conf,
      PriorityFunction priority,
      Abortable server)Constructs a  RpcScheduler. | 
| RpcScheduler | SimpleRpcSchedulerFactory. create(org.apache.hadoop.conf.Configuration conf,
      PriorityFunction priority,
      Abortable server) | 
| RpcScheduler | FifoRpcSchedulerFactory. create(org.apache.hadoop.conf.Configuration conf,
      PriorityFunction priority,
      Abortable server) | 
| RpcScheduler | MasterFifoRpcSchedulerFactory. create(org.apache.hadoop.conf.Configuration conf,
      PriorityFunction priority,
      Abortable server) | 
| EntityLock | RegionServerServices. regionLock(List<RegionInfo> regionInfos,
          String description,
          Abortable abort)Master based locks on namespaces/tables/regions. | 
| EntityLock | HRegionServer. regionLock(List<RegionInfo> regionInfos,
          String description,
          Abortable abort) | 
| Modifier and Type | Field and Description | 
|---|---|
| private Abortable | RegionServerSnapshotManager.SnapshotSubprocedurePool. abortable | 
| Constructor and Description | 
|---|
| SnapshotSubprocedurePool(String name,
                        org.apache.hadoop.conf.Configuration conf,
                        Abortable abortable) | 
| Modifier and Type | Field and Description | 
|---|---|
| protected Abortable | AbstractFSWAL. abortable | 
| Constructor and Description | 
|---|
| AbstractFSWAL(org.apache.hadoop.fs.FileSystem fs,
             Abortable abortable,
             org.apache.hadoop.fs.Path rootDir,
             String logDir,
             String archiveDir,
             org.apache.hadoop.conf.Configuration conf,
             List<WALActionsListener> listeners,
             boolean failIfWALExists,
             String prefix,
             String suffix) | 
| AsyncFSWAL(org.apache.hadoop.fs.FileSystem fs,
          Abortable abortable,
          org.apache.hadoop.fs.Path rootDir,
          String logDir,
          String archiveDir,
          org.apache.hadoop.conf.Configuration conf,
          List<WALActionsListener> listeners,
          boolean failIfWALExists,
          String prefix,
          String suffix,
          org.apache.hbase.thirdparty.io.netty.channel.EventLoopGroup eventLoopGroup,
          Class<? extends org.apache.hbase.thirdparty.io.netty.channel.Channel> channelClass) | 
| FSHLog(org.apache.hadoop.fs.FileSystem fs,
      Abortable abortable,
      org.apache.hadoop.fs.Path root,
      String logDir,
      org.apache.hadoop.conf.Configuration conf) | 
| FSHLog(org.apache.hadoop.fs.FileSystem fs,
      Abortable abortable,
      org.apache.hadoop.fs.Path rootDir,
      String logDir,
      String archiveDir,
      org.apache.hadoop.conf.Configuration conf,
      List<WALActionsListener> listeners,
      boolean failIfWALExists,
      String prefix,
      String suffix)Create an edit log at the given  dirlocation. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | HBaseReplicationEndpointA  BaseReplicationEndpointfor replication endpoints whose
 target cluster is an HBase cluster. | 
| Modifier and Type | Field and Description | 
|---|---|
| private Abortable | ReplicationTrackerZKImpl. abortable | 
| private Abortable | ReplicationEndpoint.Context. abortable | 
| Modifier and Type | Method and Description | 
|---|---|
| Abortable | ReplicationEndpoint.Context. getAbortable() | 
| Modifier and Type | Method and Description | 
|---|---|
| static ReplicationTracker | ReplicationFactory. getReplicationTracker(ZKWatcher zookeeper,
                     Abortable abortable,
                     Stoppable stopper) | 
| Constructor and Description | 
|---|
| Context(org.apache.hadoop.conf.Configuration localConf,
       org.apache.hadoop.conf.Configuration conf,
       org.apache.hadoop.fs.FileSystem fs,
       String peerId,
       UUID clusterId,
       ReplicationPeer replicationPeer,
       MetricsSource metrics,
       TableDescriptors tableDescriptors,
       Abortable abortable) | 
| ReplicationTrackerZKImpl(ZKWatcher zookeeper,
                        Abortable abortable,
                        Stoppable stopper) | 
| Modifier and Type | Class and Description | 
|---|---|
| private static class  | DumpReplicationQueues.WarnOnlyAbortable | 
| class  | HBaseInterClusterReplicationEndpointA  ReplicationEndpointimplementation for replicating to another HBase cluster. | 
| class  | RegionReplicaReplicationEndpointA  ReplicationEndpointendpoint
 which receives the WAL edits from the WAL, and sends the edits to replicas
 of regions. | 
| (package private) class  | ReplicationSyncUp.DummyServer | 
| Modifier and Type | Field and Description | 
|---|---|
| private Abortable | HBaseInterClusterReplicationEndpoint. abortable | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | ThriftAdmin | 
| class  | ThriftConnection | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | AbstractWALRoller<T extends Abortable>Runs periodically to determine if the WAL should be rolled. | 
| Modifier and Type | Field and Description | 
|---|---|
| (package private) Abortable | WALFactory. abortable | 
| protected T | AbstractWALRoller. abortable | 
| protected Abortable | AbstractFSWALProvider. abortable | 
| Modifier and Type | Method and Description | 
|---|---|
| void | RegionGroupingProvider. init(WALFactory factory,
    org.apache.hadoop.conf.Configuration conf,
    String providerId,
    Abortable abortable) | 
| void | WALProvider. init(WALFactory factory,
    org.apache.hadoop.conf.Configuration conf,
    String providerId,
    Abortable abortable)Set up the provider to create wals. | 
| void | DisabledWALProvider. init(WALFactory factory,
    org.apache.hadoop.conf.Configuration conf,
    String providerId,
    Abortable abortable) | 
| void | AbstractFSWALProvider. init(WALFactory factory,
    org.apache.hadoop.conf.Configuration conf,
    String providerId,
    Abortable abortable) | 
| Constructor and Description | 
|---|
| WALFactory(org.apache.hadoop.conf.Configuration conf,
          String factoryId,
          Abortable abortable) | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | ZKWatcherActs as the single ZooKeeper Watcher. | 
| Modifier and Type | Field and Description | 
|---|---|
| protected Abortable | ZKNodeTracker. abortableUsed to abort if a fatal error occurs | 
| private Abortable | ZKClusterId. abortable | 
| protected Abortable | ZKWatcher. abortable | 
| Constructor and Description | 
|---|
| ClusterStatusTracker(ZKWatcher watcher,
                    Abortable abortable)Creates a cluster status tracker. | 
| LoadBalancerTracker(ZKWatcher watcher,
                   Abortable abortable) | 
| MasterAddressTracker(ZKWatcher watcher,
                    Abortable abortable)Construct a master address listener with the specified
  zookeeperreference. | 
| RegionNormalizerTracker(ZKWatcher watcher,
                       Abortable abortable) | 
| SnapshotCleanupTracker(ZKWatcher watcher,
                      Abortable abortable)Constructs a new ZK node tracker. | 
| ZKClusterId(ZKWatcher watcher,
           Abortable abortable) | 
| ZKNodeTracker(ZKWatcher watcher,
             String node,
             Abortable abortable)Constructs a new ZK node tracker. | 
| ZKWatcher(org.apache.hadoop.conf.Configuration conf,
         String identifier,
         Abortable abortable)Instantiate a ZooKeeper connection and watcher. | 
| ZKWatcher(org.apache.hadoop.conf.Configuration conf,
         String identifier,
         Abortable abortable,
         boolean canCreateBaseZNode)Instantiate a ZooKeeper connection and watcher. | 
| ZKWatcher(org.apache.hadoop.conf.Configuration conf,
         String identifier,
         Abortable abortable,
         boolean canCreateBaseZNode,
         boolean clientZK)Instantiate a ZooKeeper connection and watcher. | 
Copyright © 2007–2021 The Apache Software Foundation. All rights reserved.