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.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 |
ZkCoordinatedStateManager.getServer() |
Server |
BaseCoordinatedStateManager.getServer() |
Modifier and Type | Method and Description |
---|---|
void |
ZkCoordinatedStateManager.initialize(Server server) |
void |
BaseCoordinatedStateManager.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.
|
Modifier and Type | Field and Description |
---|---|
protected Server |
RpcServer.server |
Modifier and Type | Method and Description |
---|---|
static RpcServer |
RpcServerFactory.createRpcServer(Server server,
String name,
List<RpcServer.BlockingServiceAndInterface> services,
InetSocketAddress bindAddress,
org.apache.hadoop.conf.Configuration conf,
RpcScheduler scheduler) |
Constructor and Description |
---|
NettyRpcServer(Server server,
String name,
List<RpcServer.BlockingServiceAndInterface> services,
InetSocketAddress bindAddress,
org.apache.hadoop.conf.Configuration conf,
RpcScheduler scheduler) |
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.
|
SimpleRpcServer(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 | 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 |
---|---|
static HeapMemoryManager |
HeapMemoryManager.create(org.apache.hadoop.conf.Configuration conf,
FlushRequester memStoreFlusher,
Server server,
RegionServerAccounting regionServerAccounting) |
void |
ReplicationService.initialize(Server rs,
org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path logdir,
org.apache.hadoop.fs.Path oldLogDir,
WALFileLengthProvider walFileLengthProvider)
Initializes the replication service object.
|
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 server,
LastSequenceId sequenceIdChecker,
WALFactory factory) |
SplitLogWorker(Server hserver,
org.apache.hadoop.conf.Configuration conf,
RegionServerServices server,
SplitLogWorker.TaskExecutor splitTaskExecutor) |
Modifier and Type | Method and Description |
---|---|
void |
Replication.initialize(Server server,
org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path logDir,
org.apache.hadoop.fs.Path oldLogDir,
WALFileLengthProvider walFileLengthProvider) |
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,
WALFileLengthProvider walFileLengthProvider)
Creates a replication manager and sets the watch on all the other registered region servers
|
Copyright © 2007–2017 The Apache Software Foundation. All rights reserved.