Uses of Class
org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot
Package
Description
Provides HBase Client
-
Uses of SpaceQuotaSnapshot in org.apache.hadoop.hbase.client
Modifier and TypeMethodDescriptionAsyncHBaseAdmin.getCurrentSpaceQuotaSnapshot
(String namespace) AsyncHBaseAdmin.getCurrentSpaceQuotaSnapshot
(TableName tableName) RawAsyncHBaseAdmin.getCurrentSpaceQuotaSnapshot
(String namespace) private CompletableFuture<SpaceQuotaSnapshot>
RawAsyncHBaseAdmin.getCurrentSpaceQuotaSnapshot
(RawAsyncHBaseAdmin.Converter<SpaceQuotaSnapshot, org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.GetQuotaStatesResponse> converter) RawAsyncHBaseAdmin.getCurrentSpaceQuotaSnapshot
(TableName tableName) AsyncHBaseAdmin.getRegionServerSpaceQuotaSnapshots
(ServerName serverName) RawAsyncHBaseAdmin.getRegionServerSpaceQuotaSnapshots
(ServerName serverName) Modifier and TypeMethodDescriptionprivate CompletableFuture<SpaceQuotaSnapshot>
RawAsyncHBaseAdmin.getCurrentSpaceQuotaSnapshot
(RawAsyncHBaseAdmin.Converter<SpaceQuotaSnapshot, org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.GetQuotaStatesResponse> converter) -
Uses of SpaceQuotaSnapshot in org.apache.hadoop.hbase.master
Modifier and TypeMethodDescriptionMetricsMasterWrapperImpl.convertSnapshot
(SpaceQuotaSnapshot snapshot) -
Uses of SpaceQuotaSnapshot in org.apache.hadoop.hbase.quotas
Modifier and TypeFieldDescriptionstatic final SpaceQuotaSnapshot
QuotaSnapshotStore.NO_QUOTA
Singleton to represent a table without a quota defined.private static final SpaceQuotaSnapshot
SpaceQuotaSnapshot.NO_SUCH_SNAPSHOT
Modifier and TypeFieldDescriptionprivate AtomicReference<Map<TableName,
SpaceQuotaSnapshot>> RegionServerSpaceQuotaManager.currentQuotaSnapshots
private final Map<String,
SpaceQuotaSnapshot> QuotaObserverChore.namespaceQuotaSnapshots
private final Map<String,
SpaceQuotaSnapshot> QuotaObserverChore.readOnlyNamespaceSnapshots
private final Map<TableName,
SpaceQuotaSnapshot> QuotaObserverChore.readOnlyTableQuotaSnapshots
private final Map<TableName,
SpaceQuotaSnapshot> ActivePolicyEnforcement.snapshots
private final Map<TableName,
SpaceQuotaSnapshot> QuotaObserverChore.tableQuotaSnapshots
Modifier and TypeMethodDescriptionstatic SpaceQuotaSnapshot
QuotaTableUtil.getCurrentSnapshotFromQuotaTable
(Connection conn, TableName tableName) Returns the current space quota snapshot of the giventableName
fromQuotaTableUtil.QUOTA_TABLE_NAME
or null if the no quota information is available for that tableName.NamespaceQuotaSnapshotStore.getCurrentState
(String namespace) QuotaSnapshotStore.getCurrentState
(T subject) Returns the currentSpaceQuotaSnapshot
for the givensubject
.TableQuotaSnapshotStore.getCurrentState
(TableName table) (package private) SpaceQuotaSnapshot
QuotaObserverChore.getNamespaceQuotaSnapshot
(String namespace) Fetches theSpaceQuotaSnapshot
for the given namespace from this chore.static SpaceQuotaSnapshot
SpaceQuotaSnapshot.getNoSuchSnapshot()
Returns a singleton that corresponds to no snapshot information.SpaceViolationPolicyEnforcement.getQuotaSnapshot()
Returns theSpaceQuotaSnapshot
this
was initialized with.(package private) SpaceQuotaSnapshot
QuotaObserverChore.getTableQuotaSnapshot
(TableName table) Fetches theSpaceQuotaSnapshot
for the given table.NamespaceQuotaSnapshotStore.getTargetState
(String subject, org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.SpaceQuota spaceQuota) QuotaSnapshotStore.getTargetState
(T subject, org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.SpaceQuota spaceQuota) TableQuotaSnapshotStore.getTargetState
(TableName table, org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.SpaceQuota spaceQuota) static SpaceQuotaSnapshot
SpaceQuotaSnapshot.toSpaceQuotaSnapshot
(org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.SpaceQuotaSnapshot proto) Modifier and TypeMethodDescriptionRegionServerSpaceQuotaManager.copyQuotaSnapshots()
Copies the lastSpaceQuotaSnapshot
s that were recorded.SpaceQuotaRefresherChore.fetchSnapshotsFromQuotaTable()
Reads all quota snapshots from the quota table.RegionServerSpaceQuotaManager.getActivePoliciesAsMap()
Converts a map of table toSpaceViolationPolicyEnforcement
s intoSpaceViolationPolicy
s.QuotaObserverChore.getNamespaceQuotaSnapshots()
Returns an unmodifiable view over the currentSpaceQuotaSnapshot
objects for each HBase namespace with a quota defined.static Map<TableName,
SpaceQuotaSnapshot> QuotaTableUtil.getSnapshots
(Connection conn) Fetches allSpaceQuotaSnapshot
objects from thehbase:quota
table.QuotaObserverChore.getTableQuotaSnapshots()
Returns an unmodifiable view over the currentSpaceQuotaSnapshot
objects for each HBase table with a quota defined.Modifier and TypeMethodDescriptionSpaceViolationPolicyEnforcementFactory.create
(RegionServerServices rss, TableName tableName, SpaceQuotaSnapshot snapshot) Constructs the appropriateSpaceViolationPolicyEnforcement
for tables that are in violation of their space quota.(package private) static Put
QuotaTableUtil.createPutForSpaceSnapshot
(TableName tableName, SpaceQuotaSnapshot snapshot) SpaceViolationPolicyEnforcementFactory.createWithoutViolation
(RegionServerServices rss, TableName tableName, SpaceQuotaSnapshot snapshot) Creates the "default"SpaceViolationPolicyEnforcement
for a table that isn't in violation.void
RegionServerSpaceQuotaManager.enforceViolationPolicy
(TableName tableName, SpaceQuotaSnapshot snapshot) Enforces the given violationPolicy on the given table in this RegionServer.void
SpaceViolationPolicyEnforcement.initialize
(RegionServerServices rss, TableName tableName, SpaceQuotaSnapshot snapshot) Initializes this policy instance.(package private) boolean
SpaceQuotaRefresherChore.isInViolation
(SpaceQuotaSnapshot snapshot) Checks if the givensnapshot
is in violation, allowing the snapshot to be null.void
NamespaceQuotaSnapshotStore.setCurrentState
(String namespace, SpaceQuotaSnapshot snapshot) void
QuotaSnapshotStore.setCurrentState
(T subject, SpaceQuotaSnapshot state) Persists the currentSpaceQuotaSnapshot
for thesubject
.void
TableQuotaSnapshotStore.setCurrentState
(TableName table, SpaceQuotaSnapshot snapshot) (package private) void
QuotaObserverChore.setNamespaceQuotaSnapshot
(String namespace, SpaceQuotaSnapshot snapshot) Stores the givensnapshot
for the givennamespace
in this chore.(package private) void
QuotaObserverChore.setTableQuotaSnapshot
(TableName table, SpaceQuotaSnapshot snapshot) Stores the quota state for the given table.static org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.SpaceQuotaSnapshot
SpaceQuotaSnapshot.toProtoSnapshot
(SpaceQuotaSnapshot snapshot) void
SpaceQuotaSnapshotNotifier.transitionTable
(TableName tableName, SpaceQuotaSnapshot snapshot) Informs the cluster of the current state of a space quota for a table.void
TableSpaceQuotaSnapshotNotifier.transitionTable
(TableName tableName, SpaceQuotaSnapshot snapshot) (package private) void
QuotaObserverChore.updateNamespaceQuota
(String namespace, SpaceQuotaSnapshot currentSnapshot, SpaceQuotaSnapshot targetSnapshot, org.apache.hbase.thirdparty.com.google.common.collect.Multimap<String, TableName> tablesByNamespace) Updates the hbase:quota table with the target quota policy for thisnamespace
if necessary.(package private) void
QuotaObserverChore.updateTableQuota
(TableName table, SpaceQuotaSnapshot currentSnapshot, SpaceQuotaSnapshot targetSnapshot) Updates the hbase:quota table with the new quota policy for thistable
if necessary.Modifier and TypeMethodDescriptionstatic void
QuotaTableUtil.extractQuotaSnapshot
(Result result, Map<TableName, SpaceQuotaSnapshot> snapshots) Extracts theSpaceViolationPolicy
andTableName
from the providedResult
and adds them to the givenMap
.(package private) void
SpaceQuotaRefresherChore.extractQuotaSnapshot
(Result result, Map<TableName, SpaceQuotaSnapshot> snapshots) Wrapper aroundQuotaTableUtil.extractQuotaSnapshot(Result, Map)
for testing.void
RegionServerSpaceQuotaManager.updateQuotaSnapshot
(Map<TableName, SpaceQuotaSnapshot> newSnapshots) Updates the currentSpaceQuotaSnapshot
s for the RegionServer. -
Uses of SpaceQuotaSnapshot in org.apache.hadoop.hbase.quotas.policies
Modifier and TypeFieldDescription(package private) SpaceQuotaSnapshot
AbstractViolationPolicyEnforcement.quotaSnapshot
Modifier and TypeMethodDescriptionvoid
AbstractViolationPolicyEnforcement.initialize
(RegionServerServices rss, TableName tableName, SpaceQuotaSnapshot snapshot) void
AbstractViolationPolicyEnforcement.setQuotaSnapshot
(SpaceQuotaSnapshot snapshot) -
Uses of SpaceQuotaSnapshot in org.apache.hadoop.hbase.thrift2.client
Modifier and TypeMethodDescriptionThriftAdmin.getCurrentSpaceQuotaSnapshot
(String namespace) ThriftAdmin.getCurrentSpaceQuotaSnapshot
(TableName tableName) Modifier and TypeMethodDescriptionThriftAdmin.getRegionServerSpaceQuotaSnapshots
(ServerName serverName)