| 
 | ||||||||||
| PREV NEXT | FRAMES NO FRAMES | |||||||||
| Uses of Pair in org.apache.hadoop.hbase | 
|---|
| Methods in org.apache.hadoop.hbase that return Pair | |
|---|---|
| static Pair<HRegionInfo,ServerName> | HRegionInfo.getHRegionInfoAndServerName(Result r)Extract a HRegionInfo and ServerName from catalog table Result. | 
| Uses of Pair in org.apache.hadoop.hbase.catalog | 
|---|
| Methods in org.apache.hadoop.hbase.catalog that return Pair | |
|---|---|
| static Pair<HRegionInfo,ServerName> | MetaReader.getRegion(CatalogTracker catalogTracker,
          byte[] regionName)Gets the region info and assignment for the specified region. | 
| static Pair<HRegionInfo,HRegionInfo> | MetaReader.getRegionsFromMergeQualifier(CatalogTracker catalogTracker,
                             byte[] regionName)Get regions from the merge qualifier of the specified merged region | 
| Methods in org.apache.hadoop.hbase.catalog that return types with arguments of type Pair | |
|---|---|
| static List<Pair<HRegionInfo,ServerName>> | MetaReader.getTableRegionsAndLocations(CatalogTracker catalogTracker,
                            TableName tableName) | 
| static List<Pair<HRegionInfo,ServerName>> | MetaReader.getTableRegionsAndLocations(CatalogTracker catalogTracker,
                            TableName tableName,
                            boolean excludeOfflinedSplitParents) | 
| Uses of Pair in org.apache.hadoop.hbase.client | 
|---|
| Methods in org.apache.hadoop.hbase.client that return Pair | |
|---|---|
|  Pair<Integer,Integer> | HBaseAdmin.getAlterStatus(byte[] tableName)Get the status of alter command - indicates how many regions have received the updated schema Asynchronous operation. | 
|  Pair<Integer,Integer> | HBaseAdmin.getAlterStatus(TableName tableName)Get the status of alter command - indicates how many regions have received the updated schema Asynchronous operation. | 
|  Pair<byte[][],byte[][]> | HTable.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 Pair | |
|---|---|
|  Map<byte[],List<Pair<Integer,Object>>> | MultiResponse.getResults() | 
| Methods in org.apache.hadoop.hbase.client with parameters of type Pair | |
|---|---|
|  void | MultiResponse.add(byte[] regionName,
    Pair<Integer,Object> r)Add the pair to the container, grouped by the regionName | 
| Uses of Pair in org.apache.hadoop.hbase.client.coprocessor | 
|---|
| Method parameters in org.apache.hadoop.hbase.client.coprocessor with type arguments of type Pair | |
|---|---|
|  boolean | SecureBulkLoadClient.bulkLoadHFiles(List<Pair<byte[],String>> familyPaths,
               org.apache.hadoop.security.token.Token<?> userToken,
               String bulkToken,
               byte[] startRow) | 
| Uses of Pair in org.apache.hadoop.hbase.constraint | 
|---|
| Methods in org.apache.hadoop.hbase.constraint with parameters of type Pair | |
|---|---|
| static void | Constraints.add(HTableDescriptor desc,
    Pair<Class<? extends Constraint>,org.apache.hadoop.conf.Configuration>... constraints)Add constraints and their associated configurations to the table. | 
| Uses of Pair in org.apache.hadoop.hbase.coprocessor | 
|---|
| Method parameters in org.apache.hadoop.hbase.coprocessor with type arguments of type Pair | |
|---|---|
|  boolean | RegionObserver.postBulkLoadHFile(ObserverContext<RegionCoprocessorEnvironment> ctx,
                  List<Pair<byte[],String>> familyPaths,
                  boolean hasLoaded)Called after bulkLoadHFile. | 
|  boolean | BaseRegionObserver.postBulkLoadHFile(ObserverContext<RegionCoprocessorEnvironment> ctx,
                  List<Pair<byte[],String>> familyPaths,
                  boolean hasLoaded) | 
|  void | RegionObserver.preBulkLoadHFile(ObserverContext<RegionCoprocessorEnvironment> ctx,
                 List<Pair<byte[],String>> familyPaths)Called before bulkLoadHFile. | 
|  void | BaseRegionObserver.preBulkLoadHFile(ObserverContext<RegionCoprocessorEnvironment> ctx,
                 List<Pair<byte[],String>> familyPaths) | 
