| 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.mapreduce | Provides HBase MapReduce
Input/OutputFormats, a table indexing MapReduce job, and utility methods. | 
| org.apache.hadoop.hbase.protobuf | Holds classes generated from protobuf
 src/main/protobufdefinition files. | 
| org.apache.hadoop.hbase.quotas | |
| org.apache.hadoop.hbase.regionserver | |
| org.apache.hadoop.hbase.security.access | |
| org.apache.hadoop.hbase.security.visibility | |
| org.apache.hadoop.hbase.tool | |
| org.apache.hadoop.hbase.wal | 
| Modifier and Type | Method and Description | 
|---|---|
| static void | MetaTableAccessor. mutateMetaTable(Connection connection,
               List<Mutation> mutations)Execute the passed  mutationsagainsthbase:metatable. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | AppendPerforms Append operations on a single row. | 
| class  | DeleteUsed to perform Delete operations on a single row. | 
| class  | IncrementUsed to perform Increment operations on a single row. | 
| class  | PutUsed to perform Put operations for a single row. | 
| Modifier and Type | Method and Description | 
|---|---|
| Mutation | Mutation. setACL(Map<String,Permission> perms) | 
| Mutation | Mutation. setACL(String user,
      Permission perms) | 
| Mutation | Mutation. setCellVisibility(CellVisibility expression)Sets the visibility expression associated with cells in this Mutation. | 
| Mutation | Mutation. setClusterIds(List<UUID> clusterIds)Marks that the clusters with the given clusterIds have consumed the mutation | 
| Mutation | Mutation. setDurability(Durability d)Set the durability for this mutation | 
| Mutation | Mutation. setFamilyCellMap(NavigableMap<byte[],List<Cell>> map)Method for setting the put's familyMap | 
| Mutation | Mutation. setFamilyMap(NavigableMap<byte[],List<KeyValue>> map)Deprecated. 
 use  setFamilyCellMap(NavigableMap)instead. | 
| protected Mutation | Mutation. setReturnResults(boolean returnResults) | 
| Mutation | Mutation. setTTL(long ttl)Set the TTL desired for the result of the mutation, in milliseconds. | 
| Mutation | Mutation. setWriteToWAL(boolean write)Deprecated. 
 Use  setDurability(Durability)instead. | 
| Modifier and Type | Method and Description | 
|---|---|
| List<Mutation> | RowMutations. getMutations() | 
| Modifier and Type | Method and Description | 
|---|---|
| void | BufferedMutatorImpl. mutate(Mutation m) | 
| void | BufferedMutator. mutate(Mutation mutation)Sends a  Mutationto the table. | 
| Modifier and Type | Method and Description | 
|---|---|
| void | BufferedMutatorImpl. mutate(List<? extends Mutation> ms) | 
| void | BufferedMutator. mutate(List<? extends Mutation> mutations)Send some  Mutations to the table. | 
| Modifier and Type | Method and Description | 
|---|---|
| Cell | BaseRegionObserver. postMutationBeforeWAL(ObserverContext<RegionCoprocessorEnvironment> ctx,
                     RegionObserver.MutationType opType,
                     Mutation mutation,
                     Cell oldCell,
                     Cell newCell) | 
| Cell | RegionObserver. postMutationBeforeWAL(ObserverContext<RegionCoprocessorEnvironment> ctx,
                     RegionObserver.MutationType opType,
                     Mutation mutation,
                     Cell oldCell,
                     Cell newCell)Called after a new cell has been created during an increment operation, but before
 it is committed to the WAL or memstore. | 
| void | BaseRegionObserver. prePrepareTimeStampForDeleteVersion(ObserverContext<RegionCoprocessorEnvironment> e,
                                   Mutation delete,
                                   Cell cell,
                                   byte[] byteNow,
                                   Get get) | 
