Package | Description |
---|---|
org.apache.hadoop.hbase.thrift |
Provides an HBase Thrift
service.
|
org.apache.hadoop.hbase.thrift.generated |
Modifier and Type | Method and Description |
---|---|
void |
ThriftServerRunner.HBaseHandler.mutateRows(ByteBuffer tableName,
List<BatchMutation> rowBatches,
Map<ByteBuffer,ByteBuffer> attributes) |
void |
ThriftServerRunner.HBaseHandler.mutateRowsTs(ByteBuffer tableName,
List<BatchMutation> rowBatches,
long timestamp,
Map<ByteBuffer,ByteBuffer> attributes) |
Modifier and Type | Field and Description |
---|---|
List<BatchMutation> |
Hbase.mutateRows_args.rowBatches
list of row batches
|
List<BatchMutation> |
Hbase.mutateRowsTs_args.rowBatches
list of row batches
|
Modifier and Type | Method and Description |
---|---|
BatchMutation |
BatchMutation.deepCopy() |
BatchMutation |
BatchMutation.setMutations(List<Mutation> mutations) |
BatchMutation |
BatchMutation.setRow(byte[] row) |
BatchMutation |
BatchMutation.setRow(ByteBuffer row) |
Modifier and Type | Method and Description |
---|---|
List<BatchMutation> |
Hbase.mutateRows_args.getRowBatches()
list of row batches
|
List<BatchMutation> |
Hbase.mutateRowsTs_args.getRowBatches()
list of row batches
|
Iterator<BatchMutation> |
Hbase.mutateRows_args.getRowBatchesIterator() |
Iterator<BatchMutation> |
Hbase.mutateRowsTs_args.getRowBatchesIterator() |
Modifier and Type | Method and Description |
---|---|
void |
Hbase.mutateRows_args.addToRowBatches(BatchMutation elem) |
void |
Hbase.mutateRowsTs_args.addToRowBatches(BatchMutation elem) |
int |
BatchMutation.compareTo(BatchMutation other) |
boolean |
BatchMutation.equals(BatchMutation that) |
Modifier and Type | Method and Description |
---|---|
void |
Hbase.Iface.mutateRows(ByteBuffer tableName,
List<BatchMutation> rowBatches,
Map<ByteBuffer,ByteBuffer> attributes)
Apply a series of batches (each a series of mutations on a single row)
in a single transaction.
|
void |
Hbase.Client.mutateRows(ByteBuffer tableName,
List<BatchMutation> rowBatches,
Map<ByteBuffer,ByteBuffer> attributes) |
void |
Hbase.AsyncIface.mutateRows(ByteBuffer tableName,
List<BatchMutation> rowBatches,
Map<ByteBuffer,ByteBuffer> attributes,
org.apache.thrift.async.AsyncMethodCallback<Hbase.AsyncClient.mutateRows_call> resultHandler) |
void |
Hbase.AsyncClient.mutateRows(ByteBuffer tableName,
List<BatchMutation> rowBatches,
Map<ByteBuffer,ByteBuffer> attributes,
org.apache.thrift.async.AsyncMethodCallback<Hbase.AsyncClient.mutateRows_call> resultHandler) |
void |
Hbase.Iface.mutateRowsTs(ByteBuffer tableName,
List<BatchMutation> rowBatches,
long timestamp,
Map<ByteBuffer,ByteBuffer> attributes)
Apply a series of batches (each a series of mutations on a single row)
in a single transaction.
|
void |
Hbase.Client.mutateRowsTs(ByteBuffer tableName,
List<BatchMutation> rowBatches,
long timestamp,
Map<ByteBuffer,ByteBuffer> attributes) |
void |
Hbase.AsyncIface.mutateRowsTs(ByteBuffer tableName,
List<BatchMutation> rowBatches,
long timestamp,
Map<ByteBuffer,ByteBuffer> attributes,
org.apache.thrift.async.AsyncMethodCallback<Hbase.AsyncClient.mutateRowsTs_call> resultHandler) |
void |
Hbase.AsyncClient.mutateRowsTs(ByteBuffer tableName,
List<BatchMutation> rowBatches,
long timestamp,
Map<ByteBuffer,ByteBuffer> attributes,
org.apache.thrift.async.AsyncMethodCallback<Hbase.AsyncClient.mutateRowsTs_call> resultHandler) |
void |
Hbase.Client.send_mutateRows(ByteBuffer tableName,
List<BatchMutation> rowBatches,
Map<ByteBuffer,ByteBuffer> attributes) |
void |
Hbase.Client.send_mutateRowsTs(ByteBuffer tableName,
List<BatchMutation> rowBatches,
long timestamp,
Map<ByteBuffer,ByteBuffer> attributes) |
Hbase.mutateRows_args |
Hbase.mutateRows_args.setRowBatches(List<BatchMutation> rowBatches)
list of row batches
|
Hbase.mutateRowsTs_args |
Hbase.mutateRowsTs_args.setRowBatches(List<BatchMutation> rowBatches)
list of row batches
|
Constructor and Description |
---|
BatchMutation(BatchMutation other)
Performs a deep copy on other.
|
Constructor and Description |
---|
Hbase.AsyncClient.mutateRows_call(ByteBuffer tableName,
List<BatchMutation> rowBatches,
Map<ByteBuffer,ByteBuffer> attributes,
org.apache.thrift.async.AsyncMethodCallback<Hbase.AsyncClient.mutateRows_call> resultHandler,
org.apache.thrift.async.TAsyncClient client,
org.apache.thrift.protocol.TProtocolFactory protocolFactory,
org.apache.thrift.transport.TNonblockingTransport transport) |
Hbase.AsyncClient.mutateRowsTs_call(ByteBuffer tableName,
List<BatchMutation> rowBatches,
long timestamp,
Map<ByteBuffer,ByteBuffer> attributes,
org.apache.thrift.async.AsyncMethodCallback<Hbase.AsyncClient.mutateRowsTs_call> resultHandler,
org.apache.thrift.async.TAsyncClient client,
org.apache.thrift.protocol.TProtocolFactory protocolFactory,
org.apache.thrift.transport.TNonblockingTransport transport) |
Hbase.mutateRows_args(ByteBuffer tableName,
List<BatchMutation> rowBatches,
Map<ByteBuffer,ByteBuffer> attributes) |
Hbase.mutateRowsTs_args(ByteBuffer tableName,
List<BatchMutation> rowBatches,
long timestamp,
Map<ByteBuffer,ByteBuffer> attributes) |
Copyright © 2007-2016 The Apache Software Foundation. All Rights Reserved.