Package | Description |
---|---|
org.apache.hadoop.hbase | |
org.apache.hadoop.hbase.client |
Provides HBase Client
|
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.cleaner | |
org.apache.hadoop.hbase.regionserver | |
org.apache.hadoop.hbase.replication |
Multi Cluster Replication
|
org.apache.hadoop.hbase.replication.regionserver | |
org.apache.hadoop.hbase.zookeeper |
Modifier and Type | Interface and Description |
---|---|
interface |
Server
Defines the set of shared functions implemented by HBase servers (Masters
and RegionServers).
|
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 |
HConnection
Deprecated.
in favor of
Connection and ConnectionFactory |
Modifier and Type | Class and Description |
---|---|
class |
CoprocessorHConnection
Connection to an HTable from within a Coprocessor.
|
class |
HBaseAdmin
HBaseAdmin is no longer a client API.
|
Modifier and Type | Field and Description |
---|---|
protected Abortable |
CoprocessorHost.abortable |
Constructor and Description |
---|
CoprocessorHost(Abortable abortable) |
Constructor and Description |
---|
BalancedQueueRpcExecutor(String name,
int handlerCount,
int numQueues,
org.apache.hadoop.conf.Configuration conf,
Abortable abortable,
Class<? extends BlockingQueue> queueClass,
Object... initargs) |
BalancedQueueRpcExecutor(String name,
int handlerCount,
int numQueues,
int maxQueueLength,
org.apache.hadoop.conf.Configuration conf,
Abortable abortable) |
RpcExecutor(String name,
int handlerCount,
org.apache.hadoop.conf.Configuration conf,
Abortable abortable) |
RWQueueRpcExecutor(String name,
int handlerCount,
int numQueues,
float readShare,
float scanShare,
int maxQueueLength,
org.apache.hadoop.conf.Configuration conf,
Abortable abortable) |
RWQueueRpcExecutor(String name,
int handlerCount,
int numQueues,
float readShare,
float scanShare,
int maxQueueLength,
org.apache.hadoop.conf.Configuration conf,
Abortable abortable,
Class<? extends BlockingQueue> readQueueClass,
Object... readQueueInitArgs) |
RWQueueRpcExecutor(String name,
int handlerCount,
int numQueues,
float readShare,
int maxQueueLength,
org.apache.hadoop.conf.Configuration conf,
Abortable abortable) |
RWQueueRpcExecutor(String name,
int handlerCount,
int numQueues,
float readShare,
int maxQueueLength,
org.apache.hadoop.conf.Configuration conf,
Abortable abortable,
Class<? extends BlockingQueue> readQueueClass,
Object... readQueueInitArgs) |
SimpleRpcScheduler(org.apache.hadoop.conf.Configuration conf,
int handlerCount,
int priorityHandlerCount,
int replicationHandlerCount,
PriorityFunction priority,
Abortable server,
int highPriorityLevel) |
Modifier and Type | Interface and Description |
---|---|
interface |
MasterServices
Services Master supplies
|
Modifier and Type | Class and Description |
---|---|
class |
HMaster
HMaster is the "master server" for HBase.
|
static class |
HMasterCommandLine.LocalHMaster |
Constructor and Description |
---|
ReplicationZKLockCleanerChore(Stoppable stopper,
Abortable abortable,
int period,
ZooKeeperWatcher zk,
org.apache.hadoop.conf.Configuration conf) |
Modifier and Type | Interface and Description |
---|---|
interface |
OnlineRegions
Interface to Map of online regions.
|
interface |
RegionServerServices
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 |
SimpleRpcSchedulerFactory.create(org.apache.hadoop.conf.Configuration conf,
PriorityFunction priority,
Abortable server) |
RpcScheduler |
RpcSchedulerFactory.create(org.apache.hadoop.conf.Configuration conf,
PriorityFunction priority,
Abortable server)
Constructs a
RpcScheduler . |
Modifier and Type | Class and Description |
---|---|
class |
HBaseReplicationEndpoint
A
BaseReplicationEndpoint for replication endpoints whose
target cluster is an HBase cluster. |
class |
ReplicationPeerZKImpl |
Modifier and Type | Field and Description |
---|---|
protected Abortable |
ReplicationStateZKBase.abortable |
Modifier and Type | Method and Description |
---|---|
static ReplicationPeers |
ReplicationFactory.getReplicationPeers(ZooKeeperWatcher zk,
org.apache.hadoop.conf.Configuration conf,
Abortable abortable) |
static ReplicationQueues |
ReplicationFactory.getReplicationQueues(ZooKeeperWatcher zk,
org.apache.hadoop.conf.Configuration conf,
Abortable abortable) |
static ReplicationQueuesClient |
ReplicationFactory.getReplicationQueuesClient(ZooKeeperWatcher zk,
org.apache.hadoop.conf.Configuration conf,
Abortable abortable) |
static ReplicationTracker |
ReplicationFactory.getReplicationTracker(ZooKeeperWatcher zookeeper,
ReplicationPeers replicationPeers,
org.apache.hadoop.conf.Configuration conf,
Abortable abortable,
Stoppable stopper) |
Constructor and Description |
---|
ReplicationPeersZKImpl(ZooKeeperWatcher zk,
org.apache.hadoop.conf.Configuration conf,
Abortable abortable) |
ReplicationPeerZKImpl.PeerStateTracker(String peerStateZNode,
ZooKeeperWatcher watcher,
Abortable abortable) |
ReplicationPeerZKImpl.TableCFsTracker(String tableCFsZNode,
ZooKeeperWatcher watcher,
Abortable abortable) |
ReplicationQueuesClientZKImpl(ZooKeeperWatcher zk,
org.apache.hadoop.conf.Configuration conf,
Abortable abortable) |
ReplicationQueuesZKImpl(ZooKeeperWatcher zk,
org.apache.hadoop.conf.Configuration conf,
Abortable abortable) |
ReplicationStateZKBase(ZooKeeperWatcher zookeeper,
org.apache.hadoop.conf.Configuration conf,
Abortable abortable) |
ReplicationTrackerZKImpl(ZooKeeperWatcher zookeeper,
ReplicationPeers replicationPeers,
org.apache.hadoop.conf.Configuration conf,
Abortable abortable,
Stoppable stopper) |
Modifier and Type | Class and Description |
---|---|
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. |
Modifier and Type | Class and Description |
---|---|
class |
ZooKeeperWatcher
Acts as the single ZooKeeper Watcher.
|
Modifier and Type | Field and Description |
---|---|
protected Abortable |
ZooKeeperWatcher.abortable |
protected Abortable |
ZooKeeperNodeTracker.abortable
Used to abort if a fatal error occurs
|
Constructor and Description |
---|
ClusterStatusTracker(ZooKeeperWatcher watcher,
Abortable abortable)
Creates a cluster status tracker.
|
DrainingServerTracker(ZooKeeperWatcher watcher,
Abortable abortable,
ServerManager serverManager) |
LoadBalancerTracker(ZooKeeperWatcher watcher,
Abortable abortable) |
MasterAddressTracker(ZooKeeperWatcher watcher,
Abortable abortable)
Construct a master address listener with the specified
zookeeper reference. |
ZKClusterId(ZooKeeperWatcher watcher,
Abortable abortable) |
ZooKeeperNodeTracker(ZooKeeperWatcher watcher,
String node,
Abortable abortable)
Constructs a new ZK node tracker.
|
ZooKeeperWatcher(org.apache.hadoop.conf.Configuration conf,
String identifier,
Abortable abortable)
Instantiate a ZooKeeper connection and watcher.
|
ZooKeeperWatcher(org.apache.hadoop.conf.Configuration conf,
String identifier,
Abortable abortable,
boolean canCreateBaseZNode)
Instantiate a ZooKeeper connection and watcher.
|
Copyright © 2007-2016 The Apache Software Foundation. All Rights Reserved.