Uses of Class
org.apache.hadoop.hbase.client.Put

Packages that use Put
org.apache.hadoop.hbase.client Provides HBase Client 
org.apache.hadoop.hbase.protobuf Holds classes generated from protobuf src/main/protobuf definition files. 
 

Uses of Put in org.apache.hadoop.hbase.client
 

Methods in org.apache.hadoop.hbase.client that return Put
 Put Put.add(byte[] family, byte[] qualifier, byte[] value)
          Add the specified column and value to this Put operation.
 Put Put.add(byte[] family, byte[] qualifier, long ts, byte[] value)
          Add the specified column and value, with the specified timestamp as its version to this Put operation.
 Put Put.add(byte[] family, ByteBuffer qualifier, long ts, ByteBuffer value)
          Add the specified column and value, with the specified timestamp as its version to this Put operation.
 Put Put.add(Cell kv)
          Add the specified KeyValue to this Put operation.
 Put Put.addImmutable(byte[] family, byte[] qualifier, byte[] value)
          See add(byte[], byte[], byte[]).
 Put Put.addImmutable(byte[] family, byte[] qualifier, byte[] value, Tag[] tag)
          This expects that the underlying arrays won't change.
 Put Put.addImmutable(byte[] family, byte[] qualifier, long ts, byte[] value)
          See add(byte[], byte[], long, byte[]).
 Put Put.addImmutable(byte[] family, byte[] qualifier, long ts, byte[] value, Tag[] tag)
          This expects that the underlying arrays won't change.
 Put Put.addImmutable(byte[] family, ByteBuffer qualifier, long ts, ByteBuffer value)
          See add(byte[], ByteBuffer, long, ByteBuffer).
 Put Put.addImmutable(byte[] family, ByteBuffer qualifier, long ts, ByteBuffer value, Tag[] tag)
          This expects that the underlying arrays won't change.
 

Methods in org.apache.hadoop.hbase.client that return types with arguments of type Put
 List<Put> HTableMultiplexer.put(byte[] tableName, List<Put> puts)
          Deprecated. 
 List<Put> HTableMultiplexer.put(TableName tableName, List<Put> puts)
          The puts request will be buffered by their corresponding buffer queue.
 

Methods in org.apache.hadoop.hbase.client with parameters of type Put
 void RowMutations.add(Put p)
          Add a Put operation to the list of mutations
 boolean HTable.checkAndPut(byte[] row, byte[] family, byte[] qualifier, byte[] value, Put put)
          Atomically checks if a row/family/qualifier value matches the expected value.
 boolean HTableInterface.checkAndPut(byte[] row, byte[] family, byte[] qualifier, byte[] value, Put put)
          Atomically checks if a row/family/qualifier value matches the expected value.
 boolean HTableMultiplexer.put(byte[] tableName, Put put)
          Deprecated. 
 boolean HTableMultiplexer.put(byte[] tableName, Put put, int retry)
          Deprecated. 
 void HTable.put(Put put)
          Puts some data in the table.
 void HTableInterface.put(Put put)
          Puts some data in the table.
 boolean HTableMultiplexer.put(TableName tableName, Put put)
          The put request will be buffered by its corresponding buffer queue.
 boolean HTableMultiplexer.put(TableName tableName, Put put, int retry)
          The put request will be buffered by its corresponding buffer queue.
 void HTable.validatePut(Put put)
           
static void HTable.validatePut(Put put, int maxKeyValueSize)
           
 

Method parameters in org.apache.hadoop.hbase.client with type arguments of type Put
static void HTableUtil.bucketRsPut(HTable htable, List<Put> puts)
          Processes a List of Puts and writes them to an HTable instance in RegionServer buckets via the htable.put method.
 List<Put> HTableMultiplexer.put(byte[] tableName, List<Put> puts)
          Deprecated. 
 void HTable.put(List<Put> puts)
          Puts some data in the table, in batch.
 void HTableInterface.put(List<Put> puts)
          Puts some data in the table, in batch.
 List<Put> HTableMultiplexer.put(TableName tableName, List<Put> puts)
          The puts request will be buffered by their corresponding buffer queue.
 

Constructors in org.apache.hadoop.hbase.client with parameters of type Put
Put(Put putToCopy)
          Copy constructor.
 

Uses of Put in org.apache.hadoop.hbase.protobuf
 

Methods in org.apache.hadoop.hbase.protobuf that return Put
static Put ProtobufUtil.toPut(org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto proto)
          Convert a protocol buffer Mutate to a Put.
static Put ProtobufUtil.toPut(org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto proto, CellScanner cellScanner)
          Convert a protocol buffer Mutate to a Put.
 

Methods in org.apache.hadoop.hbase.protobuf with parameters of type Put
static org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest RequestConverter.buildMutateRequest(byte[] regionName, byte[] row, byte[] family, byte[] qualifier, ByteArrayComparable comparator, org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.CompareType compareType, Put put)
          Create a protocol buffer MutateRequest for a conditioned put
static org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest RequestConverter.buildMutateRequest(byte[] regionName, Put put)
          Create a protocol buffer MutateRequest for a put
 



Copyright © 2007–2016 The Apache Software Foundation. All rights reserved.