| Package | Description | 
|---|---|
| org.apache.hadoop.hbase | |
| org.apache.hadoop.hbase.client | Provides HBase Client | 
| org.apache.hadoop.hbase.coprocessor | Table of Contents | 
| org.apache.hadoop.hbase.coprocessor.example | |
| org.apache.hadoop.hbase.mapreduce | Provides HBase MapReduce
Input/OutputFormats, a table indexing MapReduce job, and utility methods. | 
| org.apache.hadoop.hbase.quotas | |
| org.apache.hadoop.hbase.regionserver | |
| org.apache.hadoop.hbase.security.access | |
| org.apache.hadoop.hbase.thrift2 | Provides an HBase Thrift
service. | 
| org.apache.hadoop.hbase.thrift2.client | 
| Modifier and Type | Method and Description | 
|---|---|
| static Delete | MetaTableAccessor. makeDeleteFromRegionInfo(RegionInfo regionInfo,
                        long ts)Generates and returns a Delete containing the region info for the catalog table | 
| Modifier and Type | Method and Description | 
|---|---|
| private static void | MetaTableAccessor. deleteFromMetaTable(Connection connection,
                   Delete d)Delete the passed  dfrom thehbase:metatable. | 
| Modifier and Type | Method and Description | 
|---|---|
| private static void | MetaTableAccessor. deleteFromMetaTable(Connection connection,
                   List<Delete> deletes)Delete the passed  deletesfrom thehbase:metatable. | 
| Modifier and Type | Method and Description | 
|---|---|
| Delete | Delete. add(Cell cell)Add an existing delete marker to this Delete object. | 
| Delete | Delete. addColumn(byte[] family,
         byte[] qualifier)Delete the latest version of the specified column. | 
| Delete | Delete. addColumn(byte[] family,
         byte[] qualifier,
         long timestamp)Delete the specified version of the specified column. | 
| Delete | Delete. addColumns(byte[] family,
          byte[] qualifier)Delete all versions of the specified column. | 
| 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. | 
| Delete | Delete. addDeleteMarker(Cell kv)Deprecated. 
 As of release 2.0.0, this will be removed in HBase 3.0.0. Use  add(Cell)instead | 
| Delete | Delete. addFamily(byte[] family)Delete all versions of all columns of the specified family. | 
| 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. | 
| Delete | Delete. addFamilyVersion(byte[] family,
                long timestamp)Delete all columns of the specified family with a timestamp equal to
 the specified timestamp. | 
| Delete | Delete. setACL(Map<String,Permission> perms) | 
| Delete | Delete. setACL(String user,
      Permission perms) | 
| Delete | Delete. setAttribute(String name,
            byte[] value) | 
| Delete | Delete. setCellVisibility(CellVisibility expression) | 
| Delete | Delete. setClusterIds(List<UUID> clusterIds) | 
| Delete | Delete. setDurability(Durability d) | 
| Delete | Delete. setFamilyCellMap(NavigableMap<byte[],List<Cell>> map)Deprecated. 
 As of release 2.0.0, this will be removed in HBase 3.0.0.
             Use  Delete(byte[], long, NavigableMap)instead | 
| Delete | Delete. setId(String id) | 
| Delete | Delete. setPriority(int priority) | 
| Delete | Delete. setTimestamp(long timestamp) | 
| Delete | Delete. setTTL(long ttl) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | RowMutations. add(Delete d)Deprecated. 
 since 2.0 version and will be removed in 3.0 version.
             use  RowMutations.add(Mutation) | 
| CheckAndMutate | CheckAndMutate.Builder. build(Delete delete) | 
| boolean | HTable. checkAndDelete(byte[] row,
              byte[] family,
              byte[] qualifier,
              byte[] value,
              Delete delete)Deprecated.  | 
| default boolean | Table. checkAndDelete(byte[] row,
              byte[] family,
              byte[] qualifier,
              byte[] value,
              Delete delete)Deprecated. 
 Since 2.0.0. Will be removed in 3.0.0. Use  Table.checkAndMutate(byte[], byte[]) | 