| void | RegionObserver. prePrepareTimeStampForDeleteVersion(ObserverContext<RegionCoprocessorEnvironment> c,
                                   Mutation mutation,
                                   Cell cell,
                                   byte[] byteNow,
                                   Get get)Called before the server updates the timestamp for version delete with latest timestamp. | 
| Modifier and Type | Method and Description | 
|---|---|
| void | BaseRegionObserver. postBatchMutate(ObserverContext<RegionCoprocessorEnvironment> c,
               MiniBatchOperationInProgress<Mutation> miniBatchOp) | 
| void | RegionObserver. postBatchMutate(ObserverContext<RegionCoprocessorEnvironment> c,
               MiniBatchOperationInProgress<Mutation> miniBatchOp)This will be called after applying a batch of Mutations on a region. | 
| void | BaseRegionObserver. postBatchMutateIndispensably(ObserverContext<RegionCoprocessorEnvironment> ctx,
                            MiniBatchOperationInProgress<Mutation> miniBatchOp,
                            boolean success) | 
| void | RegionObserver. postBatchMutateIndispensably(ObserverContext<RegionCoprocessorEnvironment> ctx,
                            MiniBatchOperationInProgress<Mutation> miniBatchOp,
                            boolean success)Called after the completion of batch put/delete and will be called even if the batch operation
 fails | 
| void | BaseRegionObserver. preBatchMutate(ObserverContext<RegionCoprocessorEnvironment> c,
              MiniBatchOperationInProgress<Mutation> miniBatchOp) | 
| void | RegionObserver. preBatchMutate(ObserverContext<RegionCoprocessorEnvironment> c,
              MiniBatchOperationInProgress<Mutation> miniBatchOp)This will be called for every batch mutation operation happening at the server. | 
| void | BaseRegionServerObserver. preMergeCommit(ObserverContext<RegionServerCoprocessorEnvironment> ctx,
              Region regionA,
              Region regionB,
              List<Mutation> metaEntries) | 
| void | RegionServerObserver. preMergeCommit(ObserverContext<RegionServerCoprocessorEnvironment> ctx,
              Region regionA,
              Region regionB,
              List<Mutation> metaEntries)This will be called before PONR step as part of regions merge transaction. | 
| void | BaseRegionObserver. preSplitBeforePONR(ObserverContext<RegionCoprocessorEnvironment> ctx,
                  byte[] splitKey,
                  List<Mutation> metaEntries) | 
| void | RegionObserver. preSplitBeforePONR(ObserverContext<RegionCoprocessorEnvironment> ctx,
                  byte[] splitKey,
                  List<Mutation> metaEntries)This will be called before PONR step as part of split transaction. | 
| Modifier and Type | Method and Description | 
|---|---|
| org.apache.hadoop.io.serializer.Deserializer<Mutation> | MutationSerialization. getDeserializer(Class<Mutation> c) | 
| org.apache.hadoop.mapreduce.RecordWriter<KEY,Mutation> | TableOutputFormat. getRecordWriter(org.apache.hadoop.mapreduce.TaskAttemptContext context)Creates a new record writer. | 
| org.apache.hadoop.mapreduce.RecordWriter<ImmutableBytesWritable,Mutation> | MultiTableOutputFormat. getRecordWriter(org.apache.hadoop.mapreduce.TaskAttemptContext context) | 
| org.apache.hadoop.io.serializer.Serializer<Mutation> | MutationSerialization. getSerializer(Class<Mutation> c) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | MultiTableOutputFormat.MultiTableRecordWriter. write(ImmutableBytesWritable tableName,
     Mutation action)Writes an action (Put or Delete) to the specified table. | 
| void | TableOutputFormat.TableRecordWriter. write(KEY key,
     Mutation value)Writes a key/value pair into the table. | 
