Uses of Class
org.apache.hadoop.hbase.wal.WALEdit
Package
Description
Restrict the domain of a data attribute, often times to fulfill business rules/requirements.
Table of Contents
Provides HBase MapReduce
Input/OutputFormats, a table indexing MapReduce job, and utility methods.
-
Uses of WALEdit in org.apache.hadoop.hbase.constraint
Modifier and TypeMethodDescriptionvoid
ConstraintProcessor.prePut
(ObserverContext<RegionCoprocessorEnvironment> e, Put put, WALEdit edit, Durability durability) -
Uses of WALEdit in org.apache.hadoop.hbase.coprocessor
Modifier and TypeMethodDescriptiondefault Result
RegionObserver.postAppend
(ObserverContext<RegionCoprocessorEnvironment> c, Append append, Result result, WALEdit edit) Called after Appenddefault void
RegionObserver.postDelete
(ObserverContext<RegionCoprocessorEnvironment> c, Delete delete, WALEdit edit) Called after the client deletes a value.default void
RegionObserver.postDelete
(ObserverContext<RegionCoprocessorEnvironment> c, Delete delete, WALEdit edit, Durability durability) Deprecated.since 2.5.0 and will be removed in 4.0.0.default Result
RegionObserver.postIncrement
(ObserverContext<RegionCoprocessorEnvironment> c, Increment increment, Result result, WALEdit edit) Called after incrementdefault void
RegionObserver.postPut
(ObserverContext<RegionCoprocessorEnvironment> c, Put put, WALEdit edit) Called after the client stores a value.default void
RegionObserver.postPut
(ObserverContext<RegionCoprocessorEnvironment> c, Put put, WALEdit edit, Durability durability) Deprecated.since 2.5.0 and will be removed in 4.0.0.default void
RegionObserver.postWALRestore
(ObserverContext<? extends RegionCoprocessorEnvironment> ctx, RegionInfo info, WALKey logKey, WALEdit logEdit) Called after aWALEdit
replayed for this region.default void
WALObserver.postWALWrite
(ObserverContext<? extends WALCoprocessorEnvironment> ctx, RegionInfo info, WALKey logKey, WALEdit logEdit) Deprecated.Since hbase-2.0.0.default Result
RegionObserver.preAppend
(ObserverContext<RegionCoprocessorEnvironment> c, Append append, WALEdit edit) Called before Append.void
MetaTableMetrics.ExampleRegionObserverMeta.preDelete
(ObserverContext<RegionCoprocessorEnvironment> e, Delete delete, WALEdit edit, Durability durability) default void
RegionObserver.preDelete
(ObserverContext<RegionCoprocessorEnvironment> c, Delete delete, WALEdit edit) Called before the client deletes a value.default void
RegionObserver.preDelete
(ObserverContext<RegionCoprocessorEnvironment> c, Delete delete, WALEdit edit, Durability durability) Deprecated.since 2.5.0 and will be removed in 4.0.0.default Result
RegionObserver.preIncrement
(ObserverContext<RegionCoprocessorEnvironment> c, Increment increment, WALEdit edit) Called before Increment.void
MetaTableMetrics.ExampleRegionObserverMeta.prePut
(ObserverContext<RegionCoprocessorEnvironment> e, Put put, WALEdit edit, Durability durability) default void
RegionObserver.prePut
(ObserverContext<RegionCoprocessorEnvironment> c, Put put, WALEdit edit) Called before the client stores a value.default void
RegionObserver.prePut
(ObserverContext<RegionCoprocessorEnvironment> c, Put put, WALEdit edit, Durability durability) Deprecated.since 2.5.0 and will be removed in 4.0.0.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 aWALEdit
replayed for this region.default void
WALObserver.preWALWrite
(ObserverContext<? extends WALCoprocessorEnvironment> ctx, RegionInfo info, WALKey logKey, WALEdit logEdit) Deprecated.Since hbase-2.0.0. -
Uses of WALEdit in org.apache.hadoop.hbase.mapreduce
Modifier and TypeMethodDescriptionWALInputFormat.createRecordReader
(org.apache.hadoop.mapreduce.InputSplit split, org.apache.hadoop.mapreduce.TaskAttemptContext context) Modifier and TypeMethodDescriptionvoid
WALPlayer.WALCellMapper.map
(WALKey key, WALEdit value, org.apache.hadoop.mapreduce.Mapper<WALKey, WALEdit, ImmutableBytesWritable, Cell>.org.apache.hadoop.mapreduce.Mapper.Context context) void
WALPlayer.WALKeyValueMapper.map
(WALKey key, WALEdit value, org.apache.hadoop.mapreduce.Mapper<WALKey, WALEdit, ImmutableBytesWritable, KeyValue>.org.apache.hadoop.mapreduce.Mapper.Context context) Deprecated.void
WALPlayer.WALMapper.map
(WALKey key, WALEdit value, org.apache.hadoop.mapreduce.Mapper<WALKey, WALEdit, ImmutableBytesWritable, Mutation>.org.apache.hadoop.mapreduce.Mapper.Context context) -
Uses of WALEdit in org.apache.hadoop.hbase.regionserver
Modifier and TypeFieldDescriptionprotected final WALEdit[]
HRegion.BatchOperation.walEditsFromCoprocessors
private final WALEdit[]
MiniBatchOperationInProgress.walEditsFromCoprocessors
Modifier and TypeMethodDescriptionMiniBatchOperationInProgress.getWalEdit
(int index) Returns Gets the walEdit for the operation(Mutation) at the specified position.Modifier and TypeMethodDescriptionHRegion.BatchOperation.buildWALEdits
(MiniBatchOperationInProgress<Mutation> miniBatchOp) Builds separate WALEdit per nonce by applying input mutations.HRegion.MutationBatchOperation.buildWALEdits
(MiniBatchOperationInProgress<Mutation> miniBatchOp) Modifier and TypeMethodDescriptionprivate void
HRegion.MutationBatchOperation.callPreMutateCPHook
(int index, WALEdit walEdit, int[] metrics) Runs prePut/preDelete/preIncrement/preAppend coprocessor hook for input mutation in a batchvoid
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) HRegion.doWALAppend
(WALEdit walEdit, Durability durability, List<UUID> clusterIds, long now, long nonceGroup, long nonce) HRegion.doWALAppend
(WALEdit walEdit, Durability durability, List<UUID> clusterIds, long now, long nonceGroup, long nonce, long origLogSeqNum) Returns writeEntry associated with this appendRegionCoprocessorHost.postAppend
(Append append, Result result, WALEdit edit) void
RegionCoprocessorHost.postDelete
(Delete delete, WALEdit edit) RegionCoprocessorHost.postIncrement
(Increment increment, Result result, WALEdit edit) void
BaseRowProcessor.postProcess
(HRegion region, WALEdit walEdit, boolean success) void
RowProcessor.postProcess
(HRegion region, WALEdit walEdit, boolean success) Deprecated.The hook to be executed after process() and applying the Mutations to region.void
void
RegionCoprocessorHost.postWALRestore
(RegionInfo info, WALKey logKey, WALEdit logEdit) Deprecated.Since hbase-2.0.0.Supports Coprocessor 'bypass'.void
BaseRowProcessor.preBatchMutate
(HRegion region, WALEdit walEdit) void
RowProcessor.preBatchMutate
(HRegion region, WALEdit walEdit) Deprecated.The hook to be executed after the process() but before applying the Mutations to region.boolean
Supports Coprocessor 'bypass'.RegionCoprocessorHost.preIncrement
(Increment increment, WALEdit edit) Supports Coprocessor 'bypass'.void
BaseRowProcessor.preProcess
(HRegion region, WALEdit walEdit) private void
HRegion.preProcess
(RowProcessor<?, ?> processor, WALEdit walEdit) void
RowProcessor.preProcess
(HRegion region, WALEdit walEdit) Deprecated.The hook to be executed before process().boolean
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.void
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.ModifierConstructorDescriptionMiniBatchOperationInProgress
(T[] operations, OperationStatus[] retCodeDetails, WALEdit[] walEditsFromCoprocessors, int firstIndex, int lastIndexExclusive, int readyToWriteCount) -
Uses of WALEdit in org.apache.hadoop.hbase.regionserver.wal
Modifier and TypeMethodDescriptionprotected abstract long
AbstractFSWAL.append
(RegionInfo info, WALKeyImpl key, WALEdit edits, boolean inMemstore) Append a set of edits to the WAL.protected long
AsyncFSWAL.append
(RegionInfo hri, WALKeyImpl key, WALEdit edits, boolean inMemstore) protected long
FSHLog.append
(RegionInfo hri, WALKeyImpl key, WALEdit edits, boolean inMemstore) 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 final 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.private static WALKeyImpl
WALUtil.writeMarker
(WAL wal, NavigableMap<byte[], Integer> replicationScope, RegionInfo hri, WALEdit edit, MultiVersionConcurrencyControl mvcc, Map<String, byte[]> extendedAttributes) ModifierConstructorDescription(package private)
FSWALEntry
(long txid, WALKeyImpl key, WALEdit edit, RegionInfo regionInfo, boolean inMemstore, ServerCall<?> rpcCall) -
Uses of WALEdit in org.apache.hadoop.hbase.replication.regionserver
Modifier and TypeMethodDescriptionprivate void
ReplicationSourceShipper.cleanUpHFileRefs
(WALEdit edit) 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 filesvoid
ReplicationSourceWALActionListener.visitLogEntryBeforeWrite
(RegionInfo info, WALKey logKey, WALEdit logEdit) -
Uses of WALEdit in org.apache.hadoop.hbase.security.access
Modifier and TypeMethodDescriptionvoid
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) -
Uses of WALEdit in org.apache.hadoop.hbase.wal
Modifier and TypeMethodDescriptionprivate WALEdit
static WALEdit
WALEdit.createBulkLoadEvent
(RegionInfo hri, org.apache.hadoop.hbase.shaded.protobuf.generated.WALProtos.BulkLoadDescriptor bulkLoadDescriptor) Create a bulk loader WALEditstatic WALEdit
WALEdit.createCompaction
(RegionInfo hri, org.apache.hadoop.hbase.shaded.protobuf.generated.WALProtos.CompactionDescriptor c) Returns A Marker WALEdit that hasc
serialized as its valuestatic 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) static WALEdit
WALEdit.createReplicationMarkerEdit
(byte[] rowKey, long timestamp) Creates a replication tracker edit withMETAFAMILY
family andREPLICATION_MARKER
qualifier and has null value.WAL.Entry.getEdit()
Gets the editModifier and TypeMethodDescriptionprivate 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.static boolean
WALEdit.isReplicationMarkerEdit
(WALEdit edit) Checks whether this edit is a replication marker edit.Modifier and TypeMethodDescriptionstatic 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.