Uses of Class
org.apache.hadoop.hbase.client.Delete
Packages that use 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
Methods in org.apache.hadoop.hbase that return DeleteModifier and TypeMethodDescriptionstatic DeleteMetaTableAccessor.makeDeleteFromRegionInfo(RegionInfo regionInfo, long ts) Generates and returns a Delete containing the region info for the catalog tableMethods in org.apache.hadoop.hbase with parameters of type DeleteModifier and TypeMethodDescriptionprivate static voidMetaTableAccessor.deleteFromMetaTable(Connection connection, Delete d) Delete the passeddfrom thehbase:metatable.Method parameters in org.apache.hadoop.hbase with type arguments of type DeleteModifier and TypeMethodDescriptionprivate static voidMetaTableAccessor.deleteFromMetaTable(Connection connection, List<Delete> deletes) Delete the passeddeletesfrom thehbase:metatable. -
Uses of Delete in org.apache.hadoop.hbase.backup.impl
Methods in org.apache.hadoop.hbase.backup.impl that return DeleteModifier and TypeMethodDescriptionprivate DeleteBackupSystemTable.createDeleteForBackupDeleteOperation()private DeleteBackupSystemTable.createDeleteForBackupInfo(String backupId) Creates Delete operation for a given backup idprivate DeleteBackupSystemTable.createDeleteForBackupMergeOperation()private DeleteBackupSystemTable.createDeleteForBackupSet(String name) Creates Delete operation to delete backup set contentprivate DeleteBackupSystemTable.createDeleteForIncrBackupTableSet(String backupRoot) Creates Delete for incremental backup table set -
Uses of Delete in org.apache.hadoop.hbase.client
Methods in org.apache.hadoop.hbase.client that return DeleteModifier 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) Methods in org.apache.hadoop.hbase.client with parameters of type DeleteModifier and TypeMethodDescriptionBuild the CheckAndMutate objectDeletes the specified cells/row.default voidDeletes the specified cells/row.voidAsyncTable.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) booleanTable.CheckAndMutateBuilder.thenDelete(Delete delete) Deprecated.Specify a Delete to commit if the check succeeds.booleanTable.CheckAndMutateWithFilterBuilder.thenDelete(Delete delete) Deprecated.Specify a Delete to commit if the check succeeds.Method parameters in org.apache.hadoop.hbase.client with type arguments of type DeleteModifier and TypeMethodDescriptionDeletes the specified cells/rows in bulk.default voidBatch Deletes the specified cells/rows from the table.voiddefault CompletableFuture<Void>A simple version of batch delete.Constructors in org.apache.hadoop.hbase.client with parameters of type Delete -
Uses of Delete in org.apache.hadoop.hbase.coprocessor
Methods in org.apache.hadoop.hbase.coprocessor with parameters of type DeleteModifier and TypeMethodDescriptiondefault booleanRegionObserver.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 booleanRegionObserver.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 voidRegionObserver.postDelete(ObserverContext<? extends RegionCoprocessorEnvironment> c, Delete delete, WALEdit edit) Called after the client deletes a value.default voidRegionObserver.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 booleanRegionObserver.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 booleanRegionObserver.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 booleanRegionObserver.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 booleanRegionObserver.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.voidMetaTableMetrics.ExampleRegionObserverMeta.preDelete(ObserverContext<? extends RegionCoprocessorEnvironment> e, Delete delete, WALEdit edit, Durability durability) default voidRegionObserver.preDelete(ObserverContext<? extends RegionCoprocessorEnvironment> c, Delete delete, WALEdit edit) Called before the client deletes a value.default voidRegionObserver.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
Methods in org.apache.hadoop.hbase.coprocessor.example that return DeleteModifier and TypeMethodDescriptionprivate DeleteBulkDeleteEndpoint.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
Methods in org.apache.hadoop.hbase.mapreduce with parameters of type DeleteModifier and TypeMethodDescriptionprotected voidImport.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
Methods in org.apache.hadoop.hbase.master.assignment that return types with arguments of type DeleteModifier and TypeMethodDescriptionRegionStateStore.deleteRegionReplicas(ResultScanner scanner, int oldReplicaCount, int newReplicaCount, long now) -
Uses of Delete in org.apache.hadoop.hbase.quotas
Methods in org.apache.hadoop.hbase.quotas that return types with arguments of type DeleteModifier and TypeMethodDescriptionQuotaTableUtil.createDeletesForExistingNamespaceSnapshotSizes(Set<String> snapshotEntriesToRemove) Returns a list ofDeleteto remove given namespace snapshot entries to removefrom quota tableQuotaTableUtil.createDeletesForExistingNamespaceSnapshotSizes(Connection connection) Returns a list ofDeleteto remove all namespace snapshot entries from quota table.QuotaTableUtil.createDeletesForExistingSnapshotsFromScan(Connection connection, Scan scan) Returns a list ofDeleteto remove all entries returned by the passed scanner.QuotaTableUtil.createDeletesForExistingTableSnapshotSizes(Connection connection) Returns a list ofDeleteto 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 ofDeleteto remove given table snapshot entries to remove from quota tableMethods in org.apache.hadoop.hbase.quotas with parameters of type DeleteModifier and TypeMethodDescriptionprivate static voidQuotaUtil.doDelete(Connection connection, Delete delete) Method parameters in org.apache.hadoop.hbase.quotas with type arguments of type DeleteModifier and TypeMethodDescription(package private) voidSnapshotQuotaObserverChore.removeExistingSnapshotSizes(List<Delete> deletes) -
Uses of Delete in org.apache.hadoop.hbase.regionserver
Methods in org.apache.hadoop.hbase.regionserver with parameters of type DeleteModifier and TypeMethodDescriptionvoidvoidDeletes the specified cells/row.voidRegionCoprocessorHost.postDelete(Delete delete, WALEdit edit) booleanSupports Coprocessor 'bypass'.private voidHRegion.prepareDelete(Delete delete) Prepare a delete for a row mutation processor -
Uses of Delete in org.apache.hadoop.hbase.security.access
Methods in org.apache.hadoop.hbase.security.access with parameters of type DeleteModifier and TypeMethodDescriptionvoidAccessController.postDelete(ObserverContext<? extends RegionCoprocessorEnvironment> c, Delete delete, WALEdit edit, Durability durability) booleanAccessController.preCheckAndDelete(ObserverContext<? extends RegionCoprocessorEnvironment> c, byte[] row, byte[] family, byte[] qualifier, CompareOperator op, ByteArrayComparable comparator, Delete delete, boolean result) booleanAccessController.preCheckAndDeleteAfterRowLock(ObserverContext<? extends RegionCoprocessorEnvironment> c, byte[] row, byte[] family, byte[] qualifier, CompareOperator op, ByteArrayComparable comparator, Delete delete, boolean result) voidAccessController.preDelete(ObserverContext<? extends RegionCoprocessorEnvironment> c, Delete delete, WALEdit edit, Durability durability) -
Uses of Delete in org.apache.hadoop.hbase.thrift2
Methods in org.apache.hadoop.hbase.thrift2 that return DeleteModifier and TypeMethodDescriptionstatic DeleteThriftUtilities.deleteFromThrift(org.apache.hadoop.hbase.thrift2.generated.TDelete in) Creates aDelete(HBase) from aTDelete(Thrift).Methods in org.apache.hadoop.hbase.thrift2 that return types with arguments of type DeleteModifier and TypeMethodDescriptionThriftUtilities.deletesFromThrift(List<org.apache.hadoop.hbase.thrift2.generated.TDelete> in) Converts multipleTDeletes (Thrift) into a list ofDeletes (HBase).Methods in org.apache.hadoop.hbase.thrift2 with parameters of type DeleteModifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.thrift2.generated.TDeleteThriftUtilities.deleteFromHBase(Delete in) Method parameters in org.apache.hadoop.hbase.thrift2 with type arguments of type DeleteModifier 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
Methods in org.apache.hadoop.hbase.thrift2.client with parameters of type DeleteModifier and TypeMethodDescriptionvoidbooleanThriftTable.CheckAndMutateBuilderImpl.thenDelete(Delete delete) Method parameters in org.apache.hadoop.hbase.thrift2.client with type arguments of type Delete