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<? extends RegionCoprocessorEnvironment> e, Put put, WALEdit edit, Durability durability) -
Uses of WALEdit in org.apache.hadoop.hbase.coprocessor
Modifier and TypeMethodDescriptiondefault Result
RegionObserver.postAppend
(ObserverContext<? extends RegionCoprocessorEnvironment> c, Append append, Result result, WALEdit edit) Called after Appenddefault void
RegionObserver.postDelete
(ObserverContext<? extends RegionCoprocessorEnvironment> c, Delete delete, WALEdit edit) Called after the client deletes a value.default void
RegionObserver.postDelete
(ObserverContext<? extends RegionCoprocessorEnvironment> c, Delete delete, WALEdit edit, Durability durability) Deprecated.since 3.0.0 and will be removed in 4.0.0.default Result
RegionObserver.postIncrement
(ObserverContext<? extends RegionCoprocessorEnvironment> c, Increment increment, Result result, WALEdit edit) Called after incrementdefault void
RegionObserver.postPut
(ObserverContext<? extends RegionCoprocessorEnvironment> c, Put put, WALEdit edit) Called after the client stores a value.default void
RegionObserver.postPut
(ObserverContext<? extends RegionCoprocessorEnvironment> c, Put put, WALEdit edit, Durability durability) Deprecated.since 3.0.0 and will be removed in 4.0.0.default void
WALObserver.postWALWrite
(ObserverContext<? extends WALCoprocessorEnvironment> ctx, RegionInfo info, WALKey logKey, WALEdit logEdit) Called after aWALEdit
is writen to WAL.default Result
RegionObserver.preAppend
(ObserverContext<? extends RegionCoprocessorEnvironment> c, Append append, WALEdit edit) Called before Append.void
MetaTableMetrics.ExampleRegionObserverMeta.preDelete
(ObserverContext<? extends RegionCoprocessorEnvironment> e, Delete delete, WALEdit edit, Durability durability) default void
RegionObserver.preDelete
(ObserverContext<? extends RegionCoprocessorEnvironment> c, Delete delete, WALEdit edit) Called before the client deletes a value.default void
RegionObserver.preDelete
(ObserverContext<? extends RegionCoprocessorEnvironment> c, Delete delete, WALEdit edit, Durability durability) Deprecated.since 3.0.0 and will be removed in 4.0.0.default Result
RegionObserver.preIncrement
(ObserverContext<? extends RegionCoprocessorEnvironment> c, Increment increment, WALEdit edit) Called before Increment.void
MetaTableMetrics.ExampleRegionObserverMeta.prePut
(ObserverContext<? extends RegionCoprocessorEnvironment> e, Put put, WALEdit edit, Durability durability) default void
RegionObserver.prePut
(ObserverContext<? extends RegionCoprocessorEnvironment> c, Put put, WALEdit edit) Called before the client stores a value.default void
RegionObserver.prePut
(ObserverContext<? extends RegionCoprocessorEnvironment> c, Put put, WALEdit edit, Durability durability) Deprecated.since 3.0.0 and will be removed in 4.0.0.default void
RegionObserver.preWALAppend
(ObserverContext<? extends RegionCoprocessorEnvironment> ctx, WALKey key, WALEdit edit) Called just before the WAL Entry is appended to the WAL.default void
WALObserver.preWALWrite
(ObserverContext<? extends WALCoprocessorEnvironment> ctx, RegionInfo info, WALKey logKey, WALEdit logEdit) Called before aWALEdit
is writen to WAL. -
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.WALKeyValueMapper.map
(WALKey key, WALEdit value, org.apache.hadoop.mapreduce.Mapper<WALKey, WALEdit, ImmutableBytesWritable, Cell>.org.apache.hadoop.mapreduce.Mapper.Context context) 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 TypeFieldDescriptionprivate WALEdit
MiniBatchOperationInProgress.walEditForReplicateIfExistsSkipWAL
Here is for HBASE-26993,saving the all theMutation
s if there isDurability#SKIP_WAL
inHRegion.BatchOperation#buildWALEdits
forHRegion.doMiniBatchMutate(org.apache.hadoop.hbase.regionserver.HRegion.BatchOperation<?>)
to also replicateMutation
which isDurability#SKIP_WAL
to region replica.protected final WALEdit[]
HRegion.BatchOperation.walEditsFromCoprocessors
private final WALEdit[]
MiniBatchOperationInProgress.walEditsFromCoprocessors
Modifier and TypeMethodDescriptionprotected WALEdit
HRegion.BatchOperation.createWALEdit
(MiniBatchOperationInProgress<Mutation> miniBatchOp) private WALEdit
HRegion.MutationBatchOperation.createWALEditForReplicateSkipWAL
(MiniBatchOperationInProgress<Mutation> miniBatchOp, List<Pair<NonceKey, WALEdit>> nonceKeyAndWALEdits) MiniBatchOperationInProgress.getWalEdit
(int index) Returns Gets the walEdit for the operation(Mutation) at the specified position.MiniBatchOperationInProgress.getWalEditForReplicateIfExistsSkipWAL()
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 TypeMethodDescriptionprotected void
HRegion.BatchOperation.addNonSkipWALMutationsToWALEdit
(MiniBatchOperationInProgress<Mutation> miniBatchOp, WALEdit walEdit, List<ExtendedCell> cellsFromCP, Map<byte[], List<ExtendedCell>> familyCellMap) protected void
HRegion.MutationBatchOperation.addNonSkipWALMutationsToWALEdit
(MiniBatchOperationInProgress<Mutation> miniBatchOp, WALEdit walEdit, List<ExtendedCell> cellsFromCP, Map<byte[], List<ExtendedCell>> familyCellMap) private void
HRegion.attachRegionReplicationInWALAppend
(HRegion.BatchOperation<?> batchOp, MiniBatchOperationInProgress<Mutation> miniBatchOp, WALKeyImpl walKey, WALEdit walEdit, MultiVersionConcurrencyControl.WriteEntry writeEntry) AttachRegionReplicationSink.add(org.apache.hadoop.hbase.wal.WALKeyImpl, org.apache.hadoop.hbase.wal.WALEdit, org.apache.hadoop.hbase.ipc.ServerCall<?>)
to the mvcc writeEntry for replicating to region replica.private void
HRegion.MutationBatchOperation.callPreMutateCPHook
(int index, WALEdit walEdit, int[] metrics) Runs prePut/preDelete/preIncrement/preAppend coprocessor hook for input mutation in a batchprotected static void
HRegion.BatchOperation.doAddCellsToWALEdit
(WALEdit walEdit, List<ExtendedCell> cellsFromCP, Map<byte[], List<ExtendedCell>> familyCellMap) private void
HRegion.doAttachReplicateRegionReplicaAction
(WALKeyImpl walKey, WALEdit walEdit, MultiVersionConcurrencyControl.WriteEntry writeEntry) AttachRegionReplicationSink.add(org.apache.hadoop.hbase.wal.WALKeyImpl, org.apache.hadoop.hbase.wal.WALEdit, org.apache.hadoop.hbase.ipc.ServerCall<?>)
to the mvcc writeEntry for replicating to region replica.void
HRegion.BatchOperation.doPostOpCleanupForMiniBatch
(MiniBatchOperationInProgress<Mutation> miniBatchOp, WALEdit walEdit, boolean success) void
HRegion.MutationBatchOperation.doPostOpCleanupForMiniBatch
(MiniBatchOperationInProgress<Mutation> miniBatchOp, WALEdit walEdit, boolean success) HRegion.doWALAppend
(WALEdit walEdit, HRegion.BatchOperation<?> batchOp, MiniBatchOperationInProgress<Mutation> miniBatchOp, long now, NonceKey nonceKey) 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
Supports Coprocessor 'bypass'.boolean
Supports Coprocessor 'bypass'.RegionCoprocessorHost.preIncrement
(Increment increment, WALEdit edit) Supports Coprocessor 'bypass'.boolean
Supports Coprocessor 'bypass'.void
RegionCoprocessorHost.preWALAppend
(WALKey key, WALEdit edit) void
MiniBatchOperationInProgress.setWalEdit
(int index, WALEdit walEdit) Sets the walEdit for the operation(Mutation) at the specified position.void
MiniBatchOperationInProgress.setWalEditForReplicateIfExistsSkipWAL
(WALEdit walEditForReplicateSkipWAL) Modifier and TypeMethodDescriptionprotected abstract void
HRegion.BatchOperation.cacheSkipWALMutationForRegionReplication
(MiniBatchOperationInProgress<Mutation> miniBatchOp, List<Pair<NonceKey, WALEdit>> walEdits, Map<byte[], List<ExtendedCell>> familyCellMap) protected void
HRegion.MutationBatchOperation.cacheSkipWALMutationForRegionReplication
(MiniBatchOperationInProgress<Mutation> miniBatchOp, List<Pair<NonceKey, WALEdit>> nonceKeyAndWALEdits, Map<byte[], List<ExtendedCell>> familyCellMap) Here is for HBASE-26993,in order to make the new framework for region replication could work for SKIP_WAL, we save theMutation
whichMutation.getDurability()
isDurability.SKIP_WAL
in miniBatchOp.protected void
HRegion.ReplayBatchOperation.cacheSkipWALMutationForRegionReplication
(MiniBatchOperationInProgress<Mutation> miniBatchOp, List<Pair<NonceKey, WALEdit>> walEdits, Map<byte[], List<ExtendedCell>> familyCellMap) Deprecated.private WALEdit
HRegion.MutationBatchOperation.createWALEditForReplicateSkipWAL
(MiniBatchOperationInProgress<Mutation> miniBatchOp, List<Pair<NonceKey, WALEdit>> nonceKeyAndWALEdits) ModifierConstructorDescriptionMiniBatchOperationInProgress
(T[] operations, OperationStatus[] retCodeDetails, WALEdit[] walEditsFromCoprocessors, int firstIndex, int lastIndexExclusive, int readyToWriteCount) -
Uses of WALEdit in org.apache.hadoop.hbase.regionserver.regionreplication
Modifier and TypeFieldDescription(package private) final WALEdit
RegionReplicationSink.SinkEntry.edit
Modifier and TypeMethodDescriptionvoid
RegionReplicationSink.add
(WALKeyImpl key, WALEdit edit, ServerCall<?> rpcCall) Add this edit to replication queue.ModifierConstructorDescription(package private)
SinkEntry
(WALKeyImpl key, WALEdit edit, ServerCall<?> rpcCall) -
Uses of WALEdit in org.apache.hadoop.hbase.regionserver.wal
Modifier and TypeMethodDescriptionprotected long
AbstractFSWAL.append
(RegionInfo hri, 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, RegionReplicationSink sink) 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, RegionReplicationSink sink) 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<? extends RegionCoprocessorEnvironment> c, Delete delete, WALEdit edit, Durability durability) void
AccessController.postPut
(ObserverContext<? extends RegionCoprocessorEnvironment> c, Put put, WALEdit edit, Durability durability) void
AccessController.preDelete
(ObserverContext<? extends RegionCoprocessorEnvironment> c, Delete delete, WALEdit edit, Durability durability) void
AccessController.prePut
(ObserverContext<? extends RegionCoprocessorEnvironment> c, Put put, WALEdit edit, Durability durability) -
Uses of WALEdit in org.apache.hadoop.hbase.wal
Modifier and TypeMethodDescription(package private) WALEdit
WALEdit.add
(List<ExtendedCell> cells) (package private) WALEdit
WALEdit.add
(ExtendedCell cell) (package private) WALEdit
WALEdit.add
(ExtendedCell cell, byte[] family) private WALEdit
WALEdit.addCell
(ExtendedCell cell) static WALEdit
WALEditInternalHelper.addExtendedCell
(WALEdit edit, ExtendedCell cell) 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 TypeMethodDescriptionstatic void
WALEditInternalHelper.addExtendedCell
(WALEdit edit, List<ExtendedCell> cells) static WALEdit
WALEditInternalHelper.addExtendedCell
(WALEdit edit, ExtendedCell cell) static void
WALEditInternalHelper.addMap
(WALEdit edit, Map<byte[], List<ExtendedCell>> familyMap) 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.static List<ExtendedCell>
WALEditInternalHelper.getExtendedCells
(WALEdit edit) static boolean
WALEdit.isReplicationMarkerEdit
(WALEdit edit) Checks whether this edit is a replication marker edit.static void
WALEditInternalHelper.setExtendedCells
(WALEdit edit, ArrayList<ExtendedCell> cells) Modifier and TypeMethodDescriptionstatic List<WALSplitUtil.MutationReplay>
WALSplitUtil.getMutationsFromWALEntry
(org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.WALEntry entry, ExtendedCellScanner cells, Pair<WALKey, WALEdit> logEntry, Durability durability) Deprecated.Since 3.0.0, will be removed in 4.0.0.