Package | Description |
---|---|
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 |
Constructor and Description |
---|
ZkCoordinatedStateManager(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) |
static RpcServer |
RpcServerFactory.createRpcServer(Server server,
String name,
List<RpcServer.BlockingServiceAndInterface> services,
InetSocketAddress bindAddress,
org.apache.hadoop.conf.Configuration conf,
RpcScheduler scheduler,
boolean reservoirEnabled) |
Constructor and Description |
---|
NettyRpcServer(Server server,
String name,
List<RpcServer.BlockingServiceAndInterface> services,
InetSocketAddress bindAddress,
org.apache.hadoop.conf.Configuration conf,
RpcScheduler scheduler,
boolean reservoirEnabled) |
RpcServer(Server server,
String name,
List<RpcServer.BlockingServiceAndInterface> services,
InetSocketAddress bindAddress,
org.apache.hadoop.conf.Configuration conf,
RpcScheduler scheduler,
boolean reservoirEnabled)
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,
boolean reservoirEnabled)
Constructs a server listening on the named port and address.
|
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 Server |
ActiveMasterManager.master |
Modifier and Type | Method and Description |
---|---|
protected RpcServerInterface |
MasterRpcServices.createRpcServer(Server server,
org.apache.hadoop.conf.Configuration conf,
RpcSchedulerFactory rpcSchedulerFactory,
InetSocketAddress bindAddress,
String name) |
Constructor and Description |
---|
ActiveMasterManager(ZKWatcher watcher,
ServerName sn,
Server master) |
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 | Field and Description |
---|---|
private Server |
LogRoller.server |
private Server |
HeapMemoryManager.server |
Modifier and Type | Method and Description |
---|---|
static HeapMemoryManager |
HeapMemoryManager.create(org.apache.hadoop.conf.Configuration conf,
FlushRequester memStoreFlusher,
Server server,
RegionServerAccounting regionServerAccounting) |
protected RpcServerInterface |
RSRpcServices.createRpcServer(Server server,
org.apache.hadoop.conf.Configuration conf,
RpcSchedulerFactory rpcSchedulerFactory,
InetSocketAddress bindAddress,
String name) |
void |
ReplicationService.initialize(Server rs,
org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path logdir,
org.apache.hadoop.fs.Path oldLogDir,
WALProvider walProvider)
Initializes the replication service object.
|
Constructor and Description |
---|
CompactedHFilesDischargeHandler(Server server,
EventType eventType,
HStore store) |
HeapMemoryManager(ResizableBlockCache blockCache,
FlushRequester memStoreFlusher,
Server server,
RegionServerAccounting regionServerAccounting) |
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 | Field and Description |
---|---|
private Server |
OpenRegionHandler.PostOpenDeployTasksThread.server |
Constructor and Description |
---|
CloseMetaHandler(Server server,
RegionServerServices rsServices,
RegionInfo regionInfo,
boolean abort) |
CloseRegionHandler(Server server,
RegionServerServices rsServices,
RegionInfo regionInfo,
boolean abort,
EventType eventType,
ServerName destination) |
CloseRegionHandler(Server server,
RegionServerServices rsServices,
RegionInfo regionInfo,
boolean abort,
ServerName destination)
This method used internally by the RegionServer to close out regions.
|
OpenMetaHandler(Server server,
RegionServerServices rsServices,
RegionInfo regionInfo,
TableDescriptor htd,
long masterSystemTime) |
OpenPriorityRegionHandler(Server server,
RegionServerServices rsServices,
RegionInfo regionInfo,
TableDescriptor htd,
long masterSystemTime) |
OpenRegionHandler(Server server,
RegionServerServices rsServices,
RegionInfo regionInfo,
TableDescriptor htd,
long masterSystemTime) |
OpenRegionHandler(Server server,
RegionServerServices rsServices,
RegionInfo regionInfo,
TableDescriptor htd,
long masterSystemTime,
EventType eventType) |
PostOpenDeployTasksThread(HRegion region,
Server server,
RegionServerServices services,
AtomicBoolean signaller,
long masterSystemTime) |
RegionReplicaFlushHandler(Server server,
ClusterConnection connection,
RpcRetryingCallerFactory rpcRetryingCallerFactory,
RpcControllerFactory rpcControllerFactory,
int operationTimeout,
HRegion region) |
WALSplitterHandler(Server server,
SplitLogWorkerCoordination coordination,
SplitLogWorkerCoordination.SplitTaskDetails splitDetails,
CancelableProgressable reporter,
AtomicInteger inProgressTasks,
SplitLogWorker.TaskExecutor splitTaskExecutor) |
Modifier and Type | Class and Description |
---|---|
(package private) class |
ReplicationSyncUp.DummyServer |
Modifier and Type | Field and Description |
---|---|
private Server |
ReplicationSourceManager.server |
private Server |
Replication.server |
protected Server |
ReplicationSource.server |
Modifier and Type | Method and Description |
---|---|
private 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,
WALFileLengthProvider walFileLengthProvider)
Factory method to create a replication source
|
void |
RecoveredReplicationSource.init(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
ReplicationSourceManager manager,
ReplicationQueues replicationQueues,
ReplicationPeers replicationPeers,
Server server,
String peerClusterZnode,
UUID clusterId,
ReplicationEndpoint replicationEndpoint,
WALFileLengthProvider walFileLengthProvider,
MetricsSource metrics) |
void |
ReplicationSourceInterface.init(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
ReplicationSourceManager manager,
ReplicationQueues replicationQueues,
ReplicationPeers replicationPeers,
Server server,
String peerClusterZnode,
UUID clusterId,
ReplicationEndpoint replicationEndpoint,
WALFileLengthProvider walFileLengthProvider,
MetricsSource metrics)
Initializer for the source
|
void |
ReplicationSource.init(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
ReplicationSourceManager manager,
ReplicationQueues replicationQueues,
ReplicationPeers replicationPeers,
Server server,
String peerClusterZnode,
UUID clusterId,
ReplicationEndpoint replicationEndpoint,
WALFileLengthProvider walFileLengthProvider,
MetricsSource metrics)
Instantiation method used by region servers
|
void |
Replication.initialize(Server server,
org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path logDir,
org.apache.hadoop.fs.Path oldLogDir,
WALProvider walProvider) |
Constructor and Description |
---|
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–2019 The Apache Software Foundation. All rights reserved.