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

Packages that use org.apache.hadoop.hbase.client.Put
Package
Description
 
Provides HBase Client
Table of Contents
Provides HBase MapReduce Input/OutputFormats, a table indexing MapReduce job, and utility methods.
Provides HBase MapReduce Input/OutputFormats, a table indexing MapReduce job, and utility methods.
 
 
  • Uses of org.apache.hadoop.hbase.client.Put in org.apache.hadoop.hbase

    Methods in org.apache.hadoop.hbase that return org.apache.hadoop.hbase.client.Put in in
    Modifier and Type
    Method
    Description
    static org.apache.hadoop.hbase.client.Put
    MetaTableAccessor.addEmptyLocation(org.apache.hadoop.hbase.client.Put p, int replicaId)
     
    static org.apache.hadoop.hbase.client.Put
    MetaTableAccessor.addLocation(org.apache.hadoop.hbase.client.Put p, org.apache.hadoop.hbase.ServerName sn, long openSeqNum, int replicaId)
     
    static org.apache.hadoop.hbase.client.Put
    MetaTableAccessor.addRegionInfo(org.apache.hadoop.hbase.client.Put p, org.apache.hadoop.hbase.client.RegionInfo hri)
     
    static org.apache.hadoop.hbase.client.Put
    MetaTableAccessor.makePutForReplicationBarrier(org.apache.hadoop.hbase.client.RegionInfo regionInfo, long openSeqNum, long ts)
     
    static org.apache.hadoop.hbase.client.Put
    MetaTableAccessor.makePutFromRegionInfo(org.apache.hadoop.hbase.client.RegionInfo regionInfo)
    Generates and returns a Put containing the RegionInfo for the catalog table.
    static org.apache.hadoop.hbase.client.Put
    MetaTableAccessor.makePutFromRegionInfo(org.apache.hadoop.hbase.client.RegionInfo regionInfo, long ts)
    Generates and returns a Put containing the RegionInfo for the catalog table.
    static org.apache.hadoop.hbase.client.Put
    MetaTableAccessor.makePutFromTableState(org.apache.hadoop.hbase.client.TableState state, long ts)
    Construct PUT for given state
    Methods in org.apache.hadoop.hbase with parameters of type org.apache.hadoop.hbase.client.Put in in
    Modifier and Type
    Method
    Description
    static org.apache.hadoop.hbase.client.Put
    MetaTableAccessor.addEmptyLocation(org.apache.hadoop.hbase.client.Put p, int replicaId)
     
    static org.apache.hadoop.hbase.client.Put
    MetaTableAccessor.addLocation(org.apache.hadoop.hbase.client.Put p, org.apache.hadoop.hbase.ServerName sn, long openSeqNum, int replicaId)
     
    static org.apache.hadoop.hbase.client.Put
    MetaTableAccessor.addRegionInfo(org.apache.hadoop.hbase.client.Put p, org.apache.hadoop.hbase.client.RegionInfo hri)
     
    static void
    MetaTableAccessor.addReplicationBarrier(org.apache.hadoop.hbase.client.Put put, long openSeqNum)
    See class comment on SerialReplicationChecker
    Method parameters in org.apache.hadoop.hbase with type arguments of type org.apache.hadoop.hbase.client.Put in in
    Modifier and Type
    Method
    Description
    static void
    MetaTableAccessor.putsToMetaTable(org.apache.hadoop.hbase.client.Connection connection, List<org.apache.hadoop.hbase.client.Put> ps)
    Put the passed ps to the hbase:meta table.
  • Uses of org.apache.hadoop.hbase.client.Put in org.apache.hadoop.hbase.client

    Methods in org.apache.hadoop.hbase.client that return org.apache.hadoop.hbase.client.Put in in
    Modifier and Type
    Method
    Description
    org.apache.hadoop.hbase.client.Put
    Put.add(org.apache.hadoop.hbase.Cell cell)
    Add the specified KeyValue to this Put operation.
    org.apache.hadoop.hbase.client.Put
    Put.addColumn(byte[] family, byte[] qualifier, byte[] value)
    Add the specified column and value to this Put operation.
    org.apache.hadoop.hbase.client.Put
    Put.addColumn(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.
    org.apache.hadoop.hbase.client.Put
    Put.addColumn(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.
    org.apache.hadoop.hbase.client.Put
    Put.addImmutable(byte[] family, byte[] qualifier, byte[] value)
    Deprecated.
    As of release 2.0.0, this will be removed in HBase 3.0.0.
    org.apache.hadoop.hbase.client.Put
    Put.addImmutable(byte[] family, byte[] qualifier, long ts, byte[] value)
    Deprecated.
    As of release 2.0.0, this will be removed in HBase 3.0.0.
    org.apache.hadoop.hbase.client.Put
    Put.addImmutable(byte[] family, ByteBuffer qualifier, long ts, ByteBuffer value)
    Deprecated.
    As of release 2.0.0, this will be removed in HBase 3.0.0.
    org.apache.hadoop.hbase.client.Put
    Put.setACL(String user, org.apache.hadoop.hbase.security.access.Permission perms)
     
    org.apache.hadoop.hbase.client.Put
    Put.setACL(Map<String,org.apache.hadoop.hbase.security.access.Permission> perms)
     
    org.apache.hadoop.hbase.client.Put
    Put.setAttribute(String name, byte[] value)
     
    org.apache.hadoop.hbase.client.Put
    Put.setCellVisibility(org.apache.hadoop.hbase.security.visibility.CellVisibility expression)
     
    org.apache.hadoop.hbase.client.Put
    Put.setClusterIds(List<UUID> clusterIds)
     
    org.apache.hadoop.hbase.client.Put
    Put.setDurability(org.apache.hadoop.hbase.client.Durability d)
     
    org.apache.hadoop.hbase.client.Put
    Put.setFamilyCellMap(NavigableMap<byte[],List<org.apache.hadoop.hbase.Cell>> map)
    Deprecated.
    As of release 2.0.0, this will be removed in HBase 3.0.0.
    org.apache.hadoop.hbase.client.Put
    Put.setId(String id)
     
    org.apache.hadoop.hbase.client.Put
    Put.setPriority(int priority)
     
    org.apache.hadoop.hbase.client.Put
    Put.setTimestamp(long timestamp)
     
    org.apache.hadoop.hbase.client.Put
    Put.setTTL(long ttl)
     
    Methods in org.apache.hadoop.hbase.client that return types with arguments of type org.apache.hadoop.hbase.client.Put in in
    Modifier and Type
    Method
    Description
    List<org.apache.hadoop.hbase.client.Put>
    HTableMultiplexer.put(byte[] tableName, List<org.apache.hadoop.hbase.client.Put> puts)
    Deprecated.
    Use HTableMultiplexer.put(TableName, List) instead.
    List<org.apache.hadoop.hbase.client.Put>
    HTableMultiplexer.put(org.apache.hadoop.hbase.TableName tableName, List<org.apache.hadoop.hbase.client.Put> puts)
    Deprecated.
    The puts request will be buffered by their corresponding buffer queue.
    Methods in org.apache.hadoop.hbase.client with parameters of type org.apache.hadoop.hbase.client.Put in in
    Modifier and Type
    Method
    Description
    void
    RowMutations.add(org.apache.hadoop.hbase.client.Put p)
    Deprecated.
    since 2.0 version and will be removed in 3.0 version.
    CheckAndMutate.Builder.build(org.apache.hadoop.hbase.client.Put put)
    Build the CheckAndMutate object
    boolean
    HTable.checkAndPut(byte[] row, byte[] family, byte[] qualifier, byte[] value, org.apache.hadoop.hbase.client.Put put)
    Deprecated.
    boolean
    HTable.checkAndPut(byte[] row, byte[] family, byte[] qualifier, org.apache.hadoop.hbase.CompareOperator op, byte[] value, org.apache.hadoop.hbase.client.Put put)
    Deprecated.
    boolean
    HTable.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.
    default boolean
    Table.checkAndPut(byte[] row, byte[] family, byte[] qualifier, byte[] value, org.apache.hadoop.hbase.client.Put put)
    Deprecated.
    Since 2.0.0.
    default boolean
    Table.checkAndPut(byte[] row, byte[] family, byte[] qualifier, org.apache.hadoop.hbase.CompareOperator op, byte[] value, org.apache.hadoop.hbase.client.Put put)
    Deprecated.
    Since 2.0.0.
    default boolean
    Table.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.
    Since 2.0.0.
    AsyncTable.put(org.apache.hadoop.hbase.client.Put put)
    Puts some data to the table.
    void
    HTable.put(org.apache.hadoop.hbase.client.Put put)
     
    boolean
    HTableMultiplexer.put(byte[] tableName, org.apache.hadoop.hbase.client.Put put)
    Deprecated.
    Use HTableMultiplexer.put(TableName, Put) instead.
    boolean
    HTableMultiplexer.put(byte[] tableName, org.apache.hadoop.hbase.client.Put put, int retry)
    Deprecated.
    Use HTableMultiplexer.put(TableName, Put) instead.
    boolean
    HTableMultiplexer.put(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.Put put)
    Deprecated.
    The put request will be buffered by its corresponding buffer queue.
    boolean
    HTableMultiplexer.put(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.Put put, int maxAttempts)
    Deprecated.
    The put request will be buffered by its corresponding buffer queue.
    default void
    Table.put(org.apache.hadoop.hbase.client.Put put)
    Puts some data in the table.
    AsyncTable.CheckAndMutateBuilder.thenPut(org.apache.hadoop.hbase.client.Put put)
    Deprecated.
    Specify a Put to commit if the check succeeds.
    AsyncTable.CheckAndMutateWithFilterBuilder.thenPut(org.apache.hadoop.hbase.client.Put put)
    Deprecated.
    Specify a Put to commit if the check succeeds.
    boolean
    Table.CheckAndMutateBuilder.thenPut(org.apache.hadoop.hbase.client.Put put)
    Deprecated.
    Specify a Put to commit if the check succeeds.
    boolean
    Table.CheckAndMutateWithFilterBuilder.thenPut(org.apache.hadoop.hbase.client.Put put)
    Deprecated.
    Specify a Put to commit if the check succeeds.
    Method parameters in org.apache.hadoop.hbase.client with type arguments of type org.apache.hadoop.hbase.client.Put in in
    Modifier and Type
    Method
    Description
    AsyncTable.put(List<org.apache.hadoop.hbase.client.Put> puts)
    Puts some data in the table, in batch.
    void
    HTable.put(List<org.apache.hadoop.hbase.client.Put> puts)
     
    List<org.apache.hadoop.hbase.client.Put>
    HTableMultiplexer.put(byte[] tableName, List<org.apache.hadoop.hbase.client.Put> puts)
    Deprecated.
    Use HTableMultiplexer.put(TableName, List) instead.
    List<org.apache.hadoop.hbase.client.Put>
    HTableMultiplexer.put(org.apache.hadoop.hbase.TableName tableName, List<org.apache.hadoop.hbase.client.Put> puts)
    Deprecated.
    The puts request will be buffered by their corresponding buffer queue.
    default void
    Table.put(List<org.apache.hadoop.hbase.client.Put> puts)
    Batch puts the specified data into the table.
    AsyncTable.putAll(List<org.apache.hadoop.hbase.client.Put> puts)
    A simple version of batch put.
    Constructors in org.apache.hadoop.hbase.client with parameters of type org.apache.hadoop.hbase.client.Put in in
    Modifier
    Constructor
    Description
     
    Put(org.apache.hadoop.hbase.client.Put putToCopy)
    Copy constructor.
  • Uses of org.apache.hadoop.hbase.client.Put in org.apache.hadoop.hbase.coprocessor

    Methods in org.apache.hadoop.hbase.coprocessor with parameters of type org.apache.hadoop.hbase.client.Put in in
    Modifier and Type
    Method
    Description
    default boolean
    RegionObserver.postCheckAndPut(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment> c, byte[] row, byte[] family, byte[] qualifier, org.apache.hadoop.hbase.CompareOperator op, org.apache.hadoop.hbase.filter.ByteArrayComparable comparator, org.apache.hadoop.hbase.client.Put put, boolean result)
    Deprecated.
    since 2.4.0 and will be removed in 4.0.0.
    default boolean
    RegionObserver.postCheckAndPut(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment> c, byte[] row, org.apache.hadoop.hbase.filter.Filter filter, org.apache.hadoop.hbase.client.Put put, boolean result)
    Deprecated.
    since 2.4.0 and will be removed in 4.0.0.
    default void
    RegionObserver.postPut(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment> c, org.apache.hadoop.hbase.client.Put put, org.apache.hadoop.hbase.wal.WALEdit edit)
    Called after the client stores a value.
    default void
    RegionObserver.postPut(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment> c, org.apache.hadoop.hbase.client.Put put, org.apache.hadoop.hbase.wal.WALEdit edit, org.apache.hadoop.hbase.client.Durability durability)
    Deprecated.
    since 2.5.0 and will be removed in 4.0.0.
    default boolean
    RegionObserver.preCheckAndPut(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment> c, byte[] row, byte[] family, byte[] qualifier, org.apache.hadoop.hbase.CompareOperator op, org.apache.hadoop.hbase.filter.ByteArrayComparable comparator, org.apache.hadoop.hbase.client.Put put, boolean result)
    Deprecated.
    since 2.4.0 and will be removed in 4.0.0.
    default boolean
    RegionObserver.preCheckAndPut(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment> c, byte[] row, org.apache.hadoop.hbase.filter.Filter filter, org.apache.hadoop.hbase.client.Put put, boolean result)
    Deprecated.
    since 2.4.0 and will be removed in 4.0.0.
    default boolean
    RegionObserver.preCheckAndPutAfterRowLock(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment> c, byte[] row, byte[] family, byte[] qualifier, org.apache.hadoop.hbase.CompareOperator op, org.apache.hadoop.hbase.filter.ByteArrayComparable comparator, org.apache.hadoop.hbase.client.Put put, boolean result)
    Deprecated.
    since 2.4.0 and will be removed in 4.0.0.
    default boolean
    RegionObserver.preCheckAndPutAfterRowLock(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment> c, byte[] row, org.apache.hadoop.hbase.filter.Filter filter, org.apache.hadoop.hbase.client.Put put, boolean result)
    Deprecated.
    since 2.4.0 and will be removed in 4.0.0.
    default void
    RegionObserver.prePut(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment> c, org.apache.hadoop.hbase.client.Put put, org.apache.hadoop.hbase.wal.WALEdit edit)
    Called before the client stores a value.
    default void
    RegionObserver.prePut(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment> c, org.apache.hadoop.hbase.client.Put put, org.apache.hadoop.hbase.wal.WALEdit edit, org.apache.hadoop.hbase.client.Durability durability)
    Deprecated.
    since 2.5.0 and will be removed in 4.0.0.
  • Uses of org.apache.hadoop.hbase.client.Put in org.apache.hadoop.hbase.mapred

    Methods in org.apache.hadoop.hbase.mapred with parameters of type org.apache.hadoop.hbase.client.Put in in
    Modifier and Type
    Method
    Description
    void
    TableOutputFormat.TableRecordWriter.write(org.apache.hadoop.hbase.io.ImmutableBytesWritable key, org.apache.hadoop.hbase.client.Put value)
     
    Method parameters in org.apache.hadoop.hbase.mapred with type arguments of type org.apache.hadoop.hbase.client.Put in in
    Modifier and Type
    Method
    Description
    void
    IdentityTableReduce.reduce(org.apache.hadoop.hbase.io.ImmutableBytesWritable key, Iterator<org.apache.hadoop.hbase.client.Put> values, org.apache.hadoop.mapred.OutputCollector<org.apache.hadoop.hbase.io.ImmutableBytesWritable,org.apache.hadoop.hbase.client.Put> output, org.apache.hadoop.mapred.Reporter reporter)
    No aggregation, output pairs of (key, record)
    void
    IdentityTableReduce.reduce(org.apache.hadoop.hbase.io.ImmutableBytesWritable key, Iterator<org.apache.hadoop.hbase.client.Put> values, org.apache.hadoop.mapred.OutputCollector<org.apache.hadoop.hbase.io.ImmutableBytesWritable,org.apache.hadoop.hbase.client.Put> output, org.apache.hadoop.mapred.Reporter reporter)
    No aggregation, output pairs of (key, record)
  • Uses of org.apache.hadoop.hbase.client.Put in org.apache.hadoop.hbase.mapreduce

    Methods in org.apache.hadoop.hbase.mapreduce with parameters of type org.apache.hadoop.hbase.client.Put in in
    Modifier and Type
    Method
    Description
    protected void
    Import.Importer.addPutToKv(org.apache.hadoop.hbase.client.Put put, org.apache.hadoop.hbase.Cell kv)
     
    protected void
    TsvImporterMapper.populatePut(byte[] lineBytes, org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser.ParsedLine parsed, org.apache.hadoop.hbase.client.Put put, int i)
     
    protected void
    Import.Importer.processKV(org.apache.hadoop.hbase.io.ImmutableBytesWritable key, org.apache.hadoop.hbase.client.Result result, org.apache.hadoop.mapreduce.Mapper<org.apache.hadoop.hbase.io.ImmutableBytesWritable,org.apache.hadoop.hbase.client.Result,org.apache.hadoop.hbase.io.ImmutableBytesWritable,org.apache.hadoop.hbase.client.Mutation>.org.apache.hadoop.mapreduce.Mapper.Context context, org.apache.hadoop.hbase.client.Put put, org.apache.hadoop.hbase.client.Delete delete)
     
    Method parameters in org.apache.hadoop.hbase.mapreduce with type arguments of type org.apache.hadoop.hbase.client.Put in in
    Modifier and Type
    Method
    Description
    protected void
    PutCombiner.reduce(K row, Iterable<org.apache.hadoop.hbase.client.Put> vals, org.apache.hadoop.mapreduce.Reducer<K,org.apache.hadoop.hbase.client.Put,K,org.apache.hadoop.hbase.client.Put>.org.apache.hadoop.mapreduce.Reducer.Context context)
     
    protected void
    PutSortReducer.reduce(org.apache.hadoop.hbase.io.ImmutableBytesWritable row, Iterable<org.apache.hadoop.hbase.client.Put> puts, org.apache.hadoop.mapreduce.Reducer<org.apache.hadoop.hbase.io.ImmutableBytesWritable,org.apache.hadoop.hbase.client.Put,org.apache.hadoop.hbase.io.ImmutableBytesWritable,org.apache.hadoop.hbase.KeyValue>.org.apache.hadoop.mapreduce.Reducer.Context context)
     
  • Uses of org.apache.hadoop.hbase.client.Put in org.apache.hadoop.hbase.regionserver

    Methods in org.apache.hadoop.hbase.regionserver with parameters of type org.apache.hadoop.hbase.client.Put in in
    Modifier and Type
    Method
    Description
    void
    RegionCoprocessorHost.postPut(org.apache.hadoop.hbase.client.Put put, org.apache.hadoop.hbase.wal.WALEdit edit)
     
    boolean
    RegionCoprocessorHost.prePut(org.apache.hadoop.hbase.client.Put put, org.apache.hadoop.hbase.wal.WALEdit edit)
    Supports Coprocessor 'bypass'.
    void
    HRegion.put(org.apache.hadoop.hbase.client.Put put)
     
    void
    Region.put(org.apache.hadoop.hbase.client.Put put)
    Puts some data in the table.
  • Uses of org.apache.hadoop.hbase.client.Put in org.apache.hadoop.hbase.shaded.protobuf

    Methods in org.apache.hadoop.hbase.shaded.protobuf that return org.apache.hadoop.hbase.client.Put in in
    Modifier and Type
    Method
    Description
    static org.apache.hadoop.hbase.client.Put
    ProtobufUtil.toPut(org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MutationProto proto)
    Convert a protocol buffer Mutate to a Put.
    static org.apache.hadoop.hbase.client.Put
    ProtobufUtil.toPut(org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MutationProto proto, org.apache.hadoop.hbase.CellScanner cellScanner)
    Convert a protocol buffer Mutate to a Put.
    Methods in org.apache.hadoop.hbase.shaded.protobuf with parameters of type org.apache.hadoop.hbase.client.Put in in
    Modifier and Type
    Method
    Description
    static org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MutateRequest
    RequestConverter.buildMutateRequest(byte[] regionName, org.apache.hadoop.hbase.client.Put put)
    Create a protocol buffer MutateRequest for a put