| Modifier and Type | Method and Description | 
|---|---|
| org.apache.hadoop.io.serializer.Deserializer<Mutation> | MutationSerialization. getDeserializer(Class<Mutation> c) | 
| org.apache.hadoop.io.serializer.Serializer<Mutation> | MutationSerialization. getSerializer(Class<Mutation> c) | 
| void | IdentityTableReducer. reduce(org.apache.hadoop.io.Writable key,
      Iterable<Mutation> values,
      org.apache.hadoop.mapreduce.Reducer.Context context)Writes each given record, consisting of the row key and the given values,
 to the configured  OutputFormat. | 
| Modifier and Type | Method and Description | 
|---|---|
| static Mutation | ProtobufUtil. toMutation(org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto proto)Convert a MutateRequest to Mutation | 
| Modifier and Type | Method and Description | 
|---|---|
| static org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto | ProtobufUtil. toMutation(org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.MutationType type,
          Mutation mutation) | 
| static org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto | ProtobufUtil. toMutation(org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.MutationType type,
          Mutation mutation,
          org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder builder) | 
| static org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto | ProtobufUtil. toMutation(org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.MutationType type,
          Mutation mutation,
          org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder builder,
          long nonce) | 
| static org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto | ProtobufUtil. toMutation(org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.MutationType type,
          Mutation mutation,
          long nonce)Create a protocol buffer Mutate based on a client Mutation | 
| static org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto | ProtobufUtil. toMutationNoData(org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.MutationType type,
                Mutation mutation)Create a protocol buffer MutationProto based on a client Mutation. | 
| static org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto | ProtobufUtil. toMutationNoData(org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.MutationType type,
                Mutation mutation,
                org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder builder)Create a protocol buffer MutationProto based on a client Mutation. | 
| static org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto | ProtobufUtil. toMutationNoData(org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.MutationType type,
                Mutation mutation,
                org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder builder,
                long nonce) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | DefaultOperationQuota. addMutation(Mutation mutation) | 
| void | OperationQuota. addMutation(Mutation mutation)Add a mutation result. | 
| static long | QuotaUtil. calculateMutationSize(Mutation mutation) | 
| Modifier and Type | Method and Description | 
|---|---|
| Mutation[] | MiniBatchOperationInProgress. getOperationsFromCoprocessors(int index) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | MiniBatchOperationInProgress. addOperationsFromCP(int index,
                   Mutation[] newOperations)Add more Mutations corresponding to the Mutation at the given index to be committed atomically
 in the same batch. | 
| OperationStatus[] | HRegion. batchMutate(Mutation[] mutations) | 
| OperationStatus[] | HRegion. batchMutate(Mutation[] mutations,
           long nonceGroup,
           long nonce) | 
| OperationStatus[] | Region. batchMutate(Mutation[] mutations,
           long nonceGroup,
           long nonce)Perform a batch of mutations. | 
| boolean | HRegion. checkAndMutate(byte[] row,
              byte[] family,
              byte[] qualifier,
              CompareFilter.CompareOp compareOp,
              ByteArrayComparable comparator,
              Mutation w,
              boolean writeToWAL) | 
| boolean | Region. checkAndMutate(byte[] row,
              byte[] family,
              byte[] qualifier,
              CompareFilter.CompareOp compareOp,
              ByteArrayComparable comparator,
              Mutation mutation,
              boolean writeToWAL)Atomically checks if a row/family/qualifier value matches the expected val
 If it does, it performs the row mutations. | 
| Cell | RegionCoprocessorHost. postMutationBeforeWAL(RegionObserver.MutationType opType,
                     Mutation mutation,
                     Cell oldCell,
                     Cell newCell) | 
| void | HRegion. prepareDeleteTimestamps(Mutation mutation,
                       Map<byte[],List<Cell>> familyMap,
                       byte[] byteNow) | 
| void | Region. prepareDeleteTimestamps(Mutation mutation,
                       Map<byte[],List<Cell>> familyCellMap,
                       byte[] now)Set up correct timestamps in the KVs in Delete object. | 
