Package | Description |
---|---|
org.apache.hadoop.hbase | |
org.apache.hadoop.hbase.coordination | |
org.apache.hadoop.hbase.executor | |
org.apache.hadoop.hbase.ipc |
Tools to help define network clients and servers.
|
org.apache.hadoop.hbase.master | |
org.apache.hadoop.hbase.master.handler | |
org.apache.hadoop.hbase.regionserver | |
org.apache.hadoop.hbase.regionserver.handler | |
org.apache.hadoop.hbase.replication.regionserver |
Modifier and Type | Method and Description |
---|---|
Server |
CoordinatedStateManager.getServer() |
Modifier and Type | Method and Description |
---|---|
void |
CoordinatedStateManager.initialize(Server server)
Initialize coordinated state management service.
|
Modifier and Type | Field and Description |
---|---|
protected Server |
ZkCoordinatedStateManager.server |
Modifier and Type | Method and Description |
---|---|
Server |
BaseCoordinatedStateManager.getServer() |
Server |
ZkCoordinatedStateManager.getServer() |
Modifier and Type | Method and Description |
---|---|
void |
BaseCoordinatedStateManager.initialize(Server server) |
void |
ZkCoordinatedStateManager.initialize(Server server) |
Modifier and Type | Field and Description |
---|---|
protected Server |
EventHandler.server |
Constructor and Description |
---|
EventHandler(Server server,
EventType eventType)
Default base class constructor.
|
Constructor and Description |
---|
RpcServer(Server server,
String name,
List<RpcServer.BlockingServiceAndInterface> services,
InetSocketAddress bindAddress,
org.apache.hadoop.conf.Configuration conf,
RpcScheduler scheduler)
Constructs a server listening on the named port and address.
|
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 |
Modifier and Type | Field and Description |
---|---|
protected Server |
BulkAssigner.server |
Constructor and Description |
---|
BulkAssigner(Server server) |
BulkReOpen(Server server,
Map<ServerName,List<HRegionInfo>> serverToRegions,
AssignmentManager am) |
GeneralBulkAssigner(Server server,
Map<ServerName,List<HRegionInfo>> bulkPlan,
AssignmentManager am,
boolean waitTillAllAssigned) |
MasterFileSystem(Server master,
MasterServices services) |
ServerManager(Server master,
MasterServices services)
Constructor.
|
SplitLogManager(Server server,
org.apache.hadoop.conf.Configuration conf,
Stoppable stopper,
MasterServices master,
ServerName serverName)
Its OK to construct this object even when region-servers are not online.
|
Constructor and Description |
---|
ClosedRegionHandler(Server server,
AssignmentManager assignmentManager,
HRegionInfo regionInfo) |
CreateTableHandler(Server server,
MasterFileSystem fileSystemManager,
HTableDescriptor hTableDescriptor,
org.apache.hadoop.conf.Configuration conf,
HRegionInfo[] newRegions,
MasterServices masterServices) |
DisableTableHandler(Server server,
TableName tableName,
AssignmentManager assignmentManager,
TableLockManager tableLockManager,
boolean skipTableStateCheck) |
EnableTableHandler(Server server,
TableName tableName,
AssignmentManager assignmentManager,
TableLockManager tableLockManager,
boolean skipTableStateCheck) |
OpenedRegionHandler(Server server,
AssignmentManager assignmentManager,
HRegionInfo regionInfo,
OpenRegionCoordination coordination,
OpenRegionCoordination.OpenRegionDetails ord) |
TableEventHandler(EventType eventType,
TableName tableName,
Server server,
MasterServices masterServices) |
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 |
---|---|
Server |
RegionMergeTransactionImpl.getServer() |
Server |
SplitTransactionImpl.getServer() |
Server |
RegionMergeTransaction.getServer()
Get the Server running the transaction or rollback
|
Server |
SplitTransaction.getServer()
Get the Server running the transaction or rollback
|
Modifier and Type | Method and Description |
---|---|
static HeapMemoryManager |
HeapMemoryManager.create(org.apache.hadoop.conf.Configuration conf,
FlushRequester memStoreFlusher,
Server server,
RegionServerAccounting regionServerAccounting) |
HRegion |
RegionMergeTransactionImpl.execute(Server server,
RegionServerServices services)
Run the transaction.
|
PairOfSameType<Region> |
SplitTransactionImpl.execute(Server server,
RegionServerServices services) |
Region |
RegionMergeTransaction.execute(Server server,
RegionServerServices services)
Deprecated.
use #execute(Server, RegionServerServices, User)
|
PairOfSameType<Region> |
SplitTransaction.execute(Server server,
RegionServerServices services)
Deprecated.
use #execute(Server, RegionServerServices, User)
|
HRegion |
RegionMergeTransactionImpl.execute(Server server,
RegionServerServices services,
User user) |
PairOfSameType<Region> |
SplitTransactionImpl.execute(Server server,
RegionServerServices services,
User user)
Run the transaction.
|
Region |
RegionMergeTransaction.execute(Server server,
RegionServerServices services,
User user)
Run the transaction.
|
PairOfSameType<Region> |
SplitTransaction.execute(Server server,
RegionServerServices services,
User user)
Run the transaction.
|
void |
ReplicationService.initialize(Server rs,
org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path logdir,
org.apache.hadoop.fs.Path oldLogDir)
Initializes the replication service object.
|
boolean |
RegionMergeTransactionImpl.rollback(Server server,
RegionServerServices services) |
boolean |
SplitTransactionImpl.rollback(Server server,
RegionServerServices services) |
boolean |
RegionMergeTransaction.rollback(Server server,
RegionServerServices services)
Deprecated.
use #rollback(Server, RegionServerServices, User)
|
boolean |
SplitTransaction.rollback(Server server,
RegionServerServices services)
Deprecated.
use #rollback(Server, RegionServerServices, User)
|
boolean |
RegionMergeTransactionImpl.rollback(Server server,
RegionServerServices services,
User user) |
boolean |
SplitTransactionImpl.rollback(Server server,
RegionServerServices services,
User user) |
boolean |
RegionMergeTransaction.rollback(Server server,
RegionServerServices services,
User user)
Roll back a failed transaction
|
boolean |
SplitTransaction.rollback(Server server,
RegionServerServices services,
User user)
Roll back a failed transaction
|
void |
RegionMergeTransactionImpl.stepsAfterPONR(Server server,
RegionServerServices services,
HRegion mergedRegion)
Deprecated.
|
void |
RegionMergeTransactionImpl.stepsAfterPONR(Server server,
RegionServerServices services,
HRegion mergedRegion,
User user) |
PairOfSameType<Region> |
SplitTransactionImpl.stepsAfterPONR(Server server,
RegionServerServices services,
PairOfSameType<Region> regions)
Deprecated.
|
PairOfSameType<Region> |
SplitTransactionImpl.stepsAfterPONR(Server server,
RegionServerServices services,
PairOfSameType<Region> regions,
User user) |
HRegion |
RegionMergeTransactionImpl.stepsBeforePONR(Server server,
RegionServerServices services,
boolean testing) |
PairOfSameType<Region> |
SplitTransactionImpl.stepsBeforePONR(Server server,
RegionServerServices services,
boolean testing) |
Constructor and Description |
---|
CompactedHFilesDischargeHandler(Server server,
EventType eventType,
HStore store) |
LogRoller(Server server,
RegionServerServices services) |
SplitLogWorker(Server hserver,
org.apache.hadoop.conf.Configuration conf,
RegionServerServices rsServices,
LastSequenceId sequenceIdChecker,
WALFactory factory) |
SplitLogWorker(Server hserver,
org.apache.hadoop.conf.Configuration conf,
RegionServerServices server,
SplitLogWorker.TaskExecutor splitTaskExecutor) |
Modifier and Type | Method and Description |
---|---|
protected ReplicationSourceInterface |
ReplicationSourceManager.getReplicationSource(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
ReplicationSourceManager manager,
ReplicationQueues replicationQueues,
ReplicationPeers replicationPeers,
Server server,
String peerId,
UUID clusterId,
ReplicationPeerConfig peerConfig,
ReplicationPeer replicationPeer)
Factory method to create a replication source
|
void |
Replication.initialize(Server server,
org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path logDir,
org.apache.hadoop.fs.Path oldLogDir) |
Constructor and Description |
---|
Replication(Server server,
org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path logDir,
org.apache.hadoop.fs.Path oldLogDir)
Instantiate the replication management (if rep is enabled).
|
ReplicationSourceManager(ReplicationQueues replicationQueues,
ReplicationPeers replicationPeers,
ReplicationTracker replicationTracker,
org.apache.hadoop.conf.Configuration conf,
Server server,
org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path logDir,
org.apache.hadoop.fs.Path oldLogDir,
UUID clusterId)
Creates a replication manager and sets the watch on all the other registered region servers
|
Copyright © 2007–2019 The Apache Software Foundation. All rights reserved.