Uses of Class
org.apache.hadoop.hbase.client.Delete
Package
Description
Provides HBase Client
Table of Contents
Provides HBase MapReduce
Input/OutputFormats, a table indexing MapReduce job, and utility methods.
Provides an HBase Thrift
service.
-
Uses of Delete in org.apache.hadoop.hbase
Modifier and TypeMethodDescriptionstatic Delete
MetaTableAccessor.makeDeleteFromRegionInfo
(RegionInfo regionInfo, long ts) Generates and returns a Delete containing the region info for the catalog tableModifier and TypeMethodDescriptionprivate static void
MetaTableAccessor.deleteFromMetaTable
(Connection connection, Delete d) Delete the passedd
from thehbase:meta
table.Modifier and TypeMethodDescriptionprivate static void
MetaTableAccessor.deleteFromMetaTable
(Connection connection, List<Delete> deletes) Delete the passeddeletes
from thehbase:meta
table. -
Uses of Delete in org.apache.hadoop.hbase.backup.impl
Modifier and TypeMethodDescriptionprivate Delete
BackupSystemTable.createDeleteForBackupDeleteOperation()
private Delete
BackupSystemTable.createDeleteForBackupInfo
(String backupId) Creates Delete operation for a given backup idprivate Delete
BackupSystemTable.createDeleteForBackupMergeOperation()
private Delete
BackupSystemTable.createDeleteForBackupSet
(String name) Creates Delete operation to delete backup set contentprivate Delete
BackupSystemTable.createDeleteForIncrBackupTableSet
(String backupRoot) Creates Delete for incremental backup table setModifier and TypeMethodDescriptionBackupSystemTable.createDeleteForOrigBulkLoad
(List<TableName> lst) -
Uses of Delete in org.apache.hadoop.hbase.client
Modifier and TypeMethodDescriptionAdd an existing delete marker to this Delete object.Delete.addColumn
(byte[] family, byte[] qualifier) Delete the latest version of the specified column.Delete.addColumn
(byte[] family, byte[] qualifier, long timestamp) Delete the specified version of the specified column.Delete.addColumns
(byte[] family, byte[] qualifier) Delete all versions of the specified column.Delete.addColumns
(byte[] family, byte[] qualifier, long timestamp) Delete all versions of the specified column with a timestamp less than or equal to the specified timestamp.Delete.addFamily
(byte[] family) Delete all versions of all columns of the specified family.Delete.addFamily
(byte[] family, long timestamp) Delete all columns of the specified family with a timestamp less than or equal to the specified timestamp.Delete.addFamilyVersion
(byte[] family, long timestamp) Delete all columns of the specified family with a timestamp equal to the specified timestamp.Delete.setACL
(String user, Permission perms) Delete.setACL
(Map<String, Permission> perms) Delete.setAttribute
(String name, byte[] value) Delete.setCellVisibility
(CellVisibility expression) Delete.setClusterIds
(List<UUID> clusterIds) Delete.setDurability
(Durability d) Delete.setPriority
(int priority) Delete.setTimestamp
(long timestamp) Delete.setTTL
(long ttl) Modifier and TypeMethodDescriptionBuild the CheckAndMutate objectDeletes the specified cells/row.default void
Deletes the specified cells/row.void
AsyncTable.CheckAndMutateBuilder.thenDelete
(Delete delete) Deprecated.Specify a Delete to commit if the check succeeds.AsyncTable.CheckAndMutateWithFilterBuilder.thenDelete
(Delete delete) Deprecated.Specify a Delete to commit if the check succeeds.RawAsyncTableImpl.CheckAndMutateBuilderImpl.thenDelete
(Delete delete) RawAsyncTableImpl.CheckAndMutateWithFilterBuilderImpl.thenDelete
(Delete delete) boolean
Table.CheckAndMutateBuilder.thenDelete
(Delete delete) Deprecated.Specify a Delete to commit if the check succeeds.boolean
Table.CheckAndMutateWithFilterBuilder.thenDelete
(Delete delete) Deprecated.Specify a Delete to commit if the check succeeds.Modifier and TypeMethodDescriptionDeletes the specified cells/rows in bulk.default void
Batch Deletes the specified cells/rows from the table.void
default CompletableFuture<Void>
A simple version of batch delete. -
Uses of Delete in org.apache.hadoop.hbase.coprocessor
Modifier and TypeMethodDescriptiondefault boolean
RegionObserver.postCheckAndDelete
(ObserverContext<? extends RegionCoprocessorEnvironment> c, byte[] row, byte[] family, byte[] qualifier, CompareOperator op, ByteArrayComparable comparator, Delete delete, boolean result) Deprecated.since 3.0.0 and will be removed in 4.0.0.default boolean
RegionObserver.postCheckAndDelete
(ObserverContext<? extends RegionCoprocessorEnvironment> c, byte[] row, Filter filter, Delete delete, boolean result) Deprecated.since 3.0.0 and will be removed in 4.0.0.default void
RegionObserver.postDelete
(ObserverContext<? extends RegionCoprocessorEnvironment> c, Delete delete, WALEdit edit) Called after the client deletes a value.default void
RegionObserver.postDelete
(ObserverContext<? extends RegionCoprocessorEnvironment> c, Delete delete, WALEdit edit, Durability durability) Deprecated.since 3.0.0 and will be removed in 4.0.0.default boolean
RegionObserver.preCheckAndDelete
(ObserverContext<? extends RegionCoprocessorEnvironment> c, byte[] row, byte[] family, byte[] qualifier, CompareOperator op, ByteArrayComparable comparator, Delete delete, boolean result) Deprecated.since 3.0.0 and will be removed in 4.0.0.default boolean
RegionObserver.preCheckAndDelete
(ObserverContext<? extends RegionCoprocessorEnvironment> c, byte[] row, Filter filter, Delete delete, boolean result) Deprecated.since 3.0.0 and will be removed in 4.0.0.default boolean
RegionObserver.preCheckAndDeleteAfterRowLock
(ObserverContext<? extends RegionCoprocessorEnvironment> c, byte[] row, byte[] family, byte[] qualifier, CompareOperator op, ByteArrayComparable comparator, Delete delete, boolean result) Deprecated.since 3.0.0 and will be removed in 4.0.0.default boolean
RegionObserver.preCheckAndDeleteAfterRowLock
(ObserverContext<? extends RegionCoprocessorEnvironment> c, byte[] row, Filter filter, Delete delete, boolean result) Deprecated.since 3.0.0 and will be removed in 4.0.0.void
MetaTableMetrics.ExampleRegionObserverMeta.preDelete
(ObserverContext<? extends RegionCoprocessorEnvironment> e, Delete delete, WALEdit edit, Durability durability) default void
RegionObserver.preDelete
(ObserverContext<? extends RegionCoprocessorEnvironment> c, Delete delete, WALEdit edit) Called before the client deletes a value.default void
RegionObserver.preDelete
(ObserverContext<? extends RegionCoprocessorEnvironment> c, Delete delete, WALEdit edit, Durability durability) Deprecated.since 3.0.0 and will be removed in 4.0.0. -
Uses of Delete in org.apache.hadoop.hbase.coprocessor.example
Modifier and TypeMethodDescriptionprivate Delete
BulkDeleteEndpoint.createDeleteMutation
(List<Cell> deleteRow, org.apache.hadoop.hbase.shaded.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest.DeleteType deleteType, Long timestamp) -
Uses of Delete in org.apache.hadoop.hbase.mapreduce
Modifier and TypeMethodDescriptionprotected void
Import.Importer.processKV
(ImmutableBytesWritable key, Result result, org.apache.hadoop.mapreduce.Mapper<ImmutableBytesWritable, Result, ImmutableBytesWritable, Mutation>.org.apache.hadoop.mapreduce.Mapper.Context context, Put put, Delete delete) -
Uses of Delete in org.apache.hadoop.hbase.master.assignment
Modifier and TypeMethodDescriptionRegionStateStore.deleteRegionReplicas
(ResultScanner scanner, int oldReplicaCount, int newReplicaCount, long now) -
Uses of Delete in org.apache.hadoop.hbase.quotas
Modifier and TypeMethodDescriptionQuotaTableUtil.createDeletesForExistingNamespaceSnapshotSizes
(Set<String> snapshotEntriesToRemove) Returns a list ofDelete
to remove given namespace snapshot entries to removefrom quota tableQuotaTableUtil.createDeletesForExistingNamespaceSnapshotSizes
(Connection connection) Returns a list ofDelete
to remove all namespace snapshot entries from quota table.QuotaTableUtil.createDeletesForExistingSnapshotsFromScan
(Connection connection, Scan scan) Returns a list ofDelete
to remove all entries returned by the passed scanner.QuotaTableUtil.createDeletesForExistingTableSnapshotSizes
(Connection connection) Returns a list ofDelete
to remove all table snapshot entries from quota table.QuotaTableUtil.createDeletesForExistingTableSnapshotSizes
(org.apache.hbase.thirdparty.com.google.common.collect.Multimap<TableName, String> snapshotEntriesToRemove) Returns a list ofDelete
to remove given table snapshot entries to remove from quota tableModifier and TypeMethodDescriptionprivate static void
QuotaUtil.doDelete
(Connection connection, Delete delete) Modifier and TypeMethodDescription(package private) void
SnapshotQuotaObserverChore.removeExistingSnapshotSizes
(List<Delete> deletes) -
Uses of Delete in org.apache.hadoop.hbase.regionserver
Modifier and TypeMethodDescriptionvoid
void
Deletes the specified cells/row.void
RegionCoprocessorHost.postDelete
(Delete delete, WALEdit edit) boolean
Supports Coprocessor 'bypass'.private void
HRegion.prepareDelete
(Delete delete) Prepare a delete for a row mutation processor -
Uses of Delete in org.apache.hadoop.hbase.security.access
Modifier and TypeMethodDescriptionvoid
AccessController.postDelete
(ObserverContext<? extends RegionCoprocessorEnvironment> c, Delete delete, WALEdit edit, Durability durability) boolean
AccessController.preCheckAndDelete
(ObserverContext<? extends RegionCoprocessorEnvironment> c, byte[] row, byte[] family, byte[] qualifier, CompareOperator op, ByteArrayComparable comparator, Delete delete, boolean result) boolean
AccessController.preCheckAndDeleteAfterRowLock
(ObserverContext<? extends RegionCoprocessorEnvironment> c, byte[] row, byte[] family, byte[] qualifier, CompareOperator op, ByteArrayComparable comparator, Delete delete, boolean result) void
AccessController.preDelete
(ObserverContext<? extends RegionCoprocessorEnvironment> c, Delete delete, WALEdit edit, Durability durability) -
Uses of Delete in org.apache.hadoop.hbase.thrift2
Modifier and TypeMethodDescriptionstatic Delete
ThriftUtilities.deleteFromThrift
(org.apache.hadoop.hbase.thrift2.generated.TDelete in) Creates aDelete
(HBase) from aTDelete
(Thrift).Modifier and TypeMethodDescriptionThriftUtilities.deletesFromThrift
(List<org.apache.hadoop.hbase.thrift2.generated.TDelete> in) Converts multipleTDelete
s (Thrift) into a list ofDelete
s (HBase).Modifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.thrift2.generated.TDelete
ThriftUtilities.deleteFromHBase
(Delete in) Modifier and TypeMethodDescriptionstatic List<org.apache.hadoop.hbase.thrift2.generated.TDelete>
ThriftUtilities.deletesFromHBase
(List<Delete> in) -
Uses of Delete in org.apache.hadoop.hbase.thrift2.client
Modifier and TypeMethodDescriptionvoid
boolean
ThriftTable.CheckAndMutateBuilderImpl.thenDelete
(Delete delete)