| boolean | HTable. checkAndDelete(byte[] row,
              byte[] family,
              byte[] qualifier,
              CompareFilter.CompareOp compareOp,
              byte[] value,
              Delete delete)Deprecated.  | 
| default boolean | Table. checkAndDelete(byte[] row,
              byte[] family,
              byte[] qualifier,
              CompareFilter.CompareOp compareOp,
              byte[] value,
              Delete delete)Deprecated. 
 Since 2.0.0. Will be removed in 3.0.0. Use  Table.checkAndMutate(byte[], byte[]) | 
| boolean | HTable. checkAndDelete(byte[] row,
              byte[] family,
              byte[] qualifier,
              CompareOperator op,
              byte[] value,
              Delete delete)Deprecated.  | 
| default boolean | Table. checkAndDelete(byte[] row,
              byte[] family,
              byte[] qualifier,
              CompareOperator op,
              byte[] value,
              Delete delete)Deprecated. 
 Since 2.0.0. Will be removed in 3.0.0. Use  Table.checkAndMutate(byte[], byte[]) | 
| void | HTable. delete(Delete delete) | 
| CompletableFuture<Void> | AsyncTable. delete(Delete delete)Deletes the specified cells/row. | 
| default void | Table. delete(Delete delete)Deletes the specified cells/row. | 
| CompletableFuture<Void> | RawAsyncTableImpl. delete(Delete delete) | 
| CompletableFuture<Void> | AsyncTableImpl. delete(Delete delete) | 
| boolean | HTable.CheckAndMutateBuilderImpl. thenDelete(Delete delete) | 
| boolean | HTable.CheckAndMutateWithFilterBuilderImpl. thenDelete(Delete delete) | 
| CompletableFuture<Boolean> | AsyncTable.CheckAndMutateBuilder. thenDelete(Delete delete)Deprecated.  | 
| CompletableFuture<Boolean> | AsyncTable.CheckAndMutateWithFilterBuilder. thenDelete(Delete delete)Deprecated.  | 
| boolean | Table.CheckAndMutateBuilder. thenDelete(Delete delete)Deprecated.  | 
| boolean | Table.CheckAndMutateWithFilterBuilder. thenDelete(Delete delete)Deprecated.  | 
| CompletableFuture<Boolean> | RawAsyncTableImpl.CheckAndMutateBuilderImpl. thenDelete(Delete delete) | 
| CompletableFuture<Boolean> | RawAsyncTableImpl.CheckAndMutateWithFilterBuilderImpl. thenDelete(Delete delete) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | HTable. delete(List<Delete> deletes) | 
| List<CompletableFuture<Void>> | AsyncTable. delete(List<Delete> deletes)Deletes the specified cells/rows in bulk. | 
| default void | Table. delete(List<Delete> deletes)Batch Deletes the specified cells/rows from the table. | 
| List<CompletableFuture<Void>> | RawAsyncTableImpl. delete(List<Delete> deletes) | 
| List<CompletableFuture<Void>> | AsyncTableImpl. delete(List<Delete> deletes) | 
| default CompletableFuture<Void> | AsyncTable. deleteAll(List<Delete> deletes)A simple version of batch delete. | 
| Constructor and Description | 
|---|
| Delete(Delete deleteToCopy) | 
| Modifier and Type | Method and Description | 
|---|---|
| default boolean | RegionObserver. postCheckAndDelete(ObserverContext<RegionCoprocessorEnvironment> c,
                  byte[] row,
                  byte[] family,
                  byte[] qualifier,
                  CompareOperator op,
                  ByteArrayComparable comparator,
                  Delete delete,
                  boolean result)Deprecated. 
 since 2.4.0 and will be removed in 4.0.0. Use
    RegionObserver.postCheckAndMutate(ObserverContext, CheckAndMutate, CheckAndMutateResult)instead. | 
