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 PutMetaTableAccessor.addDaughtersToPut(Put put, RegionInfo splitA, RegionInfo splitB) Adds split daughters to the Putstatic PutMetaTableAccessor.addEmptyLocation(Put p, int replicaId) static PutMetaTableAccessor.addLocation(Put p, ServerName sn, long openSeqNum, int replicaId) (package private) static PutMetaTableAccessor.addMergeRegions(Put put, Collection<RegionInfo> mergeRegions) static PutMetaTableAccessor.addRegionInfo(Put p, RegionInfo hri) private static PutMetaTableAccessor.addRegionStateToPut(Put put, int replicaId, RegionState.State state) private static PutMetaTableAccessor.addSequenceNum(Put p, long openSeqNum, int replicaId) static PutMetaTableAccessor.makePutForReplicationBarrier(RegionInfo regionInfo, long openSeqNum, long ts) static PutMetaTableAccessor.makePutFromRegionInfo(RegionInfo regionInfo) Generates and returns aPutcontaining theRegionInfofor the catalog table.static PutMetaTableAccessor.makePutFromRegionInfo(RegionInfo regionInfo, long ts) Generates and returns aPutcontaining theRegionInfofor the catalog table.static PutMetaTableAccessor.makePutFromTableState(TableState state, long ts) Construct PUT for given stateMethods in org.apache.hadoop.hbase with parameters of type PutModifier and TypeMethodDescriptionprivate static PutMetaTableAccessor.addDaughtersToPut(Put put, RegionInfo splitA, RegionInfo splitB) Adds split daughters to the Putstatic PutMetaTableAccessor.addEmptyLocation(Put p, int replicaId) static PutMetaTableAccessor.addLocation(Put p, ServerName sn, long openSeqNum, int replicaId) (package private) static PutMetaTableAccessor.addMergeRegions(Put put, Collection<RegionInfo> mergeRegions) static PutMetaTableAccessor.addRegionInfo(Put p, RegionInfo hri) private static PutMetaTableAccessor.addRegionStateToPut(Put put, int replicaId, RegionState.State state) static voidMetaTableAccessor.addReplicationBarrier(Put put, long openSeqNum) See class comment on SerialReplicationCheckerprivate static voidMetaTableAccessor.addReplicationParent(Put put, List<RegionInfo> parents) private static PutMetaTableAccessor.addSequenceNum(Put p, long openSeqNum, int replicaId) private static voidprivate static voidMetaTableAccessor.putToMetaTable(Connection connection, Put p) Put the passedpto thehbase:metatable.Method parameters in org.apache.hadoop.hbase with type arguments of type PutModifier and TypeMethodDescriptionstatic voidMetaTableAccessor.putsToMetaTable(Connection connection, List<Put> ps) Put the passedpsto thehbase:metatable. -
Uses of Put in org.apache.hadoop.hbase.backup.impl
Methods in org.apache.hadoop.hbase.backup.impl that return PutModifier and TypeMethodDescriptionprivate PutBackupSystemTable.createPutForBackupInfo(BackupInfo context) Creates Put operation for a given backup info objectprivate PutBackupSystemTable.createPutForBackupSet(String name, String[] tables) Creates Put operation to update backup set content(package private) static PutBackupSystemTable.createPutForBulkLoadedFile(TableName tn, byte[] fam, String p, String backupId, long ts, int idx) private PutBackupSystemTable.createPutForDeleteOperation(String[] backupIdList) private PutBackupSystemTable.createPutForIncrBackupTableSet(Set<TableName> tables, String backupRoot) Creates Put to store incremental backup table setprivate PutBackupSystemTable.createPutForMergeOperation(String[] backupIdList) private PutBackupSystemTable.createPutForRegionServerLastLogRollResult(String server, Long timestamp, String backupRoot) Creates Put to store RS last log resultprivate PutBackupSystemTable.createPutForStartBackupSession()private PutBackupSystemTable.createPutForStartCode(String startCode, String rootPath) Creates Put operation to store start code to backup system tableprivate PutBackupSystemTable.createPutForStopBackupSession()private PutBackupSystemTable.createPutForUpdateTablesForMerge(List<TableName> tables) private PutBackupSystemTable.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 TypeMethodDescriptionvoidDeprecated.since 2.0 version and will be removed in 3.0 version.Build the CheckAndMutate objectbooleanHTable.checkAndPut(byte[] row, byte[] family, byte[] qualifier, byte[] value, Put put) Deprecated.booleanHTable.checkAndPut(byte[] row, byte[] family, byte[] qualifier, CompareOperator op, byte[] value, Put put) Deprecated.booleanHTable.checkAndPut(byte[] row, byte[] family, byte[] qualifier, CompareFilter.CompareOp compareOp, byte[] value, Put put) Deprecated.default booleanTable.checkAndPut(byte[] row, byte[] family, byte[] qualifier, byte[] value, Put put) Deprecated.Since 2.0.0.default booleanTable.checkAndPut(byte[] row, byte[] family, byte[] qualifier, CompareOperator op, byte[] value, Put put) Deprecated.Since 2.0.0.default booleanTable.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.voidbooleanDeprecated.UseHTableMultiplexer.put(TableName, Put)instead.booleanDeprecated.UseHTableMultiplexer.put(TableName, Put)instead.booleanDeprecated.The put request will be buffered by its corresponding buffer queue.booleanDeprecated.The put request will be buffered by its corresponding buffer queue.default voidPuts 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.booleanbooleanbooleanDeprecated.Specify a Put to commit if the check succeeds.booleanDeprecated.Specify a Put to commit if the check succeeds.(package private) static voidConnectionUtils.validatePut(Put put, int maxKeyValueSize) private voidHTable.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.voidDeprecated.UseHTableMultiplexer.put(TableName, List)instead.Deprecated.The puts request will be buffered by their corresponding buffer queue.default voidBatch 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 TypeMethodDescriptionvoidCheck aPutto ensure it is valid for the table.voidConstraintProcessor.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 booleanRegionObserver.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 booleanRegionObserver.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 voidRegionObserver.postPut(ObserverContext<RegionCoprocessorEnvironment> c, Put put, WALEdit edit) Called after the client stores a value.default voidRegionObserver.postPut(ObserverContext<RegionCoprocessorEnvironment> c, Put put, WALEdit edit, Durability durability) Deprecated.since 2.5.0 and will be removed in 4.0.0.default booleanRegionObserver.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 booleanRegionObserver.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 booleanRegionObserver.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 booleanRegionObserver.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.voidMetaTableMetrics.ExampleRegionObserverMeta.prePut(ObserverContext<RegionCoprocessorEnvironment> e, Put put, WALEdit edit, Durability durability) default voidRegionObserver.prePut(ObserverContext<RegionCoprocessorEnvironment> c, Put put, WALEdit edit) Called before the client stores a value.default voidRegionObserver.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 PutFavoredNodeAssignmentHelper.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 TypeMethodDescriptionvoidTableOutputFormat.TableRecordWriter.write(ImmutableBytesWritable key, Put value) Method parameters in org.apache.hadoop.hbase.mapred with type arguments of type PutModifier and TypeMethodDescriptionvoidIdentityTableReduce.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)voidIdentityTableReduce.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 voidImport.Importer.addPutToKv(Put put, Cell kv) protected voidTsvImporterMapper.populatePut(byte[] lineBytes, ImportTsv.TsvParser.ParsedLine parsed, Put put, int i) protected voidImport.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 voidPutCombiner.reduce(K row, Iterable<Put> vals, org.apache.hadoop.mapreduce.Reducer<K, Put, K, Put>.org.apache.hadoop.mapreduce.Reducer.Context context) protected voidPutSortReducer.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 voidRegionStateStore.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 voidWALEventTrackerTableAccessor.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 PutQuotaTableUtil.createPutForNamespaceSnapshotSize(String namespace, long size) Creates aPutfor the namespace's total snapshot size.(package private) static PutQuotaTableUtil.createPutForSnapshotSize(TableName tableName, String snapshot, long size) (package private) static PutQuotaTableUtil.createPutForSpaceSnapshot(TableName tableName, SpaceQuotaSnapshot snapshot) Methods in org.apache.hadoop.hbase.quotas with parameters of type PutModifier and TypeMethodDescriptionprivate static voidQuotaUtil.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 voidHRegion.BatchOperation.checkAndPreparePut(Put p) Implement any Put request specific check and prepare logic here.voidHRegion.MutationBatchOperation.checkAndPreparePut(Put p) protected voidHRegion.ReplayBatchOperation.checkAndPreparePut(Put p) During replay, there could exist column families which are removed between region server failure and replayvoidbooleanSupports Coprocessor 'bypass'.voidvoidPuts 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 PutReplicationSink.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 TypeMethodDescriptionvoidAccessController.postPut(ObserverContext<RegionCoprocessorEnvironment> c, Put put, WALEdit edit, Durability durability) booleanAccessController.preCheckAndPut(ObserverContext<RegionCoprocessorEnvironment> c, byte[] row, byte[] family, byte[] qualifier, CompareOperator op, ByteArrayComparable comparator, Put put, boolean result) booleanAccessController.preCheckAndPutAfterRowLock(ObserverContext<RegionCoprocessorEnvironment> c, byte[] row, byte[] family, byte[] qualifier, CompareOperator opp, ByteArrayComparable comparator, Put put, boolean result) voidAccessController.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 voidSlowLogTableAccessor.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 PutThriftUtilities.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 multipleTPuts (Thrift) into a list ofPuts (HBase).Methods in org.apache.hadoop.hbase.thrift2 with parameters of type PutModifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.thrift2.generated.TPutThriftUtilities.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 TypeMethodDescriptionvoidbooleanMethod parameters in org.apache.hadoop.hbase.thrift2.client with type arguments of type Put