Modifier and Type | Field and Description |
---|---|
private RegionServerServices |
ZkSplitLogWorkerCoordination.server |
Modifier and Type | Method and Description |
---|---|
void |
SplitLogWorkerCoordination.init(RegionServerServices server,
org.apache.hadoop.conf.Configuration conf,
SplitLogWorker.TaskExecutor splitTaskExecutor,
SplitLogWorker worker)
Deprecated.
Initialize internal values.
|
void |
ZkSplitLogWorkerCoordination.init(RegionServerServices server,
org.apache.hadoop.conf.Configuration conf,
SplitLogWorker.TaskExecutor splitExecutor,
SplitLogWorker worker)
Override setter from
SplitLogWorkerCoordination |
Modifier and Type | Method and Description |
---|---|
RegionServerServices |
HasRegionServerServices.getRegionServerServices()
Deprecated.
Returns An instance of RegionServerServices, an object NOT for Coprocessor consumption.
|
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 | Field and Description |
---|---|
private RegionServerServices |
RegionServerFlushTableProcedureManager.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 | Field and Description |
---|---|
private RegionServerServices |
ActivePolicyEnforcement.rss |
private RegionServerServices |
RegionServerRpcQuotaManager.rsServices |
private RegionServerServices |
RegionSizeReportingChore.rsServices |
private RegionServerServices |
RegionServerSpaceQuotaManager.rsServices |
private RegionServerServices |
QuotaCache.rsServices |
Modifier and Type | Method and Description |
---|---|
(package private) RegionServerServices |
RegionServerSpaceQuotaManager.getRegionServerServices() |
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) |
RegionServerSpaceQuotaManager(RegionServerServices rsServices,
SpaceViolationPolicyEnforcementFactory factory) |
RegionSizeReportingChore(RegionServerServices rsServices) |
Modifier and Type | Field and Description |
---|---|
(package private) RegionServerServices |
AbstractViolationPolicyEnforcement.rss |
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 |
---|---|
private RegionServerServices |
CompactedHFilesDischarger.regionServerServices |
(package private) RegionServerServices |
RegionServerCoprocessorHost.RegionServerEnvironmentForCoreCoprocessors.regionServerServices |
private RegionServerServices |
RegionScannerImpl.rsServices |
private RegionServerServices |
RegionServicesForStores.rsServices |
(package private) RegionServerServices |
RegionCoprocessorHost.rsServices
The region server services
|
private RegionServerServices |
RegionCoprocessorHost.RegionEnvironmentForCoreCoprocessors.rsServices |
private RegionServerServices |
RegionServerCoprocessorHost.rsServices |
protected RegionServerServices |
HRegion.rsServices |
private RegionServerServices |
SplitLogWorker.server
Deprecated.
|
private RegionServerServices |
RegionCoprocessorHost.RegionEnvironment.services |
private RegionServerServices |
RegionServerCoprocessorHost.RegionServerEnvironment.services |
Modifier and Type | Method and Description |
---|---|
RegionServerServices |
RegionCoprocessorHost.RegionEnvironmentForCoreCoprocessors.getRegionServerServices() |
RegionServerServices |
RegionServerCoprocessorHost.RegionServerEnvironmentForCoreCoprocessors.getRegionServerServices() |
(package private) RegionServerServices |
HRegion.getRegionServerServices()
Returns Instance of
RegionServerServices used by this HRegion. |
Modifier and Type | Method and Description |
---|---|
static HRegion |
HRegion.createHRegion(RegionInfo info,
org.apache.hadoop.fs.Path rootDir,
org.apache.hadoop.conf.Configuration conf,
TableDescriptor hTableDescriptor,
WAL wal,
boolean initialize,
RegionServerServices rsRpcServices)
Convenience method creating new HRegions.
|
static HRegion |
HRegion.newHRegion(org.apache.hadoop.fs.Path tableDir,
WAL wal,
org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.conf.Configuration conf,
RegionInfo regionInfo,
TableDescriptor htd,
RegionServerServices rsServices)
A utility method to create new instances of HRegion based on the
HConstants.REGION_IMPL
configuration property. |
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 HRegion |
HRegion.openHRegionFromTableDir(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path tableDir,
RegionInfo info,
TableDescriptor htd,
WAL wal,
RegionServerServices rsServices,
CancelableProgressable reporter)
Open a Region.
|
(package private) static SplitLogWorker.TaskExecutor.Status |
SplitLogWorker.splitLog(String filename,
CancelableProgressable p,
org.apache.hadoop.conf.Configuration conf,
RegionServerServices server,
LastSequenceId sequenceIdChecker,
WALFactory factory)
Deprecated.
Returns Result either DONE, RESIGNED, or ERR.
|
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(RegionServerServices services) |
RegionCoprocessorHost(HRegion region,
RegionServerServices rsServices,
org.apache.hadoop.conf.Configuration conf)
Constructor
|
RegionEnvironment(RegionCoprocessor impl,
int priority,
int seq,
org.apache.hadoop.conf.Configuration conf,
Region region,
RegionServerServices services,
ConcurrentMap<String,Object> sharedData)
Constructor
|
RegionEnvironmentForCoreCoprocessors(RegionCoprocessor impl,
int priority,
int seq,
org.apache.hadoop.conf.Configuration conf,
Region region,
RegionServerServices services,
ConcurrentMap<String,Object> sharedData) |
RegionServerCoprocessorHost(RegionServerServices rsServices,
org.apache.hadoop.conf.Configuration conf) |
RegionServerEnvironment(RegionServerCoprocessor impl,
int priority,
int seq,
org.apache.hadoop.conf.Configuration conf,
RegionServerServices services) |
RegionServerEnvironmentForCoreCoprocessors(RegionServerCoprocessor impl,
int priority,
int seq,
org.apache.hadoop.conf.Configuration conf,
RegionServerServices services) |
RegionServicesForStores(HRegion region,
RegionServerServices rsServices) |
SplitLogWorker(org.apache.hadoop.conf.Configuration conf,
RegionServerServices server,
LastSequenceId sequenceIdChecker,
WALFactory factory)
Deprecated.
|
SplitLogWorker(Server hserver,
org.apache.hadoop.conf.Configuration conf,
RegionServerServices server,
SplitLogWorker.TaskExecutor splitTaskExecutor)
Deprecated.
|
Modifier and Type | Field and Description |
---|---|
protected RegionServerServices |
OpenRegionHandler.rsServices
Deprecated.
|
private RegionServerServices |
CloseRegionHandler.rsServices |
private RegionServerServices |
OpenRegionHandler.PostOpenDeployTasksThread.services |
Modifier and Type | Method and Description |
---|---|
private static boolean |
OpenRegionHandler.isRegionStillOpening(RegionInfo regionInfo,
RegionServerServices rsServices)
Deprecated.
|
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)
Deprecated.
|
OpenRegionHandler(Server server,
RegionServerServices rsServices,
RegionInfo regionInfo,
TableDescriptor htd,
long masterSystemTime,
EventType eventType)
Deprecated.
|
PostOpenDeployTasksThread(HRegion region,
Server server,
RegionServerServices services,
AtomicBoolean signaller,
long masterSystemTime) |
Modifier and Type | Field and Description |
---|---|
private RegionServerServices |
RegionServerSnapshotManager.rss |
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) |
abstract void |
PressureAwareThroughputController.setup(RegionServerServices server) |
void |
ThroughputController.setup(RegionServerServices server)
Setup controller for the given region server.
|
void |
PressureAwareCompactionThroughputController.setup(RegionServerServices server) |
void |
PressureAwareFlushThroughputController.setup(RegionServerServices server) |
void |
NoLimitThroughputController.setup(RegionServerServices server) |
Modifier and Type | Field and Description |
---|---|
(package private) RegionServerServices |
WALSplitter.rsServices |
Modifier and Type | Method and Description |
---|---|
static boolean |
WALSplitter.splitLogFile(org.apache.hadoop.fs.Path walDir,
org.apache.hadoop.fs.FileStatus logfile,
org.apache.hadoop.fs.FileSystem walFS,
org.apache.hadoop.conf.Configuration conf,
CancelableProgressable reporter,
LastSequenceId idChecker,
SplitLogWorkerCoordination splitLogWorkerCoordination,
WALFactory factory,
RegionServerServices rsServices)
Splits a WAL file.
|
Constructor and Description |
---|
WALSplitter(WALFactory factory,
org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.Path walRootDir,
org.apache.hadoop.fs.FileSystem walFS,
org.apache.hadoop.fs.Path rootDir,
org.apache.hadoop.fs.FileSystem rootFS,
LastSequenceId idChecker,
SplitLogWorkerCoordination splitLogWorkerCoordination,
RegionServerServices rsServices) |
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.