Package | Description |
---|---|
org.apache.hadoop.hbase.thrift |
Provides an HBase Thrift
service.
|
org.apache.hadoop.hbase.thrift.generated |
Modifier and Type | Method and Description |
---|---|
boolean |
ThriftServerRunner.HBaseHandler.checkAndPut(ByteBuffer tableName,
ByteBuffer row,
ByteBuffer column,
ByteBuffer value,
Mutation mput,
Map<ByteBuffer,ByteBuffer> attributes) |
Modifier and Type | Method and Description |
---|---|
void |
ThriftServerRunner.HBaseHandler.mutateRow(ByteBuffer tableName,
ByteBuffer row,
List<Mutation> mutations,
Map<ByteBuffer,ByteBuffer> attributes) |
void |
ThriftServerRunner.HBaseHandler.mutateRowTs(ByteBuffer tableName,
ByteBuffer row,
List<Mutation> mutations,
long timestamp,
Map<ByteBuffer,ByteBuffer> attributes) |
Modifier and Type | Field and Description |
---|---|
Mutation |
Hbase.checkAndPut_args.mput
mutation for the put
|
Modifier and Type | Field and Description |
---|---|
List<Mutation> |
Hbase.mutateRow_args.mutations
list of mutation commands
|
List<Mutation> |
Hbase.mutateRowTs_args.mutations
list of mutation commands
|
List<Mutation> |
BatchMutation.mutations |
Modifier and Type | Method and Description |
---|---|
Mutation |
Mutation.deepCopy() |
Mutation |
Hbase.checkAndPut_args.getMput()
mutation for the put
|
Mutation |
Mutation.setColumn(byte[] column) |
Mutation |
Mutation.setColumn(ByteBuffer column) |
Mutation |
Mutation.setIsDelete(boolean isDelete) |
Mutation |
Mutation.setValue(byte[] value) |
Mutation |
Mutation.setValue(ByteBuffer value) |
Mutation |
Mutation.setWriteToWAL(boolean writeToWAL) |
Modifier and Type | Method and Description |
---|---|
List<Mutation> |
Hbase.mutateRow_args.getMutations()
list of mutation commands
|
List<Mutation> |
Hbase.mutateRowTs_args.getMutations()
list of mutation commands
|
List<Mutation> |
BatchMutation.getMutations() |
Iterator<Mutation> |
Hbase.mutateRow_args.getMutationsIterator() |
Iterator<Mutation> |
Hbase.mutateRowTs_args.getMutationsIterator() |
Iterator<Mutation> |
BatchMutation.getMutationsIterator() |
Modifier and Type | Method and Description |
---|---|
void |
Hbase.mutateRow_args.addToMutations(Mutation elem) |
void |
Hbase.mutateRowTs_args.addToMutations(Mutation elem) |
void |
BatchMutation.addToMutations(Mutation elem) |
boolean |
Hbase.Iface.checkAndPut(ByteBuffer tableName,
ByteBuffer row,
ByteBuffer column,
ByteBuffer value,
Mutation mput,
Map<ByteBuffer,ByteBuffer> attributes)
Atomically checks if a row/family/qualifier value matches the expected
value.
|
boolean |
Hbase.Client.checkAndPut(ByteBuffer tableName,
ByteBuffer row,
ByteBuffer column,
ByteBuffer value,
Mutation mput,
Map<ByteBuffer,ByteBuffer> attributes) |
void |
Hbase.AsyncIface.checkAndPut(ByteBuffer tableName,
ByteBuffer row,
ByteBuffer column,
ByteBuffer value,
Mutation mput,
Map<ByteBuffer,ByteBuffer> attributes,
org.apache.thrift.async.AsyncMethodCallback<Hbase.AsyncClient.checkAndPut_call> resultHandler) |
void |
Hbase.AsyncClient.checkAndPut(ByteBuffer tableName,
ByteBuffer row,
ByteBuffer column,
ByteBuffer value,
Mutation mput,
Map<ByteBuffer,ByteBuffer> attributes,
org.apache.thrift.async.AsyncMethodCallback<Hbase.AsyncClient.checkAndPut_call> resultHandler) |
int |
Mutation.compareTo(Mutation other) |
boolean |
Mutation.equals(Mutation that) |
void |
Hbase.Client.send_checkAndPut(ByteBuffer tableName,
ByteBuffer row,
ByteBuffer column,
ByteBuffer value,
Mutation mput,
Map<ByteBuffer,ByteBuffer> attributes) |
Hbase.checkAndPut_args |
Hbase.checkAndPut_args.setMput(Mutation mput)
mutation for the put
|
Modifier and Type | Method and Description |
---|---|
void |
Hbase.Iface.mutateRow(ByteBuffer tableName,
ByteBuffer row,
List<Mutation> mutations,
Map<ByteBuffer,ByteBuffer> attributes)
Apply a series of mutations (updates/deletes) to a row in a
single transaction.
|
void |
Hbase.Client.mutateRow(ByteBuffer tableName,
ByteBuffer row,
List<Mutation> mutations,
Map<ByteBuffer,ByteBuffer> attributes) |
void |
Hbase.AsyncIface.mutateRow(ByteBuffer tableName,
ByteBuffer row,
List<Mutation> mutations,
Map<ByteBuffer,ByteBuffer> attributes,
org.apache.thrift.async.AsyncMethodCallback<Hbase.AsyncClient.mutateRow_call> resultHandler) |
void |
Hbase.AsyncClient.mutateRow(ByteBuffer tableName,
ByteBuffer row,
List<Mutation> mutations,
Map<ByteBuffer,ByteBuffer> attributes,
org.apache.thrift.async.AsyncMethodCallback<Hbase.AsyncClient.mutateRow_call> resultHandler) |
void |
Hbase.Iface.mutateRowTs(ByteBuffer tableName,
ByteBuffer row,
List<Mutation> mutations,
long timestamp,
Map<ByteBuffer,ByteBuffer> attributes)
Apply a series of mutations (updates/deletes) to a row in a
single transaction.
|
void |
Hbase.Client.mutateRowTs(ByteBuffer tableName,
ByteBuffer row,
List<Mutation> mutations,
long timestamp,
Map<ByteBuffer,ByteBuffer> attributes) |
void |
Hbase.AsyncIface.mutateRowTs(ByteBuffer tableName,
ByteBuffer row,
List<Mutation> mutations,
long timestamp,
Map<ByteBuffer,ByteBuffer> attributes,
org.apache.thrift.async.AsyncMethodCallback<Hbase.AsyncClient.mutateRowTs_call> resultHandler) |
void |
Hbase.AsyncClient.mutateRowTs(ByteBuffer tableName,
ByteBuffer row,
List<Mutation> mutations,
long timestamp,
Map<ByteBuffer,ByteBuffer> attributes,
org.apache.thrift.async.AsyncMethodCallback<Hbase.AsyncClient.mutateRowTs_call> resultHandler) |
void |
Hbase.Client.send_mutateRow(ByteBuffer tableName,
ByteBuffer row,
List<Mutation> mutations,
Map<ByteBuffer,ByteBuffer> attributes) |
void |
Hbase.Client.send_mutateRowTs(ByteBuffer tableName,
ByteBuffer row,
List<Mutation> mutations,
long timestamp,
Map<ByteBuffer,ByteBuffer> attributes) |
Hbase.mutateRow_args |
Hbase.mutateRow_args.setMutations(List<Mutation> mutations)
list of mutation commands
|
Hbase.mutateRowTs_args |
Hbase.mutateRowTs_args.setMutations(List<Mutation> mutations)
list of mutation commands
|
BatchMutation |
BatchMutation.setMutations(List<Mutation> mutations) |
Constructor and Description |
---|
Hbase.AsyncClient.checkAndPut_call(ByteBuffer tableName,
ByteBuffer row,
ByteBuffer column,
ByteBuffer value,
Mutation mput,
Map<ByteBuffer,ByteBuffer> attributes,
org.apache.thrift.async.AsyncMethodCallback<Hbase.AsyncClient.checkAndPut_call> resultHandler,
org.apache.thrift.async.TAsyncClient client,
org.apache.thrift.protocol.TProtocolFactory protocolFactory,
org.apache.thrift.transport.TNonblockingTransport transport) |
Hbase.checkAndPut_args(ByteBuffer tableName,
ByteBuffer row,
ByteBuffer column,
ByteBuffer value,
Mutation mput,
Map<ByteBuffer,ByteBuffer> attributes) |
Mutation(Mutation other)
Performs a deep copy on other.
|
Constructor and Description |
---|
BatchMutation(ByteBuffer row,
List<Mutation> mutations) |
Hbase.AsyncClient.mutateRow_call(ByteBuffer tableName,
ByteBuffer row,
List<Mutation> mutations,
Map<ByteBuffer,ByteBuffer> attributes,
org.apache.thrift.async.AsyncMethodCallback<Hbase.AsyncClient.mutateRow_call> resultHandler,
org.apache.thrift.async.TAsyncClient client,
org.apache.thrift.protocol.TProtocolFactory protocolFactory,
org.apache.thrift.transport.TNonblockingTransport transport) |
Hbase.AsyncClient.mutateRowTs_call(ByteBuffer tableName,
ByteBuffer row,
List<Mutation> mutations,
long timestamp,
Map<ByteBuffer,ByteBuffer> attributes,
org.apache.thrift.async.AsyncMethodCallback<Hbase.AsyncClient.mutateRowTs_call> resultHandler,
org.apache.thrift.async.TAsyncClient client,
org.apache.thrift.protocol.TProtocolFactory protocolFactory,
org.apache.thrift.transport.TNonblockingTransport transport) |
Hbase.mutateRow_args(ByteBuffer tableName,
ByteBuffer row,
List<Mutation> mutations,
Map<ByteBuffer,ByteBuffer> attributes) |
Hbase.mutateRowTs_args(ByteBuffer tableName,
ByteBuffer row,
List<Mutation> mutations,
long timestamp,
Map<ByteBuffer,ByteBuffer> attributes) |
Copyright © 2007-2016 The Apache Software Foundation. All Rights Reserved.