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.
-
Uses of org.apache.hadoop.hbase.client.Delete in org.apache.hadoop.hbase
Modifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.client.Delete
MetaTableAccessor.makeDeleteFromRegionInfo
(org.apache.hadoop.hbase.client.RegionInfo regionInfo, long ts) Generates and returns a Delete containing the region info for the catalog table -
Uses of org.apache.hadoop.hbase.client.Delete in org.apache.hadoop.hbase.client
Modifier and TypeMethodDescriptionorg.apache.hadoop.hbase.client.Delete
Delete.add
(org.apache.hadoop.hbase.Cell cell) Add an existing delete marker to this Delete object.org.apache.hadoop.hbase.client.Delete
Delete.addColumn
(byte[] family, byte[] qualifier) Delete the latest version of the specified column.org.apache.hadoop.hbase.client.Delete
Delete.addColumn
(byte[] family, byte[] qualifier, long timestamp) Delete the specified version of the specified column.org.apache.hadoop.hbase.client.Delete
Delete.addColumns
(byte[] family, byte[] qualifier) Delete all versions of the specified column.org.apache.hadoop.hbase.client.Delete
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.org.apache.hadoop.hbase.client.Delete
Delete.addDeleteMarker
(org.apache.hadoop.hbase.Cell kv) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.org.apache.hadoop.hbase.client.Delete
Delete.addFamily
(byte[] family) Delete all versions of all columns of the specified family.org.apache.hadoop.hbase.client.Delete
Delete.addFamily
(byte[] family, long timestamp) Delete all columns of the specified family with a timestamp less than or equal to the specified timestamp.org.apache.hadoop.hbase.client.Delete
Delete.addFamilyVersion
(byte[] family, long timestamp) Delete all columns of the specified family with a timestamp equal to the specified timestamp.org.apache.hadoop.hbase.client.Delete
Delete.setACL
(String user, org.apache.hadoop.hbase.security.access.Permission perms) org.apache.hadoop.hbase.client.Delete
org.apache.hadoop.hbase.client.Delete
Delete.setAttribute
(String name, byte[] value) org.apache.hadoop.hbase.client.Delete
Delete.setCellVisibility
(org.apache.hadoop.hbase.security.visibility.CellVisibility expression) org.apache.hadoop.hbase.client.Delete
org.apache.hadoop.hbase.client.Delete
Delete.setDurability
(org.apache.hadoop.hbase.client.Durability d) org.apache.hadoop.hbase.client.Delete
Delete.setFamilyCellMap
(NavigableMap<byte[], List<org.apache.hadoop.hbase.Cell>> map) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.org.apache.hadoop.hbase.client.Delete
Delete.setId
(String id) org.apache.hadoop.hbase.client.Delete
Delete.setPriority
(int priority) org.apache.hadoop.hbase.client.Delete
Delete.setTimestamp
(long timestamp) org.apache.hadoop.hbase.client.Delete
Delete.setTTL
(long ttl) Modifier and TypeMethodDescriptionvoid
RowMutations.add
(org.apache.hadoop.hbase.client.Delete d) Deprecated.since 2.0 version and will be removed in 3.0 version.CheckAndMutate.Builder.build
(org.apache.hadoop.hbase.client.Delete delete) Build the CheckAndMutate objectboolean
HTable.checkAndDelete
(byte[] row, byte[] family, byte[] qualifier, byte[] value, org.apache.hadoop.hbase.client.Delete delete) Deprecated.boolean
HTable.checkAndDelete
(byte[] row, byte[] family, byte[] qualifier, org.apache.hadoop.hbase.CompareOperator op, byte[] value, org.apache.hadoop.hbase.client.Delete delete) Deprecated.boolean
HTable.checkAndDelete
(byte[] row, byte[] family, byte[] qualifier, org.apache.hadoop.hbase.filter.CompareFilter.CompareOp compareOp, byte[] value, org.apache.hadoop.hbase.client.Delete delete) Deprecated.default boolean
Table.checkAndDelete
(byte[] row, byte[] family, byte[] qualifier, byte[] value, org.apache.hadoop.hbase.client.Delete delete) Deprecated.Since 2.0.0.default boolean
Table.checkAndDelete
(byte[] row, byte[] family, byte[] qualifier, org.apache.hadoop.hbase.CompareOperator op, byte[] value, org.apache.hadoop.hbase.client.Delete delete) Deprecated.Since 2.0.0.default boolean
Table.checkAndDelete
(byte[] row, byte[] family, byte[] qualifier, org.apache.hadoop.hbase.filter.CompareFilter.CompareOp compareOp, byte[] value, org.apache.hadoop.hbase.client.Delete delete) Deprecated.Since 2.0.0.AsyncTable.delete
(org.apache.hadoop.hbase.client.Delete delete) Deletes the specified cells/row.void
HTable.delete
(org.apache.hadoop.hbase.client.Delete delete) default void
Table.delete
(org.apache.hadoop.hbase.client.Delete delete) Deletes the specified cells/row.AsyncTable.CheckAndMutateBuilder.thenDelete
(org.apache.hadoop.hbase.client.Delete delete) Deprecated.Specify a Delete to commit if the check succeeds.AsyncTable.CheckAndMutateWithFilterBuilder.thenDelete
(org.apache.hadoop.hbase.client.Delete delete) Deprecated.Specify a Delete to commit if the check succeeds.boolean
Table.CheckAndMutateBuilder.thenDelete
(org.apache.hadoop.hbase.client.Delete delete) Deprecated.Specify a Delete to commit if the check succeeds.boolean
Table.CheckAndMutateWithFilterBuilder.thenDelete
(org.apache.hadoop.hbase.client.Delete delete) Deprecated.Specify a Delete to commit if the check succeeds.Modifier and TypeMethodDescriptionAsyncTable.delete
(List<org.apache.hadoop.hbase.client.Delete> deletes) Deletes the specified cells/rows in bulk.void
HTable.delete
(List<org.apache.hadoop.hbase.client.Delete> deletes) default void
Table.delete
(List<org.apache.hadoop.hbase.client.Delete> deletes) Batch Deletes the specified cells/rows from the table.default CompletableFuture<Void>
AsyncTable.deleteAll
(List<org.apache.hadoop.hbase.client.Delete> deletes) A simple version of batch delete.ModifierConstructorDescriptionDelete
(org.apache.hadoop.hbase.client.Delete deleteToCopy) Create a Delete operation using another Delete as template. -
Uses of org.apache.hadoop.hbase.client.Delete in org.apache.hadoop.hbase.coprocessor
Modifier and TypeMethodDescriptiondefault boolean
RegionObserver.postCheckAndDelete
(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment> c, byte[] row, byte[] family, byte[] qualifier, org.apache.hadoop.hbase.CompareOperator op, org.apache.hadoop.hbase.filter.ByteArrayComparable comparator, org.apache.hadoop.hbase.client.Delete delete, boolean result) Deprecated.since 2.4.0 and will be removed in 4.0.0.default boolean
RegionObserver.postCheckAndDelete
(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment> c, byte[] row, org.apache.hadoop.hbase.filter.Filter filter, org.apache.hadoop.hbase.client.Delete delete, boolean result) Deprecated.since 2.4.0 and will be removed in 4.0.0.default void
RegionObserver.postDelete
(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment> c, org.apache.hadoop.hbase.client.Delete delete, org.apache.hadoop.hbase.wal.WALEdit edit) Called after the client deletes a value.default void
RegionObserver.postDelete
(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment> c, org.apache.hadoop.hbase.client.Delete delete, org.apache.hadoop.hbase.wal.WALEdit edit, org.apache.hadoop.hbase.client.Durability durability) Deprecated.since 2.5.0 and will be removed in 4.0.0.default boolean
RegionObserver.preCheckAndDelete
(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment> c, byte[] row, byte[] family, byte[] qualifier, org.apache.hadoop.hbase.CompareOperator op, org.apache.hadoop.hbase.filter.ByteArrayComparable comparator, org.apache.hadoop.hbase.client.Delete delete, boolean result) Deprecated.since 2.4.0 and will be removed in 4.0.0.default boolean
RegionObserver.preCheckAndDelete
(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment> c, byte[] row, org.apache.hadoop.hbase.filter.Filter filter, org.apache.hadoop.hbase.client.Delete delete, boolean result) Deprecated.since 2.4.0 and will be removed in 4.0.0.default boolean
RegionObserver.preCheckAndDeleteAfterRowLock
(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment> c, byte[] row, byte[] family, byte[] qualifier, org.apache.hadoop.hbase.CompareOperator op, org.apache.hadoop.hbase.filter.ByteArrayComparable comparator, org.apache.hadoop.hbase.client.Delete delete, boolean result) Deprecated.since 2.4.0 and will be removed in 4.0.0.default boolean
RegionObserver.preCheckAndDeleteAfterRowLock
(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment> c, byte[] row, org.apache.hadoop.hbase.filter.Filter filter, org.apache.hadoop.hbase.client.Delete delete, boolean result) Deprecated.since 2.4.0 and will be removed in 4.0.0.default void
RegionObserver.preDelete
(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment> c, org.apache.hadoop.hbase.client.Delete delete, org.apache.hadoop.hbase.wal.WALEdit edit) Called before the client deletes a value.default void
RegionObserver.preDelete
(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment> c, org.apache.hadoop.hbase.client.Delete delete, org.apache.hadoop.hbase.wal.WALEdit edit, org.apache.hadoop.hbase.client.Durability durability) Deprecated.since 2.5.0 and will be removed in 4.0.0. -
Uses of org.apache.hadoop.hbase.client.Delete in org.apache.hadoop.hbase.mapreduce
Modifier and TypeMethodDescriptionprotected void
Import.Importer.processKV
(org.apache.hadoop.hbase.io.ImmutableBytesWritable key, org.apache.hadoop.hbase.client.Result result, org.apache.hadoop.mapreduce.Mapper<org.apache.hadoop.hbase.io.ImmutableBytesWritable, org.apache.hadoop.hbase.client.Result, org.apache.hadoop.hbase.io.ImmutableBytesWritable, org.apache.hadoop.hbase.client.Mutation>.org.apache.hadoop.mapreduce.Mapper.Context context, org.apache.hadoop.hbase.client.Put put, org.apache.hadoop.hbase.client.Delete delete) -
Uses of org.apache.hadoop.hbase.client.Delete in org.apache.hadoop.hbase.regionserver
Modifier and TypeMethodDescriptionvoid
HRegion.delete
(org.apache.hadoop.hbase.client.Delete delete) void
Region.delete
(org.apache.hadoop.hbase.client.Delete delete) Deletes the specified cells/row.void
RegionCoprocessorHost.postDelete
(org.apache.hadoop.hbase.client.Delete delete, org.apache.hadoop.hbase.wal.WALEdit edit) boolean
RegionCoprocessorHost.preDelete
(org.apache.hadoop.hbase.client.Delete delete, org.apache.hadoop.hbase.wal.WALEdit edit) Supports Coprocessor 'bypass'. -
Uses of org.apache.hadoop.hbase.client.Delete in org.apache.hadoop.hbase.shaded.protobuf
Modifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.client.Delete
ProtobufUtil.toDelete
(org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MutationProto proto) Convert a protocol buffer Mutate to a Deletestatic org.apache.hadoop.hbase.client.Delete
ProtobufUtil.toDelete
(org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MutationProto proto, org.apache.hadoop.hbase.CellScanner cellScanner) Convert a protocol buffer Mutate to a DeleteModifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MutateRequest
RequestConverter.buildMutateRequest
(byte[] regionName, org.apache.hadoop.hbase.client.Delete delete) Create a protocol buffer MutateRequest for a delete