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 in
    Modifier and Type
    Method
    Description
    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.
    use MetaTableAccessor.getRegionLocation(Connection, byte[]) instead
    static org.apache.hadoop.hbase.util.Pair<Integer,Integer>
    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 in
    Modifier and Type
    Method
    Description
    static List<org.apache.hadoop.hbase.util.Pair<String,Long>>
    MetaTableAccessor.getTableEncodedRegionNameAndLastBarrier(org.apache.hadoop.hbase.client.Connection conn, org.apache.hadoop.hbase.TableName tableName)
     
    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)
    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 in
    Modifier and Type
    Method
    Description
    void
    BackupObserver.postBulkLoadHFile(org.apache.hadoop.hbase.coprocessor.ObserverContext<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<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 in
    Modifier and Type
    Method
    Description
    org.apache.hadoop.hbase.util.Pair<Integer,Integer>
    Admin.getAlterStatus(byte[] tableName)
    Deprecated.
    Since 2.0.0.
    org.apache.hadoop.hbase.util.Pair<Integer,Integer>
    Admin.getAlterStatus(org.apache.hadoop.hbase.TableName tableName)
    Deprecated.
    Since 2.0.0.
    org.apache.hadoop.hbase.util.Pair<Integer,Integer>
    HBaseAdmin.getAlterStatus(byte[] tableName)
     
    org.apache.hadoop.hbase.util.Pair<Integer,Integer>
    HBaseAdmin.getAlterStatus(org.apache.hadoop.hbase.TableName tableName)
     
    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 in
    Modifier and Type
    Method
    Description
    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 in
    Modifier and Type
    Method
    Description
    boolean
    SecureBulkLoadClient.secureBulkLoadHFiles(org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ClientService.BlockingInterface client, List<org.apache.hadoop.hbase.util.Pair<byte[],String>> familyPaths, byte[] regionName, boolean assignSeqNum, org.apache.hadoop.security.token.Token<?> userToken, String bulkToken)
    Securely bulk load a list of HFiles using client protocol.
    boolean
    SecureBulkLoadClient.secureBulkLoadHFiles(org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ClientService.BlockingInterface client, 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)
    Securely bulk load a list of HFiles using client protocol.
    boolean
    SecureBulkLoadClient.secureBulkLoadHFiles(org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ClientService.BlockingInterface client, 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)
     
  • 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 in
    Modifier and Type
    Method
    Description
    default 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<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<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 in
    Modifier and Type
    Method
    Description
    default 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<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<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<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<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<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

    Constructor parameters in org.apache.hadoop.hbase.filter with type arguments of type org.apache.hadoop.hbase.util.Pair in in
    Modifier
    Constructor
    Description
     
    FuzzyRowFilter(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
    Modifier and Type
    Method
    Description
    static org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.TableName,String>
    HFileLink.parseBackReferenceName(String name)
     
  • 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 in
    Modifier and Type
    Method
    Description
    default Optional<Map<String,org.apache.hadoop.hbase.util.Pair<String,Long>>>
    BlockCache.getFullyCachedFiles()
    Returns an Optional containing the map of files that have been fully cached (all its blocks are present in the cache.
    Optional<Map<String,org.apache.hadoop.hbase.util.Pair<String,Long>>>
    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 in
    Modifier and Type
    Method
    Description
    static 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.
    static org.apache.hadoop.hbase.util.Pair<Integer,Integer>
    StreamUtils.readRawVarint32(byte[] input, int offset)
    Reads a varInt value stored in an array.
    static org.apache.hadoop.hbase.util.Pair<Integer,Integer>
    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 in
    Modifier and Type
    Method
    Description
    org.apache.hadoop.hbase.util.Pair<org.apache.hbase.thirdparty.com.google.protobuf.Message,org.apache.hadoop.hbase.CellScanner>
    NettyRpcServer.call(org.apache.hbase.thirdparty.com.google.protobuf.BlockingService service, org.apache.hbase.thirdparty.com.google.protobuf.Descriptors.MethodDescriptor md, org.apache.hbase.thirdparty.com.google.protobuf.Message param, org.apache.hadoop.hbase.CellScanner cellScanner, long receiveTime, org.apache.hadoop.hbase.monitoring.MonitoredRPCHandler status)
     
    org.apache.hadoop.hbase.util.Pair<org.apache.hbase.thirdparty.com.google.protobuf.Message,org.apache.hadoop.hbase.CellScanner>
    NettyRpcServer.call(org.apache.hbase.thirdparty.com.google.protobuf.BlockingService service, org.apache.hbase.thirdparty.com.google.protobuf.Descriptors.MethodDescriptor md, org.apache.hbase.thirdparty.com.google.protobuf.Message param, org.apache.hadoop.hbase.CellScanner cellScanner, long receiveTime, org.apache.hadoop.hbase.monitoring.MonitoredRPCHandler status, long startTime, int timeout)
     
    org.apache.hadoop.hbase.util.Pair<org.apache.hbase.thirdparty.com.google.protobuf.Message,org.apache.hadoop.hbase.CellScanner>
    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.CellScanner>
    RpcServerInterface.call(org.apache.hadoop.hbase.ipc.RpcCall call, org.apache.hadoop.hbase.monitoring.MonitoredRPCHandler status)
     
    org.apache.hadoop.hbase.util.Pair<org.apache.hbase.thirdparty.com.google.protobuf.Message,org.apache.hadoop.hbase.CellScanner>
    RpcServerInterface.call(org.apache.hbase.thirdparty.com.google.protobuf.BlockingService service, org.apache.hbase.thirdparty.com.google.protobuf.Descriptors.MethodDescriptor md, org.apache.hbase.thirdparty.com.google.protobuf.Message param, org.apache.hadoop.hbase.CellScanner cellScanner, long receiveTime, org.apache.hadoop.hbase.monitoring.MonitoredRPCHandler status)
    Deprecated.
    As of release 1.3, this will be removed in HBase 3.0
    org.apache.hadoop.hbase.util.Pair<org.apache.hbase.thirdparty.com.google.protobuf.Message,org.apache.hadoop.hbase.CellScanner>
    RpcServerInterface.call(org.apache.hbase.thirdparty.com.google.protobuf.BlockingService service, org.apache.hbase.thirdparty.com.google.protobuf.Descriptors.MethodDescriptor md, org.apache.hbase.thirdparty.com.google.protobuf.Message param, org.apache.hadoop.hbase.CellScanner cellScanner, long receiveTime, org.apache.hadoop.hbase.monitoring.MonitoredRPCHandler status, long startTime, int timeout)
    Deprecated.
    As of release 2.0, this will be removed in HBase 3.0
    org.apache.hadoop.hbase.util.Pair<org.apache.hbase.thirdparty.com.google.protobuf.Message,org.apache.hadoop.hbase.CellScanner>
    SimpleRpcServer.call(org.apache.hbase.thirdparty.com.google.protobuf.BlockingService service, org.apache.hbase.thirdparty.com.google.protobuf.Descriptors.MethodDescriptor md, org.apache.hbase.thirdparty.com.google.protobuf.Message param, org.apache.hadoop.hbase.CellScanner cellScanner, long receiveTime, org.apache.hadoop.hbase.monitoring.MonitoredRPCHandler status)
    Deprecated.
     
    org.apache.hadoop.hbase.util.Pair<org.apache.hbase.thirdparty.com.google.protobuf.Message,org.apache.hadoop.hbase.CellScanner>
    SimpleRpcServer.call(org.apache.hbase.thirdparty.com.google.protobuf.BlockingService service, org.apache.hbase.thirdparty.com.google.protobuf.Descriptors.MethodDescriptor md, org.apache.hbase.thirdparty.com.google.protobuf.Message param, org.apache.hadoop.hbase.CellScanner cellScanner, long receiveTime, org.apache.hadoop.hbase.monitoring.MonitoredRPCHandler status, long startTime, int timeout)
    Deprecated.
     
    org.apache.hadoop.hbase.util.Pair<Long,Long>
    MetricsHBaseServerWrapper.getTotalAndMaxNettyOutboundBytes()
    These two metrics are calculated together, so we want to return them in one call
    org.apache.hadoop.hbase.util.Pair<Long,Long>
    MetricsHBaseServerWrapperImpl.getTotalAndMaxNettyOutboundBytes()
     
    org.apache.hadoop.hbase.util.Pair<Long,Long>
    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 in
    Modifier and Type
    Method
    Description
    protected org.apache.hadoop.hbase.util.Pair<byte[][],byte[][]>
    TableInputFormat.getStartEndKeys()
     
    protected org.apache.hadoop.hbase.util.Pair<byte[][],byte[][]>
    TableInputFormatBase.getStartEndKeys()
     
    org.apache.hadoop.hbase.util.Pair<Integer,Integer>
    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 in
    Modifier and Type
    Method
    Description
    protected List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.ServerName,Long>>
    ClusterStatusPublisher.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 in
    Modifier and Type
    Method
    Description
    static org.apache.hadoop.hbase.util.Pair<String,String>
    StoreFileInfo.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 in
    Modifier and Type
    Method
    Description
    protected ConcurrentMap<String,org.apache.hadoop.hbase.util.Pair<Long,Long>>
    RegionServerAccounting.getRetainedRegionRWRequestsCnt()
    Returns the retained metrics of region's read and write requests count
    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)
     
    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 in
    Modifier and Type
    Method
    Description
    Map<byte[],List<org.apache.hadoop.fs.Path>>
    HRegion.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.
    Map<byte[],List<org.apache.hadoop.fs.Path>>
    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 in
    Modifier and Type
    Method
    Description
    protected 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 in
    Modifier and Type
    Method
    Description
    protected 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 in
    Modifier and Type
    Method
    Description
    protected 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 in
    Modifier and Type
    Method
    Description
    org.apache.hadoop.hbase.util.Pair<String,SortedSet<String>>
    ReplicationQueueStorage.claimQueue(org.apache.hadoop.hbase.ServerName sourceServerName, String queueId, org.apache.hadoop.hbase.ServerName destServerName)
    Change ownership for the queue identified by queueId and belongs to a dead region server.
    Method parameters in org.apache.hadoop.hbase.replication with type arguments of type org.apache.hadoop.hbase.util.Pair in in
    Modifier and Type
    Method
    Description
    void
    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.
  • 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 in
    Modifier and Type
    Method
    Description
    static 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)
    Create a protocol buffer bulk load request
    static 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 request
    static 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 in
    Modifier and Type
    Method
    Description
    Map<String,org.apache.hadoop.hbase.util.Pair<String,String>>
    RestoreSnapshotHelper.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
    Modifier
    Constructor
    Description
     
    RestoreMetaChanges(org.apache.hadoop.hbase.client.TableDescriptor htd, Map<String,org.apache.hadoop.hbase.util.Pair<String,String>> parentsMap)
     
  • 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 in
    Modifier and Type
    Method
    Description
    static 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 in
    Modifier and Type
    Method
    Description
    static List<org.apache.hadoop.hbase.wal.WALSplitUtil.MutationReplay>
    WALSplitUtil.getMutationsFromWALEntry(org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.WALEntry entry, org.apache.hadoop.hbase.CellScanner 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)
    This function is used to construct mutations from a WALEntry.