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.procedure.flush | |
org.apache.hadoop.hbase.regionserver | |
org.apache.hadoop.hbase.regionserver.snapshot | |
org.apache.hadoop.hbase.replication |
Multi Cluster Replication
|
org.apache.hadoop.hbase.replication.regionserver | |
org.apache.hadoop.hbase.thrift2.client | |
org.apache.hadoop.hbase.zookeeper |
Modifier and Type | Interface and Description |
---|---|
interface |
Server
Defines a curated set of shared functions implemented by HBase servers (Masters
and RegionServers).
|
Modifier and Type | Class and Description |
---|---|
class |
SharedConnection
Wraps a Connection to make it can't be closed or aborted.
|
Modifier and Type | Interface and Description |
---|---|
interface |
Admin
The administrative API for HBase.
|
interface |
ClusterConnection
Internal methods on Connection that should not be used by user code.
|
interface |
Connection
A cluster connection encapsulating lower level individual connections to actual servers and
a connection to zookeeper.
|
interface |
Hbck
Hbck fixup tool APIs.
|
Modifier and Type | Class and Description |
---|---|
(package private) class |
ConnectionImplementation
Main implementation of
Connection and ClusterConnection interfaces. |
(package private) static class |
ConnectionUtils.MasterlessConnection
Some tests shut down the master.
|
static class |
ConnectionUtils.ShortCircuitingClusterConnection
A 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 |
HBaseAdmin
HBaseAdmin is no longer a client API.
|
private static class |
HBaseAdmin.ThrowableAbortable
Simple
Abortable , throwing RuntimeException on abort. |
class |
HBaseHbck
Use
Connection.getHbck() to obtain an instance of Hbck instead 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 |
MasterServices
A curated subset of services provided by
HMaster . |
Modifier and Type | Class and Description |
---|---|
class |
HMaster
HMaster 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 |
RegionServerFlushTableProcedureManager.FlushTableSubprocedurePool.abortable |
Constructor and Description |
---|
FlushTableSubprocedurePool(String name,
org.apache.hadoop.conf.Configuration conf,
Abortable abortable) |
Modifier and Type | Interface and Description |
---|---|
interface |
RegionServerServices
A curated subset of services provided by
HRegionServer . |
Modifier and Type | Class and Description |
---|---|
class |
HRegionServer
HRegionServer 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 | Class and Description |
---|---|
class |
HBaseReplicationEndpoint
A
BaseReplicationEndpoint for 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 |
HBaseInterClusterReplicationEndpoint
A
ReplicationEndpoint
implementation for replicating to another HBase cluster. |
class |
RegionReplicaReplicationEndpoint
A
ReplicationEndpoint endpoint
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 |
ZKWatcher
Acts as the single ZooKeeper Watcher.
|
Modifier and Type | Field and Description |
---|---|
protected Abortable |
ZKNodeTracker.abortable
Used 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
zookeeper reference. |
RegionNormalizerTracker(ZKWatcher watcher,
Abortable abortable) |
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–2020 The Apache Software Foundation. All rights reserved.