| Uses of Pair in org.apache.hadoop.hbase.filter | 
|---|
| Constructor parameters in org.apache.hadoop.hbase.filter with type arguments of type Pair | |
|---|---|
| FuzzyRowFilter(List<Pair<byte[],byte[]>> fuzzyKeysData) | |
| Uses of Pair in org.apache.hadoop.hbase.ipc | 
|---|
| Methods in org.apache.hadoop.hbase.ipc that return Pair | |
|---|---|
|  Pair<com.google.protobuf.Message,CellScanner> | RpcServerInterface.call(com.google.protobuf.BlockingService service,
     com.google.protobuf.Descriptors.MethodDescriptor md,
     com.google.protobuf.Message param,
     CellScanner cellScanner,
     long receiveTime,
     MonitoredRPCHandler status) | 
|  Pair<com.google.protobuf.Message,CellScanner> | RpcServer.call(com.google.protobuf.BlockingService service,
     com.google.protobuf.Descriptors.MethodDescriptor md,
     com.google.protobuf.Message param,
     CellScanner cellScanner,
     long receiveTime,
     MonitoredRPCHandler status)This is a server side method, which is invoked over RPC. | 
| Methods in org.apache.hadoop.hbase.ipc with parameters of type Pair | |
|---|---|
| protected  int | RpcServer.getQosLevel(Pair<RPCProtos.RequestHeader,com.google.protobuf.Message> headerAndParam) | 
| Method parameters in org.apache.hadoop.hbase.ipc with type arguments of type Pair | |
|---|---|
|  void | RpcServerInterface.setQosFunction(com.google.common.base.Function<Pair<RPCProtos.RequestHeader,com.google.protobuf.Message>,Integer> newFunc) | 
|  void | RpcServer.setQosFunction(com.google.common.base.Function<Pair<RPCProtos.RequestHeader,com.google.protobuf.Message>,Integer> newFunc)Gets the QOS level for this call. | 
| Uses of Pair in org.apache.hadoop.hbase.mapreduce | 
|---|
| Methods in org.apache.hadoop.hbase.mapreduce that return Pair | |
|---|---|
|  Pair<Integer,Integer> | ImportTsv.TsvParser.parseRowKey(byte[] lineBytes,
            int length) | 
| Methods in org.apache.hadoop.hbase.mapreduce with parameters of type Pair | |
|---|---|
| protected  List<org.apache.hadoop.hbase.mapreduce.LoadIncrementalHFiles.LoadQueueItem> | LoadIncrementalHFiles.groupOrSplit(com.google.common.collect.Multimap<ByteBuffer,org.apache.hadoop.hbase.mapreduce.LoadIncrementalHFiles.LoadQueueItem> regionGroups,
             org.apache.hadoop.hbase.mapreduce.LoadIncrementalHFiles.LoadQueueItem item,
             HTable table,
             Pair<byte[][],byte[][]> startEndKeys)Attempt to assign the given load queue item into its target region group. | 
| Uses of Pair in org.apache.hadoop.hbase.master | 
|---|
| Methods in org.apache.hadoop.hbase.master that return Pair | |
|---|---|
|  Pair<Integer,Integer> | AssignmentManager.getReopenStatus(TableName tableName)Used by the client to identify if all regions have the schema updates | 
| Methods in org.apache.hadoop.hbase.master that return types with arguments of type Pair | |
|---|---|
|  List<Pair<ServerName,Long>> | DeadServer.copyDeadServersSince(long ts)Extract all the servers dead since a given time, and sort them. | 
| protected  List<Pair<ServerName,Long>> | ClusterStatusPublisher.getDeadServers(long since)Get the servers which died since a given timestamp. | 
| Uses of Pair in org.apache.hadoop.hbase.master.snapshot | 
|---|
| Method parameters in org.apache.hadoop.hbase.master.snapshot with type arguments of type Pair | |
|---|---|
| protected abstract  void | TakeSnapshotHandler.snapshotRegions(List<Pair<HRegionInfo,ServerName>> regions)Snapshot the specified regions | 
| protected  void | EnabledTableSnapshotHandler.snapshotRegions(List<Pair<HRegionInfo,ServerName>> regions)This method kicks off a snapshot procedure. | 
|  void | DisabledTableSnapshotHandler.snapshotRegions(List<Pair<HRegionInfo,ServerName>> regionsAndLocations) | 
| Uses of Pair in org.apache.hadoop.hbase.metrics | 
|---|
| Methods in org.apache.hadoop.hbase.metrics that return types with arguments of type Pair | |
|---|---|
|  List<Pair<String,Long>> | ExactCounterMetric.getTop(int n)Deprecated. | 
| Uses of Pair in org.apache.hadoop.hbase.protobuf | 
|---|
| Methods in org.apache.hadoop.hbase.protobuf that return Pair | |
|---|---|
| static Pair<AdminProtos.ReplicateWALEntryRequest,CellScanner> | ReplicationProtbufUtil.buildReplicateWALEntryRequest(HLog.Entry[] entries)Create a new ReplicateWALEntryRequest from a list of HLog entries | 
| Method parameters in org.apache.hadoop.hbase.protobuf with type arguments of type Pair | |
|---|---|
| static ClientProtos.BulkLoadHFileRequest | RequestConverter.buildBulkLoadHFileRequest(List<Pair<byte[],String>> familyPaths,
                          byte[] regionName,
                          boolean assignSeqNum)Create a protocol buffer bulk load request | 
