Uses of Class
org.apache.hadoop.hbase.client.Result
Packages that use org.apache.hadoop.hbase.client.Result
Package
Description
Provides HBase Client
Table of Contents
Provides HBase MapReduce
Input/OutputFormats, a table indexing MapReduce job, and utility methods.
Provides HBase MapReduce
Input/OutputFormats, a table indexing MapReduce job, and utility methods.
Provides an HBase Thrift
service.
-
Uses of org.apache.hadoop.hbase.client.Result in org.apache.hadoop.hbase
Methods in org.apache.hadoop.hbase that return org.apache.hadoop.hbase.client.Result in inModifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.client.Result
MetaTableAccessor.getCatalogFamilyRow
(org.apache.hadoop.hbase.client.Connection connection, org.apache.hadoop.hbase.client.RegionInfo ri) Returns Return theHConstants.CATALOG_FAMILY
row from hbase:meta.static org.apache.hadoop.hbase.client.Result
MetaTableAccessor.getRegionResult
(org.apache.hadoop.hbase.client.Connection connection, org.apache.hadoop.hbase.client.RegionInfo regionInfo) Gets the result in hbase:meta for the specified region.static org.apache.hadoop.hbase.client.Result
MetaTableAccessor.scanByRegionEncodedName
(org.apache.hadoop.hbase.client.Connection connection, String regionEncodedName) Scans META table for a row whose key contains the specified regionEncodedName, returning a single relatedResult
instance if any row is found, null otherwise.Methods in org.apache.hadoop.hbase that return types with arguments of type org.apache.hadoop.hbase.client.Result in inModifier and TypeMethodDescriptionstatic List<org.apache.hadoop.hbase.client.Result>
MetaTableAccessor.fullScanRegions
(org.apache.hadoop.hbase.client.Connection connection) Performs a full scan ofhbase:meta
for regions.static NavigableMap<org.apache.hadoop.hbase.client.RegionInfo,
org.apache.hadoop.hbase.client.Result> MetaTableAccessor.getServerUserRegions
(org.apache.hadoop.hbase.client.Connection connection, org.apache.hadoop.hbase.ServerName serverName) Get the user regions a given server is hosting.Methods in org.apache.hadoop.hbase with parameters of type org.apache.hadoop.hbase.client.Result in inModifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.util.PairOfSameType<org.apache.hadoop.hbase.client.RegionInfo>
MetaTableAccessor.getDaughterRegions
(org.apache.hadoop.hbase.client.Result data) Returns the daughter regions by reading the corresponding columns of the catalog table Result.static org.apache.hadoop.hbase.client.RegionInfo
MetaTableAccessor.getRegionInfo
(org.apache.hadoop.hbase.client.Result data) Returns RegionInfo object from the column HConstants.CATALOG_FAMILY:HConstants.REGIONINFO_QUALIFIER of the catalog table Result.static org.apache.hadoop.hbase.client.RegionInfo
MetaTableAccessor.getRegionInfo
(org.apache.hadoop.hbase.client.Result r, byte[] qualifier) Returns the RegionInfo object from the columnHConstants.CATALOG_FAMILY
andqualifier
of the catalog table result.static org.apache.hadoop.hbase.RegionLocations
MetaTableAccessor.getRegionLocations
(org.apache.hadoop.hbase.client.Result r) Returns an HRegionLocationList extracted from the result.static long[]
MetaTableAccessor.getReplicationBarriers
(org.apache.hadoop.hbase.client.Result result) static org.apache.hadoop.hbase.ServerName
MetaTableAccessor.getServerName
(org.apache.hadoop.hbase.client.Result r, int replicaId) Returns aServerName
from catalog tableResult
.static org.apache.hadoop.hbase.client.TableState
MetaTableAccessor.getTableState
(org.apache.hadoop.hbase.client.Result r) Decode table state from META Result.static org.apache.hadoop.hbase.ServerName
MetaTableAccessor.getTargetServerName
(org.apache.hadoop.hbase.client.Result r, int replicaId) Returns theServerName
from catalog tableResult
where the region is transitioning on.boolean
MetaTableAccessor.DefaultVisitorBase.visit
(org.apache.hadoop.hbase.client.Result rowResult) final boolean
MetaTableAccessor.TableVisitorBase.visit
(org.apache.hadoop.hbase.client.Result rowResult) boolean
MetaTableAccessor.Visitor.visit
(org.apache.hadoop.hbase.client.Result r) Visit the catalog table row.abstract boolean
MetaTableAccessor.DefaultVisitorBase.visitInternal
(org.apache.hadoop.hbase.client.Result rowResult) -
Uses of org.apache.hadoop.hbase.client.Result in org.apache.hadoop.hbase.client
Fields in org.apache.hadoop.hbase.client declared as org.apache.hadoop.hbase.client.Result in inModifier and TypeFieldDescriptionstatic final org.apache.hadoop.hbase.client.Result
Result.EMPTY_RESULT
static final org.apache.hadoop.hbase.client.Result[]
ScanResultCache.EMPTY_RESULT_ARRAY
protected org.apache.hadoop.hbase.client.Result
ClientScanner.lastResult
Fields in org.apache.hadoop.hbase.client with type parameters of type org.apache.hadoop.hbase.client.Result in inModifier and TypeFieldDescriptionprotected Queue<org.apache.hadoop.hbase.client.Result>
ClientScanner.cache
Methods in org.apache.hadoop.hbase.client that return org.apache.hadoop.hbase.client.Result in inModifier and TypeMethodDescriptionorg.apache.hadoop.hbase.client.Result[]
BatchScanResultCache.addAndGet
(org.apache.hadoop.hbase.client.Result[] results, boolean isHeartbeatMessage) org.apache.hadoop.hbase.client.Result
HTable.append
(org.apache.hadoop.hbase.client.Append append) default org.apache.hadoop.hbase.client.Result
Table.append
(org.apache.hadoop.hbase.client.Append append) Appends values to one or more columns within a single row.org.apache.hadoop.hbase.client.Result
RpcRetryingCallerWithReadReplicas.call
(int operationTimeout) Algo: - we put the query into the execution pool.static org.apache.hadoop.hbase.client.Result
Result.create
(List<org.apache.hadoop.hbase.Cell> cells) Instantiate a Result with the specified List of KeyValues.static org.apache.hadoop.hbase.client.Result
static org.apache.hadoop.hbase.client.Result
static org.apache.hadoop.hbase.client.Result
Result.create
(List<org.apache.hadoop.hbase.Cell> cells, Boolean exists, boolean stale, boolean mayHaveMoreCellsInRow) static org.apache.hadoop.hbase.client.Result
Result.create
(org.apache.hadoop.hbase.Cell[] cells) Instantiate a Result with the specified array of KeyValues.static org.apache.hadoop.hbase.client.Result
Result.create
(org.apache.hadoop.hbase.Cell[] cells, Boolean exists, boolean stale) static org.apache.hadoop.hbase.client.Result
Result.create
(org.apache.hadoop.hbase.Cell[] cells, Boolean exists, boolean stale, boolean mayHaveMoreCellsInRow) static org.apache.hadoop.hbase.client.Result
Result.createCompleteResult
(Iterable<org.apache.hadoop.hbase.client.Result> partialResults) Forms a single result from the partial results in the partialResults list.static org.apache.hadoop.hbase.client.Result
Result.createCursorResult
(org.apache.hadoop.hbase.client.Cursor cursor) org.apache.hadoop.hbase.client.Result[]
HTable.get
(List<org.apache.hadoop.hbase.client.Get> gets) org.apache.hadoop.hbase.client.Result
HTable.get
(org.apache.hadoop.hbase.client.Get get) default org.apache.hadoop.hbase.client.Result[]
Table.get
(List<org.apache.hadoop.hbase.client.Get> gets) Extracts specified cells from the given rows, as a batch.default org.apache.hadoop.hbase.client.Result
Table.get
(org.apache.hadoop.hbase.client.Get get) Extracts certain cells from a given row.org.apache.hadoop.hbase.client.Result
CheckAndMutateResult.getResult()
Returns It is used only for CheckAndMutate operations with Increment/Append.org.apache.hadoop.hbase.client.Result
SingleResponse.Entry.getResult()
org.apache.hadoop.hbase.client.Result
HTable.increment
(org.apache.hadoop.hbase.client.Increment increment) default org.apache.hadoop.hbase.client.Result
Table.increment
(org.apache.hadoop.hbase.client.Increment increment) Increments one or more columns within a single row.org.apache.hadoop.hbase.client.Result
HTable.mutateRow
(org.apache.hadoop.hbase.client.RowMutations rm) default org.apache.hadoop.hbase.client.Result
Table.mutateRow
(org.apache.hadoop.hbase.client.RowMutations rm) Performs multiple mutations atomically on a single row.org.apache.hadoop.hbase.client.Result
ClientAsyncPrefetchScanner.next()
org.apache.hadoop.hbase.client.Result
ClientScanner.next()
org.apache.hadoop.hbase.client.Result
ClientSideRegionScanner.next()
org.apache.hadoop.hbase.client.Result
ResultScanner.next()
Grab the next row's worth of values.default org.apache.hadoop.hbase.client.Result[]
ResultScanner.next
(int nbRows) Get nbRows rows.org.apache.hadoop.hbase.client.Result
TableSnapshotScanner.next()
protected org.apache.hadoop.hbase.client.Result
ClientScanner.nextWithSyncCache()
protected org.apache.hadoop.hbase.client.Result[]
ScannerCallable.rpcCall()
Methods in org.apache.hadoop.hbase.client that return types with arguments of type org.apache.hadoop.hbase.client.Result in inModifier and TypeMethodDescriptionCompletableFuture<org.apache.hadoop.hbase.client.Result>
AsyncTable.append
(org.apache.hadoop.hbase.client.Append append) Appends values to one or more columns within a single row.List<CompletableFuture<org.apache.hadoop.hbase.client.Result>>
AsyncTable.get
(List<org.apache.hadoop.hbase.client.Get> gets) Extracts certain cells from the given rows, in batch.CompletableFuture<org.apache.hadoop.hbase.client.Result>
AsyncTable.get
(org.apache.hadoop.hbase.client.Get get) Extracts certain cells from a given row.default CompletableFuture<List<org.apache.hadoop.hbase.client.Result>>
AsyncTable.getAll
(List<org.apache.hadoop.hbase.client.Get> gets) A simple version for batch get.CompletableFuture<org.apache.hadoop.hbase.client.Result>
AsyncTable.increment
(org.apache.hadoop.hbase.client.Increment increment) Increments one or more columns within a single row.default Iterator<org.apache.hadoop.hbase.client.Result>
ResultScanner.iterator()
CompletableFuture<org.apache.hadoop.hbase.client.Result>
AsyncTable.mutateRow
(org.apache.hadoop.hbase.client.RowMutations mutation) Performs multiple mutations atomically on a single row.CompletableFuture<List<org.apache.hadoop.hbase.client.Result>>
AsyncTable.scanAll
(org.apache.hadoop.hbase.client.Scan scan) Return all the results that match the given scan object.Methods in org.apache.hadoop.hbase.client with parameters of type org.apache.hadoop.hbase.client.Result in inModifier and TypeMethodDescriptionorg.apache.hadoop.hbase.client.Result[]
BatchScanResultCache.addAndGet
(org.apache.hadoop.hbase.client.Result[] results, boolean isHeartbeatMessage) static void
Result.compareResults
(org.apache.hadoop.hbase.client.Result res1, org.apache.hadoop.hbase.client.Result res2) Does a deep comparison of two Results, down to the byte arrays.static void
Result.compareResults
(org.apache.hadoop.hbase.client.Result res1, org.apache.hadoop.hbase.client.Result res2, boolean verbose) Does a deep comparison of two Results, down to the byte arrays.void
Result.copyFrom
(org.apache.hadoop.hbase.client.Result other) Copy another Result into this one.static long
Result.getTotalSizeOfCells
(org.apache.hadoop.hbase.client.Result result) Get total size of raw cellsvoid
AdvancedScanResultConsumer.onNext
(org.apache.hadoop.hbase.client.Result[] results, org.apache.hadoop.hbase.client.AdvancedScanResultConsumer.ScanController controller) Indicate that we have receive some data.boolean
ScanResultConsumer.onNext
(org.apache.hadoop.hbase.client.Result result) Returnfalse
if you want to terminate the scan process.void
SingleResponse.Entry.setResult
(org.apache.hadoop.hbase.client.Result result) Method parameters in org.apache.hadoop.hbase.client with type arguments of type org.apache.hadoop.hbase.client.Result in inModifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.client.Result
Result.createCompleteResult
(Iterable<org.apache.hadoop.hbase.client.Result> partialResults) Forms a single result from the partial results in the partialResults list.Constructors in org.apache.hadoop.hbase.client with parameters of type org.apache.hadoop.hbase.client.Result in inModifierConstructorDescriptionCheckAndMutateResult
(boolean success, org.apache.hadoop.hbase.client.Result result) -
Uses of org.apache.hadoop.hbase.client.Result in org.apache.hadoop.hbase.coprocessor
Methods in org.apache.hadoop.hbase.coprocessor that return org.apache.hadoop.hbase.client.Result in inModifier and TypeMethodDescriptiondefault org.apache.hadoop.hbase.client.Result
RegionObserver.postAppend
(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment> c, org.apache.hadoop.hbase.client.Append append, org.apache.hadoop.hbase.client.Result result) Deprecated.since 2.5.0 and will be removed in 4.0.0.default org.apache.hadoop.hbase.client.Result
RegionObserver.postAppend
(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment> c, org.apache.hadoop.hbase.client.Append append, org.apache.hadoop.hbase.client.Result result, org.apache.hadoop.hbase.wal.WALEdit edit) Called after Appenddefault org.apache.hadoop.hbase.client.Result
RegionObserver.postIncrement
(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment> c, org.apache.hadoop.hbase.client.Increment increment, org.apache.hadoop.hbase.client.Result result) Deprecated.since 2.5.0 and will be removed in 4.0.0.default org.apache.hadoop.hbase.client.Result
RegionObserver.postIncrement
(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment> c, org.apache.hadoop.hbase.client.Increment increment, org.apache.hadoop.hbase.client.Result result, org.apache.hadoop.hbase.wal.WALEdit edit) Called after incrementdefault org.apache.hadoop.hbase.client.Result
RegionObserver.preAppend
(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment> c, org.apache.hadoop.hbase.client.Append append) Deprecated.since 2.5.0 and will be removed in 4.0.0.default org.apache.hadoop.hbase.client.Result
RegionObserver.preAppend
(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment> c, org.apache.hadoop.hbase.client.Append append, org.apache.hadoop.hbase.wal.WALEdit edit) Called before Append.default org.apache.hadoop.hbase.client.Result
RegionObserver.preAppendAfterRowLock
(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment> c, org.apache.hadoop.hbase.client.Append append) Deprecated.since 2.5.0 and will be removed in 4.0.0.default org.apache.hadoop.hbase.client.Result
RegionObserver.preIncrement
(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment> c, org.apache.hadoop.hbase.client.Increment increment) Deprecated.since 2.5.0 and will be removed in 4.0.0.default org.apache.hadoop.hbase.client.Result
RegionObserver.preIncrement
(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment> c, org.apache.hadoop.hbase.client.Increment increment, org.apache.hadoop.hbase.wal.WALEdit edit) Called before Increment.default org.apache.hadoop.hbase.client.Result
RegionObserver.preIncrementAfterRowLock
(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment> c, org.apache.hadoop.hbase.client.Increment increment) Deprecated.since 2.5.0 and will be removed in 4.0.0.Methods in org.apache.hadoop.hbase.coprocessor with parameters of type org.apache.hadoop.hbase.client.Result in inModifier and TypeMethodDescriptiondefault org.apache.hadoop.hbase.client.Result
RegionObserver.postAppend
(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment> c, org.apache.hadoop.hbase.client.Append append, org.apache.hadoop.hbase.client.Result result) Deprecated.since 2.5.0 and will be removed in 4.0.0.default org.apache.hadoop.hbase.client.Result
RegionObserver.postAppend
(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment> c, org.apache.hadoop.hbase.client.Append append, org.apache.hadoop.hbase.client.Result result, org.apache.hadoop.hbase.wal.WALEdit edit) Called after Appenddefault org.apache.hadoop.hbase.client.Result
RegionObserver.postIncrement
(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment> c, org.apache.hadoop.hbase.client.Increment increment, org.apache.hadoop.hbase.client.Result result) Deprecated.since 2.5.0 and will be removed in 4.0.0.default org.apache.hadoop.hbase.client.Result
RegionObserver.postIncrement
(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment> c, org.apache.hadoop.hbase.client.Increment increment, org.apache.hadoop.hbase.client.Result result, org.apache.hadoop.hbase.wal.WALEdit edit) Called after incrementMethod parameters in org.apache.hadoop.hbase.coprocessor with type arguments of type org.apache.hadoop.hbase.client.Result in inModifier and TypeMethodDescriptiondefault boolean
RegionObserver.postScannerNext
(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment> c, org.apache.hadoop.hbase.regionserver.InternalScanner s, List<org.apache.hadoop.hbase.client.Result> result, int limit, boolean hasNext) Called after the client asks for the next row on a scanner.default boolean
RegionObserver.preScannerNext
(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment> c, org.apache.hadoop.hbase.regionserver.InternalScanner s, List<org.apache.hadoop.hbase.client.Result> result, int limit, boolean hasNext) Called before the client asks for the next row on a scanner. -
Uses of org.apache.hadoop.hbase.client.Result in org.apache.hadoop.hbase.mapred
Methods in org.apache.hadoop.hbase.mapred that return org.apache.hadoop.hbase.client.Result in inModifier and TypeMethodDescriptionorg.apache.hadoop.hbase.client.Result
TableRecordReader.createValue()
org.apache.hadoop.hbase.client.Result
TableRecordReaderImpl.createValue()
Methods in org.apache.hadoop.hbase.mapred that return types with arguments of type org.apache.hadoop.hbase.client.Result in inModifier and TypeMethodDescriptionorg.apache.hadoop.mapred.RecordReader<org.apache.hadoop.hbase.io.ImmutableBytesWritable,
org.apache.hadoop.hbase.client.Result> MultiTableSnapshotInputFormat.getRecordReader
(org.apache.hadoop.mapred.InputSplit split, org.apache.hadoop.mapred.JobConf job, org.apache.hadoop.mapred.Reporter reporter) org.apache.hadoop.mapred.RecordReader<org.apache.hadoop.hbase.io.ImmutableBytesWritable,
org.apache.hadoop.hbase.client.Result> TableInputFormatBase.getRecordReader
(org.apache.hadoop.mapred.InputSplit split, org.apache.hadoop.mapred.JobConf job, org.apache.hadoop.mapred.Reporter reporter) Builds a TableRecordReader.org.apache.hadoop.mapred.RecordReader<org.apache.hadoop.hbase.io.ImmutableBytesWritable,
org.apache.hadoop.hbase.client.Result> TableSnapshotInputFormat.getRecordReader
(org.apache.hadoop.mapred.InputSplit split, org.apache.hadoop.mapred.JobConf job, org.apache.hadoop.mapred.Reporter reporter) Methods in org.apache.hadoop.hbase.mapred with parameters of type org.apache.hadoop.hbase.client.Result in inModifier and TypeMethodDescriptionprotected byte[][]
GroupingTableMap.extractKeyValues
(org.apache.hadoop.hbase.client.Result r) Extract columns values from the current record.void
GroupingTableMap.map
(org.apache.hadoop.hbase.io.ImmutableBytesWritable key, org.apache.hadoop.hbase.client.Result value, org.apache.hadoop.mapred.OutputCollector<org.apache.hadoop.hbase.io.ImmutableBytesWritable, org.apache.hadoop.hbase.client.Result> output, org.apache.hadoop.mapred.Reporter reporter) Extract the grouping columns from value to construct a new key.void
IdentityTableMap.map
(org.apache.hadoop.hbase.io.ImmutableBytesWritable key, org.apache.hadoop.hbase.client.Result value, org.apache.hadoop.mapred.OutputCollector<org.apache.hadoop.hbase.io.ImmutableBytesWritable, org.apache.hadoop.hbase.client.Result> output, org.apache.hadoop.mapred.Reporter reporter) Pass the key, value to reduceboolean
TableRecordReader.next
(org.apache.hadoop.hbase.io.ImmutableBytesWritable key, org.apache.hadoop.hbase.client.Result value) boolean
TableRecordReaderImpl.next
(org.apache.hadoop.hbase.io.ImmutableBytesWritable key, org.apache.hadoop.hbase.client.Result value) Method parameters in org.apache.hadoop.hbase.mapred with type arguments of type org.apache.hadoop.hbase.client.Result in inModifier and TypeMethodDescriptionvoid
GroupingTableMap.map
(org.apache.hadoop.hbase.io.ImmutableBytesWritable key, org.apache.hadoop.hbase.client.Result value, org.apache.hadoop.mapred.OutputCollector<org.apache.hadoop.hbase.io.ImmutableBytesWritable, org.apache.hadoop.hbase.client.Result> output, org.apache.hadoop.mapred.Reporter reporter) Extract the grouping columns from value to construct a new key.void
IdentityTableMap.map
(org.apache.hadoop.hbase.io.ImmutableBytesWritable key, org.apache.hadoop.hbase.client.Result value, org.apache.hadoop.mapred.OutputCollector<org.apache.hadoop.hbase.io.ImmutableBytesWritable, org.apache.hadoop.hbase.client.Result> output, org.apache.hadoop.mapred.Reporter reporter) Pass the key, value to reduce -
Uses of org.apache.hadoop.hbase.client.Result in org.apache.hadoop.hbase.mapreduce
Methods in org.apache.hadoop.hbase.mapreduce that return org.apache.hadoop.hbase.client.Result in inModifier and TypeMethodDescriptionorg.apache.hadoop.hbase.client.Result
TableRecordReader.getCurrentValue()
Returns the current value.org.apache.hadoop.hbase.client.Result
TableRecordReaderImpl.getCurrentValue()
Returns the current value.org.apache.hadoop.hbase.client.Result
TableSnapshotInputFormatImpl.RecordReader.getCurrentValue()
Methods in org.apache.hadoop.hbase.mapreduce that return types with arguments of type org.apache.hadoop.hbase.client.Result in inModifier and TypeMethodDescriptionorg.apache.hadoop.mapreduce.RecordReader<org.apache.hadoop.hbase.io.ImmutableBytesWritable,
org.apache.hadoop.hbase.client.Result> MultiTableInputFormatBase.createRecordReader
(org.apache.hadoop.mapreduce.InputSplit split, org.apache.hadoop.mapreduce.TaskAttemptContext context) Builds a TableRecordReader.org.apache.hadoop.mapreduce.RecordReader<org.apache.hadoop.hbase.io.ImmutableBytesWritable,
org.apache.hadoop.hbase.client.Result> TableInputFormatBase.createRecordReader
(org.apache.hadoop.mapreduce.InputSplit split, org.apache.hadoop.mapreduce.TaskAttemptContext context) Builds aTableRecordReader
.org.apache.hadoop.mapreduce.RecordReader<org.apache.hadoop.hbase.io.ImmutableBytesWritable,
org.apache.hadoop.hbase.client.Result> TableSnapshotInputFormat.createRecordReader
(org.apache.hadoop.mapreduce.InputSplit split, org.apache.hadoop.mapreduce.TaskAttemptContext context) org.apache.hadoop.io.serializer.Deserializer<org.apache.hadoop.hbase.client.Result>
ResultSerialization.getDeserializer
(Class<org.apache.hadoop.hbase.client.Result> c) static <K2,
V2> Class<org.apache.hadoop.mapreduce.Mapper<org.apache.hadoop.hbase.io.ImmutableBytesWritable, org.apache.hadoop.hbase.client.Result, K2, V2>> MultithreadedTableMapper.getMapperClass
(org.apache.hadoop.mapreduce.JobContext job) Get the application's mapper class.org.apache.hadoop.io.serializer.Serializer<org.apache.hadoop.hbase.client.Result>
ResultSerialization.getSerializer
(Class<org.apache.hadoop.hbase.client.Result> c) Methods in org.apache.hadoop.hbase.mapreduce with parameters of type org.apache.hadoop.hbase.client.Result in inModifier and TypeMethodDescriptionprotected byte[][]
GroupingTableMapper.extractKeyValues
(org.apache.hadoop.hbase.client.Result r) Extract columns values from the current record.void
GroupingTableMapper.map
(org.apache.hadoop.hbase.io.ImmutableBytesWritable key, org.apache.hadoop.hbase.client.Result value, org.apache.hadoop.mapreduce.Mapper<org.apache.hadoop.hbase.io.ImmutableBytesWritable, org.apache.hadoop.hbase.client.Result, org.apache.hadoop.hbase.io.ImmutableBytesWritable, org.apache.hadoop.hbase.client.Result>.org.apache.hadoop.mapreduce.Mapper.Context context) Extract the grouping columns from value to construct a new key.protected void
HashTable.HashMapper.map
(org.apache.hadoop.hbase.io.ImmutableBytesWritable key, org.apache.hadoop.hbase.client.Result value, org.apache.hadoop.mapreduce.Mapper<org.apache.hadoop.hbase.io.ImmutableBytesWritable, org.apache.hadoop.hbase.client.Result, org.apache.hadoop.hbase.io.ImmutableBytesWritable, org.apache.hadoop.hbase.io.ImmutableBytesWritable>.org.apache.hadoop.mapreduce.Mapper.Context context) void
IdentityTableMapper.map
(org.apache.hadoop.hbase.io.ImmutableBytesWritable key, org.apache.hadoop.hbase.client.Result value, org.apache.hadoop.mapreduce.Mapper<org.apache.hadoop.hbase.io.ImmutableBytesWritable, org.apache.hadoop.hbase.client.Result, org.apache.hadoop.hbase.io.ImmutableBytesWritable, org.apache.hadoop.hbase.client.Result>.org.apache.hadoop.mapreduce.Mapper.Context context) Pass the key, value to reduce.void
Import.CellImporter.map
(org.apache.hadoop.hbase.io.ImmutableBytesWritable row, org.apache.hadoop.hbase.client.Result value, org.apache.hadoop.mapreduce.Mapper<org.apache.hadoop.hbase.io.ImmutableBytesWritable, org.apache.hadoop.hbase.client.Result, org.apache.hadoop.hbase.io.ImmutableBytesWritable, org.apache.hadoop.hbase.Cell>.org.apache.hadoop.mapreduce.Mapper.Context context) void
Import.CellSortImporter.map
(org.apache.hadoop.hbase.io.ImmutableBytesWritable row, org.apache.hadoop.hbase.client.Result value, org.apache.hadoop.mapreduce.Mapper<org.apache.hadoop.hbase.io.ImmutableBytesWritable, org.apache.hadoop.hbase.client.Result, org.apache.hadoop.hbase.mapreduce.Import.CellWritableComparable, org.apache.hadoop.hbase.Cell>.org.apache.hadoop.mapreduce.Mapper.Context context) void
Import.Importer.map
(org.apache.hadoop.hbase.io.ImmutableBytesWritable row, org.apache.hadoop.hbase.client.Result value, org.apache.hadoop.mapreduce.Mapper<org.apache.hadoop.hbase.io.ImmutableBytesWritable, org.apache.hadoop.hbase.client.Result, org.apache.hadoop.hbase.io.ImmutableBytesWritable, org.apache.hadoop.hbase.client.Mutation>.org.apache.hadoop.mapreduce.Mapper.Context context) void
Import.KeyValueImporter.map
(org.apache.hadoop.hbase.io.ImmutableBytesWritable row, org.apache.hadoop.hbase.client.Result value, org.apache.hadoop.mapreduce.Mapper<org.apache.hadoop.hbase.io.ImmutableBytesWritable, org.apache.hadoop.hbase.client.Result, org.apache.hadoop.hbase.io.ImmutableBytesWritable, org.apache.hadoop.hbase.KeyValue>.org.apache.hadoop.mapreduce.Mapper.Context context) Deprecated.void
Import.KeyValueSortImporter.map
(org.apache.hadoop.hbase.io.ImmutableBytesWritable row, org.apache.hadoop.hbase.client.Result value, org.apache.hadoop.mapreduce.Mapper<org.apache.hadoop.hbase.io.ImmutableBytesWritable, org.apache.hadoop.hbase.client.Result, org.apache.hadoop.hbase.mapreduce.Import.KeyValueWritableComparable, org.apache.hadoop.hbase.KeyValue>.org.apache.hadoop.mapreduce.Mapper.Context context) Deprecated.protected void
IndexBuilder.Map.map
(org.apache.hadoop.hbase.io.ImmutableBytesWritable rowKey, org.apache.hadoop.hbase.client.Result result, org.apache.hadoop.mapreduce.Mapper<org.apache.hadoop.hbase.io.ImmutableBytesWritable, org.apache.hadoop.hbase.client.Result, org.apache.hadoop.hbase.io.ImmutableBytesWritable, org.apache.hadoop.hbase.client.Put>.org.apache.hadoop.mapreduce.Mapper.Context context) protected void
SyncTable.SyncMapper.map
(org.apache.hadoop.hbase.io.ImmutableBytesWritable key, org.apache.hadoop.hbase.client.Result value, org.apache.hadoop.mapreduce.Mapper<org.apache.hadoop.hbase.io.ImmutableBytesWritable, org.apache.hadoop.hbase.client.Result, org.apache.hadoop.hbase.io.ImmutableBytesWritable, org.apache.hadoop.hbase.client.Mutation>.org.apache.hadoop.mapreduce.Mapper.Context context) protected void
Import.Importer.processKV
(org.apache.hadoop.hbase.io.ImmutableBytesWritable key, org.apache.hadoop.hbase.client.Result result, org.apache.hadoop.mapreduce.Mapper<org.apache.hadoop.hbase.io.ImmutableBytesWritable, org.apache.hadoop.hbase.client.Result, org.apache.hadoop.hbase.io.ImmutableBytesWritable, org.apache.hadoop.hbase.client.Mutation>.org.apache.hadoop.mapreduce.Mapper.Context context, org.apache.hadoop.hbase.client.Put put, org.apache.hadoop.hbase.client.Delete delete) Method parameters in org.apache.hadoop.hbase.mapreduce with type arguments of type org.apache.hadoop.hbase.client.Result in inModifier and TypeMethodDescriptionorg.apache.hadoop.io.serializer.Deserializer<org.apache.hadoop.hbase.client.Result>
ResultSerialization.getDeserializer
(Class<org.apache.hadoop.hbase.client.Result> c) org.apache.hadoop.io.serializer.Serializer<org.apache.hadoop.hbase.client.Result>
ResultSerialization.getSerializer
(Class<org.apache.hadoop.hbase.client.Result> c) static <K2,
V2> void MultithreadedTableMapper.setMapperClass
(org.apache.hadoop.mapreduce.Job job, Class<? extends org.apache.hadoop.mapreduce.Mapper<org.apache.hadoop.hbase.io.ImmutableBytesWritable, org.apache.hadoop.hbase.client.Result, K2, V2>> cls) Set the application's mapper class. -
Uses of org.apache.hadoop.hbase.client.Result in org.apache.hadoop.hbase.mob.mapreduce
Methods in org.apache.hadoop.hbase.mob.mapreduce with parameters of type org.apache.hadoop.hbase.client.Result in inModifier and TypeMethodDescriptionvoid
MobRefReporter.MobRefMapper.map
(org.apache.hadoop.hbase.io.ImmutableBytesWritable r, org.apache.hadoop.hbase.client.Result columns, org.apache.hadoop.mapreduce.Mapper<org.apache.hadoop.hbase.io.ImmutableBytesWritable, org.apache.hadoop.hbase.client.Result, org.apache.hadoop.io.Text, org.apache.hadoop.hbase.io.ImmutableBytesWritable>.org.apache.hadoop.mapreduce.Mapper.Context context) -
Uses of org.apache.hadoop.hbase.client.Result in org.apache.hadoop.hbase.quotas
Methods in org.apache.hadoop.hbase.quotas that return org.apache.hadoop.hbase.client.Result in inModifier and TypeMethodDescriptionprotected static org.apache.hadoop.hbase.client.Result[]
QuotaTableUtil.doGet
(org.apache.hadoop.hbase.client.Connection connection, List<org.apache.hadoop.hbase.client.Get> gets) protected static org.apache.hadoop.hbase.client.Result
QuotaTableUtil.doGet
(org.apache.hadoop.hbase.client.Connection connection, org.apache.hadoop.hbase.client.Get get) Methods in org.apache.hadoop.hbase.quotas with parameters of type org.apache.hadoop.hbase.client.Result in inModifier and TypeMethodDescriptionvoid
DefaultOperationQuota.addGetResult
(org.apache.hadoop.hbase.client.Result result) void
OperationQuota.addGetResult
(org.apache.hadoop.hbase.client.Result result) Add a get result.static long
QuotaUtil.calculateResultSize
(org.apache.hadoop.hbase.client.Result result) static void
QuotaTableUtil.extractQuotaSnapshot
(org.apache.hadoop.hbase.client.Result result, Map<org.apache.hadoop.hbase.TableName, org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot> snapshots) Extracts theSpaceViolationPolicy
andTableName
from the providedResult
and adds them to the givenMap
.protected static void
QuotaTableUtil.parseNamespaceResult
(String namespace, org.apache.hadoop.hbase.client.Result result, org.apache.hadoop.hbase.quotas.QuotaTableUtil.NamespaceQuotasVisitor visitor) static void
QuotaTableUtil.parseNamespaceResult
(org.apache.hadoop.hbase.client.Result result, org.apache.hadoop.hbase.quotas.QuotaTableUtil.NamespaceQuotasVisitor visitor) static void
QuotaTableUtil.parseResult
(org.apache.hadoop.hbase.client.Result result, org.apache.hadoop.hbase.quotas.QuotaTableUtil.QuotasVisitor visitor) static void
QuotaTableUtil.parseResultToCollection
(org.apache.hadoop.hbase.client.Result result, Collection<org.apache.hadoop.hbase.quotas.QuotaSettings> quotaSettings) static void
QuotaTableUtil.parseTableResult
(org.apache.hadoop.hbase.client.Result result, org.apache.hadoop.hbase.quotas.QuotaTableUtil.TableQuotasVisitor visitor) protected static void
QuotaTableUtil.parseTableResult
(org.apache.hadoop.hbase.TableName table, org.apache.hadoop.hbase.client.Result result, org.apache.hadoop.hbase.quotas.QuotaTableUtil.TableQuotasVisitor visitor) protected static void
QuotaTableUtil.parseUserResult
(String userName, org.apache.hadoop.hbase.client.Result result, org.apache.hadoop.hbase.quotas.QuotaTableUtil.UserQuotasVisitor visitor) static void
QuotaTableUtil.parseUserResult
(org.apache.hadoop.hbase.client.Result result, org.apache.hadoop.hbase.quotas.QuotaTableUtil.UserQuotasVisitor visitor) Method parameters in org.apache.hadoop.hbase.quotas with type arguments of type org.apache.hadoop.hbase.client.Result in inModifier and TypeMethodDescriptionvoid
DefaultOperationQuota.addScanResult
(List<org.apache.hadoop.hbase.client.Result> results) void
OperationQuota.addScanResult
(List<org.apache.hadoop.hbase.client.Result> results) Add a scan result.static long
QuotaUtil.calculateResultSize
(List<org.apache.hadoop.hbase.client.Result> results) -
Uses of org.apache.hadoop.hbase.client.Result in org.apache.hadoop.hbase.regionserver
Methods in org.apache.hadoop.hbase.regionserver that return org.apache.hadoop.hbase.client.Result in inModifier and TypeMethodDescriptionorg.apache.hadoop.hbase.client.Result
HRegion.append
(org.apache.hadoop.hbase.client.Append append) org.apache.hadoop.hbase.client.Result
HRegion.append
(org.apache.hadoop.hbase.client.Append append, long nonceGroup, long nonce) org.apache.hadoop.hbase.client.Result
Region.append
(org.apache.hadoop.hbase.client.Append append) Perform one or more append operations on a row.org.apache.hadoop.hbase.client.Result
HRegion.get
(org.apache.hadoop.hbase.client.Get get) org.apache.hadoop.hbase.client.Result
Region.get
(org.apache.hadoop.hbase.client.Get get) Do a get based on the get parameter.org.apache.hadoop.hbase.client.Result
OperationStatus.getResult()
org.apache.hadoop.hbase.client.Result
HRegion.increment
(org.apache.hadoop.hbase.client.Increment increment) org.apache.hadoop.hbase.client.Result
HRegion.increment
(org.apache.hadoop.hbase.client.Increment increment, long nonceGroup, long nonce) org.apache.hadoop.hbase.client.Result
Region.increment
(org.apache.hadoop.hbase.client.Increment increment) Perform one or more increment operations on a row.org.apache.hadoop.hbase.client.Result
HRegion.mutateRow
(org.apache.hadoop.hbase.client.RowMutations rm) org.apache.hadoop.hbase.client.Result
HRegion.mutateRow
(org.apache.hadoop.hbase.client.RowMutations rm, long nonceGroup, long nonce) org.apache.hadoop.hbase.client.Result
Region.mutateRow
(org.apache.hadoop.hbase.client.RowMutations mutations) Performs multiple mutations atomically on a single row.org.apache.hadoop.hbase.client.Result
RegionCoprocessorHost.postAppend
(org.apache.hadoop.hbase.client.Append append, org.apache.hadoop.hbase.client.Result result, org.apache.hadoop.hbase.wal.WALEdit edit) org.apache.hadoop.hbase.client.Result
RegionCoprocessorHost.postIncrement
(org.apache.hadoop.hbase.client.Increment increment, org.apache.hadoop.hbase.client.Result result, org.apache.hadoop.hbase.wal.WALEdit edit) org.apache.hadoop.hbase.client.Result
RegionCoprocessorHost.preAppend
(org.apache.hadoop.hbase.client.Append append, org.apache.hadoop.hbase.wal.WALEdit edit) Supports Coprocessor 'bypass'.org.apache.hadoop.hbase.client.Result
RegionCoprocessorHost.preAppendAfterRowLock
(org.apache.hadoop.hbase.client.Append append) Supports Coprocessor 'bypass'.org.apache.hadoop.hbase.client.Result
RegionCoprocessorHost.preIncrement
(org.apache.hadoop.hbase.client.Increment increment, org.apache.hadoop.hbase.wal.WALEdit edit) Supports Coprocessor 'bypass'.org.apache.hadoop.hbase.client.Result
RegionCoprocessorHost.preIncrementAfterRowLock
(org.apache.hadoop.hbase.client.Increment increment) Supports Coprocessor 'bypass'.Methods in org.apache.hadoop.hbase.regionserver with parameters of type org.apache.hadoop.hbase.client.Result in inModifier and TypeMethodDescriptionorg.apache.hadoop.hbase.client.Result
RegionCoprocessorHost.postAppend
(org.apache.hadoop.hbase.client.Append append, org.apache.hadoop.hbase.client.Result result, org.apache.hadoop.hbase.wal.WALEdit edit) org.apache.hadoop.hbase.client.Result
RegionCoprocessorHost.postIncrement
(org.apache.hadoop.hbase.client.Increment increment, org.apache.hadoop.hbase.client.Result result, org.apache.hadoop.hbase.wal.WALEdit edit) Method parameters in org.apache.hadoop.hbase.regionserver with type arguments of type org.apache.hadoop.hbase.client.Result in inModifier and TypeMethodDescriptionboolean
RegionCoprocessorHost.postScannerNext
(org.apache.hadoop.hbase.regionserver.InternalScanner s, List<org.apache.hadoop.hbase.client.Result> results, int limit, boolean hasMore) RegionCoprocessorHost.preScannerNext
(org.apache.hadoop.hbase.regionserver.InternalScanner s, List<org.apache.hadoop.hbase.client.Result> results, int limit) Constructors in org.apache.hadoop.hbase.regionserver with parameters of type org.apache.hadoop.hbase.client.Result in inModifierConstructorDescriptionOperationStatus
(org.apache.hadoop.hbase.HConstants.OperationStatusCode code, org.apache.hadoop.hbase.client.Result result) -
Uses of org.apache.hadoop.hbase.client.Result in org.apache.hadoop.hbase.shaded.protobuf
Methods in org.apache.hadoop.hbase.shaded.protobuf that return org.apache.hadoop.hbase.client.Result in inModifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.client.Result[]
ResponseConverter.getResults
(org.apache.hadoop.hbase.CellScanner cellScanner, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ScanResponse response) Create Results from the cells using the cells meta data.static org.apache.hadoop.hbase.client.Result
ProtobufUtil.toResult
(org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.Result proto) Convert a protocol buffer Result to a client Resultstatic org.apache.hadoop.hbase.client.Result
ProtobufUtil.toResult
(org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.Result proto, boolean decodeTags) Convert a protocol buffer Result to a client Resultstatic org.apache.hadoop.hbase.client.Result
ProtobufUtil.toResult
(org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.Result proto, org.apache.hadoop.hbase.CellScanner scanner) Convert a protocol buffer Result to a client ResultMethods in org.apache.hadoop.hbase.shaded.protobuf with parameters of type org.apache.hadoop.hbase.client.Result in inModifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.Result
ProtobufUtil.toResult
(org.apache.hadoop.hbase.client.Result result) Convert a client Result to a protocol buffer Resultstatic org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.Result
ProtobufUtil.toResult
(org.apache.hadoop.hbase.client.Result result, boolean encodeTags) Convert a client Result to a protocol buffer Resultstatic org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.Result
ProtobufUtil.toResultNoData
(org.apache.hadoop.hbase.client.Result result) Convert a client Result to a protocol buffer Result. -
Uses of org.apache.hadoop.hbase.client.Result in org.apache.hadoop.hbase.thrift
Methods in org.apache.hadoop.hbase.thrift with parameters of type org.apache.hadoop.hbase.client.Result in inModifier and TypeMethodDescriptionstatic List<org.apache.hadoop.hbase.thrift.generated.TRowResult>
ThriftUtilities.rowResultFromHBase
(org.apache.hadoop.hbase.client.Result in) static List<org.apache.hadoop.hbase.thrift.generated.TRowResult>
ThriftUtilities.rowResultFromHBase
(org.apache.hadoop.hbase.client.Result[] in) This utility method creates a list of Thrift TRowResult "struct" based on an array of Hbase RowResult objects.static List<org.apache.hadoop.hbase.thrift.generated.TRowResult>
ThriftUtilities.rowResultFromHBase
(org.apache.hadoop.hbase.client.Result[] in, boolean sortColumns) This utility method creates a list of Thrift TRowResult "struct" based on an Hbase RowResult object.