Uses of Interface
org.apache.hadoop.hbase.wal.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
Modifier and TypeMethodDescriptiondefault void
WALObserver.postWALWrite
(ObserverContext<? extends WALCoprocessorEnvironment> ctx, RegionInfo info, WALKey logKey, WALEdit logEdit) Called after aWALEdit
is writen to WAL.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 WALKey in org.apache.hadoop.hbase.mapreduce
Modifier and TypeClassDescription(package private) static class
WALInputFormat.WALRecordReader<K extends WALKey>
RecordReader
for anWAL
file.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 WALKey in org.apache.hadoop.hbase.regionserver
Modifier and TypeMethodDescriptionvoid
RegionCoprocessorHost.preWALAppend
(WALKey key, WALEdit edit) -
Uses of WALKey in org.apache.hadoop.hbase.regionserver.wal
Modifier 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
Modifier 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
Modifier and TypeClassDescriptionclass
Default implementation of Key for an Entry in the WAL.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.ModifierConstructorDescriptionWALKeyImpl
(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.