Uses of Class
org.apache.hadoop.hbase.wal.WAL.Entry
Package
Description
Provides HBase MapReduce
Input/OutputFormats, a table indexing MapReduce job, and utility methods.
Multi Cluster Replication
-
Uses of WAL.Entry in org.apache.hadoop.hbase.mapreduce
Modifier and TypeFieldDescription(package private) WAL.Entry
WALInputFormat.WALRecordReader.currentEntry
-
Uses of WAL.Entry in org.apache.hadoop.hbase.regionserver.wal
Modifier and TypeClassDescription(package private) class
A WAL Entry forAbstractFSWAL
implementation.Modifier and TypeFieldDescription(package private) final WAL.Entry
ProtobufWALTailingReader.ReadWALKeyResult.entry
Modifier and TypeMethodDescriptionvoid
void
private long
AbstractFSWAL.postAppend
(WAL.Entry e, long elapsedTime) private WALTailingReader.Result
ProtobufWALTailingReader.readWALEdit
(WAL.Entry entry, int followingKvCount) ModifierConstructorDescriptionReadWALKeyResult
(WALTailingReader.State state, WAL.Entry entry, int followingKvCount) -
Uses of WAL.Entry in org.apache.hadoop.hbase.replication
Modifier and TypeMethodDescriptionApplies the filter, possibly returning a different Entry instance.Modifier and TypeMethodDescriptionApplies the filter, possibly returning a different Entry instance.NamespaceTableCfWALEntryFilter.filterCell
(WAL.Entry entry, Cell cell) ScopeWALEntryFilter.filterCell
(WAL.Entry entry, Cell cell) WALCellFilter.filterCell
(WAL.Entry entry, Cell cell) Applies the filter, possibly returning a different Cell instance.private void
ChainWALEntryFilter.filterCells
(WAL.Entry entry) Modifier and TypeMethodDescriptionReplicationEndpoint.ReplicateContext.setEntries
(List<WAL.Entry> entries) -
Uses of WAL.Entry in org.apache.hadoop.hbase.replication.regionserver
Modifier and TypeFieldDescriptionRegionReplicaReplicationEndpoint.RegionReplicaReplayCallable.entries
WALEntryBatch.walEntriesWithSize
Modifier and TypeMethodDescriptionprotected final WAL.Entry
ReplicationSourceWALReader.filterEntry
(WAL.Entry entry) WALEntryStream.next()
Returns the next WAL entry in this stream and advance the stream.WALEntryStream.peek()
Returns the next WAL entry in this stream but does not advance.Modifier and TypeMethodDescriptionHBaseInterClusterReplicationEndpoint.createBatches
(List<WAL.Entry> entries) Divide the entries into multiple batches, so that we can replicate each batch in a thread pool concurrently.HBaseInterClusterReplicationEndpoint.createParallelBatches
(List<WAL.Entry> entries) HBaseInterClusterReplicationEndpoint.createSerialBatches
(List<WAL.Entry> entries) HBaseInterClusterReplicationEndpoint.filterNotExistColumnFamilyEdits
(List<List<WAL.Entry>> oldEntryList) HBaseInterClusterReplicationEndpoint.filterNotExistTableEdits
(List<List<WAL.Entry>> oldEntryList) WALEntryBatch.getWalEntries()
Returns the WAL Entries.WALEntryBatch.getWalEntriesWithSize()
Returns the WAL Entries.Modifier and TypeMethodDescription(package private) boolean
ReplicationSourceManager.acquireWALEntryBufferQuota
(WALEntryBatch walEntryBatch, WAL.Entry entry) Acquire the buffer quota forWAL.Entry
which is added toWALEntryBatch
.void
protected final boolean
ReplicationSourceWALReader.addEntryToBatch
(WALEntryBatch batch, WAL.Entry entry) private boolean
boolean
protected final WAL.Entry
ReplicationSourceWALReader.filterEntry
(WAL.Entry entry) (package private) static long
WALEntryBatch.getEntrySizeExcludeBulkLoad
(WAL.Entry entry) private long
ReplicationSourceWALReader.getEntrySizeIncludeBulkLoad
(WAL.Entry entry) private int
HBaseInterClusterReplicationEndpoint.getEstimatedEntrySize
(WAL.Entry e) long
WALEntryBatch.incrementUsedBufferSize
(WAL.Entry entry) boolean
RegionReplicaReplicationEndpoint.RegionReplicaOutputSink.keepRegionEvent
(WAL.Entry entry) private void
ReplicationSourceWALReader.updateBatchStats
(WALEntryBatch batch, WAL.Entry entry, long entrySize) private void
ReplicationSourceWALReader.updateReplicationMarkerEdit
(WAL.Entry entry, long offset) void
SerialReplicationChecker.waitUntilCanPush
(WAL.Entry entry, Cell firstCellInEdit) Modifier and TypeMethodDescriptionvoid
RegionReplicaReplicationEndpoint.RegionReplicaSinkWriter.append
(TableName tableName, byte[] encodedRegionName, byte[] row, List<WAL.Entry> entries) HBaseInterClusterReplicationEndpoint.createBatches
(List<WAL.Entry> entries) Divide the entries into multiple batches, so that we can replicate each batch in a thread pool concurrently.HBaseInterClusterReplicationEndpoint.createParallelBatches
(List<WAL.Entry> entries) HBaseInterClusterReplicationEndpoint.createReplicator
(List<WAL.Entry> entries, int batchIndex, int timeout) HBaseInterClusterReplicationEndpoint.createSerialBatches
(List<WAL.Entry> entries) HBaseInterClusterReplicationEndpoint.filterNotExistColumnFamilyEdits
(List<List<WAL.Entry>> oldEntryList) HBaseInterClusterReplicationEndpoint.filterNotExistTableEdits
(List<List<WAL.Entry>> oldEntryList) private long
HBaseInterClusterReplicationEndpoint.parallelReplicate
(CompletionService<Integer> pool, ReplicationEndpoint.ReplicateContext replicateContext, List<List<WAL.Entry>> batches) void
ReplicationSource.postShipEdits
(List<WAL.Entry> entries, long batchSize) void
ReplicationSourceInterface.postShipEdits
(List<WAL.Entry> entries, long batchSize) Call this after the shipper thread ship some entries to peer cluster.protected int
HBaseInterClusterReplicationEndpoint.replicateEntries
(List<WAL.Entry> entries, int batchIndex, int timeout) private boolean
RegionReplicaReplicationEndpoint.RegionReplicaOutputSink.requiresReplication
(TableName tableName, List<WAL.Entry> entries) returns true if the specified entry must be replicated.private int
HBaseInterClusterReplicationEndpoint.serialReplicateRegionEntries
(List<WAL.Entry> entries, int batchIndex, int timeout) void
MetricsSource.updateTableLevelMetrics
(List<Pair<WAL.Entry, Long>> walEntries) Update the table level replication metrics per tableModifierConstructorDescriptionRegionReplicaReplayCallable
(ClusterConnection connection, RpcControllerFactory rpcControllerFactory, TableName tableName, HRegionLocation location, RegionInfo regionInfo, byte[] row, List<WAL.Entry> entries, AtomicLong skippedEntries) -
Uses of WAL.Entry in org.apache.hadoop.hbase.wal
Modifier and TypeMethodDescriptionWALTailingReader.Result.getEntry()
private WAL.Entry
WALSplitter.getNextLogLine
(WALStreamReader in, org.apache.hadoop.fs.Path path, boolean skipErrors) default WAL.Entry
WALStreamReader.next()
Read the next entry in WAL.Read the next entry in WAL, use the givenWAL.Entry
if notnull
to hold the data.Modifier and TypeMethodDescriptionvoid
void
void
EntryBuffers.appendEntry
(WAL.Entry entry) Append a log entry into the corresponding region buffer.(package private) long
EntryBuffers.RegionEntryBuffer.appendEntry
(WAL.Entry entry) private void
AbstractRecoveredEditsOutputSink.RecoveredEditsWriter.filterCellByStore
(WAL.Entry logEntry) private void
boolean
AbstractRecoveredEditsOutputSink.keepRegionEvent
(WAL.Entry entry) boolean
BoundedRecoveredHFilesOutputSink.keepRegionEvent
(WAL.Entry entry) protected abstract boolean
OutputSink.keepRegionEvent
(WAL.Entry entry) Some WALEdit's contain only KV's for account on what happened to a region.private void
AbstractRecoveredEditsOutputSink.RecoveredEditsWriter.logAndThrowWriterAppendFailure
(WAL.Entry logEntry, IOException e) Read the next entry in WAL, use the givenWAL.Entry
if notnull
to hold the data.(package private) void
AbstractRecoveredEditsOutputSink.updateRegionMaximumEditLogSeqNum
(WAL.Entry entry) Update region's maximum edit log SeqNum.Modifier and TypeMethodDescription(package private) void
AbstractRecoveredEditsOutputSink.RecoveredEditsWriter.writeRegionEntries
(List<WAL.Entry> entries) ModifierConstructorDescriptionResult
(WALTailingReader.State state, WAL.Entry entry, long entryEndPos)