Uses of Interface
org.apache.hadoop.hbase.wal.WALKey
Packages that use WALKey
Package
Description
Table of Contents
Provides HBase MapReduce
Input/OutputFormats, a table indexing MapReduce job, and utility methods.
-
Uses of WALKey in org.apache.hadoop.hbase.coprocessor
Methods in org.apache.hadoop.hbase.coprocessor with parameters of type WALKeyModifier and TypeMethodDescriptiondefault 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 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 WALKey in org.apache.hadoop.hbase.mapreduce
Classes in org.apache.hadoop.hbase.mapreduce with type parameters of type WALKeyModifier and TypeClassDescription(package private) static classWALInputFormat.WALRecordReader<K extends WALKey>RecordReaderfor anWALfile.Methods in org.apache.hadoop.hbase.mapreduce that return WALKeyMethods in org.apache.hadoop.hbase.mapreduce that return types with arguments of type WALKeyModifier 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 WALKeyModifier 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 WALKey in org.apache.hadoop.hbase.regionserver
Methods in org.apache.hadoop.hbase.regionserver with parameters of type WALKeyModifier and TypeMethodDescriptionvoidRegionCoprocessorHost.postWALRestore(RegionInfo info, WALKey logKey, WALEdit logEdit) voidRegionCoprocessorHost.preWALAppend(WALKey key, WALEdit edit) booleanRegionCoprocessorHost.preWALRestore(RegionInfo info, WALKey logKey, WALEdit logEdit) Supports Coprocessor 'bypass'. -
Uses of WALKey in org.apache.hadoop.hbase.regionserver.wal
Methods in org.apache.hadoop.hbase.regionserver.wal with parameters of type WALKeyModifier and TypeMethodDescriptionvoidMetricsWAL.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) default voidWALActionsListener.visitLogEntryBeforeWrite(RegionInfo info, WALKey logKey, WALEdit logEdit) Called before each write. -
Uses of WALKey in org.apache.hadoop.hbase.replication.regionserver
Methods in org.apache.hadoop.hbase.replication.regionserver with parameters of type WALKeyModifier and TypeMethodDescription(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.voidReplicationSourceWALActionListener.visitLogEntryBeforeWrite(RegionInfo info, WALKey logKey, WALEdit logEdit) -
Uses of WALKey in org.apache.hadoop.hbase.wal
Classes in org.apache.hadoop.hbase.wal that implement WALKeyModifier and TypeClassDescriptionclassDefault implementation of Key for an Entry in the WAL.Methods in org.apache.hadoop.hbase.wal with parameters of type WALKeyMethod parameters in org.apache.hadoop.hbase.wal with type arguments of type WALKeyModifier 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 WALKeyModifierConstructorDescriptionWALKeyImpl(WALKey key, List<UUID> clusterIds, MultiVersionConcurrencyControl mvcc, NavigableMap<byte[], Integer> replicationScopes, Map<String, byte[]> extendedAttributes) Copy constructor that takes in an existing WALKey, the extra WALKeyImpl fields that the parent interface is missing, plus some extended attributes.