| Package | Description | 
|---|---|
| org.apache.hadoop.hbase.constraint | Restrict the domain of a data attribute, often times to fulfill business rules/requirements. | 
| 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.regionserver | |
| org.apache.hadoop.hbase.regionserver.wal | |
| org.apache.hadoop.hbase.replication.regionserver | |
| org.apache.hadoop.hbase.security.access | |
| org.apache.hadoop.hbase.wal | 
| Modifier and Type | Method and Description | 
|---|---|
| void | ConstraintProcessor. prePut(ObserverContext<RegionCoprocessorEnvironment> e,
      Put put,
      WALEdit edit,
      Durability durability) | 
| Modifier and Type | Method and Description | 
|---|---|
| default void | RegionObserver. postDelete(ObserverContext<RegionCoprocessorEnvironment> c,
          Delete delete,
          WALEdit edit,
          Durability durability)Called after the client deletes a value. | 
| default void | RegionObserver. postPut(ObserverContext<RegionCoprocessorEnvironment> c,
       Put put,
       WALEdit edit,
       Durability durability)Called after the client stores a value. | 
| default void | RegionObserver. postWALRestore(ObserverContext<? extends RegionCoprocessorEnvironment> ctx,
              RegionInfo info,
              WALKey logKey,
              WALEdit logEdit)Called after a  WALEditreplayed for this region. | 
| default void | WALObserver. postWALWrite(ObserverContext<? extends WALCoprocessorEnvironment> ctx,
            RegionInfo info,
            WALKey logKey,
            WALEdit logEdit)Deprecated. 
 Since hbase-2.0.0. To be replaced with an alternative that does not expose
 InterfaceAudience classes such as WALKey and WALEdit. Will be removed in hbase-3.0.0. | 
| 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) | 
| default void | RegionObserver. prePut(ObserverContext<RegionCoprocessorEnvironment> c,
      Put put,
      WALEdit edit,
      Durability durability)Called before the client stores a value. | 
| void | MetaTableMetrics.ExampleRegionObserverMeta. prePut(ObserverContext<RegionCoprocessorEnvironment> e,
      Put put,
      WALEdit edit,
      Durability durability) | 
| default void | RegionObserver. preWALAppend(ObserverContext<RegionCoprocessorEnvironment> ctx,
            WALKey key,
            WALEdit edit)Called just before the WAL Entry is appended to the WAL. | 
| default void | RegionObserver. preWALRestore(ObserverContext<? extends RegionCoprocessorEnvironment> ctx,
             RegionInfo info,
             WALKey logKey,
             WALEdit logEdit)Called before a  WALEditreplayed for this region. | 
| default void | WALObserver. preWALWrite(ObserverContext<? extends WALCoprocessorEnvironment> ctx,
           RegionInfo info,
           WALKey logKey,
           WALEdit logEdit)Deprecated. 
 Since hbase-2.0.0. To be replaced with an alternative that does not expose
 InterfaceAudience classes such as WALKey and WALEdit. Will be removed in hbase-3.0.0. | 
| Modifier and Type | Method and Description | 
|---|---|
| WALEdit | WALInputFormat.WALRecordReader. getCurrentValue() | 
| Modifier and Type | Method and Description | 
|---|---|
| org.apache.hadoop.mapreduce.RecordReader<WALKey,WALEdit> | WALInputFormat. createRecordReader(org.apache.hadoop.mapreduce.InputSplit split,
                  org.apache.hadoop.mapreduce.TaskAttemptContext context) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | WALPlayer.WALCellMapper. map(WALKey key,
   WALEdit value,
   org.apache.hadoop.mapreduce.Mapper.Context context) | 
| void | WALPlayer.WALKeyValueMapper. map(WALKey key,
   WALEdit value,
   org.apache.hadoop.mapreduce.Mapper.Context context)Deprecated.  | 
| void | WALPlayer.WALMapper. map(WALKey key,
   WALEdit value,
   org.apache.hadoop.mapreduce.Mapper.Context context) | 
