Package | Description |
---|---|
org.apache.hadoop.hbase | |
org.apache.hadoop.hbase.client |
Provides HBase Client
|
org.apache.hadoop.hbase.constraint |
Restrict the domain of a data attribute, often times to fulfill business rules/requirements.
|
org.apache.hadoop.hbase.coprocessor |
Table of Contents
|
org.apache.hadoop.hbase.favored | |
org.apache.hadoop.hbase.mapred |
Provides HBase MapReduce
Input/OutputFormats, a table indexing MapReduce job, and utility methods.
|
org.apache.hadoop.hbase.mapreduce |
Provides HBase MapReduce
Input/OutputFormats, a table indexing MapReduce job, and utility methods.
|
org.apache.hadoop.hbase.master.assignment | |
org.apache.hadoop.hbase.quotas | |
org.apache.hadoop.hbase.regionserver | |
org.apache.hadoop.hbase.rest.client | |
org.apache.hadoop.hbase.security.access | |
org.apache.hadoop.hbase.thrift2 |
Provides an HBase Thrift
service.
|
org.apache.hadoop.hbase.thrift2.client |
Modifier and Type | Method and Description |
---|---|
private static Put |
MetaTableAccessor.addDaughtersToPut(Put put,
RegionInfo splitA,
RegionInfo splitB)
Adds split daughters to the Put
|
private static 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,
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,
long ts)
Generates and returns a Put containing the region into for the catalog table
|
static Put |
MetaTableAccessor.makePutFromTableState(TableState state,
long ts)
Construct PUT for given state
|
Modifier and Type | Method and Description |
---|---|
private static Put |
MetaTableAccessor.addDaughtersToPut(Put put,
RegionInfo splitA,
RegionInfo splitB)
Adds split daughters to the Put
|
private static 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,
RegionState.State state) |
static void |
MetaTableAccessor.addReplicationBarrier(Put put,
long openSeqNum)
See class comment on SerialReplicationChecker
|
private static void |
MetaTableAccessor.addReplicationParent(Put put,
List<RegionInfo> parents) |
private static Put |
MetaTableAccessor.addSequenceNum(Put p,
long openSeqNum,
int replicaId) |
private static void |
MetaTableAccessor.put(Table t,
Put p) |
private static void |
MetaTableAccessor.putToMetaTable(Connection connection,
Put p)
Put the passed
p to the hbase:meta table. |
Modifier and Type | Method and Description |
---|---|
static void |
MetaTableAccessor.putsToMetaTable(Connection connection,
List<Put> ps)
Put the passed
ps to the hbase:meta table. |
Modifier and Type | Field and Description |
---|---|
(package private) Put |
HTableMultiplexer.PutStatus.put |
Modifier and Type | Method and Description |
---|---|
Put |
Put.add(Cell cell)
Add the specified KeyValue to this Put operation.
|
Put |
Put.addColumn(byte[] family,
byte[] qualifier,
byte[] value)
Add the specified column and value to this Put operation.
|
Put |
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 |
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 |
Put.addImmutable(byte[] family,
byte[] qualifier,
byte[] value)
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0.
Use
add(Cell) and CellBuilder instead |
Put |
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.
Use
add(Cell) and CellBuilder instead |
Put |
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.
Use
add(Cell) and CellBuilder instead |
Put |
Put.setACL(Map<String,Permission> perms) |
Put |
Put.setACL(String user,
Permission perms) |
Put |
Put.setAttribute(String name,
byte[] value) |
Put |
Put.setCellVisibility(CellVisibility expression) |
Put |
Put.setClusterIds(List<UUID> clusterIds) |
Put |
Put.setDurability(Durability d) |
Put |
Put.setFamilyCellMap(NavigableMap<byte[],List<Cell>> map)
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0.
Use
Put(byte[], long, NavigableMap) instead |
Put |
Put.setId(String id) |
Put |
Put.setPriority(int priority) |
Put |
Put.setTimestamp(long timestamp) |
Put |
Put.setTTL(long ttl) |
Modifier and Type | Method and Description |
---|---|
List<Put> |
HTableMultiplexer.put(byte[] tableName,
List<Put> puts)
Deprecated.
Use
HTableMultiplexer.put(TableName, List) instead. |
List<Put> |
HTableMultiplexer.put(TableName tableName,
List<Put> puts)
Deprecated.
The puts request will be buffered by their corresponding buffer queue.
|
Modifier and Type | Method and Description |
---|---|
void |
RowMutations.add(Put p)
Deprecated.
since 2.0 version and will be removed in 3.0 version.
use
RowMutations.add(Mutation) |
boolean |
HTable.checkAndPut(byte[] row,
byte[] family,
byte[] qualifier,
byte[] value,
Put put)
Deprecated.
|
default boolean |
Table.checkAndPut(byte[] row,
byte[] family,
byte[] qualifier,
byte[] value,
Put put)
Deprecated.
Since 2.0.0. Will be removed in 3.0.0. Use
Table.checkAndMutate(byte[], byte[]) |
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,
CompareFilter.CompareOp compareOp,
byte[] value,
Put put)
Deprecated.
Since 2.0.0. Will be removed in 3.0.0. Use
Table.checkAndMutate(byte[], byte[]) |
boolean |
HTable.checkAndPut(byte[] row,
byte[] family,
byte[] qualifier,
CompareOperator op,
byte[] value,
Put put)
Deprecated.
|
default boolean |
Table.checkAndPut(byte[] row,
byte[] family,
byte[] qualifier,
CompareOperator op,
byte[] value,
Put put)
Deprecated.
Since 2.0.0. Will be removed in 3.0.0. Use
Table.checkAndMutate(byte[], byte[]) |
private boolean |
HTable.doCheckAndPut(byte[] row,
byte[] family,
byte[] qualifier,
String opName,
byte[] value,
TimeRange timeRange,
Put put) |
boolean |
HTableMultiplexer.put(byte[] tableName,
Put put)
Deprecated.
Use
HTableMultiplexer.put(TableName, Put) instead. |
boolean |
HTableMultiplexer.put(byte[] tableName,
Put put,
int retry)
Deprecated.
Use
HTableMultiplexer.put(TableName, Put) instead. |
void |
HTable.put(Put put) |
CompletableFuture<Void> |
AsyncTable.put(Put put)
Puts some data to the table.
|
default void |
Table.put(Put put)
Puts some data in the table.
|
CompletableFuture<Void> |
RawAsyncTableImpl.put(Put put) |
CompletableFuture<Void> |
AsyncTableImpl.put(Put put) |
boolean |
HTableMultiplexer.put(TableName tableName,
Put put)
Deprecated.
The put request will be buffered by its corresponding buffer queue.
|
boolean |
HTableMultiplexer.put(TableName tableName,
Put put,
int maxAttempts)
Deprecated.
The put request will be buffered by its corresponding buffer queue.
|
boolean |
HTable.CheckAndMutateBuilderImpl.thenPut(Put put) |
CompletableFuture<Boolean> |
AsyncTable.CheckAndMutateBuilder.thenPut(Put put) |
boolean |
Table.CheckAndMutateBuilder.thenPut(Put put) |
CompletableFuture<Boolean> |
RawAsyncTableImpl.CheckAndMutateBuilderImpl.thenPut(Put put) |
private void |
HTable.validatePut(Put put) |
(package private) static void |
ConnectionUtils.validatePut(Put put,
int maxKeyValueSize) |
Modifier and Type | Method and Description |
---|---|
List<Put> |
HTableMultiplexer.put(byte[] tableName,
List<Put> puts)
Deprecated.
Use
HTableMultiplexer.put(TableName, List) instead. |
void |
HTable.put(List<Put> puts) |
List<CompletableFuture<Void>> |
AsyncTable.put(List<Put> puts)
Puts some data in the table, in batch.
|
default void |
Table.put(List<Put> puts)
Batch puts the specified data into the table.
|
List<CompletableFuture<Void>> |
RawAsyncTableImpl.put(List<Put> puts) |
List<CompletableFuture<Void>> |
AsyncTableImpl.put(List<Put> puts) |
List<Put> |
HTableMultiplexer.put(TableName tableName,
List<Put> puts)
Deprecated.
The puts request will be buffered by their corresponding buffer queue.
|
default CompletableFuture<Void> |
AsyncTable.putAll(List<Put> puts)
A simple version of batch put.
|
Constructor and Description |
---|
Put(Put putToCopy)
Copy constructor.
|
PutStatus(RegionInfo regionInfo,
Put put,
int maxAttempCount) |
Modifier and Type | Method and Description |
---|---|
void |
Constraint.check(Put p)
Check a
Put to ensure it is valid for the table. |
void |
ConstraintProcessor.prePut(ObserverContext<RegionCoprocessorEnvironment> e,
Put put,
WALEdit edit,
Durability durability) |
Modifier and Type | Method and Description |
---|---|
default boolean |
RegionObserver.postCheckAndPut(ObserverContext<RegionCoprocessorEnvironment> c,
byte[] row,
byte[] family,
byte[] qualifier,
CompareOperator op,
ByteArrayComparable comparator,
Put put,
boolean result)
Called after checkAndPut
|
default void |
RegionObserver.postPut(ObserverContext<RegionCoprocessorEnvironment> c,
Put put,
WALEdit edit,
Durability durability)
Called after the client stores a value.
|
default boolean |
RegionObserver.preCheckAndPut(ObserverContext<RegionCoprocessorEnvironment> c,
byte[] row,
byte[] family,
byte[] qualifier,
CompareOperator op,
ByteArrayComparable comparator,
Put put,
boolean result)
Called before checkAndPut.
|
default boolean |
RegionObserver.preCheckAndPutAfterRowLock(ObserverContext<RegionCoprocessorEnvironment> c,
byte[] row,
byte[] family,
byte[] qualifier,
CompareOperator op,
ByteArrayComparable comparator,
Put put,
boolean result)
Called before checkAndPut but after acquiring rowlock.
|
default void |
RegionObserver.prePut(ObserverContext<RegionCoprocessorEnvironment> c,
Put put,
WALEdit edit,
Durability durability)
Called before the client stores a value.
|
void |
MetaTableMetrics.ExampleRegionObserverMeta.prePut(ObserverContext<RegionCoprocessorEnvironment> e,
Put put,
WALEdit edit,
Durability durability) |
Modifier and Type | Method and Description |
---|---|
private static Put |
FavoredNodeAssignmentHelper.makePutFromRegionInfo(RegionInfo regionInfo,
List<ServerName> favoredNodeList)
Generates and returns a Put containing the region info for the catalog table and the servers
|
Modifier and Type | Method and Description |
---|---|
void |
TableOutputFormat.TableRecordWriter.write(ImmutableBytesWritable key,
Put value) |
Modifier and Type | Method and Description |
---|---|
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)
|
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)
|
Modifier and Type | Method and Description |
---|---|
protected 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.Context context,
Put put,
Delete delete) |
Modifier and Type | Method and Description |
---|---|
protected void |
PutSortReducer.reduce(ImmutableBytesWritable row,
Iterable<Put> puts,
org.apache.hadoop.mapreduce.Reducer.Context context) |
protected void |
PutCombiner.reduce(K row,
Iterable<Put> vals,
org.apache.hadoop.mapreduce.Reducer.Context context) |
Modifier and Type | Method and Description |
---|---|
private void |
RegionStateStore.updateRegionLocation(RegionInfo regionInfo,
RegionState.State state,
Put put) |
Modifier and Type | Method and Description |
---|---|
(package private) static Put |
QuotaTableUtil.createPutForNamespaceSnapshotSize(String namespace,
long size)
Creates a
Put 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 Type | Method and Description |
---|---|
private static void |
QuotaUtil.doPut(Connection connection,
Put put) |
Modifier and Type | Method and Description |
---|---|
protected 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 replay
|
boolean |
RegionCoprocessorHost.postCheckAndPut(byte[] row,
byte[] family,
byte[] qualifier,
CompareOperator op,
ByteArrayComparable comparator,
Put put,
boolean result) |
void |
RegionCoprocessorHost.postPut(Put put,
WALEdit edit,
Durability durability) |
Boolean |
RegionCoprocessorHost.preCheckAndPut(byte[] row,
byte[] family,
byte[] qualifier,
CompareOperator op,
ByteArrayComparable comparator,
Put put)
Supports Coprocessor 'bypass'.
|
Boolean |
RegionCoprocessorHost.preCheckAndPutAfterRowLock(byte[] row,
byte[] family,
byte[] qualifier,
CompareOperator op,
ByteArrayComparable comparator,
Put put)
Supports Coprocessor 'bypass'.
|
boolean |
RegionCoprocessorHost.prePut(Put put,
WALEdit edit,
Durability durability)
Supports Coprocessor 'bypass'.
|
void |
Region.put(Put put)
Puts some data in the table.
|
void |
HRegion.put(Put put) |
Modifier and Type | Method and Description |
---|---|
protected CellSetModel |
RemoteHTable.buildModelFromPut(Put put) |
boolean |
RemoteHTable.checkAndPut(byte[] row,
byte[] family,
byte[] qualifier,
byte[] value,
Put put)
Deprecated.
|
boolean |
RemoteHTable.checkAndPut(byte[] row,
byte[] family,
byte[] qualifier,
CompareFilter.CompareOp compareOp,
byte[] value,
Put put)
Deprecated.
|
boolean |
RemoteHTable.checkAndPut(byte[] row,
byte[] family,
byte[] qualifier,
CompareOperator compareOp,
byte[] value,
Put put)
Deprecated.
|
private boolean |
RemoteHTable.doCheckAndPut(byte[] row,
byte[] family,
byte[] qualifier,
byte[] value,
Put put) |
void |
RemoteHTable.put(Put put) |
boolean |
RemoteHTable.CheckAndMutateBuilderImpl.thenPut(Put put) |
Modifier and Type | Method and Description |
---|---|
void |
RemoteHTable.put(List<Put> puts) |
Modifier and Type | Method and Description |
---|---|
void |
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) |
Modifier and Type | Method and Description |
---|---|
static Put |
ThriftUtilities.putFromThrift(org.apache.hadoop.hbase.thrift2.generated.TPut in)
Creates a
Put (HBase) from a TPut (Thrift) |
Modifier and Type | Method and Description |
---|---|
static List<Put> |
ThriftUtilities.putsFromThrift(List<org.apache.hadoop.hbase.thrift2.generated.TPut> in)
Converts multiple
TPut s (Thrift) into a list of Put s (HBase). |
Modifier and Type | Method and Description |
---|---|
static org.apache.hadoop.hbase.thrift2.generated.TPut |
ThriftUtilities.putFromHBase(Put in) |
Modifier and Type | Method and Description |
---|---|
static List<org.apache.hadoop.hbase.thrift2.generated.TPut> |
ThriftUtilities.putsFromHBase(List<Put> in) |
Modifier and Type | Method and Description |
---|---|
void |
ThriftTable.put(Put put) |
boolean |
ThriftTable.CheckAndMutateBuilderImpl.thenPut(Put put) |
Modifier and Type | Method and Description |
---|---|
void |
ThriftTable.put(List<Put> puts) |
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.