| boolean | RegionCoprocessorHost. prePrepareTimeStampForDeleteVersion(Mutation mutation,
                                   Cell kv,
                                   byte[] byteNow,
                                   Get get) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | HRegion. mutateRowsWithLocks(Collection<Mutation> mutations,
                   Collection<byte[]> rowsToLock)Perform atomic mutations within the region w/o nonces. | 
| void | HRegion. mutateRowsWithLocks(Collection<Mutation> mutations,
                   Collection<byte[]> rowsToLock,
                   long nonceGroup,
                   long nonce)Perform atomic mutations within the region. | 
| void | Region. mutateRowsWithLocks(Collection<Mutation> mutations,
                   Collection<byte[]> rowsToLock,
                   long nonceGroup,
                   long nonce)Perform atomic mutations within the region. | 
| void | RegionCoprocessorHost. postBatchMutate(MiniBatchOperationInProgress<Mutation> miniBatchOp) | 
| void | RegionCoprocessorHost. postBatchMutateIndispensably(MiniBatchOperationInProgress<Mutation> miniBatchOp,
                            boolean success) | 
| boolean | RegionCoprocessorHost. preBatchMutate(MiniBatchOperationInProgress<Mutation> miniBatchOp) | 
| boolean | RegionServerCoprocessorHost. preMergeCommit(HRegion regionA,
              HRegion regionB,
              List<Mutation> metaEntries) | 
| void | RegionMergeTransactionImpl. prepareMutationsForMerge(HRegionInfo mergedRegion,
                        HRegionInfo regionA,
                        HRegionInfo regionB,
                        ServerName serverName,
                        List<Mutation> mutations,
                        int regionReplication) | 
| boolean | RegionCoprocessorHost. preSplitBeforePONR(byte[] splitKey,
                  List<Mutation> metaEntries) | 
| void | RowProcessor. process(long now,
       HRegion region,
       List<Mutation> mutations,
       WALEdit walEdit)HRegion handles the locks and MVCC and invokes this method properly. | 
| Modifier and Type | Method and Description | 
|---|---|
| Cell | AccessController. postMutationBeforeWAL(ObserverContext<RegionCoprocessorEnvironment> ctx,
                     RegionObserver.MutationType opType,
                     Mutation mutation,
                     Cell oldCell,
                     Cell newCell) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | AccessController. preBatchMutate(ObserverContext<RegionCoprocessorEnvironment> c,
              MiniBatchOperationInProgress<Mutation> miniBatchOp) | 
| void | AccessController. preMergeCommit(ObserverContext<RegionServerCoprocessorEnvironment> ctx,
              Region regionA,
              Region regionB,
              List<Mutation> metaEntries) | 
| Modifier and Type | Method and Description | 
|---|---|
| Cell | VisibilityController. postMutationBeforeWAL(ObserverContext<RegionCoprocessorEnvironment> ctx,
                     RegionObserver.MutationType opType,
                     Mutation mutation,
                     Cell oldCell,
                     Cell newCell) | 
| void | VisibilityController. prePrepareTimeStampForDeleteVersion(ObserverContext<RegionCoprocessorEnvironment> ctx,
                                   Mutation delete,
                                   Cell cell,
                                   byte[] byteNow,
                                   Get get) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | VisibilityController. preBatchMutate(ObserverContext<RegionCoprocessorEnvironment> c,
              MiniBatchOperationInProgress<Mutation> miniBatchOp) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | WriteSinkCoprocessor. preBatchMutate(ObserverContext<RegionCoprocessorEnvironment> c,
              MiniBatchOperationInProgress<Mutation> miniBatchOp) | 
| Modifier and Type | Field and Description | 
|---|---|
| Mutation | WALSplitter.MutationReplay. mutation | 
| Constructor and Description | 
|---|
| WALSplitter.MutationReplay(org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.MutationType type,
                          Mutation mutation,
                          long nonceGroup,
                          long nonce) | 
Copyright © 2007–2019 The Apache Software Foundation. All rights reserved.