Uses of Class
org.apache.hadoop.hbase.client.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.
Multi Cluster Replication
Provides an HBase Thrift
service.
-
Uses of Put in org.apache.hadoop.hbase
Modifier and TypeFieldDescriptionPerformanceEvaluation.AsyncSequentialWriteTest.puts
PerformanceEvaluation.SequentialWriteTest.puts
Modifier and TypeMethodDescriptionstatic 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) static Put
MetaTableAccessor.addRegionInfo
(Put p, RegionInfo hri) static Put
MetaTableAccessor.addRegionStateToPut
(Put put, int replicaId, RegionState.State state) 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 stateModifier and TypeMethodDescriptionstatic 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) static Put
MetaTableAccessor.addRegionInfo
(Put p, RegionInfo hri) static Put
MetaTableAccessor.addRegionStateToPut
(Put put, int replicaId, RegionState.State state) private static void
private static void
MetaTableAccessor.putToMetaTable
(Connection connection, Put p) Put the passedp
to thehbase:meta
table.Modifier 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
Modifier 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 mapModifier 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
Modifier 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.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.setPriority
(int priority) Put.setTimestamp
(long timestamp) Put.setTTL
(long ttl) Modifier and TypeMethodDescriptionBuild the CheckAndMutate objectPuts some data to the table.default void
Puts some data in the table.void
Deprecated.Specify a Put to commit if the check succeeds.Deprecated.Specify a Put to commit if the check succeeds.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) Modifier and TypeMethodDescriptionPuts some data in the table, in batch.default void
Batch puts the specified data into the table.void
default CompletableFuture<Void>
A simple version of batch put. -
Uses of Put in org.apache.hadoop.hbase.constraint
Modifier and TypeMethodDescriptionvoid
Check aPut
to ensure it is valid for the table.void
ConstraintProcessor.prePut
(ObserverContext<? extends RegionCoprocessorEnvironment> e, Put put, WALEdit edit, Durability durability) -
Uses of Put in org.apache.hadoop.hbase.coprocessor
Modifier and TypeMethodDescriptiondefault boolean
RegionObserver.postCheckAndPut
(ObserverContext<? extends RegionCoprocessorEnvironment> c, byte[] row, byte[] family, byte[] qualifier, CompareOperator op, ByteArrayComparable comparator, Put put, boolean result) Deprecated.since 3.0.0 and will be removed in 4.0.0.default boolean
RegionObserver.postCheckAndPut
(ObserverContext<? extends RegionCoprocessorEnvironment> c, byte[] row, Filter filter, Put put, boolean result) Deprecated.since 3.0.0 and will be removed in 4.0.0.default void
RegionObserver.postPut
(ObserverContext<? extends RegionCoprocessorEnvironment> c, Put put, WALEdit edit) Called after the client stores a value.default void
RegionObserver.postPut
(ObserverContext<? extends RegionCoprocessorEnvironment> c, Put put, WALEdit edit, Durability durability) Deprecated.since 3.0.0 and will be removed in 4.0.0.default boolean
RegionObserver.preCheckAndPut
(ObserverContext<? extends RegionCoprocessorEnvironment> c, byte[] row, byte[] family, byte[] qualifier, CompareOperator op, ByteArrayComparable comparator, Put put, boolean result) Deprecated.since 3.0.0 and will be removed in 4.0.0.default boolean
RegionObserver.preCheckAndPut
(ObserverContext<? extends RegionCoprocessorEnvironment> c, byte[] row, Filter filter, Put put, boolean result) Deprecated.since 3.0.0 and will be removed in 4.0.0.default boolean
RegionObserver.preCheckAndPutAfterRowLock
(ObserverContext<? extends RegionCoprocessorEnvironment> c, byte[] row, byte[] family, byte[] qualifier, CompareOperator op, ByteArrayComparable comparator, Put put, boolean result) Deprecated.since 3.0.0 and will be removed in 4.0.0.default boolean
RegionObserver.preCheckAndPutAfterRowLock
(ObserverContext<? extends RegionCoprocessorEnvironment> c, byte[] row, Filter filter, Put put, boolean result) Deprecated.since 3.0.0 and will be removed in 4.0.0.void
MetaTableMetrics.ExampleRegionObserverMeta.prePut
(ObserverContext<? extends RegionCoprocessorEnvironment> e, Put put, WALEdit edit, Durability durability) default void
RegionObserver.prePut
(ObserverContext<? extends RegionCoprocessorEnvironment> c, Put put, WALEdit edit) Called before the client stores a value.default void
RegionObserver.prePut
(ObserverContext<? extends RegionCoprocessorEnvironment> c, Put put, WALEdit edit, Durability durability) Deprecated.since 3.0.0 and will be removed in 4.0.0. -
Uses of Put in org.apache.hadoop.hbase.favored
Modifier and TypeMethodDescriptionprivate static Put
FavoredNodeAssignmentHelper.makePut
(RegionInfo regionInfo, List<ServerName> favoredNodeList) -
Uses of Put in org.apache.hadoop.hbase.mapred
Modifier and TypeMethodDescriptionvoid
TableOutputFormat.TableRecordWriter.write
(ImmutableBytesWritable key, Put value) Modifier 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
Modifier 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) Modifier 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
Modifier and TypeMethodDescription(package private) static Put
RegionStateStore.addMergeRegions
(Put put, Collection<RegionInfo> mergeRegions) private static Put
RegionStateStore.addSequenceNum
(Put p, long openSeqNum, int replicaId) private Put
RegionStateStore.generateUpdateRegionLocationPut
(RegionStateNode regionStateNode) Modifier and TypeMethodDescription(package private) static Put
RegionStateStore.addMergeRegions
(Put put, Collection<RegionInfo> mergeRegions) private static Put
RegionStateStore.addSequenceNum
(Put p, long openSeqNum, int replicaId) private CompletableFuture<Void>
RegionStateStore.updateRegionLocation
(RegionInfo regionInfo, RegionState.State state, Put put) -
Uses of Put in org.apache.hadoop.hbase.namequeues
Modifier and TypeMethodDescriptionprivate static void
WALEventTrackerTableAccessor.doPut
(Connection connection, List<Put> puts) -
Uses of Put in org.apache.hadoop.hbase.quotas
Modifier 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) Modifier and TypeMethodDescriptionprivate static void
QuotaUtil.doPut
(Connection connection, Put put) -
Uses of Put in org.apache.hadoop.hbase.regionserver
Modifier 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) Deprecated.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
Modifier and TypeMethodDescriptionstatic Put
ReplicationBarrierFamilyFormat.makePutForReplicationBarrier
(RegionInfo regionInfo, long openSeqNum, long ts) Modifier and TypeMethodDescriptionstatic void
ReplicationBarrierFamilyFormat.addReplicationBarrier
(Put put, long openSeqNum) static void
ReplicationBarrierFamilyFormat.addReplicationParent
(Put put, List<RegionInfo> parents) -
Uses of Put in org.apache.hadoop.hbase.replication.regionserver
Modifier and TypeMethodDescriptionprivate Put
ReplicationSink.processReplicationMarkerEntry
(Cell cell) -
Uses of Put in org.apache.hadoop.hbase.security.access
Modifier and TypeMethodDescriptionvoid
AccessController.postPut
(ObserverContext<? extends RegionCoprocessorEnvironment> c, Put put, WALEdit edit, Durability durability) boolean
AccessController.preCheckAndPut
(ObserverContext<? extends RegionCoprocessorEnvironment> c, byte[] row, byte[] family, byte[] qualifier, CompareOperator op, ByteArrayComparable comparator, Put put, boolean result) boolean
AccessController.preCheckAndPutAfterRowLock
(ObserverContext<? extends RegionCoprocessorEnvironment> c, byte[] row, byte[] family, byte[] qualifier, CompareOperator opp, ByteArrayComparable comparator, Put put, boolean result) void
AccessController.prePut
(ObserverContext<? extends RegionCoprocessorEnvironment> c, Put put, WALEdit edit, Durability durability) -
Uses of Put in org.apache.hadoop.hbase.slowlog
Modifier and TypeMethodDescriptionprivate static void
SlowLogTableAccessor.doPut
(Connection connection, List<Put> puts) -
Uses of Put in org.apache.hadoop.hbase.thrift2
Modifier and TypeMethodDescriptionstatic Put
ThriftUtilities.putFromThrift
(org.apache.hadoop.hbase.thrift2.generated.TPut in) Creates aPut
(HBase) from aTPut
(Thrift)Modifier and TypeMethodDescriptionThriftUtilities.putsFromThrift
(List<org.apache.hadoop.hbase.thrift2.generated.TPut> in) Converts multipleTPut
s (Thrift) into a list ofPut
s (HBase).Modifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.thrift2.generated.TPut
ThriftUtilities.putFromHBase
(Put in) Modifier 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
Modifier and TypeMethodDescriptionvoid
boolean
-
Uses of Put in org.apache.hadoop.hbase.util
Modifier and TypeFieldDescriptionprivate Put
MultiThreadedWriterWithACL.HBaseWriterThreadWithACL.WriteAccessAction.put
Modifier and TypeMethodDescriptionvoid
void
private void
MultiThreadedWriterWithACL.recordFailure
(Table table, Put put, long keyBase, long start, IOException e) void
-
Uses of Put in org.apache.hadoop.hbase.wal