| Modifier and Type | Field and Description | 
|---|---|
| private WALEdit[] | MiniBatchOperationInProgress. walEditsFromCoprocessors | 
| protected WALEdit[] | HRegion.BatchOperation. walEditsFromCoprocessors | 
| Modifier and Type | Method and Description | 
|---|---|
| WALEdit | MiniBatchOperationInProgress. getWalEdit(int index) | 
| Modifier and Type | Method and Description | 
|---|---|
| List<Pair<NonceKey,WALEdit>> | HRegion.BatchOperation. buildWALEdits(MiniBatchOperationInProgress<Mutation> miniBatchOp)Builds separate WALEdit per nonce by applying input mutations. | 
| List<Pair<NonceKey,WALEdit>> | HRegion.MutationBatchOperation. buildWALEdits(MiniBatchOperationInProgress<Mutation> miniBatchOp) | 
| Modifier and Type | Method and Description | 
|---|---|
| private void | HRegion.MutationBatchOperation. callPreMutateCPHook(int index,
                   WALEdit walEdit,
                   int[] metrics)Runs prePut/preDelete/preIncrement/preAppend coprocessor hook for input mutation in a batch | 
| void | HRegion.BatchOperation. doPostOpCleanupForMiniBatch(MiniBatchOperationInProgress<Mutation> miniBatchOp,
                           WALEdit walEdit,
                           boolean success) | 
| void | HRegion.MutationBatchOperation. doPostOpCleanupForMiniBatch(MiniBatchOperationInProgress<Mutation> miniBatchOp,
                           WALEdit walEdit,
                           boolean success) | 
| private void | HRegion. doProcessRowWithTimeout(RowProcessor<?,?> processor,
                       long now,
                       HRegion region,
                       List<Mutation> mutations,
                       WALEdit walEdit,
                       long timeout) | 
| private MultiVersionConcurrencyControl.WriteEntry | HRegion. doWALAppend(WALEdit walEdit,
           Durability durability,
           List<UUID> clusterIds,
           long now,
           long nonceGroup,
           long nonce) | 
| private MultiVersionConcurrencyControl.WriteEntry | HRegion. doWALAppend(WALEdit walEdit,
           Durability durability,
           List<UUID> clusterIds,
           long now,
           long nonceGroup,
           long nonce,
           long origLogSeqNum) | 
| void | RegionCoprocessorHost. postDelete(Delete delete,
          WALEdit edit,
          Durability durability) | 
| void | RowProcessor. postProcess(HRegion region,
           WALEdit walEdit,
           boolean success)Deprecated.  The hook to be executed after process() and applying the Mutations to region. | 
| void | BaseRowProcessor. postProcess(HRegion region,
           WALEdit walEdit,
           boolean success) | 
| void | RegionCoprocessorHost. postPut(Put put,
       WALEdit edit,
       Durability durability) | 
| void | RegionCoprocessorHost. postWALRestore(RegionInfo info,
              WALKey logKey,
              WALEdit logEdit)Deprecated. 
 Since hbase-2.0.0. No replacement. To be removed in hbase-3.0.0 and replaced
 with something that doesn't expose IntefaceAudience.Private classes. | 
| void | RowProcessor. preBatchMutate(HRegion region,
              WALEdit walEdit)Deprecated.  The hook to be executed after the process() but before applying the Mutations to region. | 
| void | BaseRowProcessor. preBatchMutate(HRegion region,
              WALEdit walEdit) | 
| boolean | RegionCoprocessorHost. preDelete(Delete delete,
         WALEdit edit,
         Durability durability)Supports Coprocessor 'bypass'. | 
| void | RowProcessor. preProcess(HRegion region,
          WALEdit walEdit)Deprecated.  The hook to be executed before process(). | 
| void | BaseRowProcessor. preProcess(HRegion region,
          WALEdit walEdit) | 
| private void | HRegion. preProcess(RowProcessor<?,?> processor,
          WALEdit walEdit) | 
| boolean | RegionCoprocessorHost. prePut(Put put,
      WALEdit edit,
      Durability durability)Supports Coprocessor 'bypass'. | 
| void | RegionCoprocessorHost. preWALAppend(WALKey key,
            WALEdit edit) | 
| boolean | RegionCoprocessorHost. preWALRestore(RegionInfo info,
             WALKey logKey,
             WALEdit logEdit)Deprecated. 
 Since hbase-2.0.0. No replacement. To be removed in hbase-3.0.0 and replaced
 with something that doesn't expose IntefaceAudience.Private classes. | 
