Uses of Interface
org.apache.hadoop.hbase.regionserver.RegionServerServices
Package
Description
Table of Contents
-
Uses of RegionServerServices in org.apache.hadoop.hbase
Modifier and TypeClassDescriptionstatic class
Deprecated.Subclass so can get at protected methods (none at moment).class
Basic mock region server services.Modifier and TypeMethodDescriptionHBaseTestingUtility.createMockRegionServerService()
Deprecated.Create a stubbed out RegionServerService, mainly for getting FS.HBaseTestingUtility.createMockRegionServerService
(RpcServerInterface rpc) Deprecated.Create a stubbed out RegionServerService, mainly for getting FS.HBaseTestingUtility.createMockRegionServerService
(ServerName name) Deprecated.Create a stubbed out RegionServerService, mainly for getting FS. -
Uses of RegionServerServices in org.apache.hadoop.hbase.backup.regionserver
Modifier and TypeFieldDescriptionprivate final RegionServerServices
LogRollBackupSubprocedure.rss
private RegionServerServices
LogRollRegionServerProcedureManager.rss
Modifier and TypeMethodDescriptionvoid
LogRollRegionServerProcedureManager.initialize
(RegionServerServices rss) ModifierConstructorDescriptionLogRollBackupSubprocedure
(RegionServerServices rss, ProcedureMember member, ForeignExceptionDispatcher errorListener, long wakeFrequency, long timeout, LogRollBackupSubprocedurePool taskManager, byte[] data) -
Uses of RegionServerServices in org.apache.hadoop.hbase.coordination
Modifier and TypeFieldDescriptionprivate RegionServerServices
ZkSplitLogWorkerCoordination.server
Modifier and TypeMethodDescriptionvoid
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 fromSplitLogWorkerCoordination
-
Uses of RegionServerServices in org.apache.hadoop.hbase.coprocessor
Modifier and TypeMethodDescriptionHasRegionServerServices.getRegionServerServices()
Deprecated.Returns An instance of RegionServerServices, an object NOT for Coprocessor consumption. -
Uses of RegionServerServices in org.apache.hadoop.hbase.procedure
Modifier and TypeMethodDescriptionabstract void
RegionServerProcedureManager.initialize
(RegionServerServices rss) Initialize a globally barriered procedure for region servers.void
RegionServerProcedureManagerHost.initialize
(RegionServerServices rss) -
Uses of RegionServerServices in org.apache.hadoop.hbase.procedure.flush
Modifier and TypeFieldDescriptionprivate RegionServerServices
RegionServerFlushTableProcedureManager.rss
Modifier and TypeMethodDescriptionvoid
RegionServerFlushTableProcedureManager.initialize
(RegionServerServices rss) Initialize this region server flush procedure manager Uses a zookeeper based member controller. -
Uses of RegionServerServices in org.apache.hadoop.hbase.quotas
Modifier and TypeFieldDescriptionprivate final RegionServerServices
ActivePolicyEnforcement.rss
private final RegionServerServices
QuotaCache.rsServices
private final RegionServerServices
RegionServerRpcQuotaManager.rsServices
private final RegionServerServices
RegionServerSpaceQuotaManager.rsServices
private final RegionServerServices
RegionSizeReportingChore.rsServices
Modifier and TypeMethodDescription(package private) RegionServerServices
RegionServerSpaceQuotaManager.getRegionServerServices()
Modifier and TypeMethodDescriptionSpaceViolationPolicyEnforcementFactory.create
(RegionServerServices rss, TableName tableName, SpaceQuotaSnapshot snapshot) Constructs the appropriateSpaceViolationPolicyEnforcement
for tables that are in violation of their space quota.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.ModifierConstructorDescriptionActivePolicyEnforcement
(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) (package private)
RegionServerSpaceQuotaManager
(RegionServerServices rsServices, SpaceViolationPolicyEnforcementFactory factory) RegionSizeReportingChore
(RegionServerServices rsServices) -
Uses of RegionServerServices in org.apache.hadoop.hbase.quotas.policies
Modifier and TypeFieldDescription(package private) RegionServerServices
AbstractViolationPolicyEnforcement.rss
Modifier and TypeMethodDescriptionvoid
AbstractViolationPolicyEnforcement.initialize
(RegionServerServices rss, TableName tableName, SpaceQuotaSnapshot snapshot) void
AbstractViolationPolicyEnforcement.setRegionServerServices
(RegionServerServices rss) -
Uses of RegionServerServices in org.apache.hadoop.hbase.regionserver
Modifier and TypeClassDescriptionclass
HRegionServer makes a set of HRegions available to clients.Modifier and TypeFieldDescriptionprivate RegionServerServices
CompactedHFilesDischarger.regionServerServices
(package private) final RegionServerServices
RegionServerCoprocessorHost.RegionServerEnvironmentForCoreCoprocessors.regionServerServices
protected RegionServerServices
HRegion.rsServices
private final RegionServerServices
RegionCoprocessorHost.RegionEnvironmentForCoreCoprocessors.rsServices
(package private) RegionServerServices
RegionCoprocessorHost.rsServices
The region server servicesprivate RegionServerServices
RegionScannerImpl.rsServices
private RegionServerServices
RegionServerCoprocessorHost.rsServices
private final RegionServerServices
RegionServicesForStores.rsServices
private final RegionServerServices
SplitLogWorker.server
Deprecated.private final RegionServerServices
RegionCoprocessorHost.RegionEnvironment.services
private final RegionServerServices
RegionServerCoprocessorHost.RegionServerEnvironment.services
Modifier and TypeMethodDescription(package private) RegionServerServices
HRegion.getRegionServerServices()
Returns Instance ofRegionServerServices
used by this HRegion.RegionCoprocessorHost.RegionEnvironmentForCoreCoprocessors.getRegionServerServices()
RegionServerCoprocessorHost.RegionServerEnvironmentForCoreCoprocessors.getRegionServerServices()
Modifier and TypeMethodDescriptionstatic 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 theHConstants.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.private static boolean
SplitLogWorker.processSyncReplicationWAL
(String name, org.apache.hadoop.conf.Configuration conf, RegionServerServices server, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.fs.Path walDir) Deprecated.(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 HRegion
HRegion.warmupHRegion
(RegionInfo info, TableDescriptor htd, WAL wal, org.apache.hadoop.conf.Configuration conf, RegionServerServices rsServices, CancelableProgressable reporter) ModifierConstructorDescriptionCompactedHFilesDischarger
(int period, Stoppable stopper, RegionServerServices regionServerServices) CompactedHFilesDischarger
(int period, Stoppable stopper, RegionServerServices regionServerServices, boolean useExecutor) 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.HRegion
(HRegionFileSystem fs, WAL wal, org.apache.hadoop.conf.Configuration confParam, TableDescriptor htd, RegionServerServices rsServices) HRegion constructor.LogRoller
(RegionServerServices services) RegionCoprocessorHost
(HRegion region, RegionServerServices rsServices, org.apache.hadoop.conf.Configuration conf) ConstructorRegionEnvironment
(RegionCoprocessor impl, int priority, int seq, org.apache.hadoop.conf.Configuration conf, Region region, RegionServerServices services, ConcurrentMap<String, Object> sharedData) ConstructorRegionEnvironmentForCoreCoprocessors
(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. -
Uses of RegionServerServices in org.apache.hadoop.hbase.regionserver.handler
Modifier and TypeFieldDescriptionprivate final RegionServerServices
CloseRegionHandler.rsServices
protected final RegionServerServices
OpenRegionHandler.rsServices
Deprecated.private final RegionServerServices
OpenRegionHandler.PostOpenDeployTasksThread.services
Modifier and TypeMethodDescriptionprivate static boolean
OpenRegionHandler.isRegionStillOpening
(RegionInfo regionInfo, RegionServerServices rsServices) Deprecated.ModifierConstructorDescriptionCloseMetaHandler
(Server server, RegionServerServices rsServices, RegionInfo regionInfo, boolean abort) protected
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.protected
OpenRegionHandler
(Server server, RegionServerServices rsServices, RegionInfo regionInfo, TableDescriptor htd, long masterSystemTime, EventType eventType) Deprecated.(package private)
PostOpenDeployTasksThread
(HRegion region, Server server, RegionServerServices services, AtomicBoolean signaller, long masterSystemTime) -
Uses of RegionServerServices in org.apache.hadoop.hbase.regionserver.regionreplication
Modifier and TypeFieldDescriptionprivate final RegionServerServices
RegionReplicationBufferManager.rsServices
-
Uses of RegionServerServices in org.apache.hadoop.hbase.regionserver.snapshot
Modifier and TypeMethodDescriptionvoid
RegionServerSnapshotManager.initialize
(RegionServerServices rss) Create a default snapshot handler - uses a zookeeper based member controller. -
Uses of RegionServerServices in org.apache.hadoop.hbase.regionserver.throttle
Modifier and TypeMethodDescriptionstatic ThroughputController
CompactionThroughputControllerFactory.create
(RegionServerServices server, org.apache.hadoop.conf.Configuration conf) static ThroughputController
FlushThroughputControllerFactory.create
(RegionServerServices server, org.apache.hadoop.conf.Configuration conf) void
NoLimitThroughputController.setup
(RegionServerServices server) void
PressureAwareCompactionThroughputController.setup
(RegionServerServices server) void
PressureAwareFlushThroughputController.setup
(RegionServerServices server) abstract void
PressureAwareThroughputController.setup
(RegionServerServices server) void
ThroughputController.setup
(RegionServerServices server) Setup controller for the given region server. -
Uses of RegionServerServices in org.apache.hadoop.hbase.replication.regionserver
Modifier and TypeFieldDescriptionprivate final RegionServerServices
ReplicationMarkerChore.rsServices
ModifierConstructorDescriptionReplicationMarkerChore
(Stoppable stopper, RegionServerServices rsServices, int period, org.apache.hadoop.conf.Configuration conf) -
Uses of RegionServerServices in org.apache.hadoop.hbase.wal
Modifier and TypeFieldDescription(package private) final RegionServerServices
WALSplitter.rsServices
Modifier and TypeMethodDescriptionstatic 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.ModifierConstructorDescription(package private)
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)