Modifier and Type | Method and Description |
---|---|
static Pair<HRegionInfo,ServerName> |
MetaReader.getRegion(CatalogTracker catalogTracker,
byte[] regionName)
Gets the region info and assignment for the specified region.
|
static Pair<HRegionInfo,ServerName> |
MetaReader.parseCatalogResult(Result r)
Extract a HRegionInfo and ServerName.
|
Modifier and Type | Method and Description |
---|---|
static List<Pair<HRegionInfo,ServerName>> |
MetaReader.getTableRegionsAndLocations(CatalogTracker catalogTracker,
byte[] tableName,
boolean excludeOfflinedSplitParents) |
static List<Pair<HRegionInfo,ServerName>> |
MetaReader.getTableRegionsAndLocations(CatalogTracker catalogTracker,
String tableName) |
Modifier and Type | Method and Description |
---|---|
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<byte[][],byte[][]> |
HTable.getStartEndKeys()
Gets the starting and ending row keys for every region in the currently
open table.
|
Modifier and Type | Method and Description |
---|---|
Map<byte[],List<Pair<Integer,Object>>> |
MultiResponse.getResults() |
Modifier and Type | Method and Description |
---|---|
void |
MultiResponse.add(byte[] regionName,
Pair<Integer,Object> r)
Add the pair to the container, grouped by the regionName
|
Modifier and Type | Method and Description |
---|---|
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.
|
Modifier and Type | Method and Description |
---|---|
<T,S> Pair<S,Long> |
AggregateImplementation.getAvg(ColumnInterpreter<T,S> ci,
Scan scan) |
<T,S> Pair<S,Long> |
AggregateProtocol.getAvg(ColumnInterpreter<T,S> ci,
Scan scan)
Gives a Pair with first object as Sum and second object as row count,
computed for a given combination of column qualifier and column family in
the given row range as defined in the Scan object.
|
<T,S> Pair<List<S>,Long> |
AggregateImplementation.getStd(ColumnInterpreter<T,S> ci,
Scan scan) |
<T,S> Pair<List<S>,Long> |
AggregateProtocol.getStd(ColumnInterpreter<T,S> ci,
Scan scan)
Gives a Pair with first object a List containing Sum and sum of squares,
and the second object as row count.
|
Modifier and Type | Method and Description |
---|---|
boolean |
SecureBulkLoadClient.bulkLoadHFiles(List<Pair<byte[],String>> familyPaths,
org.apache.hadoop.security.token.Token<?> userToken,
String bulkToken) |
boolean |
SecureBulkLoadClient.bulkLoadHFiles(List<Pair<byte[],String>> familyPaths,
org.apache.hadoop.security.token.Token<?> userToken,
String bulkToken,
boolean assignSeqNum) |
void |
BaseRegionObserver.postBatchMutate(ObserverContext<RegionCoprocessorEnvironment> c,
MiniBatchOperationInProgress<Pair<Mutation,Integer>> miniBatchOp) |
void |
RegionObserver.postBatchMutate(ObserverContext<RegionCoprocessorEnvironment> c,
MiniBatchOperationInProgress<Pair<Mutation,Integer>> miniBatchOp)
This will be called after applying a batch of Mutations on a region.
|
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.preBatchMutate(ObserverContext<RegionCoprocessorEnvironment> c,
MiniBatchOperationInProgress<Pair<Mutation,Integer>> miniBatchOp) |
void |
RegionObserver.preBatchMutate(ObserverContext<RegionCoprocessorEnvironment> c,
MiniBatchOperationInProgress<Pair<Mutation,Integer>> miniBatchOp)
This will be called for every batch mutation operation happening at the server.
|
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.
|
Constructor and Description |
---|
FuzzyRowFilter(List<Pair<byte[],byte[]>> fuzzyKeysData) |
Modifier and Type | Method and Description |
---|---|
Pair<ByteBuffer,BlockType> |
HFileDataBlockEncoderImpl.beforeWriteToDisk(ByteBuffer in,
boolean includesMemstoreTS,
byte[] dummyHeader)
Precondition: a non-encoded buffer.
|
Pair<ByteBuffer,BlockType> |
NoOpDataBlockEncoder.beforeWriteToDisk(ByteBuffer in,
boolean includesMemstoreTS,
byte[] dummyHeader) |
Pair<ByteBuffer,BlockType> |
HFileDataBlockEncoder.beforeWriteToDisk(ByteBuffer in,
boolean includesMemstoreTS,
byte[] dummyHeader)
Should be called before an encoded or unencoded data block is written to
disk.
|
Modifier and Type | Method and Description |
---|---|
Pair<Integer,Integer> |
HMasterInterface.getAlterStatus(byte[] tableName)
Used by the client to get the number of regions that have received the
updated schema
|
Modifier and Type | Method and Description |
---|---|
boolean |
HRegionInterface.bulkLoadHFiles(List<Pair<byte[],String>> familyPaths,
byte[] regionName)
Atomically bulk load multiple HFiles (say from different column families)
into an open region.
|
boolean |
HRegionInterface.bulkLoadHFiles(List<Pair<byte[],String>> familyPaths,
byte[] regionName,
boolean assignSeqNum)
Atomically bulk load multiple HFiles (say from different column families)
into an open region.
|
Modifier and Type | Method and Description |
---|---|
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.
|
Modifier and Type | Method and Description |
---|---|
Pair<Integer,Integer> |
HMaster.getAlterStatus(byte[] tableName)
Get the number of regions of the table that have been updated by the alter.
|
Pair<Integer,Integer> |
AssignmentManager.getReopenStatus(byte[] tableName)
Used by the client to identify if all regions have the schema updates
|
Pair<Set<HRegionInfo>,List<AssignmentManager.RegionState>> |
AssignmentManager.processServerShutdown(ServerName sn)
Start processing of shutdown server.
|
Modifier and Type | Method and Description |
---|---|
protected void |
EnabledTableSnapshotHandler.snapshotRegions(List<Pair<HRegionInfo,ServerName>> regions)
This method kicks off a snapshot procedure.
|
void |
DisabledTableSnapshotHandler.snapshotRegions(List<Pair<HRegionInfo,ServerName>> regionsAndLocations) |
protected abstract void |
TakeSnapshotHandler.snapshotRegions(List<Pair<HRegionInfo,ServerName>> regions)
Snapshot the specified regions
|
Modifier and Type | Method and Description |
---|---|
List<Pair<String,Long>> |
ExactCounterMetric.getTop(int n) |
Modifier and Type | Method and Description |
---|---|
List<Pair<Long,Long>> |
HRegion.getRecentFlushInfo() |
Modifier and Type | Method and Description |
---|---|
OperationStatus[] |
HRegion.batchMutate(Pair<Mutation,Integer>[] mutationsAndLocks)
Perform a batch of mutations.
|
OperationStatus[] |
HRegion.put(Pair<Put,Integer>[] putsAndLocks)
Deprecated.
Instead use
HRegion.batchMutate(Pair[]) |
Modifier and Type | Method and Description |
---|---|
boolean |
HRegion.bulkLoadHFiles(List<Pair<byte[],String>> familyPaths)
Attempts to atomically load a group of hfiles.
|
boolean |
HRegion.bulkLoadHFiles(List<Pair<byte[],String>> familyPaths,
boolean assignSeqId)
Attempts to atomically load a group of hfiles.
|
boolean |
HRegionServer.bulkLoadHFiles(List<Pair<byte[],String>> familyPaths,
byte[] regionName)
Atomically bulk load several HFiles into an open region
|
boolean |
HRegionServer.bulkLoadHFiles(List<Pair<byte[],String>> familyPaths,
byte[] regionName,
boolean assignSeqNum)
Atomically bulk load several HFiles into an open region
|
boolean |
HRegion.bulkLoadHFiles(List<Pair<byte[],String>> familyPaths,
HRegion.BulkLoadListener bulkLoadListener)
Attempts to atomically load a group of hfiles.
|
boolean |
HRegion.bulkLoadHFiles(List<Pair<byte[],String>> familyPaths,
HRegion.BulkLoadListener bulkLoadListener,
boolean assignSeqId)
Attempts to atomically load a group of hfiles.
|
void |
RegionCoprocessorHost.postBatchMutate(MiniBatchOperationInProgress<Pair<Mutation,Integer>> miniBatchOp) |
boolean |
RegionCoprocessorHost.postBulkLoadHFile(List<Pair<byte[],String>> familyPaths,
boolean hasLoaded) |
boolean |
RegionCoprocessorHost.preBatchMutate(MiniBatchOperationInProgress<Pair<Mutation,Integer>> miniBatchOp) |
boolean |
RegionCoprocessorHost.preBulkLoadHFile(List<Pair<byte[],String>> familyPaths) |
Modifier and Type | Method and Description |
---|---|
static Pair<Long,Integer> |
RegionMetricsStorage.getTimeVaryingMetric(String key) |
Modifier and Type | Method and Description |
---|---|
static Map<String,Pair<AtomicLong,AtomicInteger>> |
RegionMetricsStorage.getTimeVaryingMetrics() |
Modifier and Type | Method and Description |
---|---|
void |
RegionServerMetrics.addFlush(List<Pair<Long,Long>> flushes) |
Modifier and Type | Method and Description |
---|---|
boolean |
SecureBulkLoadProtocol.bulkLoadHFiles(List<Pair<byte[],String>> familyPaths,
org.apache.hadoop.security.token.Token<?> userToken,
String bulkToken,
boolean assignSeqNum)
Secure version of HRegionServer.bulkLoadHFiles().
|
boolean |
SecureBulkLoadEndpoint.bulkLoadHFiles(List<Pair<byte[],String>> familyPaths,
org.apache.hadoop.security.token.Token<?> userToken,
String bulkToken,
boolean assignSeqNum) |
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.
|
Modifier and Type | Method and Description |
---|---|
void |
WriteSinkCoprocessor.preBatchMutate(ObserverContext<RegionCoprocessorEnvironment> c,
MiniBatchOperationInProgress<Pair<Mutation,Integer>> miniBatchOp) |
Modifier and Type | Method and Description |
---|---|
static <T1,T2> Pair<T1,T2> |
Pair.newPair(T1 a,
T2 b)
Constructs a new pair, inferring the type via the passed arguments
|
Copyright © 2014 The Apache Software Foundation. All Rights Reserved.