Uses of Class
org.apache.hadoop.hbase.util.Pair
Packages that use org.apache.hadoop.hbase.util.Pair
Package
Description
Provides HBase Client
Table of Contents
Provides row-level filters applied to HRegion scan results during calls to
ResultScanner.next()
.Provides implementations of
HFile
and HFile
BlockCache
.Tools to help define network clients and servers.
Provides HBase MapReduce
Input/OutputFormats, a table indexing MapReduce job, and utility methods.
Multi Cluster Replication
-
Uses of org.apache.hadoop.hbase.util.Pair in org.apache.hadoop.hbase
Methods in org.apache.hadoop.hbase that return org.apache.hadoop.hbase.util.Pair in inModifier and TypeMethodDescriptionExecutorStatusChore.getExecutorStatus
(String poolName) static org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.client.RegionInfo,
org.apache.hadoop.hbase.ServerName> MetaTableAccessor.getRegion
(org.apache.hadoop.hbase.client.Connection connection, byte[] regionName) Deprecated.TagUtil.readVIntValuePart
(org.apache.hadoop.hbase.Tag tag, int offset) Reads an int value stored as a VInt at tag's given offset.Methods in org.apache.hadoop.hbase that return types with arguments of type org.apache.hadoop.hbase.util.Pair in inModifier and TypeMethodDescriptionstatic List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.client.RegionInfo,
org.apache.hadoop.hbase.ServerName>> MetaTableAccessor.getTableRegionsAndLocations
(org.apache.hadoop.hbase.client.Connection connection, org.apache.hadoop.hbase.TableName tableName) Do not use this method to get meta table regions, use methods in MetaTableLocator instead.static List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.client.RegionInfo,
org.apache.hadoop.hbase.ServerName>> MetaTableAccessor.getTableRegionsAndLocations
(org.apache.hadoop.hbase.client.Connection connection, org.apache.hadoop.hbase.TableName tableName, boolean excludeOfflinedSplitParents) Do not use this method to get meta table regions, use methods in MetaTableLocator instead. -
Uses of org.apache.hadoop.hbase.util.Pair in org.apache.hadoop.hbase.backup
Method parameters in org.apache.hadoop.hbase.backup with type arguments of type org.apache.hadoop.hbase.util.Pair in inModifier and TypeMethodDescriptionvoid
BackupObserver.postBulkLoadHFile
(org.apache.hadoop.hbase.coprocessor.ObserverContext<? extends org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment> ctx, List<org.apache.hadoop.hbase.util.Pair<byte[], String>> stagingFamilyPaths, Map<byte[], List<org.apache.hadoop.fs.Path>> finalPaths) void
BackupObserver.preCommitStoreFile
(org.apache.hadoop.hbase.coprocessor.ObserverContext<? extends org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment> ctx, byte[] family, List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.fs.Path, org.apache.hadoop.fs.Path>> pairs) -
Uses of org.apache.hadoop.hbase.util.Pair in org.apache.hadoop.hbase.client
Methods in org.apache.hadoop.hbase.client that return org.apache.hadoop.hbase.util.Pair in inModifier and TypeMethodDescriptionAdmin.getConfiguredNamespacesAndTablesInRSGroup
(String groupName) Get the namespaces and tables which have this RegionServer group in descriptor.default org.apache.hadoop.hbase.util.Pair<byte[][],
byte[][]> RegionLocator.getStartEndKeys()
Gets the starting and ending row keys for every region in the currently open table.Methods in org.apache.hadoop.hbase.client that return types with arguments of type org.apache.hadoop.hbase.util.Pair in inModifier and TypeMethodDescriptionCompletableFuture<org.apache.hadoop.hbase.util.Pair<List<String>,
List<org.apache.hadoop.hbase.TableName>>> AsyncAdmin.getConfiguredNamespacesAndTablesInRSGroup
(String groupName) Get the namespaces and tables which have this RegionServer group in descriptor.default CompletableFuture<List<org.apache.hadoop.hbase.util.Pair<byte[],
byte[]>>> AsyncTableRegionLocator.getStartEndKeys()
Gets the starting and ending row keys for every region in the currently open table.Method parameters in org.apache.hadoop.hbase.client with type arguments of type org.apache.hadoop.hbase.util.Pair in inModifier and TypeMethodDescriptionAsyncClusterConnection.bulkLoad
(org.apache.hadoop.hbase.TableName tableName, List<org.apache.hadoop.hbase.util.Pair<byte[], String>> familyPaths, byte[] row, boolean assignSeqNum, org.apache.hadoop.security.token.Token<?> userToken, String bulkToken, boolean copyFiles, List<String> clusterIds, boolean replicate) Securely bulk load a list of HFiles, passing additional list of clusters ids tracking clusters where the given bulk load has already been processed (important for bulk loading replication). -
Uses of org.apache.hadoop.hbase.util.Pair in org.apache.hadoop.hbase.coprocessor
Methods in org.apache.hadoop.hbase.coprocessor that return types with arguments of type org.apache.hadoop.hbase.util.Pair in inModifier and TypeMethodDescriptiondefault List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell,
org.apache.hadoop.hbase.Cell>> RegionObserver.postAppendBeforeWAL
(org.apache.hadoop.hbase.coprocessor.ObserverContext<? extends org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.client.Mutation mutation, List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell, org.apache.hadoop.hbase.Cell>> cellPairs) Called after a list of new cells has been created during an append operation, but before they are committed to the WAL or memstore.default List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell,
org.apache.hadoop.hbase.Cell>> RegionObserver.postIncrementBeforeWAL
(org.apache.hadoop.hbase.coprocessor.ObserverContext<? extends org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.client.Mutation mutation, List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell, org.apache.hadoop.hbase.Cell>> cellPairs) Called after a list of new cells has been created during an increment operation, but before they are committed to the WAL or memstore.Method parameters in org.apache.hadoop.hbase.coprocessor with type arguments of type org.apache.hadoop.hbase.util.Pair in inModifier and TypeMethodDescriptiondefault List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell,
org.apache.hadoop.hbase.Cell>> RegionObserver.postAppendBeforeWAL
(org.apache.hadoop.hbase.coprocessor.ObserverContext<? extends org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.client.Mutation mutation, List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell, org.apache.hadoop.hbase.Cell>> cellPairs) Called after a list of new cells has been created during an append operation, but before they are committed to the WAL or memstore.default void
RegionObserver.postBulkLoadHFile
(org.apache.hadoop.hbase.coprocessor.ObserverContext<? extends org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment> ctx, List<org.apache.hadoop.hbase.util.Pair<byte[], String>> stagingFamilyPaths, Map<byte[], List<org.apache.hadoop.fs.Path>> finalPaths) Called after bulkLoadHFile.default List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell,
org.apache.hadoop.hbase.Cell>> RegionObserver.postIncrementBeforeWAL
(org.apache.hadoop.hbase.coprocessor.ObserverContext<? extends org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.client.Mutation mutation, List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell, org.apache.hadoop.hbase.Cell>> cellPairs) Called after a list of new cells has been created during an increment operation, but before they are committed to the WAL or memstore.default void
RegionObserver.preBulkLoadHFile
(org.apache.hadoop.hbase.coprocessor.ObserverContext<? extends org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment> ctx, List<org.apache.hadoop.hbase.util.Pair<byte[], String>> familyPaths) Called before bulkLoadHFile.default void
RegionObserver.preCommitStoreFile
(org.apache.hadoop.hbase.coprocessor.ObserverContext<? extends org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment> ctx, byte[] family, List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.fs.Path, org.apache.hadoop.fs.Path>> pairs) Called before moving bulk loaded hfile to region directory. -
Uses of org.apache.hadoop.hbase.util.Pair in org.apache.hadoop.hbase.filter
Methods in org.apache.hadoop.hbase.filter that return types with arguments of type org.apache.hadoop.hbase.util.Pair in inModifier and TypeMethodDescriptionList<org.apache.hadoop.hbase.util.Pair<byte[],
byte[]>> FuzzyRowFilter.getFuzzyKeys()
Returns the Fuzzy keys in the format expected by the constructor.Constructor parameters in org.apache.hadoop.hbase.filter with type arguments of type org.apache.hadoop.hbase.util.Pair in inModifierConstructorDescriptionFuzzyRowFilter
(List<org.apache.hadoop.hbase.util.Pair<byte[], byte[]>> fuzzyKeysData) -
Uses of org.apache.hadoop.hbase.util.Pair in org.apache.hadoop.hbase.io
Methods in org.apache.hadoop.hbase.io that return org.apache.hadoop.hbase.util.Pair in in -
Uses of org.apache.hadoop.hbase.util.Pair in org.apache.hadoop.hbase.io.hfile
Methods in org.apache.hadoop.hbase.io.hfile that return types with arguments of type org.apache.hadoop.hbase.util.Pair in inModifier and TypeMethodDescriptionBlockCache.getFullyCachedFiles()
Returns an Optional containing the map of files that have been fully cached (all its blocks are present in the cache.CombinedBlockCache.getFullyCachedFiles()
Returns the list of fully cached files -
Uses of org.apache.hadoop.hbase.util.Pair in org.apache.hadoop.hbase.io.util
Methods in org.apache.hadoop.hbase.io.util that return org.apache.hadoop.hbase.util.Pair in inModifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.util.Pair<Long,
MemoryType> MemorySizeUtil.getGlobalMemStoreSize
(org.apache.hadoop.conf.Configuration conf) Returns Pair of global memstore size and memory type(ie.StreamUtils.readRawVarint32
(byte[] input, int offset) Reads a varInt value stored in an array.StreamUtils.readRawVarint32
(ByteBuffer input, int offset) -
Uses of org.apache.hadoop.hbase.util.Pair in org.apache.hadoop.hbase.ipc
Methods in org.apache.hadoop.hbase.ipc that return org.apache.hadoop.hbase.util.Pair in inModifier and TypeMethodDescriptionorg.apache.hadoop.hbase.util.Pair<org.apache.hbase.thirdparty.com.google.protobuf.Message,
org.apache.hadoop.hbase.ExtendedCellScanner> RpcServer.call
(org.apache.hadoop.hbase.ipc.RpcCall call, org.apache.hadoop.hbase.monitoring.MonitoredRPCHandler status) This is a server side method, which is invoked over RPC.org.apache.hadoop.hbase.util.Pair<org.apache.hbase.thirdparty.com.google.protobuf.Message,
org.apache.hadoop.hbase.ExtendedCellScanner> RpcServerInterface.call
(org.apache.hadoop.hbase.ipc.RpcCall call, org.apache.hadoop.hbase.monitoring.MonitoredRPCHandler status) MetricsHBaseServerWrapper.getTotalAndMaxNettyOutboundBytes()
These two metrics are calculated together, so we want to return them in one callMetricsHBaseServerWrapperImpl.getTotalAndMaxNettyOutboundBytes()
NettyRpcServer.getTotalAndMaxNettyOutboundBytes()
-
Uses of org.apache.hadoop.hbase.util.Pair in org.apache.hadoop.hbase.mapreduce
Methods in org.apache.hadoop.hbase.mapreduce that return org.apache.hadoop.hbase.util.Pair in inModifier and TypeMethodDescriptionprotected org.apache.hadoop.hbase.util.Pair<byte[][],
byte[][]> TableInputFormat.getStartEndKeys()
protected org.apache.hadoop.hbase.util.Pair<byte[][],
byte[][]> TableInputFormatBase.getStartEndKeys()
ImportTsv.TsvParser.parseRowKey
(byte[] lineBytes, int length) Return starting position and length of row key from the specified line bytes. -
Uses of org.apache.hadoop.hbase.util.Pair in org.apache.hadoop.hbase.master
Methods in org.apache.hadoop.hbase.master that return types with arguments of type org.apache.hadoop.hbase.util.Pair in inModifier and TypeMethodDescriptionClusterStatusPublisher.getDeadServers
(long since) Get the servers which died since a given timestamp.HashMap<String,
List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.ServerName, org.apache.hadoop.hbase.replication.ReplicationLoadSource>>> HMaster.getReplicationLoad
(org.apache.hadoop.hbase.ServerName[] serverNames) -
Uses of org.apache.hadoop.hbase.util.Pair in org.apache.hadoop.hbase.regionserver
Methods in org.apache.hadoop.hbase.regionserver that return org.apache.hadoop.hbase.util.Pair in inModifier and TypeMethodDescriptionStoreFileInfo.getReferredToRegionAndFile
(String referenceFile) org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.fs.Path,
org.apache.hadoop.fs.Path> HStore.preBulkLoadHFile
(String srcPathStr, long seqNum) This method should only be called from Region.Methods in org.apache.hadoop.hbase.regionserver that return types with arguments of type org.apache.hadoop.hbase.util.Pair in inModifier and TypeMethodDescriptionprotected ConcurrentMap<String,
org.apache.hadoop.hbase.util.Pair<Long, Long>> RegionServerAccounting.getRetainedRegionRWRequestsCnt()
Returns the retained metrics of region's read and write requests countList<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell,
org.apache.hadoop.hbase.Cell>> RegionCoprocessorHost.postAppendBeforeWAL
(org.apache.hadoop.hbase.client.Mutation mutation, List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell, org.apache.hadoop.hbase.Cell>> cellPairs) List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell,
org.apache.hadoop.hbase.Cell>> RegionCoprocessorHost.postIncrementBeforeWAL
(org.apache.hadoop.hbase.client.Mutation mutation, List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell, org.apache.hadoop.hbase.Cell>> cellPairs) Method parameters in org.apache.hadoop.hbase.regionserver with type arguments of type org.apache.hadoop.hbase.util.Pair in inModifier and TypeMethodDescriptionHRegion.bulkLoadHFiles
(Collection<org.apache.hadoop.hbase.util.Pair<byte[], String>> familyPaths, boolean assignSeqId, org.apache.hadoop.hbase.regionserver.HRegion.BulkLoadListener bulkLoadListener) Attempts to atomically load a group of hfiles.HRegion.bulkLoadHFiles
(Collection<org.apache.hadoop.hbase.util.Pair<byte[], String>> familyPaths, boolean assignSeqId, org.apache.hadoop.hbase.regionserver.HRegion.BulkLoadListener bulkLoadListener, boolean copyFile, List<String> clusterIds, boolean replicate) Attempts to atomically load a group of hfiles.List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell,
org.apache.hadoop.hbase.Cell>> RegionCoprocessorHost.postAppendBeforeWAL
(org.apache.hadoop.hbase.client.Mutation mutation, List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell, org.apache.hadoop.hbase.Cell>> cellPairs) void
RegionCoprocessorHost.postBulkLoadHFile
(List<org.apache.hadoop.hbase.util.Pair<byte[], String>> familyPaths, Map<byte[], List<org.apache.hadoop.fs.Path>> map) List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell,
org.apache.hadoop.hbase.Cell>> RegionCoprocessorHost.postIncrementBeforeWAL
(org.apache.hadoop.hbase.client.Mutation mutation, List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell, org.apache.hadoop.hbase.Cell>> cellPairs) void
RegionCoprocessorHost.preBulkLoadHFile
(List<org.apache.hadoop.hbase.util.Pair<byte[], String>> familyPaths) boolean
RegionCoprocessorHost.preCommitStoreFile
(byte[] family, List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.fs.Path, org.apache.hadoop.fs.Path>> pairs) -
Uses of org.apache.hadoop.hbase.util.Pair in org.apache.hadoop.hbase.regionserver.querymatcher
Methods in org.apache.hadoop.hbase.regionserver.querymatcher that return org.apache.hadoop.hbase.util.Pair in inModifier and TypeMethodDescriptionprotected static org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.regionserver.querymatcher.DeleteTracker,
org.apache.hadoop.hbase.regionserver.querymatcher.ColumnTracker> ScanQueryMatcher.getTrackers
(org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost host, NavigableSet<byte[]> columns, org.apache.hadoop.hbase.regionserver.ScanInfo scanInfo, long oldestUnexpiredTS, org.apache.hadoop.hbase.client.Scan userScan) -
Uses of org.apache.hadoop.hbase.util.Pair in org.apache.hadoop.hbase.regionserver.wal
Methods in org.apache.hadoop.hbase.regionserver.wal that return org.apache.hadoop.hbase.util.Pair in inModifier and TypeMethodDescriptionprotected final org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.fs.FSDataInputStream,
org.apache.hadoop.fs.FileStatus> AbstractProtobufWALReader.open()
Methods in org.apache.hadoop.hbase.regionserver.wal with parameters of type org.apache.hadoop.hbase.util.Pair in inModifier and TypeMethodDescriptionprotected void
AbstractFSWAL.archive
(org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.fs.Path, Long> log) -
Uses of org.apache.hadoop.hbase.util.Pair in org.apache.hadoop.hbase.replication
Methods in org.apache.hadoop.hbase.replication that return org.apache.hadoop.hbase.util.Pair in inModifier and TypeMethodDescriptionorg.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.replication.SyncReplicationState,
org.apache.hadoop.hbase.replication.SyncReplicationState> ReplicationPeerImpl.getSyncReplicationStateAndNewState()
static org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.replication.SyncReplicationState,
org.apache.hadoop.hbase.replication.SyncReplicationState> SyncReplicationState.parseStateAndNewStateFrom
(byte[] bytes) Methods in org.apache.hadoop.hbase.replication that return types with arguments of type org.apache.hadoop.hbase.util.Pair in inModifier and TypeMethodDescriptionReplicationBarrierFamilyFormat.getTableEncodedRegionNameAndLastBarrier
(org.apache.hadoop.hbase.client.Connection conn, org.apache.hadoop.hbase.TableName tableName) org.apache.hadoop.hbase.replication.ZKReplicationQueueStorageForMigration.MigrationIterator<org.apache.hadoop.hbase.util.Pair<String,
List<String>>> ZKReplicationQueueStorageForMigration.listAllHFileRefs()
Pair<PeerId, List<HFileRefs>>org.apache.hadoop.hbase.replication.ZKReplicationQueueStorageForMigration.MigrationIterator<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.ServerName,
List<org.apache.hadoop.hbase.replication.ZKReplicationQueueStorageForMigration.ZkReplicationQueueData>>> ZKReplicationQueueStorageForMigration.listAllQueues()
Method parameters in org.apache.hadoop.hbase.replication with type arguments of type org.apache.hadoop.hbase.util.Pair in inModifier and TypeMethodDescriptionvoid
ReplicationQueueStorage.addHFileRefs
(String peerId, List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.fs.Path, org.apache.hadoop.fs.Path>> pairs) Add new hfile references to the queue.void
TableReplicationQueueStorage.addHFileRefs
(String peerId, List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.fs.Path, org.apache.hadoop.fs.Path>> pairs) -
Uses of org.apache.hadoop.hbase.util.Pair in org.apache.hadoop.hbase.shaded.protobuf
Method parameters in org.apache.hadoop.hbase.shaded.protobuf with type arguments of type org.apache.hadoop.hbase.util.Pair in inModifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.BulkLoadHFileRequest
RequestConverter.buildBulkLoadHFileRequest
(List<org.apache.hadoop.hbase.util.Pair<byte[], String>> familyPaths, byte[] regionName, boolean assignSeqNum, org.apache.hadoop.security.token.Token<?> userToken, String bulkToken, boolean copyFiles, List<String> clusterIds, boolean replicate) Create a protocol buffer bulk load requeststatic org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest
RequestConverter.buildUpdateFavoredNodesRequest
(List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.client.RegionInfo, List<org.apache.hadoop.hbase.ServerName>>> updateRegionInfos) Create a protocol buffer UpdateFavoredNodesRequest to update a list of favorednode mappings -
Uses of org.apache.hadoop.hbase.util.Pair in org.apache.hadoop.hbase.snapshot
Methods in org.apache.hadoop.hbase.snapshot that return types with arguments of type org.apache.hadoop.hbase.util.Pair in inModifier and TypeMethodDescriptionRestoreSnapshotHelper.RestoreMetaChanges.getParentToChildrenPairMap()
Returns the map of parent-children_pair.Constructor parameters in org.apache.hadoop.hbase.snapshot with type arguments of type org.apache.hadoop.hbase.util.Pair in in -
Uses of org.apache.hadoop.hbase.util.Pair in org.apache.hadoop.hbase.util
Methods in org.apache.hadoop.hbase.util that return org.apache.hadoop.hbase.util.Pair in inModifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.fs.Path,
org.apache.hadoop.fs.FSDataOutputStream> HBaseFsck.checkAndMarkRunningHbck
(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.util.RetryCounter retryCounter) Deprecated.This method maintains a lock using a file.static <T1,
T2> org.apache.hadoop.hbase.util.Pair<T1, T2> Pair.newPair
(T1 a, T2 b) Constructs a new pair, inferring the type via the passed arguments -
Uses of org.apache.hadoop.hbase.util.Pair in org.apache.hadoop.hbase.wal
Methods in org.apache.hadoop.hbase.wal with parameters of type org.apache.hadoop.hbase.util.Pair in inModifier and TypeMethodDescriptionstatic List<org.apache.hadoop.hbase.wal.WALSplitUtil.MutationReplay>
WALSplitUtil.getMutationsFromWALEntry
(org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.WALEntry entry, org.apache.hadoop.hbase.ExtendedCellScanner cells, org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.wal.WALKey, org.apache.hadoop.hbase.wal.WALEdit> logEntry, org.apache.hadoop.hbase.client.Durability durability) Deprecated.Since 3.0.0, will be removed in 4.0.0.
MetaTableAccessor.getRegionLocation(Connection, byte[])
instead