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<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<RegionCoprocessorEnvironment> c, Append append, Result result, WALEdit edit) Called after Appenddefault voidRegionObserver.postDelete(ObserverContext<RegionCoprocessorEnvironment> c, Delete delete, WALEdit edit) Called after the client deletes a value.default voidRegionObserver.postDelete(ObserverContext<RegionCoprocessorEnvironment> c, Delete delete, WALEdit edit, Durability durability) Deprecated.since 2.5.0 and will be removed in 4.0.0.default ResultRegionObserver.postIncrement(ObserverContext<RegionCoprocessorEnvironment> c, Increment increment, Result result, WALEdit edit) Called after incrementdefault voidRegionObserver.postPut(ObserverContext<RegionCoprocessorEnvironment> c, Put put, WALEdit edit) Called after the client stores a value.default voidRegionObserver.postPut(ObserverContext<RegionCoprocessorEnvironment> c, Put put, WALEdit edit, Durability durability) Deprecated.since 2.5.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) Deprecated.Since hbase-2.0.0.default ResultRegionObserver.preAppend(ObserverContext<RegionCoprocessorEnvironment> c, Append append, WALEdit edit) Called before Append.voidMetaTableMetrics.ExampleRegionObserverMeta.preDelete(ObserverContext<RegionCoprocessorEnvironment> e, Delete delete, WALEdit edit, Durability durability) default voidRegionObserver.preDelete(ObserverContext<RegionCoprocessorEnvironment> c, Delete delete, WALEdit edit) Called before the client deletes a value.default voidRegionObserver.preDelete(ObserverContext<RegionCoprocessorEnvironment> c, Delete delete, WALEdit edit, Durability durability) Deprecated.since 2.5.0 and will be removed in 4.0.0.default ResultRegionObserver.preIncrement(ObserverContext<RegionCoprocessorEnvironment> c, Increment increment, WALEdit edit) Called before Increment.voidMetaTableMetrics.ExampleRegionObserverMeta.prePut(ObserverContext<RegionCoprocessorEnvironment> e, Put put, WALEdit edit, Durability durability) default voidRegionObserver.prePut(ObserverContext<RegionCoprocessorEnvironment> c, Put put, WALEdit edit) Called before the client stores a value.default voidRegionObserver.prePut(ObserverContext<RegionCoprocessorEnvironment> c, Put put, WALEdit edit, Durability durability) Deprecated.since 2.5.0 and will be removed in 4.0.0.default voidRegionObserver.preWALAppend(ObserverContext<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) Deprecated.Since hbase-2.0.0. -
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.WALCellMapper.map(WALKey key, WALEdit value, org.apache.hadoop.mapreduce.Mapper<WALKey, WALEdit, ImmutableBytesWritable, Cell>.org.apache.hadoop.mapreduce.Mapper.Context context) voidWALPlayer.WALKeyValueMapper.map(WALKey key, WALEdit value, org.apache.hadoop.mapreduce.Mapper<WALKey, WALEdit, ImmutableBytesWritable, KeyValue>.org.apache.hadoop.mapreduce.Mapper.Context context) Deprecated.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 TypeFieldDescriptionprotected final WALEdit[]HRegion.BatchOperation.walEditsFromCoprocessorsprivate final WALEdit[]MiniBatchOperationInProgress.walEditsFromCoprocessorsMethods in org.apache.hadoop.hbase.regionserver that return WALEditModifier and TypeMethodDescriptionMiniBatchOperationInProgress.getWalEdit(int index) Returns Gets the walEdit for the operation(Mutation) at the specified position.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 TypeMethodDescriptionprivate voidHRegion.MutationBatchOperation.callPreMutateCPHook(int index, WALEdit walEdit, int[] metrics) Runs prePut/preDelete/preIncrement/preAppend coprocessor hook for input mutation in a batchvoidHRegion.BatchOperation.doPostOpCleanupForMiniBatch(MiniBatchOperationInProgress<Mutation> miniBatchOp, WALEdit walEdit, boolean success) voidHRegion.MutationBatchOperation.doPostOpCleanupForMiniBatch(MiniBatchOperationInProgress<Mutation> miniBatchOp, WALEdit walEdit, boolean success) private voidHRegion.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) voidRegionCoprocessorHost.postDelete(Delete delete, WALEdit edit) RegionCoprocessorHost.postIncrement(Increment increment, Result result, WALEdit edit) voidBaseRowProcessor.postProcess(HRegion region, WALEdit walEdit, boolean success) voidRowProcessor.postProcess(HRegion region, WALEdit walEdit, boolean success) Deprecated.The hook to be executed after process() and applying the Mutations to region.voidvoidRegionCoprocessorHost.postWALRestore(RegionInfo info, WALKey logKey, WALEdit logEdit) Deprecated.Since hbase-2.0.0.Supports Coprocessor 'bypass'.voidBaseRowProcessor.preBatchMutate(HRegion region, WALEdit walEdit) voidRowProcessor.preBatchMutate(HRegion region, WALEdit walEdit) Deprecated.The hook to be executed after the process() but before applying the Mutations to region.booleanSupports Coprocessor 'bypass'.RegionCoprocessorHost.preIncrement(Increment increment, WALEdit edit) Supports Coprocessor 'bypass'.voidBaseRowProcessor.preProcess(HRegion region, WALEdit walEdit) private voidHRegion.preProcess(RowProcessor<?, ?> processor, WALEdit walEdit) voidRowProcessor.preProcess(HRegion region, WALEdit walEdit) Deprecated.The hook to be executed before process().booleanSupports Coprocessor 'bypass'.voidRegionCoprocessorHost.preWALAppend(WALKey key, WALEdit edit) booleanRegionCoprocessorHost.preWALRestore(RegionInfo info, WALKey logKey, WALEdit logEdit) Deprecated.Since hbase-2.0.0.voidDeprecated.HRegion handles the locks and MVCC and invokes this method properly.voidMiniBatchOperationInProgress.setWalEdit(int index, WALEdit walEdit) Sets the walEdit for the operation(Mutation) at the specified position.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.wal
Methods in org.apache.hadoop.hbase.regionserver.wal with parameters of type WALEditModifier and TypeMethodDescriptionprotected abstract longAbstractFSWAL.append(RegionInfo info, WALKeyImpl key, WALEdit edits, boolean inMemstore) Append a set of edits to the WAL.protected longAsyncFSWAL.append(RegionInfo hri, WALKeyImpl key, WALEdit edits, boolean inMemstore) protected longFSHLog.append(RegionInfo hri, WALKeyImpl key, WALEdit edits, boolean inMemstore) 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) 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) 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<RegionCoprocessorEnvironment> c, Delete delete, WALEdit edit, Durability durability) voidAccessController.postPut(ObserverContext<RegionCoprocessorEnvironment> c, Put put, WALEdit edit, Durability durability) voidAccessController.preDelete(ObserverContext<RegionCoprocessorEnvironment> c, Delete delete, WALEdit edit, Durability durability) voidAccessController.prePut(ObserverContext<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 TypeMethodDescriptionprivate WALEditstatic 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 TypeMethodDescriptionprivate 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 booleanWALEdit.isReplicationMarkerEdit(WALEdit edit) Checks whether this edit is a replication marker edit.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, CellScanner cells, Pair<WALKey, WALEdit> logEntry, Durability durability) This function is used to construct mutations from a WALEntry.Constructors in org.apache.hadoop.hbase.wal with parameters of type WALEdit