Modifier and Type | Method and Description |
---|---|
void |
ZkSplitLogWorkerCoordination.init(RegionServerServices server,
org.apache.hadoop.conf.Configuration conf,
SplitLogWorker.TaskExecutor splitExecutor,
SplitLogWorker worker)
Override setter from
SplitLogWorkerCoordination |
void |
SplitLogWorkerCoordination.init(RegionServerServices server,
org.apache.hadoop.conf.Configuration conf,
SplitLogWorker.TaskExecutor splitTaskExecutor,
SplitLogWorker worker)
Initialize internal values.
|
Modifier and Type | Method and Description |
---|---|
RegionServerServices |
HasRegionServerServices.getRegionServerServices()
Deprecated.
|
Modifier and Type | Class and Description |
---|---|
class |
HMaster
HMaster is the "master server" for HBase.
|
static class |
HMasterCommandLine.LocalHMaster |
Modifier and Type | Method and Description |
---|---|
abstract void |
RegionServerProcedureManager.initialize(RegionServerServices rss)
Initialize a globally barriered procedure for region servers.
|
void |
RegionServerProcedureManagerHost.initialize(RegionServerServices rss) |
Modifier and Type | Method and Description |
---|---|
void |
RegionServerFlushTableProcedureManager.initialize(RegionServerServices rss)
Initialize this region server flush procedure manager
Uses a zookeeper based member controller.
|
Modifier and Type | Method and Description |
---|---|
SpaceViolationPolicyEnforcement |
SpaceViolationPolicyEnforcementFactory.create(RegionServerServices rss,
TableName tableName,
SpaceQuotaSnapshot snapshot)
Constructs the appropriate
SpaceViolationPolicyEnforcement for tables that are
in violation of their space quota. |
SpaceViolationPolicyEnforcement |
SpaceViolationPolicyEnforcementFactory.createWithoutViolation(RegionServerServices rss,
TableName tableName,
SpaceQuotaSnapshot snapshot)
Creates the "default"
SpaceViolationPolicyEnforcement for a table that isn't in
violation. |
void |
SpaceViolationPolicyEnforcement.initialize(RegionServerServices rss,
TableName tableName,
SpaceQuotaSnapshot snapshot)
Initializes this policy instance.
|
Constructor and Description |
---|
ActivePolicyEnforcement(Map<TableName,SpaceViolationPolicyEnforcement> activePolicies,
Map<TableName,SpaceQuotaSnapshot> snapshots,
RegionServerServices rss) |
ActivePolicyEnforcement(Map<TableName,SpaceViolationPolicyEnforcement> activePolicies,
Map<TableName,SpaceQuotaSnapshot> snapshots,
RegionServerServices rss,
SpaceViolationPolicyEnforcementFactory factory) |
QuotaCache(RegionServerServices rsServices) |
RegionServerRpcQuotaManager(RegionServerServices rsServices) |
RegionServerSpaceQuotaManager(RegionServerServices rsServices) |
Modifier and Type | Method and Description |
---|---|
RegionServerServices |
AbstractViolationPolicyEnforcement.getRegionServerServices() |
Modifier and Type | Method and Description |
---|---|
void |
AbstractViolationPolicyEnforcement.initialize(RegionServerServices rss,
TableName tableName,
SpaceQuotaSnapshot snapshot) |
void |
AbstractViolationPolicyEnforcement.setRegionServerServices(RegionServerServices rss) |
Modifier and Type | Class and Description |
---|---|
class |
HRegionServer
HRegionServer makes a set of HRegions available to clients.
|
Modifier and Type | Field and Description |
---|---|
protected RegionServerServices |
LogRoller.services |
Modifier and Type | Method and Description |
---|---|
static HRegion |
HRegion.openHRegion(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path rootDir,
org.apache.hadoop.fs.Path tableDir,
RegionInfo info,
TableDescriptor htd,
WAL wal,
RegionServerServices rsServices,
CancelableProgressable reporter)
Open a Region.
|
static HRegion |
HRegion.openHRegion(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path rootDir,
RegionInfo info,
TableDescriptor htd,
WAL wal,
RegionServerServices rsServices,
CancelableProgressable reporter)
Open a Region.
|
static HRegion |
HRegion.openHRegion(org.apache.hadoop.fs.Path rootDir,
RegionInfo info,
TableDescriptor htd,
WAL wal,
org.apache.hadoop.conf.Configuration conf,
RegionServerServices rsServices,
CancelableProgressable reporter)
Open a Region.
|
static HRegion |
HRegion.openHRegion(RegionInfo info,
TableDescriptor htd,
WAL wal,
org.apache.hadoop.conf.Configuration conf,
RegionServerServices rsServices,
CancelableProgressable reporter)
Open a Region.
|
static void |
HRegion.warmupHRegion(RegionInfo info,
TableDescriptor htd,
WAL wal,
org.apache.hadoop.conf.Configuration conf,
RegionServerServices rsServices,
CancelableProgressable reporter) |
Constructor and Description |
---|
CompactedHFilesDischarger(int period,
Stoppable stopper,
RegionServerServices regionServerServices) |
CompactedHFilesDischarger(int period,
Stoppable stopper,
RegionServerServices regionServerServices,
boolean useExecutor) |
HRegion(HRegionFileSystem fs,
WAL wal,
org.apache.hadoop.conf.Configuration confParam,
TableDescriptor htd,
RegionServerServices rsServices)
HRegion constructor.
|
HRegion(org.apache.hadoop.fs.Path tableDir,
WAL wal,
org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.conf.Configuration confParam,
RegionInfo regionInfo,
TableDescriptor htd,
RegionServerServices rsServices)
Deprecated.
Use other constructors.
|
LogRoller(Server server,
RegionServerServices services) |
RegionCoprocessorHost(HRegion region,
RegionServerServices rsServices,
org.apache.hadoop.conf.Configuration conf)
Constructor
|
RegionServerCoprocessorHost(RegionServerServices rsServices,
org.apache.hadoop.conf.Configuration conf) |
RegionServicesForStores(HRegion region,
RegionServerServices rsServices) |
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 |
---|---|
protected RegionServerServices |
OpenRegionHandler.rsServices |
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) |
Modifier and Type | Method and Description |
---|---|
void |
RegionServerSnapshotManager.initialize(RegionServerServices rss)
Create a default snapshot handler - uses a zookeeper based member controller.
|
Modifier and Type | Method and Description |
---|---|
static ThroughputController |
FlushThroughputControllerFactory.create(RegionServerServices server,
org.apache.hadoop.conf.Configuration conf) |
static ThroughputController |
CompactionThroughputControllerFactory.create(RegionServerServices server,
org.apache.hadoop.conf.Configuration conf) |
void |
PressureAwareFlushThroughputController.setup(RegionServerServices server) |
void |
NoLimitThroughputController.setup(RegionServerServices server) |
abstract void |
PressureAwareThroughputController.setup(RegionServerServices server) |
void |
PressureAwareCompactionThroughputController.setup(RegionServerServices server) |
void |
ThroughputController.setup(RegionServerServices server)
Setup controller for the given region server.
|
Copyright © 2007–2019 Cloudera. All rights reserved.