| void | RowProcessor. process(long now,
       HRegion region,
       List<Mutation> mutations,
       WALEdit walEdit)Deprecated.  HRegion handles the locks and MVCC and invokes this method properly. | 
| void | MiniBatchOperationInProgress. setWalEdit(int index,
          WALEdit walEdit)Sets the walEdit for the operation(Mutation) at the specified position. | 
| Constructor and Description | 
|---|
| MiniBatchOperationInProgress(T[] operations,
                            OperationStatus[] retCodeDetails,
                            WALEdit[] walEditsFromCoprocessors,
                            int firstIndex,
                            int lastIndexExclusive,
                            int readyToWriteCount) | 
| Modifier and Type | Method and Description | 
|---|---|
| protected long | AsyncFSWAL. append(RegionInfo hri,
      WALKeyImpl key,
      WALEdit edits,
      boolean inMemstore) | 
| protected long | FSHLog. append(RegionInfo hri,
      WALKeyImpl key,
      WALEdit edits,
      boolean inMemstore) | 
| protected abstract long | AbstractFSWAL. append(RegionInfo info,
      WALKeyImpl key,
      WALEdit edits,
      boolean inMemstore)Append a set of edits to the WAL. | 
| long | AbstractFSWAL. appendData(RegionInfo info,
          WALKeyImpl key,
          WALEdit edits) | 
| long | AbstractFSWAL. appendMarker(RegionInfo info,
            WALKeyImpl key,
            WALEdit edits) | 
| private static WALKeyImpl | WALUtil. doFullMarkerAppendTransaction(WAL wal,
                             NavigableMap<byte[],Integer> replicationScope,
                             RegionInfo hri,
                             WALEdit edit,
                             MultiVersionConcurrencyControl mvcc,
                             Map<String,byte[]> extendedAttributes,
                             boolean sync)A 'full' WAL transaction involves starting an mvcc transaction followed by an append, an
 optional sync, and then a call to complete the mvcc transaction. | 
| static void | WALUtil. filterCells(WALEdit edit,
           Function<Cell,Cell> mapper) | 
| void | MetricsWAL. postAppend(long size,
          long time,
          WALKey logkey,
          WALEdit logEdit) | 
| default void | WALActionsListener. postAppend(long entryLen,
          long elapsedTimeMillis,
          WALKey logKey,
          WALEdit logEdit)For notification post append to the writer. | 
| void | WALCoprocessorHost. postWALWrite(RegionInfo info,
            WALKey logKey,
            WALEdit logEdit) | 
| void | WALCoprocessorHost. preWALWrite(RegionInfo info,
           WALKey logKey,
           WALEdit logEdit) | 
| protected long | AbstractFSWAL. stampSequenceIdAndPublishToRingBuffer(RegionInfo hri,
                                     WALKeyImpl key,
                                     WALEdit edits,
                                     boolean inMemstore,
                                     com.lmax.disruptor.RingBuffer<RingBufferTruck> ringBuffer) | 
| default void | WALActionsListener. visitLogEntryBeforeWrite(RegionInfo info,
                        WALKey logKey,
                        WALEdit logEdit)Called before each write. | 
| default void | WALActionsListener. visitLogEntryBeforeWrite(WALKey logKey,
                        WALEdit logEdit) | 
| private static WALKeyImpl | WALUtil. writeMarker(WAL wal,
           NavigableMap<byte[],Integer> replicationScope,
           RegionInfo hri,
           WALEdit edit,
           MultiVersionConcurrencyControl mvcc,
           Map<String,byte[]> extendedAttributes) | 
| Constructor and Description | 
|---|
| FSWALEntry(long txid,
          WALKeyImpl key,
          WALEdit edit,
          RegionInfo regionInfo,
          boolean inMemstore,
          ServerCall<?> rpcCall) | 
| Modifier and Type | Method and Description | 
|---|---|
| private void | ReplicationSourceShipper. cleanUpHFileRefs(WALEdit edit) | 
| private Pair<Integer,Integer> | ReplicationSourceWALReader. countDistinctRowKeysAndHFiles(WALEdit edit)Count the number of different row keys in the given edit because of mini-batching. | 
| (package private) static void | ReplicationSourceWALActionListener. scopeWALEdits(WALKey logKey,
             WALEdit logEdit,
             org.apache.hadoop.conf.Configuration conf)Utility method used to set the correct scopes on each log key. | 
