Uses of Class
org.apache.hadoop.hbase.wal.WAL.Entry
Packages that use WAL.Entry
Package
Description
Provides HBase Client
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.client
Fields in org.apache.hadoop.hbase.client declared as WAL.EntryModifier and TypeFieldDescriptionprivate final WAL.Entry[]
AsyncRegionReplicationRetryingCaller.entries
Method parameters in org.apache.hadoop.hbase.client with type arguments of type WAL.EntryModifier and TypeMethodDescriptionAsyncClusterConnection.replicate
(RegionInfo replica, List<WAL.Entry> entries, int numRetries, long rpcTimeoutNs, long operationTimeoutNs) Replicate wal edits to a secondary replica.AsyncClusterConnectionImpl.replicate
(RegionInfo replica, List<WAL.Entry> entries, int retries, long rpcTimeoutNs, long operationTimeoutNs) Constructor parameters in org.apache.hadoop.hbase.client with type arguments of type WAL.EntryModifierConstructorDescriptionAsyncRegionReplicationRetryingCaller
(org.apache.hbase.thirdparty.io.netty.util.HashedWheelTimer retryTimer, AsyncClusterConnectionImpl conn, int maxAttempts, long rpcTimeoutNs, long operationTimeoutNs, RegionInfo replica, List<WAL.Entry> entries) -
Uses of WAL.Entry in org.apache.hadoop.hbase.mapreduce
Fields in org.apache.hadoop.hbase.mapreduce declared as WAL.EntryModifier and TypeFieldDescription(package private) WAL.Entry
WALInputFormat.WALRecordReader.currentEntry
-
Uses of WAL.Entry in org.apache.hadoop.hbase.regionserver.wal
Subclasses of WAL.Entry in org.apache.hadoop.hbase.regionserver.walModifier and TypeClassDescription(package private) class
A WAL Entry forAbstractFSWAL
implementation.Fields in org.apache.hadoop.hbase.regionserver.wal declared as WAL.EntryModifier and TypeFieldDescription(package private) final WAL.Entry
ProtobufWALTailingReader.ReadWALKeyResult.entry
Methods in org.apache.hadoop.hbase.regionserver.wal that return WAL.EntryMethods in org.apache.hadoop.hbase.regionserver.wal with parameters of type WAL.EntryModifier and TypeMethodDescriptionvoid
void
void
void
private long
AbstractFSWAL.postAppend
(WAL.Entry e, long elapsedTime) private WALTailingReader.Result
ProtobufWALTailingReader.readWALEdit
(WAL.Entry entry, int followingKvCount) Constructors in org.apache.hadoop.hbase.regionserver.wal with parameters of type WAL.EntryModifierConstructorDescriptionReadWALKeyResult
(WALTailingReader.State state, WAL.Entry entry, int followingKvCount) -
Uses of WAL.Entry in org.apache.hadoop.hbase.replication
Fields in org.apache.hadoop.hbase.replication with type parameters of type WAL.EntryMethods in org.apache.hadoop.hbase.replication that return WAL.EntryModifier and TypeMethodDescriptionApplies the filter, possibly returning a different Entry instance.protected WAL.Entry
ChainWALEntryFilter.filterEntry
(WAL.Entry entry) Methods in org.apache.hadoop.hbase.replication that return types with arguments of type WAL.EntryMethods in org.apache.hadoop.hbase.replication with parameters of type WAL.EntryModifier and TypeMethodDescriptionApplies the filter, possibly returning a different Entry instance.private Cell
ChainWALEntryFilter.filterCell
(WAL.Entry entry, Cell cell) 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.protected void
ChainWALEntryFilter.filterCells
(WAL.Entry entry) protected WAL.Entry
ChainWALEntryFilter.filterEntry
(WAL.Entry entry) Method parameters in org.apache.hadoop.hbase.replication with type arguments of type WAL.EntryModifier and TypeMethodDescriptionReplicationEndpoint.ReplicateContext.setEntries
(List<WAL.Entry> entries) -
Uses of WAL.Entry in org.apache.hadoop.hbase.replication.regionserver
Fields in org.apache.hadoop.hbase.replication.regionserver declared as WAL.EntryFields in org.apache.hadoop.hbase.replication.regionserver with type parameters of type WAL.EntryMethods in org.apache.hadoop.hbase.replication.regionserver that return WAL.EntryModifier 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.Methods in org.apache.hadoop.hbase.replication.regionserver that return types with arguments of type WAL.EntryModifier 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.ReplaySyncReplicationWALCallable.readWALEntries
(WALStreamReader reader, String wal) Methods in org.apache.hadoop.hbase.replication.regionserver with parameters of type WAL.EntryModifier 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
private 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) 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) Method parameters in org.apache.hadoop.hbase.replication.regionserver with type arguments of type WAL.EntryModifier and TypeMethodDescriptionprotected CompletableFuture<Integer>
HBaseInterClusterReplicationEndpoint.asyncReplicate
(List<WAL.Entry> entries, int batchIndex, int timeout) Replicate entries to peer cluster by async API.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.createSerialBatches
(List<WAL.Entry> entries) HBaseInterClusterReplicationEndpoint.filterNotExistColumnFamilyEdits
(List<List<WAL.Entry>> oldEntryList) HBaseInterClusterReplicationEndpoint.filterNotExistTableEdits
(List<List<WAL.Entry>> oldEntryList) private long
HBaseInterClusterReplicationEndpoint.parallelReplicate
(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 CompletableFuture<Integer>
HBaseInterClusterReplicationEndpoint.replicateEntries
(List<WAL.Entry> entries, int batchIndex, int timeout) private CompletableFuture<Integer>
HBaseInterClusterReplicationEndpoint.serialReplicateRegionEntries
(org.apache.hbase.thirdparty.com.google.common.collect.PeekingIterator<WAL.Entry> walEntryPeekingIterator, int batchIndex, int timeout) Here forHBaseInterClusterReplicationEndpoint#isSerialis
is true, we iterator over the WALWAL.Entry
list, once we reached a batch limit, we send it out, and in the callback, we send the next batch, until we send all entries out.void
MetricsSource.updateTableLevelMetrics
(List<Pair<WAL.Entry, Long>> walEntries) Update the table level replication metrics per table -
Uses of WAL.Entry in org.apache.hadoop.hbase.wal
Fields in org.apache.hadoop.hbase.wal declared as WAL.EntryFields in org.apache.hadoop.hbase.wal with type parameters of type WAL.EntryMethods in org.apache.hadoop.hbase.wal that return WAL.EntryModifier 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.Methods in org.apache.hadoop.hbase.wal with parameters of type WAL.EntryModifier and TypeMethodDescriptionvoid
void
(package private) 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) (package private) boolean
BoundedRecoveredHFilesOutputSink.keepRegionEvent
(WAL.Entry entry) (package private) 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.Method parameters in org.apache.hadoop.hbase.wal with type arguments of type WAL.EntryModifier and TypeMethodDescription(package private) void
AbstractRecoveredEditsOutputSink.RecoveredEditsWriter.writeRegionEntries
(List<WAL.Entry> entries) Constructors in org.apache.hadoop.hbase.wal with parameters of type WAL.EntryModifierConstructorDescriptionResult
(WALTailingReader.State state, WAL.Entry entry, long entryEndPos)