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.
Multi Cluster Replication
Provides an HBase Thrift
service.
-
Uses of Put in org.apache.hadoop.hbase
Fields in org.apache.hadoop.hbase with type parameters of type PutModifier and TypeFieldDescriptionPerformanceEvaluation.AsyncSequentialWriteTest.puts
PerformanceEvaluation.SequentialWriteTest.puts
Methods in org.apache.hadoop.hbase that return PutModifier 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 stateMethods in org.apache.hadoop.hbase with parameters of type PutModifier 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.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 Put -
Uses of Put in org.apache.hadoop.hbase.client
Methods 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.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) Methods in org.apache.hadoop.hbase.client with parameters of type PutModifier 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) Method parameters in org.apache.hadoop.hbase.client with type arguments of type PutModifier 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.Constructors in org.apache.hadoop.hbase.client with parameters of type Put -
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<? extends 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<? 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.coprocessor.example.row.stats.utils
Methods in org.apache.hadoop.hbase.coprocessor.example.row.stats.utils that return PutModifier and TypeMethodDescriptionstatic Put
RowStatisticsTableUtil.buildPutForRegion
(byte[] regionRowKey, RowStatistics rowStatistics, boolean isMajor) -
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 that return PutModifier 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) Methods in org.apache.hadoop.hbase.master.assignment with parameters of type PutModifier 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
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) 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
Methods in org.apache.hadoop.hbase.replication that return PutModifier and TypeMethodDescriptionstatic Put
ReplicationBarrierFamilyFormat.makePutForReplicationBarrier
(RegionInfo regionInfo, long openSeqNum, long ts) Methods in org.apache.hadoop.hbase.replication with parameters of type PutModifier 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
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<? 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
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 -
Uses of Put in org.apache.hadoop.hbase.util
Fields in org.apache.hadoop.hbase.util declared as PutModifier and TypeFieldDescriptionprivate Put
MultiThreadedWriterWithACL.HBaseWriterThreadWithACL.WriteAccessAction.put
Methods in org.apache.hadoop.hbase.util with parameters of type PutModifier 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
Methods in org.apache.hadoop.hbase.wal that return Put