| private int | ReplicationSourceWALReader. sizeOfStoreFilesIncludeBulkLoad(WALEdit edit)Calculate the total size of all the store files | 
| void | ReplicationSourceWALActionListener. visitLogEntryBeforeWrite(WALKey logKey,
                        WALEdit logEdit) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | AccessController. postDelete(ObserverContext<RegionCoprocessorEnvironment> c,
          Delete delete,
          WALEdit edit,
          Durability durability) | 
| void | AccessController. postPut(ObserverContext<RegionCoprocessorEnvironment> c,
       Put put,
       WALEdit edit,
       Durability durability) | 
| void | AccessController. preDelete(ObserverContext<RegionCoprocessorEnvironment> c,
         Delete delete,
         WALEdit edit,
         Durability durability) | 
| void | AccessController. prePut(ObserverContext<RegionCoprocessorEnvironment> c,
      Put put,
      WALEdit edit,
      Durability durability) | 
| Modifier and Type | Field and Description | 
|---|---|
| private WALEdit | WAL.Entry. edit | 
| Modifier and Type | Method and Description | 
|---|---|
| WALEdit | WALEdit. add(Cell cell) | 
| WALEdit | WALEdit. add(Cell cell,
   byte[] family) | 
| private WALEdit | WALEdit. addCell(Cell cell) | 
| static WALEdit | WALEdit. createBulkLoadEvent(RegionInfo hri,
                   org.apache.hadoop.hbase.shaded.protobuf.generated.WALProtos.BulkLoadDescriptor bulkLoadDescriptor)Create a bulk loader WALEdit | 
| static WALEdit | WALEdit. createCompaction(RegionInfo hri,
                org.apache.hadoop.hbase.shaded.protobuf.generated.WALProtos.CompactionDescriptor c) | 
| static WALEdit | WALEdit. createFlushWALEdit(RegionInfo hri,
                  org.apache.hadoop.hbase.shaded.protobuf.generated.WALProtos.FlushDescriptor f) | 
| static WALEdit | WALEdit. createRegionEventWALEdit(byte[] rowForRegion,
                        org.apache.hadoop.hbase.shaded.protobuf.generated.WALProtos.RegionEventDescriptor regionEventDesc) | 
| static WALEdit | WALEdit. createRegionEventWALEdit(RegionInfo hri,
                        org.apache.hadoop.hbase.shaded.protobuf.generated.WALProtos.RegionEventDescriptor regionEventDesc) | 
| WALEdit | WAL.Entry. getEdit()Gets the edit | 
| Modifier and Type | Method and Description | 
|---|---|
| private long | DisabledWALProvider.DisabledWAL. append(RegionInfo info,
      WALKeyImpl key,
      WALEdit edits,
      boolean inMemstore) | 
| long | DisabledWALProvider.DisabledWAL. appendData(RegionInfo info,
          WALKeyImpl key,
          WALEdit edits) | 
| long | WAL. appendData(RegionInfo info,
          WALKeyImpl key,
          WALEdit edits)Append a set of data edits to the WAL. | 
| long | DisabledWALProvider.DisabledWAL. appendMarker(RegionInfo info,
            WALKeyImpl key,
            WALEdit edits) | 
| long | WAL. appendMarker(RegionInfo info,
            WALKeyImpl key,
            WALEdit edits)Append an operational 'meta' event marker edit to the WAL. | 
| Modifier and Type | Method and Description | 
|---|---|
| static List<WALSplitUtil.MutationReplay> | WALSplitUtil. getMutationsFromWALEntry(org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.WALEntry entry,
                        CellScanner cells,
                        Pair<WALKey,WALEdit> logEntry,
                        Durability durability)This function is used to construct mutations from a WALEntry. | 
| Constructor and Description | 
|---|
| Entry(WALKeyImpl key,
     WALEdit edit)Constructor for both params | 
Copyright © 2007–2021 The Apache Software Foundation. All rights reserved.