| default boolean | RegionObserver. postCheckAndDelete(ObserverContext<RegionCoprocessorEnvironment> c,
                  byte[] row,
                  Filter filter,
                  Delete delete,
                  boolean result)Deprecated. 
 since 2.4.0 and will be removed in 4.0.0. Use
    RegionObserver.postCheckAndMutate(ObserverContext, CheckAndMutate, CheckAndMutateResult)instead. | 
| default void | RegionObserver. postDelete(ObserverContext<RegionCoprocessorEnvironment> c,
          Delete delete,
          WALEdit edit,
          Durability durability)Called after the client deletes a value. | 
| default boolean | RegionObserver. preCheckAndDelete(ObserverContext<RegionCoprocessorEnvironment> c,
                 byte[] row,
                 byte[] family,
                 byte[] qualifier,
                 CompareOperator op,
                 ByteArrayComparable comparator,
                 Delete delete,
                 boolean result)Deprecated. 
 since 2.4.0 and will be removed in 4.0.0. Use
    RegionObserver.preCheckAndMutate(ObserverContext, CheckAndMutate, CheckAndMutateResult)instead. | 
| default boolean | RegionObserver. preCheckAndDelete(ObserverContext<RegionCoprocessorEnvironment> c,
                 byte[] row,
                 Filter filter,
                 Delete delete,
                 boolean result)Deprecated. 
 since 2.4.0 and will be removed in 4.0.0. Use
    RegionObserver.preCheckAndMutate(ObserverContext, CheckAndMutate, CheckAndMutateResult)instead. | 
| default boolean | RegionObserver. preCheckAndDeleteAfterRowLock(ObserverContext<RegionCoprocessorEnvironment> c,
                             byte[] row,
                             byte[] family,
                             byte[] qualifier,
                             CompareOperator op,
                             ByteArrayComparable comparator,
                             Delete delete,
                             boolean result)Deprecated. 
 since 2.4.0 and will be removed in 4.0.0. Use
    RegionObserver.preCheckAndMutateAfterRowLock(ObserverContext, CheckAndMutate,CheckAndMutateResult)instead. | 
| default boolean | RegionObserver. preCheckAndDeleteAfterRowLock(ObserverContext<RegionCoprocessorEnvironment> c,
                             byte[] row,
                             Filter filter,
                             Delete delete,
                             boolean result)Deprecated. 
 since 2.4.0 and will be removed in 4.0.0. Use
    RegionObserver.preCheckAndMutateAfterRowLock(ObserverContext, CheckAndMutate,CheckAndMutateResult)instead. | 
| default void | RegionObserver. preDelete(ObserverContext<RegionCoprocessorEnvironment> c,
         Delete delete,
         WALEdit edit,
         Durability durability)Called before the client deletes a value. | 
| void | MetaTableMetrics.ExampleRegionObserverMeta. preDelete(ObserverContext<RegionCoprocessorEnvironment> e,
         Delete delete,
         WALEdit edit,
         Durability durability) | 
| Modifier and Type | Method and Description | 
|---|---|
| private Delete | BulkDeleteEndpoint. createDeleteMutation(List<Cell> deleteRow,
                    org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest.DeleteType deleteType,
                    Long timestamp) | 
| Modifier and Type | Method and Description | 
|---|---|
| protected void | Import.Importer. processKV(ImmutableBytesWritable key,
         Result result,
         org.apache.hadoop.mapreduce.Mapper.Context context,
         Put put,
         Delete delete) | 
| Modifier and Type | Method and Description | 
|---|---|
| (package private) static List<Delete> | QuotaTableUtil. createDeletesForExistingNamespaceSnapshotSizes(Connection connection)Returns a list of  Deleteto remove all namespace snapshot entries from quota table. | 
| (package private) static List<Delete> | QuotaTableUtil. createDeletesForExistingNamespaceSnapshotSizes(Set<String> snapshotEntriesToRemove)Returns a list of  Deleteto remove given namespace snapshot
 entries to removefrom quota table | 
