| Package | Description |
|---|---|
| org.apache.hadoop.hbase.client |
Provides HBase Client
|
| org.apache.hadoop.hbase.coprocessor |
Table of Contents
|
| org.apache.hadoop.hbase.master | |
| org.apache.hadoop.hbase.master.procedure | |
| org.apache.hadoop.hbase.quotas | |
| org.apache.hadoop.hbase.quotas.policies | |
| org.apache.hadoop.hbase.regionserver | |
| org.apache.hadoop.hbase.security.access | |
| org.apache.hadoop.hbase.thrift2.client |
| Class and Description |
|---|
| QuotaFilter
Filter to use to filter the QuotaRetriever results.
|
| QuotaRetriever
Scanner to iterate over the quota settings.
|
| QuotaSettings |
| SpaceQuotaSnapshot
A point-in-time view of a space quota on a table.
|
| SpaceQuotaSnapshotView
A point-in-time view of a space quota on a table, read only.
|
| Class and Description |
|---|
| GlobalQuotaSettings
An object which captures all quotas types (throttle or space) for a subject (user, table, or
namespace).
|
| Class and Description |
|---|
| GlobalQuotaSettings
An object which captures all quotas types (throttle or space) for a subject (user, table, or
namespace).
|
| MasterQuotaManager
Master Quota Manager.
|
| QuotaObserverChore
Reads the currently received Region filesystem-space use reports and acts on those which
violate a defined quota.
|
| SnapshotQuotaObserverChore
A Master-invoked
Chore that computes the size of each snapshot which was created from
a table which has a space quota. |
| SpaceQuotaSnapshot
A point-in-time view of a space quota on a table.
|
| SpaceQuotaSnapshotNotifier
An interface which abstract away the action taken to enable or disable
a space quota violation policy across the HBase cluster.
|
| Class and Description |
|---|
| MasterQuotaManager
Master Quota Manager.
|
| RpcThrottleStorage
ZK based rpc throttle storage.
|
| Class and Description |
|---|
| ActivePolicyEnforcement
A class to ease dealing with tables that have and do not have violation policies
being enforced.
|
| DefaultOperationQuota |
| FileArchiverNotifier
Interface allowing various implementations of tracking files that have recently been archived to
allow for the Master to notice changes to snapshot sizes for space quotas.
|
| FileArchiverNotifierFactory
Factory class to create
FileArchiverNotifier instances. |
| FileArchiverNotifierFactoryImpl
A factory for getting instances of
FileArchiverNotifier. |
| FileArchiverNotifierImpl.SnapshotWithSize
A struct encapsulating the name of a snapshot and its "size" on the filesystem.
|
| FileArchiverNotifierImpl.StoreFileReference
A reference to a collection of files in the archive directory for a single region.
|
| GlobalQuotaSettings
An object which captures all quotas types (throttle or space) for a subject (user, table, or
namespace).
|
| GlobalQuotaSettingsImpl
Implementation of
GlobalQuotaSettings to hide the Protobuf messages we use internally. |
| MasterQuotaManager
Master Quota Manager.
|
| MasterQuotaManager.NamedLock |
| MasterQuotaManager.SetQuotaOperations
Encapsulates CRUD quota operations for some subject.
|
| MasterQuotaManager.SizeSnapshotWithTimestamp
Holds the size of a region at the given time, millis since the epoch.
|
| NoOpRegionSizeStore
A
RegionSizeStore implementation that stores nothing. |
| OperationQuota
Interface that allows to check the quota available for an operation.
|
| OperationQuota.OperationType |
| QuotaCache
Cache that keeps track of the quota settings for the users and tables that
are interacting with it.
|
| QuotaCache.Fetcher |
| QuotaCache.QuotaRefresherChore |
| QuotaExceededException
Generic quota exceeded exception
|
| QuotaFilter
Filter to use to filter the QuotaRetriever results.
|
| QuotaLimiter
Internal interface used to interact with the user/table quota.
|
| QuotaObserverChore
Reads the currently received Region filesystem-space use reports and acts on those which
violate a defined quota.
|
| QuotaObserverChore.TablesWithQuotas
A container which encapsulates the tables that have either a table quota or are contained in a
namespace which have a namespace quota.
|
| QuotaRetriever
Scanner to iterate over the quota settings.
|
| QuotaScope
Describe the Scope of the quota rules.
|
| QuotaSettings |
| QuotaSettingsFactory.QuotaGlobalsSettingsBypass |
| QuotaSnapshotStore
A common interface for computing and storing space quota observance/violation for entities.
|
| QuotaState
In-Memory state of table or namespace quotas
|
| QuotaTableUtil
Helper class to interact with the quota table.
|
| QuotaTableUtil.NamespaceQuotasVisitor |
| QuotaTableUtil.QuotasVisitor |
| QuotaTableUtil.RegionServerQuotasVisitor |
| QuotaTableUtil.TableQuotasVisitor |
| QuotaTableUtil.UserQuotasVisitor |
| QuotaType
Describe the Quota Type.
|
| QuotaUtil.KeyFromRow |
| RateLimiter
Simple rate limiter.
|
| RegionServerSpaceQuotaManager
A manager for filesystem space quotas in the RegionServer.
|
| RegionSize
Interface that encapsulates optionally sending a Region's size to the master.
|
| RegionSizeImpl
An object encapsulating a Region's size and whether it's been reported to the master since
the value last changed.
|
| RegionSizeReportingChore
A Chore which sends the region size reports on this RegionServer to the Master.
|
| RegionSizeStore
An interface for concurrently storing and updating the size of a Region.
|
| RegionSizeStoreFactory
A factory class for creating implementations of
RegionSizeStore. |
| RpcThrottleStorage
ZK based rpc throttle storage.
|
| RpcThrottlingException
Describe the throttling result.
|
| RpcThrottlingException.Type |
| SpaceLimitingException
An Exception that is thrown when a space quota is in violation.
|
| SpaceLimitSettings
A
QuotaSettings implementation for configuring filesystem-use quotas. |
| SpaceQuotaRefresherChore
A
ScheduledChore which periodically updates the RegionServerSpaceQuotaManager
with information from the hbase:quota. |
| SpaceQuotaSnapshot
A point-in-time view of a space quota on a table.
|
| SpaceQuotaSnapshot.SpaceQuotaStatus
Encapsulates the state of a quota on a table.
|
| SpaceQuotaSnapshotNotifier
An interface which abstract away the action taken to enable or disable
a space quota violation policy across the HBase cluster.
|
| SpaceQuotaSnapshotNotifierFactory
Factory for creating
SpaceQuotaSnapshotNotifier implementations. |
| SpaceQuotaSnapshotView
A point-in-time view of a space quota on a table, read only.
|
| SpaceQuotaSnapshotView.SpaceQuotaStatusView
Encapsulates the state of a quota on a table.
|
| SpaceViolationPolicy
Enumeration that represents the action HBase will take when a space quota is violated.
|
| SpaceViolationPolicyEnforcement
RegionServer implementation of
SpaceViolationPolicy. |
| SpaceViolationPolicyEnforcementFactory
A factory class for instantiating
SpaceViolationPolicyEnforcement instances. |
| ThrottleSettings |
| ThrottleType
Describe the Throttle Type.
|
| ThrottlingException
Deprecated.
replaced by
RpcThrottlingException since hbase-2.0.0. |
| ThrottlingException.Type
Deprecated.
|
| TimeBasedLimiter
Simple time based limiter that checks the quota Throttle
|
| UserQuotaState
In-Memory state of the user quotas
|
| Class and Description |
|---|
| SpaceLimitingException
An Exception that is thrown when a space quota is in violation.
|
| SpaceQuotaSnapshot
A point-in-time view of a space quota on a table.
|
| SpaceViolationPolicyEnforcement
RegionServer implementation of
SpaceViolationPolicy. |
| Class and Description |
|---|
| ActivePolicyEnforcement
A class to ease dealing with tables that have and do not have violation policies
being enforced.
|
| FileSystemUtilizationChore
A chore which computes the size of each
HRegion on the FileSystem hosted by the given
HRegionServer. |
| OperationQuota
Interface that allows to check the quota available for an operation.
|
| RegionServerRpcQuotaManager
Region Server Quota Manager.
|
| RegionServerSpaceQuotaManager
A manager for filesystem space quotas in the RegionServer.
|
| RegionSizeStore
An interface for concurrently storing and updating the size of a Region.
|
| Class and Description |
|---|
| GlobalQuotaSettings
An object which captures all quotas types (throttle or space) for a subject (user, table, or
namespace).
|
| Class and Description |
|---|
| QuotaFilter
Filter to use to filter the QuotaRetriever results.
|
| QuotaRetriever
Scanner to iterate over the quota settings.
|
| QuotaSettings |
| SpaceQuotaSnapshot
A point-in-time view of a space quota on a table.
|
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.