Uses of Class
org.apache.hadoop.hbase.util.Pair

Packages that use Pair
org.apache.hadoop.hbase   
org.apache.hadoop.hbase.catalog   
org.apache.hadoop.hbase.client Provides HBase Client 
org.apache.hadoop.hbase.client.coprocessor Provides client classes for invoking Coprocessor RPC protocols 
org.apache.hadoop.hbase.constraint Restrict the domain of a data attribute, often times to fulfill business rules/requirements. 
org.apache.hadoop.hbase.coprocessor Table of Contents 
org.apache.hadoop.hbase.filter Provides row-level filters applied to HRegion scan results during calls to ResultScanner.next()
org.apache.hadoop.hbase.io.util   
org.apache.hadoop.hbase.ipc Tools to help define network clients and servers. 
org.apache.hadoop.hbase.mapreduce Provides HBase MapReduce Input/OutputFormats, a table indexing MapReduce job, and utility 
org.apache.hadoop.hbase.master   
org.apache.hadoop.hbase.master.snapshot   
org.apache.hadoop.hbase.metrics   
org.apache.hadoop.hbase.protobuf Holds classes generated from protobuf src/main/protobuf definition files. 
org.apache.hadoop.hbase.regionserver   
org.apache.hadoop.hbase.regionserver.wal   
org.apache.hadoop.hbase.replication Multi Cluster Replication 
org.apache.hadoop.hbase.security.access   
org.apache.hadoop.hbase.security.visibility   
org.apache.hadoop.hbase.util   
 

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.
 

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 BaseRegionObserver.postBulkLoadHFile(ObserverContext<RegionCoprocessorEnvironment> ctx, List<Pair<byte[],String>> familyPaths, boolean hasLoaded)
           
 boolean RegionObserver.postBulkLoadHFile(ObserverContext<RegionCoprocessorEnvironment> ctx, List<Pair<byte[],String>> familyPaths, boolean hasLoaded)
          Called after bulkLoadHFile.
 void BaseRegionObserver.preBulkLoadHFile(ObserverContext<RegionCoprocessorEnvironment> ctx, List<Pair<byte[],String>> familyPaths)
           
 void RegionObserver.preBulkLoadHFile(ObserverContext<RegionCoprocessorEnvironment> ctx, List<Pair<byte[],String>> familyPaths)
          Called before bulkLoadHFile.
 

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.io.util
 

Methods in org.apache.hadoop.hbase.io.util that return Pair
static Pair<Integer,Integer> StreamUtils.readRawVarint32(byte[] input, int offset)
          Reads a varInt value stored in an array.
 

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> 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.
 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)
           
 

Uses of Pair in org.apache.hadoop.hbase.mapreduce
 

Methods in org.apache.hadoop.hbase.mapreduce that return Pair
protected  Pair<byte[][],byte[][]> TableInputFormat.getStartEndKeys()
           
protected  Pair<byte[][],byte[][]> TableInputFormatBase.getStartEndKeys()
           
 Pair<Integer,Integer> ImportTsv.TsvParser.parseRowKey(byte[] lineBytes, int length)
          Return starting position and length of row key from the specified line bytes.
 

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 AdminProtos.UpdateFavoredNodesRequest RequestConverter.buildUpdateFavoredNodesRequest(List<Pair<HRegionInfo,List<ServerName>>> updateRegionInfos)
          Create a protocol buffer UpdateFavoredNodesRequest to update a list of favorednode mappings
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.
static boolean ProtobufUtil.bulkLoadHFile(ClientProtos.ClientService.BlockingInterface client, List<Pair<byte[],String>> familyPaths, byte[] regionName, boolean assignSeqNum, PayloadCarryingRpcController controller)
          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, User user)
           
 List<CompactionRequest> CompactionRequestor.requestCompaction(HRegion r, String why, int pri, List<Pair<CompactionRequest,Store>> requests, User user)
           
 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
 

Methods in org.apache.hadoop.hbase.regionserver.wal with parameters of type Pair
static List<HLogSplitter.MutationReplay> HLogSplitter.getMutationsFromWALEntry(AdminProtos.WALEntry entry, CellScanner cells, Pair<HLogKey,WALEdit> logEntry, boolean addLogReplayTag)
          This function is used to construct mutations from a WALEntry.
 

Method parameters in org.apache.hadoop.hbase.regionserver.wal with type arguments of type Pair
 void WALEditsReplaySink.replayEntries(List<Pair<HRegionLocation,HLog.Entry>> entries)
          Replay an array of actions of the same region directly into the newly assigned Region Server
 

Uses of Pair in org.apache.hadoop.hbase.replication
 

Methods in org.apache.hadoop.hbase.replication that return Pair
 Pair<ReplicationPeerConfig,org.apache.hadoop.conf.Configuration> ReplicationPeersZKImpl.getPeerConf(String peerId)
           
 Pair<ReplicationPeerConfig,org.apache.hadoop.conf.Configuration> ReplicationPeers.getPeerConf(String peerId)
          Returns the configuration needed to talk to the remote slave cluster.
 

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 CREATE privileges on the Column Families involved in the bulkLoadHFile request.
 

Uses of Pair in org.apache.hadoop.hbase.security.visibility
 

Methods in org.apache.hadoop.hbase.security.visibility that return Pair
protected  Pair<Map<String,Integer>,Map<String,List<Integer>>> DefaultVisibilityLabelServiceImpl.extractLabelsAndAuths(List<List<Cell>> labelDetails)
           
 

Uses of Pair in org.apache.hadoop.hbase.util
 

Methods in org.apache.hadoop.hbase.util that return Pair
static
<T1,T2> Pair<T1,T2>
Pair.newPair(T1 a, T2 b)
          Constructs a new pair, inferring the type via the passed arguments
 



Copyright © 2007–2016 The Apache Software Foundation. All rights reserved.