Package | Description |
---|---|
org.apache.hadoop.hbase | |
org.apache.hadoop.hbase.client |
Provides HBase Client
|
org.apache.hadoop.hbase.codec | |
org.apache.hadoop.hbase.codec.prefixtree.decode | |
org.apache.hadoop.hbase.codec.prefixtree.scanner | |
org.apache.hadoop.hbase.coprocessor |
Table of Contents
|
org.apache.hadoop.hbase.io | |
org.apache.hadoop.hbase.ipc |
Tools to help define network clients and servers.
|
org.apache.hadoop.hbase.protobuf |
Holds classes generated from protobuf
src/main/protobuf definition files. |
org.apache.hadoop.hbase.regionserver | |
org.apache.hadoop.hbase.replication.regionserver | |
org.apache.hadoop.hbase.security.access | |
org.apache.hadoop.hbase.wal |
Modifier and Type | Method and Description |
---|---|
CellScanner |
CellScannable.cellScanner() |
static CellScanner |
CellUtil.createCellScanner(Cell[] cellArray) |
static CellScanner |
CellUtil.createCellScanner(Iterable<Cell> cellIterable) |
static CellScanner |
CellUtil.createCellScanner(Iterator<Cell> cells) |
static CellScanner |
CellUtil.createCellScanner(List<? extends CellScannable> cellScannerables) |
static CellScanner |
CellUtil.createCellScanner(NavigableMap<byte[],List<Cell>> map)
Flatten the map of cells out under the CellScanner
|
Modifier and Type | Class and Description |
---|---|
class |
Result
|
Modifier and Type | Method and Description |
---|---|
CellScanner |
Result.cellScanner() |
CellScanner |
Mutation.cellScanner() |
Modifier and Type | Interface and Description |
---|---|
static interface |
Codec.Decoder
Implementations should implicitly clean up any resources allocated when the
Decoder/CellScanner runs off the end of the cell block.
|
Modifier and Type | Class and Description |
---|---|
class |
BaseDecoder
TODO javadoc
|
static class |
KeyValueCodec.KeyValueDecoder |
static class |
KeyValueCodecWithTags.KeyValueDecoder |
Modifier and Type | Class and Description |
---|---|
class |
PrefixTreeArrayReversibleScanner
Methods for going backwards through a PrefixTree block.
|
class |
PrefixTreeArrayScanner
Extends PtCell and manipulates its protected fields.
|
class |
PrefixTreeArraySearcher
Searcher extends the capabilities of the Scanner + ReversibleScanner to add the ability to
position itself on a requested Cell without scanning through cells before it.
|
Modifier and Type | Interface and Description |
---|---|
interface |
CellSearcher
Methods for seeking to a random
Cell inside a sorted collection of cells. |
interface |
ReversibleCellScanner
An extension of CellScanner indicating the scanner supports iterating backwards through cells.
|
Modifier and Type | Method and Description |
---|---|
void |
RegionServerObserver.postReplicateLogEntries(ObserverContext<RegionServerCoprocessorEnvironment> ctx,
List<AdminProtos.WALEntry> entries,
CellScanner cells)
This will be called after executing replication request to shipping log entries.
|
void |
BaseRegionServerObserver.postReplicateLogEntries(ObserverContext<RegionServerCoprocessorEnvironment> ctx,
List<AdminProtos.WALEntry> entries,
CellScanner cells) |
void |
RegionServerObserver.preReplicateLogEntries(ObserverContext<RegionServerCoprocessorEnvironment> ctx,
List<AdminProtos.WALEntry> entries,
CellScanner cells)
This will be called before executing replication request to shipping log entries.
|
void |
BaseRegionServerObserver.preReplicateLogEntries(ObserverContext<RegionServerCoprocessorEnvironment> ctx,
List<AdminProtos.WALEntry> entries,
CellScanner cells) |
Modifier and Type | Interface and Description |
---|---|
interface |
SizedCellScanner
A CellScanner that knows its size in memory in bytes.
|
Modifier and Type | Field and Description |
---|---|
protected CellScanner |
RpcServer.Call.cellScanner |
Modifier and Type | Method and Description |
---|---|
CellScanner |
PayloadCarryingRpcController.cellScanner() |
CellScanner |
DelegatingPayloadCarryingRpcController.cellScanner() |
CellScanner |
AsyncRpcClient.createCellScanner(byte[] cellBlock)
Create a cell scanner
|
CellScanner |
IPCUtil.createCellScanner(Codec codec,
org.apache.hadoop.io.compress.CompressionCodec compressor,
byte[] cellBlock) |
CellScanner |
IPCUtil.createCellScanner(Codec codec,
org.apache.hadoop.io.compress.CompressionCodec compressor,
byte[] cellBlock,
int offset,
int length) |
Modifier and Type | Method and Description |
---|---|
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.
|
protected Pair<com.google.protobuf.Message,CellScanner> |
RpcClientImpl.call(PayloadCarryingRpcController pcrc,
com.google.protobuf.Descriptors.MethodDescriptor md,
com.google.protobuf.Message param,
com.google.protobuf.Message returnType,
User ticket,
InetSocketAddress addr)
Make a call, passing
param , to the IPC server running at
address which is servicing the protocol protocol,
with the ticket credentials, returning the value. |
protected Pair<com.google.protobuf.Message,CellScanner> |
AsyncRpcClient.call(PayloadCarryingRpcController pcrc,
com.google.protobuf.Descriptors.MethodDescriptor md,
com.google.protobuf.Message param,
com.google.protobuf.Message returnType,
User ticket,
InetSocketAddress addr)
Make a call, passing
param , to the IPC server running at
address which is servicing the protocol protocol,
with the ticket credentials, returning the value. |
protected abstract Pair<com.google.protobuf.Message,CellScanner> |
AbstractRpcClient.call(PayloadCarryingRpcController pcrc,
com.google.protobuf.Descriptors.MethodDescriptor md,
com.google.protobuf.Message param,
com.google.protobuf.Message returnType,
User ticket,
InetSocketAddress isa)
Make a call, passing
param , to the IPC server running at
address which is servicing the protocol protocol,
with the ticket credentials, returning the value. |
Modifier and Type | Method and Description |
---|---|
ByteBuffer |
AsyncRpcClient.buildCellBlock(CellScanner cells)
Build cell block
|
ByteBuffer |
IPCUtil.buildCellBlock(Codec codec,
org.apache.hadoop.io.compress.CompressionCodec compressor,
CellScanner cellScanner)
Puts CellScanner Cells into a cell block using passed in
codec and/or
compressor . |
ByteBuffer |
IPCUtil.buildCellBlock(Codec codec,
org.apache.hadoop.io.compress.CompressionCodec compressor,
CellScanner cellScanner,
BoundedByteBufferPool pool)
Puts CellScanner Cells into a cell block using passed in
codec and/or
compressor . |
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.
|
PayloadCarryingRpcController |
RpcControllerFactory.newController(CellScanner cellScanner) |
void |
PayloadCarryingRpcController.setCellScanner(CellScanner cellScanner) |
void |
DelegatingPayloadCarryingRpcController.setCellScanner(CellScanner cellScanner) |
void |
Call.setResponse(com.google.protobuf.Message response,
CellScanner cells)
Set the return value when there is no error.
|
protected void |
RpcServer.Call.setResponse(Object m,
CellScanner cells,
Throwable t,
String errorMsg) |
void |
AsyncCall.setSuccess(com.google.protobuf.Message value,
CellScanner cellBlockScanner)
Set success with a cellBlockScanner
|
Constructor and Description |
---|
Call(int id,
com.google.protobuf.Descriptors.MethodDescriptor md,
com.google.protobuf.Message param,
CellScanner cells,
com.google.protobuf.Message responseDefaultType,
int timeout) |
PayloadCarryingRpcController(CellScanner cellScanner) |
Modifier and Type | Method and Description |
---|---|
static Pair<AdminProtos.ReplicateWALEntryRequest,CellScanner> |
ReplicationProtbufUtil.buildReplicateWALEntryRequest(WAL.Entry[] entries)
Create a new ReplicateWALEntryRequest from a list of WAL entries
|
static Pair<AdminProtos.ReplicateWALEntryRequest,CellScanner> |
ReplicationProtbufUtil.buildReplicateWALEntryRequest(WAL.Entry[] entries,
byte[] encodedRegionName)
Create a new ReplicateWALEntryRequest from a list of HLog entries
|
Modifier and Type | Method and Description |
---|---|
static Result[] |
ResponseConverter.getResults(CellScanner cellScanner,
ClientProtos.ScanResponse response)
Create Results from the cells using the cells meta data.
|
static MultiResponse |
ResponseConverter.getResults(ClientProtos.MultiRequest request,
ClientProtos.MultiResponse response,
CellScanner cells)
Get the results from a protocol buffer MultiResponse
|
static Append |
ProtobufUtil.toAppend(ClientProtos.MutationProto proto,
CellScanner cellScanner)
Convert a protocol buffer Mutate to an Append
|
static Delete |
ProtobufUtil.toDelete(ClientProtos.MutationProto proto,
CellScanner cellScanner)
Convert a protocol buffer Mutate to a Delete
|
static Increment |
ProtobufUtil.toIncrement(ClientProtos.MutationProto proto,
CellScanner cellScanner)
Convert a protocol buffer Mutate to an Increment
|
static Put |
ProtobufUtil.toPut(ClientProtos.MutationProto proto,
CellScanner cellScanner)
Convert a protocol buffer Mutate to a Put.
|
static Result |
ProtobufUtil.toResult(ClientProtos.Result proto,
CellScanner scanner)
Convert a protocol buffer Result to a client Result
|
Modifier and Type | Method and Description |
---|---|
void |
RegionServerCoprocessorHost.postReplicateLogEntries(List<AdminProtos.WALEntry> entries,
CellScanner cells) |
void |
RegionServerCoprocessorHost.preReplicateLogEntries(List<AdminProtos.WALEntry> entries,
CellScanner cells) |
void |
ReplicationSinkService.replicateLogEntries(List<AdminProtos.WALEntry> entries,
CellScanner cells)
Carry on the list of log entries down to the sink
|
Modifier and Type | Method and Description |
---|---|
void |
ReplicationSink.replicateEntries(List<AdminProtos.WALEntry> entries,
CellScanner cells)
Replicate this array of entries directly into the local cluster using the native client.
|
void |
Replication.replicateLogEntries(List<AdminProtos.WALEntry> entries,
CellScanner cells)
Carry on the list of log entries down to the sink
|
Modifier and Type | Method and Description |
---|---|
void |
AccessController.postReplicateLogEntries(ObserverContext<RegionServerCoprocessorEnvironment> ctx,
List<AdminProtos.WALEntry> entries,
CellScanner cells) |
void |
AccessController.preReplicateLogEntries(ObserverContext<RegionServerCoprocessorEnvironment> ctx,
List<AdminProtos.WALEntry> entries,
CellScanner cells) |
Modifier and Type | Method and Description |
---|---|
static List<WALSplitter.MutationReplay> |
WALSplitter.getMutationsFromWALEntry(AdminProtos.WALEntry entry,
CellScanner cells,
Pair<WALKey,WALEdit> logEntry,
Durability durability)
This function is used to construct mutations from a WALEntry.
|
Copyright © 2007-2016 The Apache Software Foundation. All Rights Reserved.