| static boolean | ProtobufUtil.bulkLoadHFile(ClientProtos.ClientService.BlockingInterface client,
              List<Pair<byte[],String>> familyPaths,
              byte[] regionName,
              boolean assignSeqNum)A helper to bulk load a list of HFiles using client protocol. | 
| Uses of Pair in org.apache.hadoop.hbase.regionserver | 
|---|
| Method parameters in org.apache.hadoop.hbase.regionserver with type arguments of type Pair | |
|---|---|
|  boolean | HRegion.bulkLoadHFiles(List<Pair<byte[],String>> familyPaths,
               boolean assignSeqId) | 
|  boolean | HRegion.bulkLoadHFiles(List<Pair<byte[],String>> familyPaths,
               boolean assignSeqId,
               HRegion.BulkLoadListener bulkLoadListener)Attempts to atomically load a group of hfiles. | 
|  boolean | RegionCoprocessorHost.postBulkLoadHFile(List<Pair<byte[],String>> familyPaths,
                  boolean hasLoaded) | 
|  boolean | RegionCoprocessorHost.preBulkLoadHFile(List<Pair<byte[],String>> familyPaths) | 
|  List<CompactionRequest> | CompactSplitThread.requestCompaction(HRegion r,
                  String why,
                  int p,
                  List<Pair<CompactionRequest,Store>> requests) | 
|  List<CompactionRequest> | CompactionRequestor.requestCompaction(HRegion r,
                  String why,
                  int pri,
                  List<Pair<CompactionRequest,Store>> requests) | 
|  List<CompactionRequest> | CompactSplitThread.requestCompaction(HRegion r,
                  String why,
                  List<Pair<CompactionRequest,Store>> requests) | 
|  List<CompactionRequest> | CompactionRequestor.requestCompaction(HRegion r,
                  String why,
                  List<Pair<CompactionRequest,Store>> requests) | 
| Uses of Pair in org.apache.hadoop.hbase.regionserver.wal | 
|---|
| Method parameters in org.apache.hadoop.hbase.regionserver.wal with type arguments of type Pair | |
|---|---|
|  void | WALEditsReplaySink.replayEntries(List<Pair<HRegionLocation,Row>> actions)Replay an array of actions of the same region directly into the newly assigned Region Server | 
| Uses of Pair in org.apache.hadoop.hbase.security.access | 
|---|
| Method parameters in org.apache.hadoop.hbase.security.access with type arguments of type Pair | |
|---|---|
|  void | AccessController.preBulkLoadHFile(ObserverContext<RegionCoprocessorEnvironment> ctx,
                 List<Pair<byte[],String>> familyPaths)Verifies user has WRITE privileges on the Column Families involved in the bulkLoadHFile request. | 
| Uses of Pair in org.apache.hadoop.hbase.util | 
|---|
| Methods in org.apache.hadoop.hbase.util that return Pair | ||
|---|---|---|
| static
 | Pair.newPair(T1 a,
        T2 b)Constructs a new pair, inferring the type via the passed arguments | |
| 
 | ||||||||||
| PREV NEXT | FRAMES NO FRAMES | |||||||||