Uses of Class
org.apache.hadoop.hbase.client.Put
Packages that use Put
Package
Description
Provides HBase Client
Restrict the domain of a data attribute, often times to fulfill business rules/requirements.
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.
Provides an HBase Thrift
service.
-
Uses of Put in org.apache.hadoop.hbase
Methods in org.apache.hadoop.hbase that return PutModifier and TypeMethodDescriptionprivate static Put
MetaTableAccessor.addDaughtersToPut
(Put put, RegionInfo splitA, RegionInfo splitB) Adds split daughters to the Putstatic Put
MetaTableAccessor.addEmptyLocation
(Put p, int replicaId) static Put
MetaTableAccessor.addLocation
(Put p, ServerName sn, long openSeqNum, int replicaId) (package private) static Put
MetaTableAccessor.addMergeRegions
(Put put, Collection<RegionInfo> mergeRegions) static Put
MetaTableAccessor.addRegionInfo
(Put p, RegionInfo hri) private static Put
MetaTableAccessor.addRegionStateToPut
(Put put, int replicaId, RegionState.State state) private static Put
MetaTableAccessor.addSequenceNum
(Put p, long openSeqNum, int replicaId) static Put
MetaTableAccessor.makePutForReplicationBarrier
(RegionInfo regionInfo, long openSeqNum, long ts) static Put
MetaTableAccessor.makePutFromRegionInfo
(RegionInfo regionInfo) Generates and returns aPut
containing theRegionInfo
for the catalog table.static Put
MetaTableAccessor.makePutFromRegionInfo
(RegionInfo regionInfo, long ts) Generates and returns aPut
containing theRegionInfo
for the catalog table.static Put
MetaTableAccessor.makePutFromTableState
(TableState state, long ts) Construct PUT for given stateMethods in org.apache.hadoop.hbase with parameters of type PutModifier and TypeMethodDescriptionprivate static Put
MetaTableAccessor.addDaughtersToPut
(Put put, RegionInfo splitA, RegionInfo splitB) Adds split daughters to the Putstatic Put
MetaTableAccessor.addEmptyLocation
(Put p, int replicaId) static Put
MetaTableAccessor.addLocation
(Put p, ServerName sn, long openSeqNum, int replicaId) (package private) static Put
MetaTableAccessor.addMergeRegions
(Put put, Collection<RegionInfo> mergeRegions) static Put
MetaTableAccessor.addRegionInfo
(Put p, RegionInfo hri) private static Put
MetaTableAccessor.addRegionStateToPut
(Put put, int replicaId, RegionState.State state) static void
MetaTableAccessor.addReplicationBarrier
(Put put, long openSeqNum) See class comment on SerialReplicationCheckerprivate static void
MetaTableAccessor.addReplicationParent
(Put put, List<RegionInfo> parents) private static Put
MetaTableAccessor.addSequenceNum
(Put p, long openSeqNum, int replicaId) private static void
private static void
MetaTableAccessor.putToMetaTable
(Connection connection, Put p) Put the passedp
to thehbase:meta
table.Method parameters in org.apache.hadoop.hbase with type arguments of type PutModifier and TypeMethodDescriptionstatic void
MetaTableAccessor.putsToMetaTable
(Connection connection, List<Put> ps) Put the passedps
to thehbase:meta
table. -
Uses of Put in org.apache.hadoop.hbase.backup.impl
Methods in org.apache.hadoop.hbase.backup.impl that return PutModifier and TypeMethodDescriptionprivate Put
BackupSystemTable.createPutForBackupInfo
(BackupInfo context) Creates Put operation for a given backup info objectprivate Put
BackupSystemTable.createPutForBackupSet
(String name, String[] tables) Creates Put operation to update backup set content(package private) static Put
BackupSystemTable.createPutForBulkLoadedFile
(TableName tn, byte[] fam, String p, String backupId, long ts, int idx) private Put
BackupSystemTable.createPutForDeleteOperation
(String[] backupIdList) private Put
BackupSystemTable.createPutForIncrBackupTableSet
(Set<TableName> tables, String backupRoot) Creates Put to store incremental backup table setprivate Put
BackupSystemTable.createPutForMergeOperation
(String[] backupIdList) private Put
BackupSystemTable.createPutForRegionServerLastLogRollResult
(String server, Long timestamp, String backupRoot) Creates Put to store RS last log resultprivate Put
BackupSystemTable.createPutForStartBackupSession()
private Put
BackupSystemTable.createPutForStartCode
(String startCode, String rootPath) Creates Put operation to store start code to backup system tableprivate Put
BackupSystemTable.createPutForStopBackupSession()
private Put
BackupSystemTable.createPutForUpdateTablesForMerge
(List<TableName> tables) private Put
BackupSystemTable.createPutForWriteRegionServerLogTimestamp
(TableName table, byte[] smap, String backupRoot) Creates Put to write RS last roll log timestamp mapMethods in org.apache.hadoop.hbase.backup.impl that return types with arguments of type PutModifier and TypeMethodDescriptionBackupSystemTable.createPutForCommittedBulkload
(TableName table, byte[] region, Map<byte[], List<org.apache.hadoop.fs.Path>> finalPaths) BackupSystemTable.createPutForPreparedBulkload
(TableName table, byte[] region, byte[] family, List<Pair<org.apache.hadoop.fs.Path, org.apache.hadoop.fs.Path>> pairs) -
Uses of Put in org.apache.hadoop.hbase.client
Fields in org.apache.hadoop.hbase.client declared as PutMethods in org.apache.hadoop.hbase.client that return PutModifier and TypeMethodDescriptionAdd the specified KeyValue to this Put operation.Put.addColumn
(byte[] family, byte[] qualifier, byte[] value) Add the specified column and value to this Put operation.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.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.Put.addImmutable
(byte[] family, byte[] qualifier, byte[] value) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.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.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.Put.setACL
(String user, Permission perms) Put.setACL
(Map<String, Permission> perms) Put.setAttribute
(String name, byte[] value) Put.setCellVisibility
(CellVisibility expression) Put.setClusterIds
(List<UUID> clusterIds) Put.setDurability
(Durability d) Put.setFamilyCellMap
(NavigableMap<byte[], List<Cell>> map) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.Put.setPriority
(int priority) Put.setTimestamp
(long timestamp) Put.setTTL
(long ttl) Methods in org.apache.hadoop.hbase.client that return types with arguments of type PutModifier and TypeMethodDescriptionDeprecated.UseHTableMultiplexer.put(TableName, List)
instead.Deprecated.The puts request will be buffered by their corresponding buffer queue.Methods in org.apache.hadoop.hbase.client with parameters of type PutModifier and TypeMethodDescriptionvoid
Deprecated.since 2.0 version and will be removed in 3.0 version.Build the CheckAndMutate objectboolean
HTable.checkAndPut
(byte[] row, byte[] family, byte[] qualifier, byte[] value, Put put) Deprecated.boolean
HTable.checkAndPut
(byte[] row, byte[] family, byte[] qualifier, CompareOperator op, byte[] value, Put put) Deprecated.boolean
HTable.checkAndPut
(byte[] row, byte[] family, byte[] qualifier, CompareFilter.CompareOp compareOp, byte[] value, Put put) Deprecated.default boolean
Table.checkAndPut
(byte[] row, byte[] family, byte[] qualifier, byte[] value, Put put) Deprecated.Since 2.0.0.default boolean
Table.checkAndPut
(byte[] row, byte[] family, byte[] qualifier, CompareOperator op, byte[] value, Put put) Deprecated.Since 2.0.0.default boolean
Table.checkAndPut
(byte[] row, byte[] family, byte[] qualifier, CompareFilter.CompareOp compareOp, byte[] value, Put put) Deprecated.Since 2.0.0.Puts some data to the table.void
boolean
Deprecated.UseHTableMultiplexer.put(TableName, Put)
instead.boolean
Deprecated.UseHTableMultiplexer.put(TableName, Put)
instead.boolean
Deprecated.The put request will be buffered by its corresponding buffer queue.boolean
Deprecated.The put request will be buffered by its corresponding buffer queue.default void
Puts some data in the table.Deprecated.Specify a Put to commit if the check succeeds.Deprecated.Specify a Put to commit if the check succeeds.boolean
boolean
boolean
Deprecated.Specify a Put to commit if the check succeeds.boolean
Deprecated.Specify a Put to commit if the check succeeds.(package private) static void
ConnectionUtils.validatePut
(Put put, int maxKeyValueSize) private void
HTable.validatePut
(Put put) Method parameters in org.apache.hadoop.hbase.client with type arguments of type PutModifier and TypeMethodDescriptionPuts some data in the table, in batch.void
Deprecated.UseHTableMultiplexer.put(TableName, List)
instead.Deprecated.The puts request will be buffered by their corresponding buffer queue.default void
Batch puts the specified data into the table.default CompletableFuture<Void>
A simple version of batch put.Constructors in org.apache.hadoop.hbase.client with parameters of type PutModifierConstructorDescriptionCopy constructor.PutStatus
(RegionInfo regionInfo, Put put, int maxAttempCount) -
Uses of Put in org.apache.hadoop.hbase.constraint
Methods in org.apache.hadoop.hbase.constraint with parameters of type PutModifier and TypeMethodDescriptionvoid
Check aPut
to ensure it is valid for the table.void
ConstraintProcessor.prePut
(ObserverContext<RegionCoprocessorEnvironment> e, Put put, WALEdit edit, Durability durability) -
Uses of Put in org.apache.hadoop.hbase.coprocessor
Methods in org.apache.hadoop.hbase.coprocessor with parameters of type PutModifier and TypeMethodDescriptiondefault boolean
RegionObserver.postCheckAndPut
(ObserverContext<RegionCoprocessorEnvironment> c, byte[] row, byte[] family, byte[] qualifier, CompareOperator op, ByteArrayComparable comparator, Put put, boolean result) Deprecated.since 2.4.0 and will be removed in 4.0.0.default boolean
RegionObserver.postCheckAndPut
(ObserverContext<RegionCoprocessorEnvironment> c, byte[] row, Filter filter, Put put, boolean result) Deprecated.since 2.4.0 and will be removed in 4.0.0.default void
RegionObserver.postPut
(ObserverContext<RegionCoprocessorEnvironment> c, Put put, WALEdit edit) Called after the client stores a value.default void
RegionObserver.postPut
(ObserverContext<RegionCoprocessorEnvironment> c, Put put, WALEdit edit, Durability durability) Deprecated.since 2.5.0 and will be removed in 4.0.0.default boolean
RegionObserver.preCheckAndPut
(ObserverContext<RegionCoprocessorEnvironment> c, byte[] row, byte[] family, byte[] qualifier, CompareOperator op, ByteArrayComparable comparator, Put put, boolean result) Deprecated.since 2.4.0 and will be removed in 4.0.0.default boolean
RegionObserver.preCheckAndPut
(ObserverContext<RegionCoprocessorEnvironment> c, byte[] row, Filter filter, Put put, boolean result) Deprecated.since 2.4.0 and will be removed in 4.0.0.default boolean
RegionObserver.preCheckAndPutAfterRowLock
(ObserverContext<RegionCoprocessorEnvironment> c, byte[] row, byte[] family, byte[] qualifier, CompareOperator op, ByteArrayComparable comparator, Put put, boolean result) Deprecated.since 2.4.0 and will be removed in 4.0.0.default boolean
RegionObserver.preCheckAndPutAfterRowLock
(ObserverContext<RegionCoprocessorEnvironment> c, byte[] row, Filter filter, Put put, boolean result) Deprecated.since 2.4.0 and will be removed in 4.0.0.void
MetaTableMetrics.ExampleRegionObserverMeta.prePut
(ObserverContext<RegionCoprocessorEnvironment> e, Put put, WALEdit edit, Durability durability) default void
RegionObserver.prePut
(ObserverContext<RegionCoprocessorEnvironment> c, Put put, WALEdit edit) Called before the client stores a value.default void
RegionObserver.prePut
(ObserverContext<RegionCoprocessorEnvironment> c, Put put, WALEdit edit, Durability durability) Deprecated.since 2.5.0 and will be removed in 4.0.0. -
Uses of Put in org.apache.hadoop.hbase.favored
Methods in org.apache.hadoop.hbase.favored that return PutModifier and TypeMethodDescriptionprivate static Put
FavoredNodeAssignmentHelper.makePut
(RegionInfo regionInfo, List<ServerName> favoredNodeList) -
Uses of Put in org.apache.hadoop.hbase.mapred
Methods in org.apache.hadoop.hbase.mapred with parameters of type PutModifier and TypeMethodDescriptionvoid
TableOutputFormat.TableRecordWriter.write
(ImmutableBytesWritable key, Put value) Method parameters in org.apache.hadoop.hbase.mapred with type arguments of type PutModifier and TypeMethodDescriptionvoid
IdentityTableReduce.reduce
(ImmutableBytesWritable key, Iterator<Put> values, org.apache.hadoop.mapred.OutputCollector<ImmutableBytesWritable, Put> output, org.apache.hadoop.mapred.Reporter reporter) No aggregation, output pairs of (key, record)void
IdentityTableReduce.reduce
(ImmutableBytesWritable key, Iterator<Put> values, org.apache.hadoop.mapred.OutputCollector<ImmutableBytesWritable, Put> output, org.apache.hadoop.mapred.Reporter reporter) No aggregation, output pairs of (key, record) -
Uses of Put in org.apache.hadoop.hbase.mapreduce
Methods in org.apache.hadoop.hbase.mapreduce with parameters of type PutModifier and TypeMethodDescriptionprotected void
Import.Importer.addPutToKv
(Put put, Cell kv) protected void
TsvImporterMapper.populatePut
(byte[] lineBytes, ImportTsv.TsvParser.ParsedLine parsed, Put put, int i) protected void
Import.Importer.processKV
(ImmutableBytesWritable key, Result result, org.apache.hadoop.mapreduce.Mapper<ImmutableBytesWritable, Result, ImmutableBytesWritable, Mutation>.org.apache.hadoop.mapreduce.Mapper.Context context, Put put, Delete delete) Method parameters in org.apache.hadoop.hbase.mapreduce with type arguments of type PutModifier and TypeMethodDescriptionprotected void
PutCombiner.reduce
(K row, Iterable<Put> vals, org.apache.hadoop.mapreduce.Reducer<K, Put, K, Put>.org.apache.hadoop.mapreduce.Reducer.Context context) protected void
PutSortReducer.reduce
(ImmutableBytesWritable row, Iterable<Put> puts, org.apache.hadoop.mapreduce.Reducer<ImmutableBytesWritable, Put, ImmutableBytesWritable, KeyValue>.org.apache.hadoop.mapreduce.Reducer.Context context) -
Uses of Put in org.apache.hadoop.hbase.master.assignment
Methods in org.apache.hadoop.hbase.master.assignment with parameters of type PutModifier and TypeMethodDescriptionprivate void
RegionStateStore.updateRegionLocation
(RegionInfo regionInfo, RegionState.State state, Put put) -
Uses of Put in org.apache.hadoop.hbase.namequeues
Method parameters in org.apache.hadoop.hbase.namequeues with type arguments of type PutModifier and TypeMethodDescriptionprivate static void
WALEventTrackerTableAccessor.doPut
(Connection connection, List<Put> puts) -
Uses of Put in org.apache.hadoop.hbase.quotas
Methods in org.apache.hadoop.hbase.quotas that return PutModifier and TypeMethodDescription(package private) static Put
QuotaTableUtil.createPutForNamespaceSnapshotSize
(String namespace, long size) Creates aPut
for the namespace's total snapshot size.(package private) static Put
QuotaTableUtil.createPutForSnapshotSize
(TableName tableName, String snapshot, long size) (package private) static Put
QuotaTableUtil.createPutForSpaceSnapshot
(TableName tableName, SpaceQuotaSnapshot snapshot) Methods in org.apache.hadoop.hbase.quotas with parameters of type PutModifier and TypeMethodDescriptionprivate static void
QuotaUtil.doPut
(Connection connection, Put put) -
Uses of Put in org.apache.hadoop.hbase.regionserver
Methods in org.apache.hadoop.hbase.regionserver with parameters of type PutModifier and TypeMethodDescriptionprotected abstract void
HRegion.BatchOperation.checkAndPreparePut
(Put p) Implement any Put request specific check and prepare logic here.void
HRegion.MutationBatchOperation.checkAndPreparePut
(Put p) protected void
HRegion.ReplayBatchOperation.checkAndPreparePut
(Put p) During replay, there could exist column families which are removed between region server failure and replayvoid
boolean
Supports Coprocessor 'bypass'.void
void
Puts some data in the table. -
Uses of Put in org.apache.hadoop.hbase.replication.regionserver
Methods in org.apache.hadoop.hbase.replication.regionserver that return PutModifier and TypeMethodDescriptionprivate Put
ReplicationSink.processReplicationMarkerEntry
(Cell cell) -
Uses of Put in org.apache.hadoop.hbase.security.access
Methods in org.apache.hadoop.hbase.security.access with parameters of type PutModifier and TypeMethodDescriptionvoid
AccessController.postPut
(ObserverContext<RegionCoprocessorEnvironment> c, Put put, WALEdit edit, Durability durability) boolean
AccessController.preCheckAndPut
(ObserverContext<RegionCoprocessorEnvironment> c, byte[] row, byte[] family, byte[] qualifier, CompareOperator op, ByteArrayComparable comparator, Put put, boolean result) boolean
AccessController.preCheckAndPutAfterRowLock
(ObserverContext<RegionCoprocessorEnvironment> c, byte[] row, byte[] family, byte[] qualifier, CompareOperator opp, ByteArrayComparable comparator, Put put, boolean result) void
AccessController.prePut
(ObserverContext<RegionCoprocessorEnvironment> c, Put put, WALEdit edit, Durability durability) -
Uses of Put in org.apache.hadoop.hbase.slowlog
Method parameters in org.apache.hadoop.hbase.slowlog with type arguments of type PutModifier and TypeMethodDescriptionprivate static void
SlowLogTableAccessor.doPut
(Connection connection, List<Put> puts) -
Uses of Put in org.apache.hadoop.hbase.thrift2
Methods in org.apache.hadoop.hbase.thrift2 that return PutModifier and TypeMethodDescriptionstatic Put
ThriftUtilities.putFromThrift
(org.apache.hadoop.hbase.thrift2.generated.TPut in) Creates aPut
(HBase) from aTPut
(Thrift)Methods in org.apache.hadoop.hbase.thrift2 that return types with arguments of type PutModifier and TypeMethodDescriptionThriftUtilities.putsFromThrift
(List<org.apache.hadoop.hbase.thrift2.generated.TPut> in) Converts multipleTPut
s (Thrift) into a list ofPut
s (HBase).Methods in org.apache.hadoop.hbase.thrift2 with parameters of type PutModifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.thrift2.generated.TPut
ThriftUtilities.putFromHBase
(Put in) Method parameters in org.apache.hadoop.hbase.thrift2 with type arguments of type PutModifier and TypeMethodDescriptionstatic List<org.apache.hadoop.hbase.thrift2.generated.TPut>
ThriftUtilities.putsFromHBase
(List<Put> in) -
Uses of Put in org.apache.hadoop.hbase.thrift2.client
Methods in org.apache.hadoop.hbase.thrift2.client with parameters of type PutModifier and TypeMethodDescriptionvoid
boolean
Method parameters in org.apache.hadoop.hbase.thrift2.client with type arguments of type Put