| (package private) static List<Delete> | QuotaTableUtil. createDeletesForExistingSnapshotsFromScan(Connection connection,
                                         Scan scan)Returns a list of  Deleteto remove all entries returned by the passed scanner. | 
| (package private) static List<Delete> | QuotaTableUtil. createDeletesForExistingTableSnapshotSizes(Connection connection)Returns a list of  Deleteto remove all table snapshot entries from quota table. | 
| (package private) static List<Delete> | QuotaTableUtil. createDeletesForExistingTableSnapshotSizes(org.apache.hbase.thirdparty.com.google.common.collect.Multimap<TableName,String> snapshotEntriesToRemove)Returns a list of  Deleteto remove given table snapshot
 entries to remove from quota table | 
| Modifier and Type | Method and Description | 
|---|---|
| private static void | QuotaUtil. doDelete(Connection connection,
        Delete delete) | 
| Modifier and Type | Method and Description | 
|---|---|
| (package private) void | SnapshotQuotaObserverChore. removeExistingSnapshotSizes(List<Delete> deletes) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | Region. delete(Delete delete)Deletes the specified cells/row. | 
| void | HRegion. delete(Delete delete) | 
| void | RegionCoprocessorHost. postDelete(Delete delete,
          WALEdit edit,
          Durability durability) | 
| boolean | RegionCoprocessorHost. preDelete(Delete delete,
         WALEdit edit,
         Durability durability)Supports Coprocessor 'bypass'. | 
| void | HRegion. prepareDelete(Delete delete)Prepare a delete for a row mutation processor | 
| Modifier and Type | Method and Description | 
|---|---|
| void | AccessController. postDelete(ObserverContext<RegionCoprocessorEnvironment> c,
          Delete delete,
          WALEdit edit,
          Durability durability) | 
| boolean | AccessController. preCheckAndDelete(ObserverContext<RegionCoprocessorEnvironment> c,
                 byte[] row,
                 byte[] family,
                 byte[] qualifier,
                 CompareOperator op,
                 ByteArrayComparable comparator,
                 Delete delete,
                 boolean result) | 
| boolean | AccessController. preCheckAndDeleteAfterRowLock(ObserverContext<RegionCoprocessorEnvironment> c,
                             byte[] row,
                             byte[] family,
                             byte[] qualifier,
                             CompareOperator op,
                             ByteArrayComparable comparator,
                             Delete delete,
                             boolean result) | 
| void | AccessController. preDelete(ObserverContext<RegionCoprocessorEnvironment> c,
         Delete delete,
         WALEdit edit,
         Durability durability) | 
| Modifier and Type | Method and Description | 
|---|---|
| static Delete | ThriftUtilities. deleteFromThrift(org.apache.hadoop.hbase.thrift2.generated.TDelete in)Creates a  Delete(HBase) from aTDelete(Thrift). | 
| Modifier and Type | Method and Description | 
|---|---|
| static List<Delete> | ThriftUtilities. deletesFromThrift(List<org.apache.hadoop.hbase.thrift2.generated.TDelete> in)Converts multiple  TDeletes (Thrift) into a list ofDeletes (HBase). | 
| Modifier and Type | Method and Description | 
|---|---|
| static org.apache.hadoop.hbase.thrift2.generated.TDelete | ThriftUtilities. deleteFromHBase(Delete in) | 
| Modifier and Type | Method and Description | 
|---|---|
| static List<org.apache.hadoop.hbase.thrift2.generated.TDelete> | ThriftUtilities. deletesFromHBase(List<Delete> in) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | ThriftTable. delete(Delete delete) | 
| boolean | ThriftTable.CheckAndMutateBuilderImpl. thenDelete(Delete delete) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | ThriftTable. delete(List<Delete> deletes) | 
Copyright © 2007–2021 The Apache Software Foundation. All rights reserved.