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.
Multi Cluster Replication
-
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 inModifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.client.PutMetaTableAccessor.addDaughtersToPut(org.apache.hadoop.hbase.client.Put put, org.apache.hadoop.hbase.client.RegionInfo splitA, org.apache.hadoop.hbase.client.RegionInfo splitB) Adds split daughters to the Putstatic org.apache.hadoop.hbase.client.PutMetaTableAccessor.addEmptyLocation(org.apache.hadoop.hbase.client.Put p, int replicaId) static org.apache.hadoop.hbase.client.PutMetaTableAccessor.addLocation(org.apache.hadoop.hbase.client.Put p, org.apache.hadoop.hbase.ServerName sn, long openSeqNum, int replicaId) static org.apache.hadoop.hbase.client.PutMetaTableAccessor.addRegionInfo(org.apache.hadoop.hbase.client.Put p, org.apache.hadoop.hbase.client.RegionInfo hri) static org.apache.hadoop.hbase.client.PutMetaTableAccessor.addRegionStateToPut(org.apache.hadoop.hbase.client.Put put, int replicaId, org.apache.hadoop.hbase.master.RegionState.State state) Set the column value corresponding to thisreplicaId'sRegionStateto the providedstate.static org.apache.hadoop.hbase.client.PutMetaTableAccessor.makePutFromRegionInfo(org.apache.hadoop.hbase.client.RegionInfo regionInfo) Generates and returns aPutcontaining theRegionInfofor the catalog table.static org.apache.hadoop.hbase.client.PutMetaTableAccessor.makePutFromRegionInfo(org.apache.hadoop.hbase.client.RegionInfo regionInfo, long ts) Generates and returns aPutcontaining theRegionInfofor the catalog table.static org.apache.hadoop.hbase.client.PutMetaTableAccessor.makePutFromTableState(org.apache.hadoop.hbase.client.TableState state, long ts) Construct PUT for given stateMethods in org.apache.hadoop.hbase with parameters of type org.apache.hadoop.hbase.client.Put in inModifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.client.PutMetaTableAccessor.addDaughtersToPut(org.apache.hadoop.hbase.client.Put put, org.apache.hadoop.hbase.client.RegionInfo splitA, org.apache.hadoop.hbase.client.RegionInfo splitB) Adds split daughters to the Putstatic org.apache.hadoop.hbase.client.PutMetaTableAccessor.addEmptyLocation(org.apache.hadoop.hbase.client.Put p, int replicaId) static org.apache.hadoop.hbase.client.PutMetaTableAccessor.addLocation(org.apache.hadoop.hbase.client.Put p, org.apache.hadoop.hbase.ServerName sn, long openSeqNum, int replicaId) static org.apache.hadoop.hbase.client.PutMetaTableAccessor.addRegionInfo(org.apache.hadoop.hbase.client.Put p, org.apache.hadoop.hbase.client.RegionInfo hri) static org.apache.hadoop.hbase.client.PutMetaTableAccessor.addRegionStateToPut(org.apache.hadoop.hbase.client.Put put, int replicaId, org.apache.hadoop.hbase.master.RegionState.State state) Set the column value corresponding to thisreplicaId'sRegionStateto the providedstate.Method parameters in org.apache.hadoop.hbase with type arguments of type org.apache.hadoop.hbase.client.Put in inModifier and TypeMethodDescriptionstatic voidMetaTableAccessor.putsToMetaTable(org.apache.hadoop.hbase.client.Connection connection, List<org.apache.hadoop.hbase.client.Put> ps) Put the passedpsto thehbase:metatable. -
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 inModifier and TypeMethodDescriptionorg.apache.hadoop.hbase.client.PutPut.add(org.apache.hadoop.hbase.Cell cell) Add the specified KeyValue to this Put operation.org.apache.hadoop.hbase.client.PutPut.addColumn(byte[] family, byte[] qualifier, byte[] value) Add the specified column and value to this Put operation.org.apache.hadoop.hbase.client.PutPut.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.PutPut.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.PutPut.setACL(String user, org.apache.hadoop.hbase.security.access.Permission perms) org.apache.hadoop.hbase.client.Putorg.apache.hadoop.hbase.client.PutPut.setAttribute(String name, byte[] value) org.apache.hadoop.hbase.client.PutPut.setCellVisibility(org.apache.hadoop.hbase.security.visibility.CellVisibility expression) org.apache.hadoop.hbase.client.Putorg.apache.hadoop.hbase.client.PutPut.setDurability(org.apache.hadoop.hbase.client.Durability d) org.apache.hadoop.hbase.client.PutPut.setId(String id) org.apache.hadoop.hbase.client.PutPut.setPriority(int priority) org.apache.hadoop.hbase.client.PutPut.setTimestamp(long timestamp) org.apache.hadoop.hbase.client.PutPut.setTTL(long ttl) Methods in org.apache.hadoop.hbase.client with parameters of type org.apache.hadoop.hbase.client.Put in inModifier and TypeMethodDescriptionCheckAndMutate.Builder.build(org.apache.hadoop.hbase.client.Put put) Build the CheckAndMutate objectAsyncTable.put(org.apache.hadoop.hbase.client.Put put) Puts some data to the table.default voidTable.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.booleanTable.CheckAndMutateBuilder.thenPut(org.apache.hadoop.hbase.client.Put put) Deprecated.Specify a Put to commit if the check succeeds.booleanTable.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 inModifier and TypeMethodDescriptionAsyncTable.put(List<org.apache.hadoop.hbase.client.Put> puts) Puts some data in the table, in batch.default voidTable.put(List<org.apache.hadoop.hbase.client.Put> puts) Batch puts the specified data into the table.default CompletableFuture<Void>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 inModifierConstructorDescriptionPut(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 inModifier and TypeMethodDescriptiondefault booleanRegionObserver.postCheckAndPut(org.apache.hadoop.hbase.coprocessor.ObserverContext<? extends 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 3.0.0 and will be removed in 4.0.0.default booleanRegionObserver.postCheckAndPut(org.apache.hadoop.hbase.coprocessor.ObserverContext<? extends 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 3.0.0 and will be removed in 4.0.0.default voidRegionObserver.postPut(org.apache.hadoop.hbase.coprocessor.ObserverContext<? extends 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 voidRegionObserver.postPut(org.apache.hadoop.hbase.coprocessor.ObserverContext<? extends 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 3.0.0 and will be removed in 4.0.0.default booleanRegionObserver.preCheckAndPut(org.apache.hadoop.hbase.coprocessor.ObserverContext<? extends 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 3.0.0 and will be removed in 4.0.0.default booleanRegionObserver.preCheckAndPut(org.apache.hadoop.hbase.coprocessor.ObserverContext<? extends 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 3.0.0 and will be removed in 4.0.0.default booleanRegionObserver.preCheckAndPutAfterRowLock(org.apache.hadoop.hbase.coprocessor.ObserverContext<? extends 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 3.0.0 and will be removed in 4.0.0.default booleanRegionObserver.preCheckAndPutAfterRowLock(org.apache.hadoop.hbase.coprocessor.ObserverContext<? extends 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 3.0.0 and will be removed in 4.0.0.default voidRegionObserver.prePut(org.apache.hadoop.hbase.coprocessor.ObserverContext<? extends 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 voidRegionObserver.prePut(org.apache.hadoop.hbase.coprocessor.ObserverContext<? extends 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 3.0.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 inModifier and TypeMethodDescriptionvoidTableOutputFormat.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 inModifier and TypeMethodDescriptionvoidIdentityTableReduce.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)voidIdentityTableReduce.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 inModifier and TypeMethodDescriptionprotected voidImport.Importer.addPutToKv(org.apache.hadoop.hbase.client.Put put, org.apache.hadoop.hbase.Cell kv) protected voidTsvImporterMapper.populatePut(byte[] lineBytes, org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser.ParsedLine parsed, org.apache.hadoop.hbase.client.Put put, int i) protected voidImport.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 inModifier and TypeMethodDescriptionprotected voidPutCombiner.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 voidPutSortReducer.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 inModifier and TypeMethodDescriptionvoidRegionCoprocessorHost.postPut(org.apache.hadoop.hbase.client.Put put, org.apache.hadoop.hbase.wal.WALEdit edit) booleanRegionCoprocessorHost.prePut(org.apache.hadoop.hbase.client.Put put, org.apache.hadoop.hbase.wal.WALEdit edit) Supports Coprocessor 'bypass'.voidHRegion.put(org.apache.hadoop.hbase.client.Put put) voidRegion.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.replication
Methods in org.apache.hadoop.hbase.replication that return org.apache.hadoop.hbase.client.Put in inModifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.client.PutReplicationBarrierFamilyFormat.makePutForReplicationBarrier(org.apache.hadoop.hbase.client.RegionInfo regionInfo, long openSeqNum, long ts) Methods in org.apache.hadoop.hbase.replication with parameters of type org.apache.hadoop.hbase.client.Put in inModifier and TypeMethodDescriptionstatic voidReplicationBarrierFamilyFormat.addReplicationBarrier(org.apache.hadoop.hbase.client.Put put, long openSeqNum) static voidReplicationBarrierFamilyFormat.addReplicationParent(org.apache.hadoop.hbase.client.Put put, List<org.apache.hadoop.hbase.client.RegionInfo> parents) -
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 inModifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.client.PutProtobufUtil.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.PutProtobufUtil.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 inModifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MutateRequestRequestConverter.buildMutateRequest(byte[] regionName, org.apache.hadoop.hbase.client.Put put) Create a protocol buffer MutateRequest for a put -
Uses of org.apache.hadoop.hbase.client.Put in org.apache.hadoop.hbase.util
Methods in org.apache.hadoop.hbase.util with parameters of type org.apache.hadoop.hbase.client.Put in inModifier and TypeMethodDescriptionvoidMultiThreadedWriter.HBaseWriterThread.insert(org.apache.hadoop.hbase.client.Table table, org.apache.hadoop.hbase.client.Put put, long keyBase) voidMultiThreadedWriterWithACL.HBaseWriterThreadWithACL.insert(org.apache.hadoop.hbase.client.Table table, org.apache.hadoop.hbase.client.Put put, long keyBase)