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.entriesMethod 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.EntryWALInputFormat.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) classA WAL Entry forAbstractFSWALimplementation.Fields in org.apache.hadoop.hbase.regionserver.wal declared as WAL.EntryModifier and TypeFieldDescription(package private) final WAL.EntryProtobufWALTailingReader.ReadWALKeyResult.entryMethods 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 TypeMethodDescriptionvoidvoidvoidvoidprivate longAbstractFSWAL.postAppend(WAL.Entry e, long elapsedTime) private WALTailingReader.ResultProtobufWALTailingReader.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 TypeMethodDescriptionprotected final WAL.EntryWALEntryFilterBase.clearOrNull(WAL.Entry entry) Call this method when you do not need to replicate the entry.Applies the filter, possibly returning a different Entry instance.protected WAL.EntryChainWALEntryFilter.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 TypeMethodDescriptionprotected final WAL.EntryWALEntryFilterBase.clearOrNull(WAL.Entry entry) Call this method when you do not need to replicate the entry.Applies the filter, possibly returning a different Entry instance.private CellChainWALEntryFilter.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 voidChainWALEntryFilter.filterCells(WAL.Entry entry) protected WAL.EntryChainWALEntryFilter.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.EntryReplicationSourceWALReader.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) booleanReplicationSourceManager.acquireWALEntryBufferQuota(WALEntryBatch walEntryBatch, WAL.Entry entry) Acquire the buffer quota forWAL.Entrywhich is added toWALEntryBatch.voidprotected final booleanReplicationSourceWALReader.addEntryToBatch(WALEntryBatch batch, WAL.Entry entry) private booleanbooleanprivate booleanprotected final WAL.EntryReplicationSourceWALReader.filterEntry(WAL.Entry entry) (package private) static longWALEntryBatch.getEntrySizeExcludeBulkLoad(WAL.Entry entry) private longReplicationSourceWALReader.getEntrySizeIncludeBulkLoad(WAL.Entry entry) private intHBaseInterClusterReplicationEndpoint.getEstimatedEntrySize(WAL.Entry e) longWALEntryBatch.incrementUsedBufferSize(WAL.Entry entry) private voidSerialReplicationSourceWALReader.removeEntryFromStream(WAL.Entry entry, WALEntryStream entryStream, WALEntryBatch batch) private voidReplicationSourceWALReader.updateBatchStats(WALEntryBatch batch, WAL.Entry entry, long entrySize) private voidReplicationSourceWALReader.updateReplicationMarkerEdit(WAL.Entry entry, long offset) voidSerialReplicationChecker.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 longHBaseInterClusterReplicationEndpoint.parallelReplicate(ReplicationEndpoint.ReplicateContext replicateContext, List<List<WAL.Entry>> batches) voidReplicationSource.postShipEdits(List<WAL.Entry> entries, long batchSize) voidReplicationSourceInterface.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#isSerialisis true, we iterator over the WALWAL.Entrylist, 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.voidMetricsSource.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.EntryWALSplitter.getNextLogLine(WALStreamReader in, org.apache.hadoop.fs.Path path, boolean skipErrors) default WAL.EntryWALStreamReader.next()Read the next entry in WAL.Read the next entry in WAL, use the givenWAL.Entryif notnullto hold the data.Methods in org.apache.hadoop.hbase.wal with parameters of type WAL.EntryModifier and TypeMethodDescriptionvoidvoid(package private) voidEntryBuffers.appendEntry(WAL.Entry entry) Append a log entry into the corresponding region buffer.(package private) longEntryBuffers.RegionEntryBuffer.appendEntry(WAL.Entry entry) private voidAbstractRecoveredEditsOutputSink.RecoveredEditsWriter.filterCellByStore(WAL.Entry logEntry) private voidbooleanAbstractRecoveredEditsOutputSink.keepRegionEvent(WAL.Entry entry) (package private) booleanBoundedRecoveredHFilesOutputSink.keepRegionEvent(WAL.Entry entry) (package private) abstract booleanOutputSink.keepRegionEvent(WAL.Entry entry) Some WALEdit's contain only KV's for account on what happened to a region.private voidAbstractRecoveredEditsOutputSink.RecoveredEditsWriter.logAndThrowWriterAppendFailure(WAL.Entry logEntry, IOException e) Read the next entry in WAL, use the givenWAL.Entryif notnullto hold the data.(package private) voidAbstractRecoveredEditsOutputSink.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) voidAbstractRecoveredEditsOutputSink.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)