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 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 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 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 class
WALInputFormat.WALRecordReader<K extends WALKey>
RecordReader
for anWAL
file.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 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 WALKey in org.apache.hadoop.hbase.regionserver
Methods in org.apache.hadoop.hbase.regionserver with parameters of type WALKeyModifier and TypeMethodDescriptionvoid
RegionCoprocessorHost.postWALRestore
(RegionInfo info, WALKey logKey, WALEdit logEdit) Deprecated.Since hbase-2.0.0.void
RegionCoprocessorHost.preWALAppend
(WALKey key, WALEdit edit) boolean
RegionCoprocessorHost.preWALRestore
(RegionInfo info, WALKey logKey, WALEdit logEdit) Deprecated.Since hbase-2.0.0. -
Uses of WALKey in org.apache.hadoop.hbase.regionserver.wal
Methods in org.apache.hadoop.hbase.regionserver.wal with parameters of type WALKeyModifier and TypeMethodDescriptionvoid
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) default void
WALActionsListener.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 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.void
ReplicationSourceWALActionListener.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 TypeClassDescriptionclass
Default 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, 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 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.