org.apache.hadoop.hbase.mapreduce
Class BufferedHTable
java.lang.Object
org.apache.hadoop.hbase.client.HTable
org.apache.hadoop.hbase.mapreduce.BufferedHTable
- All Implemented Interfaces:
- Closeable, HTableInterface
@InterfaceAudience.Private
public class BufferedHTable
- extends HTable
Buffers writes for Deletes in addition to Puts. Buffering Deletes can significantly speed up
MapReduce jobs. The order of both Mutation types is preserved in the write buffer, and a buffer
flush can be triggered by either Put or Delete operations.
Constructor Summary |
BufferedHTable(org.apache.hadoop.conf.Configuration conf,
byte[] tableName)
|
BufferedHTable(org.apache.hadoop.conf.Configuration conf,
String tableName)
|
Methods inherited from class org.apache.hadoop.hbase.client.HTable |
append, batch, batch, batchCallback, batchCallback, batchCoprocessorService, batchCoprocessorService, checkAndDelete, checkAndMutate, checkAndPut, clearRegionCache, coprocessorService, coprocessorService, coprocessorService, exists, exists, flushCommits, get, get, getConfiguration, getConnection, getDefaultExecutor, getEndKeys, getMaxKeyValueSize, getName, getOperationTimeout, getRegionCachePrefetch, getRegionCachePrefetch, getRegionCachePrefetch, getRegionCachePrefetch, getRegionLocation, getRegionLocation, getRegionLocation, getRegionLocations, getRegionsInRange, getRegionsInRange, getRowOrBefore, getScanner, getScanner, getScanner, getScannerCaching, getStartEndKeys, getStartKeys, getTableDescriptor, getTableName, getWriteBuffer, getWriteBufferSize, increment, incrementColumnValue, incrementColumnValue, incrementColumnValue, isAutoFlush, isTableEnabled, isTableEnabled, isTableEnabled, isTableEnabled, isTableEnabled, isTableEnabled, main, mutateRow, processBatch, processBatchCallback, put, put, setAutoFlush, setAutoFlush, setAutoFlushTo, setOperationTimeout, setRegionCachePrefetch, setRegionCachePrefetch, setRegionCachePrefetch, setRegionCachePrefetch, setScannerCaching, setWriteBufferSize, toString, validatePut, validatePut |
BufferedHTable
public BufferedHTable(org.apache.hadoop.conf.Configuration conf,
String tableName)
throws IOException
- Throws:
IOException
BufferedHTable
public BufferedHTable(org.apache.hadoop.conf.Configuration conf,
byte[] tableName)
throws IOException
- Throws:
IOException
delete
public void delete(Delete delete)
throws IOException
- Specified by:
delete
in interface HTableInterface
- Overrides:
delete
in class HTable
- Throws:
IOException
delete
public void delete(List<Delete> deletes)
throws IOException
- Specified by:
delete
in interface HTableInterface
- Overrides:
delete
in class HTable
- Throws:
IOException
close
public void close()
throws IOException
- Specified by:
close
in interface Closeable
- Specified by:
close
in interface HTableInterface
- Overrides:
close
in class HTable
- Throws:
IOException
Copyright © 2007-2016 The Apache Software Foundation. All Rights Reserved.