@InterfaceAudience.Private public class RemoteHTable extends Object implements org.apache.hadoop.hbase.client.Table
Modifier and Type | Class and Description |
---|---|
private class |
RemoteHTable.CheckAndMutateBuilderImpl |
(package private) class |
RemoteHTable.Scanner |
Modifier and Type | Field and Description |
---|---|
(package private) org.apache.hadoop.hbase.rest.client.Client |
client |
(package private) org.apache.hadoop.conf.Configuration |
conf |
private static org.slf4j.Logger |
LOG |
(package private) int |
maxRetries |
(package private) byte[] |
name |
(package private) long |
sleepTime |
Constructor and Description |
---|
RemoteHTable(org.apache.hadoop.hbase.rest.client.Client client,
org.apache.hadoop.conf.Configuration conf,
byte[] name)
Constructor
|
RemoteHTable(org.apache.hadoop.hbase.rest.client.Client client,
org.apache.hadoop.conf.Configuration conf,
String name)
Constructor
|
RemoteHTable(org.apache.hadoop.hbase.rest.client.Client client,
String name)
Constructor
|
Modifier and Type | Method and Description |
---|---|
org.apache.hadoop.hbase.client.Result |
append(org.apache.hadoop.hbase.client.Append append) |
void |
batch(List<? extends org.apache.hadoop.hbase.client.Row> actions,
Object[] results) |
<R> void |
batchCallback(List<? extends org.apache.hadoop.hbase.client.Row> actions,
Object[] results,
org.apache.hadoop.hbase.client.coprocessor.Batch.Callback<R> callback) |
<R extends com.google.protobuf.Message> |
batchCoprocessorService(com.google.protobuf.Descriptors.MethodDescriptor method,
com.google.protobuf.Message request,
byte[] startKey,
byte[] endKey,
R responsePrototype) |
<R extends com.google.protobuf.Message> |
batchCoprocessorService(com.google.protobuf.Descriptors.MethodDescriptor method,
com.google.protobuf.Message request,
byte[] startKey,
byte[] endKey,
R responsePrototype,
org.apache.hadoop.hbase.client.coprocessor.Batch.Callback<R> callback) |
protected org.apache.hadoop.hbase.rest.model.CellSetModel |
buildModelFromPut(org.apache.hadoop.hbase.client.Put put) |
protected String |
buildMultiRowSpec(byte[][] rows,
int maxVersions) |
protected org.apache.hadoop.hbase.client.Result[] |
buildResultFromModel(org.apache.hadoop.hbase.rest.model.CellSetModel model) |
protected String |
buildRowSpec(byte[] row,
Map familyMap,
long startTime,
long endTime,
int maxVersions) |
boolean |
checkAndDelete(byte[] row,
byte[] family,
byte[] qualifier,
byte[] value,
org.apache.hadoop.hbase.client.Delete delete) |
boolean |
checkAndDelete(byte[] row,
byte[] family,
byte[] qualifier,
org.apache.hadoop.hbase.filter.CompareFilter.CompareOp compareOp,
byte[] value,
org.apache.hadoop.hbase.client.Delete delete)
Deprecated.
|
boolean |
checkAndDelete(byte[] row,
byte[] family,
byte[] qualifier,
org.apache.hadoop.hbase.CompareOperator compareOp,
byte[] value,
org.apache.hadoop.hbase.client.Delete delete)
Deprecated.
|
org.apache.hadoop.hbase.client.Table.CheckAndMutateBuilder |
checkAndMutate(byte[] row,
byte[] family) |
boolean |
checkAndMutate(byte[] row,
byte[] family,
byte[] qualifier,
org.apache.hadoop.hbase.filter.CompareFilter.CompareOp compareOp,
byte[] value,
org.apache.hadoop.hbase.client.RowMutations rm)
Deprecated.
|
boolean |
checkAndMutate(byte[] row,
byte[] family,
byte[] qualifier,
org.apache.hadoop.hbase.CompareOperator compareOp,
byte[] value,
org.apache.hadoop.hbase.client.RowMutations rm)
Deprecated.
|
org.apache.hadoop.hbase.client.Table.CheckAndMutateWithFilterBuilder |
checkAndMutate(byte[] row,
org.apache.hadoop.hbase.filter.Filter filter) |
org.apache.hadoop.hbase.client.CheckAndMutateResult |
checkAndMutate(org.apache.hadoop.hbase.client.CheckAndMutate checkAndMutate) |
List<org.apache.hadoop.hbase.client.CheckAndMutateResult> |
checkAndMutate(List<org.apache.hadoop.hbase.client.CheckAndMutate> checkAndMutates) |
boolean |
checkAndPut(byte[] row,
byte[] family,
byte[] qualifier,
byte[] value,
org.apache.hadoop.hbase.client.Put put)
Deprecated.
|
boolean |
checkAndPut(byte[] row,
byte[] family,
byte[] qualifier,
org.apache.hadoop.hbase.filter.CompareFilter.CompareOp compareOp,
byte[] value,
org.apache.hadoop.hbase.client.Put put)
Deprecated.
|
boolean |
checkAndPut(byte[] row,
byte[] family,
byte[] qualifier,
org.apache.hadoop.hbase.CompareOperator compareOp,
byte[] value,
org.apache.hadoop.hbase.client.Put put)
Deprecated.
|
void |
close() |
org.apache.hadoop.hbase.ipc.CoprocessorRpcChannel |
coprocessorService(byte[] row) |
<T extends com.google.protobuf.Service,R> |
coprocessorService(Class<T> service,
byte[] startKey,
byte[] endKey,
org.apache.hadoop.hbase.client.coprocessor.Batch.Call<T,R> callable) |
<T extends com.google.protobuf.Service,R> |
coprocessorService(Class<T> service,
byte[] startKey,
byte[] endKey,
org.apache.hadoop.hbase.client.coprocessor.Batch.Call<T,R> callable,
org.apache.hadoop.hbase.client.coprocessor.Batch.Callback<R> callback) |
void |
delete(org.apache.hadoop.hbase.client.Delete delete) |
void |
delete(List<org.apache.hadoop.hbase.client.Delete> deletes) |
private boolean |
doCheckAndDelete(byte[] row,
byte[] family,
byte[] qualifier,
byte[] value,
org.apache.hadoop.hbase.client.Delete delete) |
private boolean |
doCheckAndPut(byte[] row,
byte[] family,
byte[] qualifier,
byte[] value,
org.apache.hadoop.hbase.client.Put put) |
boolean |
exists(org.apache.hadoop.hbase.client.Get get) |
boolean[] |
exists(List<org.apache.hadoop.hbase.client.Get> gets) |
void |
flushCommits() |
org.apache.hadoop.hbase.client.Result |
get(org.apache.hadoop.hbase.client.Get get) |
org.apache.hadoop.hbase.client.Result[] |
get(List<org.apache.hadoop.hbase.client.Get> gets) |
org.apache.hadoop.conf.Configuration |
getConfiguration() |
org.apache.hadoop.hbase.client.TableDescriptor |
getDescriptor() |
org.apache.hadoop.hbase.TableName |
getName() |
int |
getOperationTimeout()
Deprecated.
|
long |
getOperationTimeout(TimeUnit unit) |
int |
getReadRpcTimeout()
Deprecated.
|
long |
getReadRpcTimeout(TimeUnit unit) |
org.apache.hadoop.hbase.client.RegionLocator |
getRegionLocator() |
private org.apache.hadoop.hbase.client.Result[] |
getResults(String spec) |
int |
getRpcTimeout()
Deprecated.
|
long |
getRpcTimeout(TimeUnit unit) |
org.apache.hadoop.hbase.client.ResultScanner |
getScanner(byte[] family) |
org.apache.hadoop.hbase.client.ResultScanner |
getScanner(byte[] family,
byte[] qualifier) |
org.apache.hadoop.hbase.client.ResultScanner |
getScanner(org.apache.hadoop.hbase.client.Scan scan) |
org.apache.hadoop.hbase.HTableDescriptor |
getTableDescriptor()
Deprecated.
|
byte[] |
getTableName() |
int |
getWriteRpcTimeout()
Deprecated.
|
long |
getWriteRpcTimeout(TimeUnit unit) |
org.apache.hadoop.hbase.client.Result |
increment(org.apache.hadoop.hbase.client.Increment increment) |
long |
incrementColumnValue(byte[] row,
byte[] family,
byte[] qualifier,
long amount) |
long |
incrementColumnValue(byte[] row,
byte[] family,
byte[] qualifier,
long amount,
org.apache.hadoop.hbase.client.Durability durability) |
boolean |
isAutoFlush() |
org.apache.hadoop.hbase.client.Result |
mutateRow(org.apache.hadoop.hbase.client.RowMutations rm) |
void |
put(List<org.apache.hadoop.hbase.client.Put> puts) |
void |
put(org.apache.hadoop.hbase.client.Put put) |
void |
setOperationTimeout(int operationTimeout)
Deprecated.
|
void |
setReadRpcTimeout(int readRpcTimeout)
Deprecated.
|
void |
setRpcTimeout(int rpcTimeout)
Deprecated.
|
void |
setWriteRpcTimeout(int writeRpcTimeout)
Deprecated.
|
private static String |
toURLEncodedBytes(byte[] row) |
private static final org.slf4j.Logger LOG
final org.apache.hadoop.hbase.rest.client.Client client
final org.apache.hadoop.conf.Configuration conf
final byte[] name
final int maxRetries
final long sleepTime
public RemoteHTable(org.apache.hadoop.hbase.rest.client.Client client, String name)
public RemoteHTable(org.apache.hadoop.hbase.rest.client.Client client, org.apache.hadoop.conf.Configuration conf, String name)
public RemoteHTable(org.apache.hadoop.hbase.rest.client.Client client, org.apache.hadoop.conf.Configuration conf, byte[] name)
protected String buildRowSpec(byte[] row, Map familyMap, long startTime, long endTime, int maxVersions)
protected String buildMultiRowSpec(byte[][] rows, int maxVersions)
protected org.apache.hadoop.hbase.client.Result[] buildResultFromModel(org.apache.hadoop.hbase.rest.model.CellSetModel model)
protected org.apache.hadoop.hbase.rest.model.CellSetModel buildModelFromPut(org.apache.hadoop.hbase.client.Put put)
public byte[] getTableName()
public org.apache.hadoop.hbase.TableName getName()
getName
in interface org.apache.hadoop.hbase.client.Table
public org.apache.hadoop.conf.Configuration getConfiguration()
getConfiguration
in interface org.apache.hadoop.hbase.client.Table
@Deprecated public org.apache.hadoop.hbase.HTableDescriptor getTableDescriptor() throws IOException
getTableDescriptor
in interface org.apache.hadoop.hbase.client.Table
IOException
public void close() throws IOException
close
in interface Closeable
close
in interface AutoCloseable
close
in interface org.apache.hadoop.hbase.client.Table
IOException
public org.apache.hadoop.hbase.client.Result get(org.apache.hadoop.hbase.client.Get get) throws IOException
get
in interface org.apache.hadoop.hbase.client.Table
IOException
public org.apache.hadoop.hbase.client.Result[] get(List<org.apache.hadoop.hbase.client.Get> gets) throws IOException
get
in interface org.apache.hadoop.hbase.client.Table
IOException
private org.apache.hadoop.hbase.client.Result[] getResults(String spec) throws IOException
IOException
public boolean exists(org.apache.hadoop.hbase.client.Get get) throws IOException
exists
in interface org.apache.hadoop.hbase.client.Table
IOException
public boolean[] exists(List<org.apache.hadoop.hbase.client.Get> gets) throws IOException
exists
in interface org.apache.hadoop.hbase.client.Table
IOException
public void put(org.apache.hadoop.hbase.client.Put put) throws IOException
put
in interface org.apache.hadoop.hbase.client.Table
IOException
public void put(List<org.apache.hadoop.hbase.client.Put> puts) throws IOException
put
in interface org.apache.hadoop.hbase.client.Table
IOException
public void delete(org.apache.hadoop.hbase.client.Delete delete) throws IOException
delete
in interface org.apache.hadoop.hbase.client.Table
IOException
public void delete(List<org.apache.hadoop.hbase.client.Delete> deletes) throws IOException
delete
in interface org.apache.hadoop.hbase.client.Table
IOException
public void flushCommits() throws IOException
IOException
public org.apache.hadoop.hbase.client.TableDescriptor getDescriptor() throws IOException
getDescriptor
in interface org.apache.hadoop.hbase.client.Table
IOException
public org.apache.hadoop.hbase.client.ResultScanner getScanner(org.apache.hadoop.hbase.client.Scan scan) throws IOException
getScanner
in interface org.apache.hadoop.hbase.client.Table
IOException
public org.apache.hadoop.hbase.client.ResultScanner getScanner(byte[] family) throws IOException
getScanner
in interface org.apache.hadoop.hbase.client.Table
IOException
public org.apache.hadoop.hbase.client.ResultScanner getScanner(byte[] family, byte[] qualifier) throws IOException
getScanner
in interface org.apache.hadoop.hbase.client.Table
IOException
public boolean isAutoFlush()
@Deprecated public boolean checkAndPut(byte[] row, byte[] family, byte[] qualifier, byte[] value, org.apache.hadoop.hbase.client.Put put) throws IOException
checkAndPut
in interface org.apache.hadoop.hbase.client.Table
IOException
private boolean doCheckAndPut(byte[] row, byte[] family, byte[] qualifier, byte[] value, org.apache.hadoop.hbase.client.Put put) throws IOException
IOException
@Deprecated public boolean checkAndPut(byte[] row, byte[] family, byte[] qualifier, org.apache.hadoop.hbase.filter.CompareFilter.CompareOp compareOp, byte[] value, org.apache.hadoop.hbase.client.Put put) throws IOException
checkAndPut
in interface org.apache.hadoop.hbase.client.Table
IOException
@Deprecated public boolean checkAndPut(byte[] row, byte[] family, byte[] qualifier, org.apache.hadoop.hbase.CompareOperator compareOp, byte[] value, org.apache.hadoop.hbase.client.Put put) throws IOException
checkAndPut
in interface org.apache.hadoop.hbase.client.Table
IOException
public boolean checkAndDelete(byte[] row, byte[] family, byte[] qualifier, byte[] value, org.apache.hadoop.hbase.client.Delete delete) throws IOException
checkAndDelete
in interface org.apache.hadoop.hbase.client.Table
IOException
private boolean doCheckAndDelete(byte[] row, byte[] family, byte[] qualifier, byte[] value, org.apache.hadoop.hbase.client.Delete delete) throws IOException
IOException
@Deprecated public boolean checkAndDelete(byte[] row, byte[] family, byte[] qualifier, org.apache.hadoop.hbase.filter.CompareFilter.CompareOp compareOp, byte[] value, org.apache.hadoop.hbase.client.Delete delete) throws IOException
checkAndDelete
in interface org.apache.hadoop.hbase.client.Table
IOException
@Deprecated public boolean checkAndDelete(byte[] row, byte[] family, byte[] qualifier, org.apache.hadoop.hbase.CompareOperator compareOp, byte[] value, org.apache.hadoop.hbase.client.Delete delete) throws IOException
checkAndDelete
in interface org.apache.hadoop.hbase.client.Table
IOException
public org.apache.hadoop.hbase.client.Table.CheckAndMutateBuilder checkAndMutate(byte[] row, byte[] family)
checkAndMutate
in interface org.apache.hadoop.hbase.client.Table
public org.apache.hadoop.hbase.client.Table.CheckAndMutateWithFilterBuilder checkAndMutate(byte[] row, org.apache.hadoop.hbase.filter.Filter filter)
checkAndMutate
in interface org.apache.hadoop.hbase.client.Table
@Deprecated public boolean checkAndMutate(byte[] row, byte[] family, byte[] qualifier, org.apache.hadoop.hbase.filter.CompareFilter.CompareOp compareOp, byte[] value, org.apache.hadoop.hbase.client.RowMutations rm) throws IOException
checkAndMutate
in interface org.apache.hadoop.hbase.client.Table
IOException
@Deprecated public boolean checkAndMutate(byte[] row, byte[] family, byte[] qualifier, org.apache.hadoop.hbase.CompareOperator compareOp, byte[] value, org.apache.hadoop.hbase.client.RowMutations rm) throws IOException
checkAndMutate
in interface org.apache.hadoop.hbase.client.Table
IOException
public org.apache.hadoop.hbase.client.CheckAndMutateResult checkAndMutate(org.apache.hadoop.hbase.client.CheckAndMutate checkAndMutate)
checkAndMutate
in interface org.apache.hadoop.hbase.client.Table
public List<org.apache.hadoop.hbase.client.CheckAndMutateResult> checkAndMutate(List<org.apache.hadoop.hbase.client.CheckAndMutate> checkAndMutates)
checkAndMutate
in interface org.apache.hadoop.hbase.client.Table
public org.apache.hadoop.hbase.client.Result increment(org.apache.hadoop.hbase.client.Increment increment) throws IOException
increment
in interface org.apache.hadoop.hbase.client.Table
IOException
public org.apache.hadoop.hbase.client.Result append(org.apache.hadoop.hbase.client.Append append) throws IOException
append
in interface org.apache.hadoop.hbase.client.Table
IOException
public long incrementColumnValue(byte[] row, byte[] family, byte[] qualifier, long amount) throws IOException
incrementColumnValue
in interface org.apache.hadoop.hbase.client.Table
IOException
public long incrementColumnValue(byte[] row, byte[] family, byte[] qualifier, long amount, org.apache.hadoop.hbase.client.Durability durability) throws IOException
incrementColumnValue
in interface org.apache.hadoop.hbase.client.Table
IOException
public void batch(List<? extends org.apache.hadoop.hbase.client.Row> actions, Object[] results) throws IOException
batch
in interface org.apache.hadoop.hbase.client.Table
IOException
public <R> void batchCallback(List<? extends org.apache.hadoop.hbase.client.Row> actions, Object[] results, org.apache.hadoop.hbase.client.coprocessor.Batch.Callback<R> callback) throws IOException, InterruptedException
batchCallback
in interface org.apache.hadoop.hbase.client.Table
IOException
InterruptedException
public org.apache.hadoop.hbase.ipc.CoprocessorRpcChannel coprocessorService(byte[] row)
coprocessorService
in interface org.apache.hadoop.hbase.client.Table
public <T extends com.google.protobuf.Service,R> Map<byte[],R> coprocessorService(Class<T> service, byte[] startKey, byte[] endKey, org.apache.hadoop.hbase.client.coprocessor.Batch.Call<T,R> callable) throws com.google.protobuf.ServiceException, Throwable
coprocessorService
in interface org.apache.hadoop.hbase.client.Table
com.google.protobuf.ServiceException
Throwable
public <T extends com.google.protobuf.Service,R> void coprocessorService(Class<T> service, byte[] startKey, byte[] endKey, org.apache.hadoop.hbase.client.coprocessor.Batch.Call<T,R> callable, org.apache.hadoop.hbase.client.coprocessor.Batch.Callback<R> callback) throws com.google.protobuf.ServiceException, Throwable
coprocessorService
in interface org.apache.hadoop.hbase.client.Table
com.google.protobuf.ServiceException
Throwable
public org.apache.hadoop.hbase.client.Result mutateRow(org.apache.hadoop.hbase.client.RowMutations rm) throws IOException
mutateRow
in interface org.apache.hadoop.hbase.client.Table
IOException
public <R extends com.google.protobuf.Message> Map<byte[],R> batchCoprocessorService(com.google.protobuf.Descriptors.MethodDescriptor method, com.google.protobuf.Message request, byte[] startKey, byte[] endKey, R responsePrototype) throws com.google.protobuf.ServiceException, Throwable
batchCoprocessorService
in interface org.apache.hadoop.hbase.client.Table
com.google.protobuf.ServiceException
Throwable
public <R extends com.google.protobuf.Message> void batchCoprocessorService(com.google.protobuf.Descriptors.MethodDescriptor method, com.google.protobuf.Message request, byte[] startKey, byte[] endKey, R responsePrototype, org.apache.hadoop.hbase.client.coprocessor.Batch.Callback<R> callback) throws com.google.protobuf.ServiceException, Throwable
batchCoprocessorService
in interface org.apache.hadoop.hbase.client.Table
com.google.protobuf.ServiceException
Throwable
@Deprecated public void setOperationTimeout(int operationTimeout)
setOperationTimeout
in interface org.apache.hadoop.hbase.client.Table
@Deprecated public int getOperationTimeout()
getOperationTimeout
in interface org.apache.hadoop.hbase.client.Table
@Deprecated public void setRpcTimeout(int rpcTimeout)
setRpcTimeout
in interface org.apache.hadoop.hbase.client.Table
public long getReadRpcTimeout(TimeUnit unit)
getReadRpcTimeout
in interface org.apache.hadoop.hbase.client.Table
@Deprecated public int getRpcTimeout()
getRpcTimeout
in interface org.apache.hadoop.hbase.client.Table
public long getRpcTimeout(TimeUnit unit)
getRpcTimeout
in interface org.apache.hadoop.hbase.client.Table
@Deprecated public int getReadRpcTimeout()
getReadRpcTimeout
in interface org.apache.hadoop.hbase.client.Table
@Deprecated public void setReadRpcTimeout(int readRpcTimeout)
setReadRpcTimeout
in interface org.apache.hadoop.hbase.client.Table
public long getWriteRpcTimeout(TimeUnit unit)
getWriteRpcTimeout
in interface org.apache.hadoop.hbase.client.Table
@Deprecated public int getWriteRpcTimeout()
getWriteRpcTimeout
in interface org.apache.hadoop.hbase.client.Table
@Deprecated public void setWriteRpcTimeout(int writeRpcTimeout)
setWriteRpcTimeout
in interface org.apache.hadoop.hbase.client.Table
public long getOperationTimeout(TimeUnit unit)
getOperationTimeout
in interface org.apache.hadoop.hbase.client.Table
private static String toURLEncodedBytes(byte[] row)
public org.apache.hadoop.hbase.client.RegionLocator getRegionLocator() throws IOException
getRegionLocator
in interface org.apache.hadoop.hbase.client.Table
IOException
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.