Uses of Class
org.apache.hadoop.hbase.wal.WALEdit
Packages that use 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
Methods in org.apache.hadoop.hbase.constraint with parameters of type WALEditModifier and TypeMethodDescriptionvoidConstraintProcessor.prePut(ObserverContext<? extends RegionCoprocessorEnvironment> e, Put put, WALEdit edit, Durability durability) -
Uses of WALEdit in org.apache.hadoop.hbase.coprocessor
Methods in org.apache.hadoop.hbase.coprocessor with parameters of type WALEditModifier and TypeMethodDescriptiondefault ResultRegionObserver.postAppend(ObserverContext<? extends RegionCoprocessorEnvironment> c, Append append, Result result, WALEdit edit) Called after Appenddefault voidRegionObserver.postDelete(ObserverContext<? extends RegionCoprocessorEnvironment> c, Delete delete, WALEdit edit) Called after the client deletes a value.default voidRegionObserver.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 ResultRegionObserver.postIncrement(ObserverContext<? extends RegionCoprocessorEnvironment> c, Increment increment, Result result, WALEdit edit) Called after incrementdefault voidRegionObserver.postPut(ObserverContext<? extends RegionCoprocessorEnvironment> c, Put put, WALEdit edit) Called after the client stores a value.default voidRegionObserver.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 voidRegionObserver.postWALRestore(ObserverContext<? extends RegionCoprocessorEnvironment> ctx, RegionInfo info, WALKey logKey, WALEdit logEdit) Called after aWALEditreplayed for this region.default voidWALObserver.postWALWrite(ObserverContext<? extends WALCoprocessorEnvironment> ctx, RegionInfo info, WALKey logKey, WALEdit logEdit) Called after aWALEditis writen to WAL.default ResultRegionObserver.preAppend(ObserverContext<? extends RegionCoprocessorEnvironment> c, Append append, WALEdit edit) Called before Append.voidMetaTableMetrics.ExampleRegionObserverMeta.preDelete(ObserverContext<? extends RegionCoprocessorEnvironment> e, Delete delete, WALEdit edit, Durability durability) default voidRegionObserver.preDelete(ObserverContext<? extends RegionCoprocessorEnvironment> c, Delete delete, WALEdit edit) Called before the client deletes a value.default voidRegionObserver.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 ResultRegionObserver.preIncrement(ObserverContext<? extends RegionCoprocessorEnvironment> c, Increment increment, WALEdit edit) Called before Increment.voidMetaTableMetrics.ExampleRegionObserverMeta.prePut(ObserverContext<? extends RegionCoprocessorEnvironment> e, Put put, WALEdit edit, Durability durability) default voidRegionObserver.prePut(ObserverContext<? extends RegionCoprocessorEnvironment> c, Put put, WALEdit edit) Called before the client stores a value.default voidRegionObserver.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 voidRegionObserver.preWALAppend(ObserverContext<? extends RegionCoprocessorEnvironment> ctx, WALKey key, WALEdit edit) Called just before the WAL Entry is appended to the WAL.default voidRegionObserver.preWALRestore(ObserverContext<? extends RegionCoprocessorEnvironment> ctx, RegionInfo info, WALKey logKey, WALEdit logEdit) Called before aWALEditreplayed for this region.default voidWALObserver.preWALWrite(ObserverContext<? extends WALCoprocessorEnvironment> ctx, RegionInfo info, WALKey logKey, WALEdit logEdit) Called before aWALEditis writen to WAL. -
Uses of WALEdit in org.apache.hadoop.hbase.mapreduce
Methods in org.apache.hadoop.hbase.mapreduce that return WALEditMethods in org.apache.hadoop.hbase.mapreduce that return types with arguments of type WALEditModifier and TypeMethodDescriptionWALInputFormat.createRecordReader(org.apache.hadoop.mapreduce.InputSplit split, org.apache.hadoop.mapreduce.TaskAttemptContext context) Methods in org.apache.hadoop.hbase.mapreduce with parameters of type WALEditModifier and TypeMethodDescriptionvoidWALPlayer.WALKeyValueMapper.map(WALKey key, WALEdit value, org.apache.hadoop.mapreduce.Mapper<WALKey, WALEdit, org.apache.hadoop.io.WritableComparable<?>, Cell>.org.apache.hadoop.mapreduce.Mapper.Context context) voidWALPlayer.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
Fields in org.apache.hadoop.hbase.regionserver declared as WALEditModifier and TypeFieldDescriptionprivate WALEditMiniBatchOperationInProgress.walEditForReplicateIfExistsSkipWALHere is for HBASE-26993,saving the all theMutations if there isDurability#SKIP_WALinHRegion.BatchOperation#buildWALEditsforHRegion.doMiniBatchMutate(org.apache.hadoop.hbase.regionserver.HRegion.BatchOperation<?>)to also replicateMutationwhich isDurability#SKIP_WALto region replica.protected final WALEdit[]HRegion.BatchOperation.walEditsFromCoprocessorsprivate final WALEdit[]MiniBatchOperationInProgress.walEditsFromCoprocessorsMethods in org.apache.hadoop.hbase.regionserver that return WALEditModifier and TypeMethodDescriptionprotected WALEditHRegion.BatchOperation.createWALEdit(MiniBatchOperationInProgress<Mutation> miniBatchOp) private WALEditHRegion.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()Methods in org.apache.hadoop.hbase.regionserver that return types with arguments of type WALEditModifier and TypeMethodDescriptionHRegion.BatchOperation.buildWALEdits(MiniBatchOperationInProgress<Mutation> miniBatchOp) Builds separate WALEdit per nonce by applying input mutations.HRegion.MutationBatchOperation.buildWALEdits(MiniBatchOperationInProgress<Mutation> miniBatchOp) Methods in org.apache.hadoop.hbase.regionserver with parameters of type WALEditModifier and TypeMethodDescriptionprotected voidHRegion.BatchOperation.addNonSkipWALMutationsToWALEdit(MiniBatchOperationInProgress<Mutation> miniBatchOp, WALEdit walEdit, List<ExtendedCell> cellsFromCP, Map<byte[], List<ExtendedCell>> familyCellMap) protected voidHRegion.MutationBatchOperation.addNonSkipWALMutationsToWALEdit(MiniBatchOperationInProgress<Mutation> miniBatchOp, WALEdit walEdit, List<ExtendedCell> cellsFromCP, Map<byte[], List<ExtendedCell>> familyCellMap) private voidHRegion.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 voidHRegion.MutationBatchOperation.callPreMutateCPHook(int index, WALEdit walEdit, int[] metrics) Runs prePut/preDelete/preIncrement/preAppend coprocessor hook for input mutation in a batchprotected static voidHRegion.BatchOperation.doAddCellsToWALEdit(WALEdit walEdit, List<ExtendedCell> cellsFromCP, Map<byte[], List<ExtendedCell>> familyCellMap) private voidHRegion.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.voidHRegion.BatchOperation.doPostOpCleanupForMiniBatch(MiniBatchOperationInProgress<Mutation> miniBatchOp, WALEdit walEdit, boolean success) voidHRegion.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) voidRegionCoprocessorHost.postDelete(Delete delete, WALEdit edit) RegionCoprocessorHost.postIncrement(Increment increment, Result result, WALEdit edit) voidvoidRegionCoprocessorHost.postWALRestore(RegionInfo info, WALKey logKey, WALEdit logEdit) Supports Coprocessor 'bypass'.booleanSupports Coprocessor 'bypass'.RegionCoprocessorHost.preIncrement(Increment increment, WALEdit edit) Supports Coprocessor 'bypass'.booleanSupports Coprocessor 'bypass'.voidRegionCoprocessorHost.preWALAppend(WALKey key, WALEdit edit) booleanRegionCoprocessorHost.preWALRestore(RegionInfo info, WALKey logKey, WALEdit logEdit) Supports Coprocessor 'bypass'.voidMiniBatchOperationInProgress.setWalEdit(int index, WALEdit walEdit) Sets the walEdit for the operation(Mutation) at the specified position.voidMiniBatchOperationInProgress.setWalEditForReplicateIfExistsSkipWAL(WALEdit walEditForReplicateSkipWAL) Method parameters in org.apache.hadoop.hbase.regionserver with type arguments of type WALEditModifier and TypeMethodDescriptionprotected abstract voidHRegion.BatchOperation.cacheSkipWALMutationForRegionReplication(MiniBatchOperationInProgress<Mutation> miniBatchOp, List<Pair<NonceKey, WALEdit>> walEdits, Map<byte[], List<ExtendedCell>> familyCellMap) protected voidHRegion.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 theMutationwhichMutation.getDurability()isDurability.SKIP_WALin miniBatchOp.protected voidHRegion.ReplayBatchOperation.cacheSkipWALMutationForRegionReplication(MiniBatchOperationInProgress<Mutation> miniBatchOp, List<Pair<NonceKey, WALEdit>> walEdits, Map<byte[], List<ExtendedCell>> familyCellMap) Deprecated.private WALEditHRegion.MutationBatchOperation.createWALEditForReplicateSkipWAL(MiniBatchOperationInProgress<Mutation> miniBatchOp, List<Pair<NonceKey, WALEdit>> nonceKeyAndWALEdits) Constructors in org.apache.hadoop.hbase.regionserver with parameters of type WALEditModifierConstructorDescriptionMiniBatchOperationInProgress(T[] operations, OperationStatus[] retCodeDetails, WALEdit[] walEditsFromCoprocessors, int firstIndex, int lastIndexExclusive, int readyToWriteCount) -
Uses of WALEdit in org.apache.hadoop.hbase.regionserver.regionreplication
Fields in org.apache.hadoop.hbase.regionserver.regionreplication declared as WALEditModifier and TypeFieldDescription(package private) final WALEditRegionReplicationSink.SinkEntry.editMethods in org.apache.hadoop.hbase.regionserver.regionreplication with parameters of type WALEditModifier and TypeMethodDescriptionvoidRegionReplicationSink.add(WALKeyImpl key, WALEdit edit, ServerCall<?> rpcCall) Add this edit to replication queue.Constructors in org.apache.hadoop.hbase.regionserver.regionreplication with parameters of type WALEditModifierConstructorDescription(package private)SinkEntry(WALKeyImpl key, WALEdit edit, ServerCall<?> rpcCall) -
Uses of WALEdit in org.apache.hadoop.hbase.regionserver.wal
Methods in org.apache.hadoop.hbase.regionserver.wal with parameters of type WALEditModifier and TypeMethodDescriptionprotected longAbstractFSWAL.append(RegionInfo hri, WALKeyImpl key, WALEdit edits, boolean inMemstore) Append a set of edits to the WAL.longAbstractFSWAL.appendData(RegionInfo info, WALKeyImpl key, WALEdit edits) longAbstractFSWAL.appendMarker(RegionInfo info, WALKeyImpl key, WALEdit edits) private static WALKeyImplWALUtil.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 voidWALUtil.filterCells(WALEdit edit, Function<Cell, Cell> mapper) voidMetricsWAL.postAppend(long size, long time, WALKey logkey, WALEdit logEdit) default voidWALActionsListener.postAppend(long entryLen, long elapsedTimeMillis, WALKey logKey, WALEdit logEdit) For notification post append to the writer.voidWALCoprocessorHost.postWALWrite(RegionInfo info, WALKey logKey, WALEdit logEdit) voidWALCoprocessorHost.preWALWrite(RegionInfo info, WALKey logKey, WALEdit logEdit) protected final longAbstractFSWAL.stampSequenceIdAndPublishToRingBuffer(RegionInfo hri, WALKeyImpl key, WALEdit edits, boolean inMemstore, com.lmax.disruptor.RingBuffer<RingBufferTruck> ringBuffer) default voidWALActionsListener.visitLogEntryBeforeWrite(RegionInfo info, WALKey logKey, WALEdit logEdit) Called before each write.private static WALKeyImplWALUtil.writeMarker(WAL wal, NavigableMap<byte[], Integer> replicationScope, RegionInfo hri, WALEdit edit, MultiVersionConcurrencyControl mvcc, Map<String, byte[]> extendedAttributes, RegionReplicationSink sink) Constructors in org.apache.hadoop.hbase.regionserver.wal with parameters of type WALEditModifierConstructorDescription(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
Methods in org.apache.hadoop.hbase.replication.regionserver with parameters of type WALEditModifier and TypeMethodDescriptionprivate voidReplicationSourceShipper.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 voidReplicationSourceWALActionListener.scopeWALEdits(WALKey logKey, WALEdit logEdit, org.apache.hadoop.conf.Configuration conf) Utility method used to set the correct scopes on each log key.private intReplicationSourceWALReader.sizeOfStoreFilesIncludeBulkLoad(WALEdit edit) Calculate the total size of all the store filesvoidReplicationSourceWALActionListener.visitLogEntryBeforeWrite(RegionInfo info, WALKey logKey, WALEdit logEdit) -
Uses of WALEdit in org.apache.hadoop.hbase.security.access
Methods in org.apache.hadoop.hbase.security.access with parameters of type WALEditModifier and TypeMethodDescriptionvoidAccessController.postDelete(ObserverContext<? extends RegionCoprocessorEnvironment> c, Delete delete, WALEdit edit, Durability durability) voidAccessController.postPut(ObserverContext<? extends RegionCoprocessorEnvironment> c, Put put, WALEdit edit, Durability durability) voidAccessController.preDelete(ObserverContext<? extends RegionCoprocessorEnvironment> c, Delete delete, WALEdit edit, Durability durability) voidAccessController.prePut(ObserverContext<? extends RegionCoprocessorEnvironment> c, Put put, WALEdit edit, Durability durability) -
Uses of WALEdit in org.apache.hadoop.hbase.wal
Fields in org.apache.hadoop.hbase.wal declared as WALEditMethods in org.apache.hadoop.hbase.wal that return WALEditModifier and TypeMethodDescription(package private) WALEditWALEdit.add(List<ExtendedCell> cells) (package private) WALEditWALEdit.add(ExtendedCell cell) (package private) WALEditWALEdit.add(ExtendedCell cell, byte[] family) private WALEditWALEdit.addCell(ExtendedCell cell) static WALEditWALEditInternalHelper.addExtendedCell(WALEdit edit, ExtendedCell cell) static WALEditWALEdit.createBulkLoadEvent(RegionInfo hri, org.apache.hadoop.hbase.shaded.protobuf.generated.WALProtos.BulkLoadDescriptor bulkLoadDescriptor) Create a bulk loader WALEditstatic WALEditWALEdit.createCompaction(RegionInfo hri, org.apache.hadoop.hbase.shaded.protobuf.generated.WALProtos.CompactionDescriptor c) Returns A Marker WALEdit that hascserialized as its valuestatic WALEditWALEdit.createFlushWALEdit(RegionInfo hri, org.apache.hadoop.hbase.shaded.protobuf.generated.WALProtos.FlushDescriptor f) static WALEditWALEdit.createRegionEventWALEdit(byte[] rowForRegion, org.apache.hadoop.hbase.shaded.protobuf.generated.WALProtos.RegionEventDescriptor regionEventDesc) static WALEditWALEdit.createRegionEventWALEdit(RegionInfo hri, org.apache.hadoop.hbase.shaded.protobuf.generated.WALProtos.RegionEventDescriptor regionEventDesc) static WALEditWALEdit.createReplicationMarkerEdit(byte[] rowKey, long timestamp) Creates a replication tracker edit withMETAFAMILYfamily andREPLICATION_MARKERqualifier and has null value.WAL.Entry.getEdit()Gets the editMethods in org.apache.hadoop.hbase.wal with parameters of type WALEditModifier and TypeMethodDescriptionstatic voidWALEditInternalHelper.addExtendedCell(WALEdit edit, List<ExtendedCell> cells) static WALEditWALEditInternalHelper.addExtendedCell(WALEdit edit, ExtendedCell cell) static voidWALEditInternalHelper.addMap(WALEdit edit, Map<byte[], List<ExtendedCell>> familyMap) private longDisabledWALProvider.DisabledWAL.append(RegionInfo info, WALKeyImpl key, WALEdit edits, boolean inMemstore) longDisabledWALProvider.DisabledWAL.appendData(RegionInfo info, WALKeyImpl key, WALEdit edits) longWAL.appendData(RegionInfo info, WALKeyImpl key, WALEdit edits) Append a set of data edits to the WAL.longDisabledWALProvider.DisabledWAL.appendMarker(RegionInfo info, WALKeyImpl key, WALEdit edits) longWAL.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 booleanWALEdit.isReplicationMarkerEdit(WALEdit edit) Checks whether this edit is a replication marker edit.static voidWALEditInternalHelper.setExtendedCells(WALEdit edit, ArrayList<ExtendedCell> cells) Method parameters in org.apache.hadoop.hbase.wal with type arguments of type WALEditModifier 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.Constructors in org.apache.hadoop.hbase.wal with parameters of type WALEdit