@InterfaceAudience.Private @InterfaceStability.Evolving public class BufferedMutatorImpl extends Object implements BufferedMutator
Used to communicate with a single HBase table similar to Table
but meant for batched, potentially asynchronous puts. Obtain an instance from
a Connection
and call close()
afterwards. Provide an alternate
to this implementation by setting BufferedMutatorParams.implementationClassName(String)
or by setting alternate classname via the key {} in Configuration.
While this can be used across threads, great care should be used when doing so. Errors are global to the buffered mutator and the Exceptions can be thrown on any thread that causes the flush for requests.
ConnectionFactory
,
Connection
BufferedMutator.ExceptionListener
Modifier and Type | Field and Description |
---|---|
static String |
HBASE_BUFFEREDMUTATOR_CLASSNAME_KEY
Key to use setting non-default BufferedMutator implementation
classname via Configuration.
|
CLASSNAME_KEY
Modifier and Type | Method and Description |
---|---|
void |
close()
Performs a
BufferedMutator.flush() and releases any resources held. |
void |
flush()
Executes all the buffered, asynchronous
Mutation operations and waits until they
are done. |
org.apache.hadoop.conf.Configuration |
getConfiguration()
Returns the
Configuration object used by this instance. |
TableName |
getName()
Gets the fully qualified table name instance of the table that this BufferedMutator writes to.
|
long |
getWriteBufferSize()
Returns the maximum size in bytes of the write buffer for this HTable.
|
void |
mutate(List<? extends Mutation> ms)
Send some
Mutation s to the table. |
void |
mutate(Mutation m)
Sends a
Mutation to the table. |
void |
setOperationTimeout(int operationTimeout)
Set operation timeout for this mutator instance
|
void |
setRpcTimeout(int rpcTimeout)
Set rpc timeout for this mutator instance
|
void |
setWriteBufferSize(long writeBufferSize)
Deprecated.
Going away when we drop public support for
HTable . |
void |
validatePut(Put put) |
public static final String HBASE_BUFFEREDMUTATOR_CLASSNAME_KEY
public TableName getName()
BufferedMutator
getName
in interface BufferedMutator
public org.apache.hadoop.conf.Configuration getConfiguration()
BufferedMutator
Configuration
object used by this instance.
The reference returned is not a copy, so any change made to it will affect this instance.
getConfiguration
in interface BufferedMutator
public void mutate(Mutation m) throws InterruptedIOException, RetriesExhaustedWithDetailsException
BufferedMutator
Mutation
to the table. The mutations will be buffered and sent over the
wire as part of a batch. Currently only supports Put
and Delete
mutations.mutate
in interface BufferedMutator
m
- The data to send.InterruptedIOException
RetriesExhaustedWithDetailsException
public void mutate(List<? extends Mutation> ms) throws InterruptedIOException, RetriesExhaustedWithDetailsException
BufferedMutator
Mutation
s to the table. The mutations will be buffered and sent over the
wire as part of a batch. There is no guarantee of sending entire content of mutations
in a single batch; it will be broken up according to the write buffer capacity.mutate
in interface BufferedMutator
ms
- The data to send.InterruptedIOException
RetriesExhaustedWithDetailsException
public void validatePut(Put put) throws IllegalArgumentException
IllegalArgumentException
public void close() throws IOException
BufferedMutator
BufferedMutator.flush()
and releases any resources held.close
in interface Closeable
close
in interface AutoCloseable
close
in interface BufferedMutator
IOException
- if a remote or network exception occurs.public void flush() throws InterruptedIOException, RetriesExhaustedWithDetailsException
BufferedMutator
Mutation
operations and waits until they
are done.flush
in interface BufferedMutator
InterruptedIOException
RetriesExhaustedWithDetailsException
@Deprecated public void setWriteBufferSize(long writeBufferSize) throws RetriesExhaustedWithDetailsException, InterruptedIOException
HTable
.HTable.setWriteBufferSize(long)
only. This ought
not be called for production uses.
If the new buffer size is smaller than the stored data, the flush()
will be called.writeBufferSize
- The max size of internal buffer where data is stored.RetriesExhaustedWithDetailsException
- if an I/O error occurs and there are too many retries.InterruptedIOException
- if the I/O task is interrupted.public long getWriteBufferSize()
The default value comes from the configuration parameter hbase.client.write.buffer
.
getWriteBufferSize
in interface BufferedMutator
public void setRpcTimeout(int rpcTimeout)
BufferedMutator
setRpcTimeout
in interface BufferedMutator
public void setOperationTimeout(int operationTimeout)
BufferedMutator
setOperationTimeout
in interface BufferedMutator
Copyright © 2007–2017 The Apache Software Foundation. All rights reserved.