Package | Description |
---|---|
org.apache.hadoop.hbase | |
org.apache.hadoop.hbase.client |
Provides HBase Client
|
org.apache.hadoop.hbase.master | |
org.apache.hadoop.hbase.master.balancer | |
org.apache.hadoop.hbase.master.cleaner | |
org.apache.hadoop.hbase.master.hbck | |
org.apache.hadoop.hbase.master.janitor | |
org.apache.hadoop.hbase.master.migrate | |
org.apache.hadoop.hbase.master.normalizer |
The Region Normalizer subsystem is responsible for coaxing all the regions in a table toward
a "normal" size, according to their storefile size.
|
org.apache.hadoop.hbase.mob | |
org.apache.hadoop.hbase.namequeues | |
org.apache.hadoop.hbase.quotas | |
org.apache.hadoop.hbase.regionserver | |
org.apache.hadoop.hbase.replication |
Multi Cluster Replication
|
Modifier and Type | Class and Description |
---|---|
class |
HealthCheckChore
The Class HealthCheckChore for running health checker regularly.
|
Modifier and Type | Field and Description |
---|---|
private HashMap<ScheduledChore,Boolean> |
ChoreService.choresMissingStartTime
Maps chores to Booleans which indicate whether or not a chore has caused an increase in the
core pool size of the ScheduledThreadPoolExecutor.
|
private HashMap<ScheduledChore,ScheduledFuture<?>> |
ChoreService.scheduledChores
Maps chores to their futures.
|
Modifier and Type | Method and Description |
---|---|
static ScheduledChore |
AuthUtil.getAuthChore(org.apache.hadoop.conf.Configuration conf)
Deprecated.
Deprecated since 2.2.0, this method will be
InterfaceAudience.Private use only after 4.0.0. |
static ScheduledChore |
AuthUtil.getAuthRenewalChore(org.apache.hadoop.security.UserGroupInformation user,
org.apache.hadoop.conf.Configuration conf)
Deprecated.
Checks if security is enabled and if so, launches chore for refreshing kerberos ticket.
|
Modifier and Type | Method and Description |
---|---|
(package private) void |
ChoreService.cancelChore(ScheduledChore chore)
Cancel any ongoing schedules that this chore has with the implementer of this interface.
|
(package private) void |
ChoreService.cancelChore(ScheduledChore chore,
boolean mayInterruptIfRunning)
Cancel any ongoing schedules that this chore has with the implementer of this interface.
|
boolean |
ChoreService.isChoreScheduled(ScheduledChore chore)
Returns true when the chore is scheduled with the implementer of this interface
|
(package private) void |
ChoreService.onChoreMissedStartTime(ScheduledChore chore)
A callback that tells the implementer of this interface that one of the scheduled chores is
missing its start time.
|
private void |
ChoreService.printChoreDetails(String header,
ScheduledChore chore)
Prints a summary of important details about the chore.
|
private void |
ChoreService.rescheduleChore(ScheduledChore chore) |
boolean |
ChoreService.scheduleChore(ScheduledChore chore)
Schedule a chore.
|
(package private) void |
ChoreService.triggerNow(ScheduledChore chore)
This method tries to execute the chore immediately.
|
Modifier and Type | Method and Description |
---|---|
private ScheduledChore |
CatalogReplicaLoadBalanceSimpleSelector.getCacheCleanupChore(CatalogReplicaLoadBalanceSimpleSelector selector) |
private ScheduledChore |
CatalogReplicaLoadBalanceSimpleSelector.getRefreshReplicaCountChore(CatalogReplicaLoadBalanceSimpleSelector selector) |
Modifier and Type | Class and Description |
---|---|
class |
ClusterStatusPublisher
Class to publish the cluster status to the client.
|
class |
RegionsRecoveryChore
This chore, every time it runs, will try to recover regions with high store ref count by
reopening them
|
private class |
SplitLogManager.TimeoutMonitor
Deprecated.
Periodically checks all active tasks and resubmits the ones that have timed out
|
Modifier and Type | Class and Description |
---|---|
class |
BalancerChore
Chore that will call HMaster.balance
HMaster.balance() when
needed. |
class |
ClusterStatusChore
Chore that will feed the balancer the cluster status.
|
Modifier and Type | Class and Description |
---|---|
class |
CleanerChore<T extends FileCleanerDelegate>
Abstract Cleaner that uses a chain of delegates to clean a directory of files
|
class |
HFileCleaner
This Chore, every time it runs, will clear the HFiles in the hfile archive folder that are
deletable for each HFile cleaner in the chain.
|
class |
LogCleaner
This Chore, every time it runs, will attempt to delete the WALs and Procedure WALs in the old
logs folder.
|
class |
ReplicationBarrierCleaner
Used to clean the useless barriers in
HConstants.REPLICATION_BARRIER_FAMILY_STR family in
meta table. |
class |
SnapshotCleanerChore
This chore, every time it runs, will try to delete snapshots that are expired based on TTL in
seconds configured for each Snapshot
|
Modifier and Type | Class and Description |
---|---|
class |
HbckChore
Used to do the hbck checking job at master side.
|
Modifier and Type | Class and Description |
---|---|
class |
CatalogJanitor
A janitor for the catalog tables.
|
Modifier and Type | Class and Description |
---|---|
class |
RollingUpgradeChore
To avoid too many migrating/upgrade threads to be submitted at the time during master
initialization, RollingUpgradeChore handles all rolling-upgrade tasks.
|
Modifier and Type | Class and Description |
---|---|
(package private) class |
RegionNormalizerChore
Chore that will periodically call
HMaster.normalizeRegions(NormalizeTableFilterParams, boolean) . |
Modifier and Type | Method and Description |
---|---|
ScheduledChore |
RegionNormalizerManager.getRegionNormalizerChore() |
Modifier and Type | Class and Description |
---|---|
class |
MobFileCleanerChore
The class MobFileCleanerChore for running cleaner regularly to remove the expired and obsolete
(files which have no active references to) mob files.
|
class |
MobFileCompactionChore
Periodic MOB compaction chore.
|
class |
RSMobFileCleanerChore
The class RSMobFileCleanerChore for running cleaner regularly to remove the obsolete (files which
have no active references to) mob files that were referenced from the current RS.
|
Modifier and Type | Class and Description |
---|---|
class |
SlowLogTableOpsChore
Chore to insert multiple accumulated slow/large logs to hbase:slowlog system table
|
Modifier and Type | Class and Description |
---|---|
class |
FileSystemUtilizationChore
A chore which computes the size of each
HRegion on the FileSystem hosted by the given
HRegionServer . |
private class |
QuotaCache.QuotaRefresherChore |
class |
QuotaObserverChore
Reads the currently received Region filesystem-space use reports and acts on those which violate
a defined quota.
|
class |
RegionSizeReportingChore
A Chore which sends the region size reports on this RegionServer to the Master.
|
class |
SnapshotQuotaObserverChore
A Master-invoked
Chore that computes the size of each snapshot which was created from a
table which has a space quota. |
class |
SpaceQuotaRefresherChore
A
ScheduledChore which periodically updates the RegionServerSpaceQuotaManager
with information from the hbase:quota. |
Modifier and Type | Class and Description |
---|---|
class |
BrokenStoreFileCleaner
This Chore, every time it runs, will clear the unsused HFiles in the data folder.
|
class |
CompactedHFilesDischarger
A chore service that periodically cleans up the compacted files when there are no active readers
using those compacted files and also helps in clearing the block cache of these compacted file
entries.
|
private class |
HeapMemoryManager.HeapMemoryTunerChore |
private static class |
HRegionServer.CompactionChecker
Inner class that runs on a long period checking if regions need compaction.
|
private static class |
HRegionServer.PeriodicMemStoreFlusher |
class |
StorefileRefresherChore
A chore for refreshing the store files for secondary regions hosted in the region server.
|
Modifier and Type | Field and Description |
---|---|
private ScheduledChore |
HRegionServer.compactionChecker
Check for compactions requests.
|
private ScheduledChore |
HRegionServer.nonceManagerChore
The nonce manager chore.
|
private ScheduledChore |
HRegionServer.periodicFlusher
Check for flushes
|
Modifier and Type | Method and Description |
---|---|
ScheduledChore |
ServerNonceManager.createCleanupScheduledChore(Stoppable stoppable)
Creates a scheduled chore that is used to clean up old nonces.
|
Modifier and Type | Method and Description |
---|---|
protected void |
HRegionServer.shutdownChore(ScheduledChore chore) |
Modifier and Type | Class and Description |
---|---|
private class |
ReplicationSinkServiceImpl.ReplicationStatisticsChore |
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.