@InterfaceAudience.LimitedPrivate(value="Coprocesssor") @InterfaceStability.Stable public final class HTableWrapper extends Object implements Table
Modifier and Type | Method and Description |
---|---|
Result |
append(Append append) |
void |
batch(List<? extends Row> actions,
Object[] results) |
<R> void |
batchCallback(List<? extends Row> actions,
Object[] results,
Batch.Callback<R> callback) |
<R extends com.google.protobuf.Message> |
batchCoprocessorService(com.google.protobuf.Descriptors.MethodDescriptor methodDescriptor,
com.google.protobuf.Message request,
byte[] startKey,
byte[] endKey,
R responsePrototype) |
<R extends com.google.protobuf.Message> |
batchCoprocessorService(com.google.protobuf.Descriptors.MethodDescriptor methodDescriptor,
com.google.protobuf.Message request,
byte[] startKey,
byte[] endKey,
R responsePrototype,
Batch.Callback<R> callback) |
boolean |
checkAndDelete(byte[] row,
byte[] family,
byte[] qualifier,
byte[] value,
Delete delete) |
boolean |
checkAndDelete(byte[] row,
byte[] family,
byte[] qualifier,
CompareFilter.CompareOp compareOp,
byte[] value,
Delete delete) |
boolean |
checkAndDelete(byte[] row,
byte[] family,
byte[] qualifier,
CompareOperator op,
byte[] value,
Delete delete) |
boolean |
checkAndMutate(byte[] row,
byte[] family,
byte[] qualifier,
CompareFilter.CompareOp compareOp,
byte[] value,
RowMutations rm) |
boolean |
checkAndMutate(byte[] row,
byte[] family,
byte[] qualifier,
CompareOperator op,
byte[] value,
RowMutations rm) |
boolean |
checkAndPut(byte[] row,
byte[] family,
byte[] qualifier,
byte[] value,
Put put) |
boolean |
checkAndPut(byte[] row,
byte[] family,
byte[] qualifier,
CompareFilter.CompareOp compareOp,
byte[] value,
Put put) |
boolean |
checkAndPut(byte[] row,
byte[] family,
byte[] qualifier,
CompareOperator op,
byte[] value,
Put put) |
void |
close() |
CoprocessorRpcChannel |
coprocessorService(byte[] row) |
<T extends com.google.protobuf.Service,R> |
coprocessorService(Class<T> service,
byte[] startKey,
byte[] endKey,
Batch.Call<T,R> callable) |
<T extends com.google.protobuf.Service,R> |
coprocessorService(Class<T> service,
byte[] startKey,
byte[] endKey,
Batch.Call<T,R> callable,
Batch.Callback<R> callback) |
static Table |
createWrapper(List<Table> openTables,
TableName tableName,
CoprocessorHost.Environment env,
ExecutorService pool) |
void |
delete(Delete delete) |
void |
delete(List<Delete> deletes) |
boolean |
exists(Get get) |
Boolean[] |
exists(List<Get> gets)
Deprecated.
Use
existsAll(java.util.List) instead. since 2.0. remove in 3.0 |
boolean[] |
existsAll(List<Get> gets) |
Result |
get(Get get) |
Result[] |
get(List<Get> gets) |
org.apache.hadoop.conf.Configuration |
getConfiguration() |
TableDescriptor |
getDescriptor() |
TableName |
getName() |
int |
getOperationTimeout() |
int |
getReadRpcTimeout() |
int |
getRpcTimeout()
Deprecated.
|
ResultScanner |
getScanner(byte[] family) |
ResultScanner |
getScanner(byte[] family,
byte[] qualifier) |
ResultScanner |
getScanner(Scan scan) |
HTableDescriptor |
getTableDescriptor() |
int |
getWriteRpcTimeout() |
Result |
increment(Increment increment) |
long |
incrementColumnValue(byte[] row,
byte[] family,
byte[] qualifier,
long amount) |
long |
incrementColumnValue(byte[] row,
byte[] family,
byte[] qualifier,
long amount,
Durability durability) |
void |
internalClose() |
void |
mutateRow(RowMutations rm) |
void |
put(List<Put> puts) |
void |
put(Put put) |
void |
setOperationTimeout(int operationTimeout) |
void |
setReadRpcTimeout(int readRpcTimeout) |
void |
setRpcTimeout(int rpcTimeout)
Deprecated.
|
void |
setWriteRpcTimeout(int writeRpcTimeout) |
public static Table createWrapper(List<Table> openTables, TableName tableName, CoprocessorHost.Environment env, ExecutorService pool) throws IOException
openTables
- External list of tables used for tracking wrappers.IOException
public void internalClose() throws IOException
IOException
public org.apache.hadoop.conf.Configuration getConfiguration()
getConfiguration
in interface Table
public void close() throws IOException
close
in interface Closeable
close
in interface AutoCloseable
close
in interface Table
IOException
public Result get(Get get) throws IOException
get
in interface Table
IOException
public boolean exists(Get get) throws IOException
exists
in interface Table
IOException
public boolean[] existsAll(List<Get> gets) throws IOException
existsAll
in interface Table
IOException
@Deprecated public Boolean[] exists(List<Get> gets) throws IOException
existsAll(java.util.List)
instead. since 2.0. remove in 3.0IOException
public void put(Put put) throws IOException
put
in interface Table
IOException
public void put(List<Put> puts) throws IOException
put
in interface Table
IOException
public void delete(Delete delete) throws IOException
delete
in interface Table
IOException
public void delete(List<Delete> deletes) throws IOException
delete
in interface Table
IOException
public boolean checkAndPut(byte[] row, byte[] family, byte[] qualifier, byte[] value, Put put) throws IOException
checkAndPut
in interface Table
IOException
public boolean checkAndPut(byte[] row, byte[] family, byte[] qualifier, CompareFilter.CompareOp compareOp, byte[] value, Put put) throws IOException
checkAndPut
in interface Table
IOException
public boolean checkAndPut(byte[] row, byte[] family, byte[] qualifier, CompareOperator op, byte[] value, Put put) throws IOException
checkAndPut
in interface Table
IOException
public boolean checkAndDelete(byte[] row, byte[] family, byte[] qualifier, byte[] value, Delete delete) throws IOException
checkAndDelete
in interface Table
IOException
public boolean checkAndDelete(byte[] row, byte[] family, byte[] qualifier, CompareFilter.CompareOp compareOp, byte[] value, Delete delete) throws IOException
checkAndDelete
in interface Table
IOException
public boolean checkAndDelete(byte[] row, byte[] family, byte[] qualifier, CompareOperator op, byte[] value, Delete delete) throws IOException
checkAndDelete
in interface Table
IOException
public long incrementColumnValue(byte[] row, byte[] family, byte[] qualifier, long amount) throws IOException
incrementColumnValue
in interface Table
IOException
public long incrementColumnValue(byte[] row, byte[] family, byte[] qualifier, long amount, Durability durability) throws IOException
incrementColumnValue
in interface Table
IOException
public Result append(Append append) throws IOException
append
in interface Table
IOException
public Result increment(Increment increment) throws IOException
increment
in interface Table
IOException
public ResultScanner getScanner(Scan scan) throws IOException
getScanner
in interface Table
IOException
public ResultScanner getScanner(byte[] family) throws IOException
getScanner
in interface Table
IOException
public ResultScanner getScanner(byte[] family, byte[] qualifier) throws IOException
getScanner
in interface Table
IOException
public HTableDescriptor getTableDescriptor() throws IOException
getTableDescriptor
in interface Table
IOException
public TableDescriptor getDescriptor() throws IOException
getDescriptor
in interface Table
IOException
public void batch(List<? extends Row> actions, Object[] results) throws IOException, InterruptedException
batch
in interface Table
IOException
InterruptedException
public <R> void batchCallback(List<? extends Row> actions, Object[] results, Batch.Callback<R> callback) throws IOException, InterruptedException
batchCallback
in interface Table
IOException
InterruptedException
public Result[] get(List<Get> gets) throws IOException
get
in interface Table
IOException
public CoprocessorRpcChannel coprocessorService(byte[] row)
coprocessorService
in interface Table
public <T extends com.google.protobuf.Service,R> Map<byte[],R> coprocessorService(Class<T> service, byte[] startKey, byte[] endKey, Batch.Call<T,R> callable) throws com.google.protobuf.ServiceException, Throwable
coprocessorService
in interface Table
com.google.protobuf.ServiceException
Throwable
public <T extends com.google.protobuf.Service,R> void coprocessorService(Class<T> service, byte[] startKey, byte[] endKey, Batch.Call<T,R> callable, Batch.Callback<R> callback) throws com.google.protobuf.ServiceException, Throwable
coprocessorService
in interface Table
com.google.protobuf.ServiceException
Throwable
public void mutateRow(RowMutations rm) throws IOException
mutateRow
in interface Table
IOException
public <R extends com.google.protobuf.Message> Map<byte[],R> batchCoprocessorService(com.google.protobuf.Descriptors.MethodDescriptor methodDescriptor, com.google.protobuf.Message request, byte[] startKey, byte[] endKey, R responsePrototype) throws com.google.protobuf.ServiceException, Throwable
batchCoprocessorService
in interface Table
com.google.protobuf.ServiceException
Throwable
public <R extends com.google.protobuf.Message> void batchCoprocessorService(com.google.protobuf.Descriptors.MethodDescriptor methodDescriptor, com.google.protobuf.Message request, byte[] startKey, byte[] endKey, R responsePrototype, Batch.Callback<R> callback) throws com.google.protobuf.ServiceException, Throwable
batchCoprocessorService
in interface Table
com.google.protobuf.ServiceException
Throwable
public boolean checkAndMutate(byte[] row, byte[] family, byte[] qualifier, CompareFilter.CompareOp compareOp, byte[] value, RowMutations rm) throws IOException
checkAndMutate
in interface Table
IOException
public boolean checkAndMutate(byte[] row, byte[] family, byte[] qualifier, CompareOperator op, byte[] value, RowMutations rm) throws IOException
checkAndMutate
in interface Table
IOException
public void setOperationTimeout(int operationTimeout)
setOperationTimeout
in interface Table
public int getOperationTimeout()
getOperationTimeout
in interface Table
@Deprecated public void setRpcTimeout(int rpcTimeout)
setRpcTimeout
in interface Table
public void setWriteRpcTimeout(int writeRpcTimeout)
setWriteRpcTimeout
in interface Table
public void setReadRpcTimeout(int readRpcTimeout)
setReadRpcTimeout
in interface Table
@Deprecated public int getRpcTimeout()
getRpcTimeout
in interface Table
public int getWriteRpcTimeout()
getWriteRpcTimeout
in interface Table
public int getReadRpcTimeout()
getReadRpcTimeout
in interface Table
Copyright © 2007–2017 The Apache Software Foundation. All rights reserved.