Package | Description |
---|---|
org.apache.accumulo.core.client | |
org.apache.accumulo.core.client.admin | |
org.apache.accumulo.core.client.mapred | |
org.apache.accumulo.core.client.mapreduce | |
org.apache.accumulo.core.client.mapreduce.lib.util |
This package exists to store common helpers for configuring MapReduce jobs in a single location.
|
org.apache.accumulo.core.client.mock |
Modifier and Type | Method and Description |
---|---|
abstract BatchDeleter |
Connector.createBatchDeleter(String tableName,
Authorizations authorizations,
int numQueryThreads,
BatchWriterConfig config) |
abstract BatchDeleter |
Connector.createBatchDeleter(String tableName,
Authorizations authorizations,
int numQueryThreads,
long maxMemory,
long maxLatency,
int maxWriteThreads)
Deprecated.
since 1.5.0; Use
Connector.createBatchDeleter(String, Authorizations, int, BatchWriterConfig) instead. |
abstract BatchScanner |
Connector.createBatchScanner(String tableName,
Authorizations authorizations,
int numQueryThreads)
Factory method to create a BatchScanner connected to Accumulo.
|
abstract BatchWriter |
Connector.createBatchWriter(String tableName,
BatchWriterConfig config)
Factory method to create a BatchWriter connected to Accumulo.
|
abstract BatchWriter |
Connector.createBatchWriter(String tableName,
long maxMemory,
long maxLatency,
int maxWriteThreads)
Deprecated.
since 1.5.0; Use
Connector.createBatchWriter(String, BatchWriterConfig) instead. |
abstract Scanner |
Connector.createScanner(String tableName,
Authorizations authorizations)
Factory method to create a Scanner connected to Accumulo.
|
void |
BatchDeleter.delete()
Deletes the ranges specified by
BatchDeleter.setRanges(java.util.Collection<org.apache.accumulo.core.data.Range>) . |
BatchWriter |
MultiTableBatchWriter.getBatchWriter(String table)
Returns a BatchWriter for a particular table.
|
Modifier and Type | Method and Description |
---|---|
int |
TableOperationsImpl.addConstraint(String tableName,
String constraintClassName) |
int |
TableOperationsHelper.addConstraint(String tableName,
String constraintClassName) |
int |
TableOperations.addConstraint(String tableName,
String constraintClassName)
Add a new constraint to a table.
|
void |
TableOperationsImpl.addSplits(String tableName,
SortedSet<org.apache.hadoop.io.Text> partitionKeys) |
void |
TableOperations.addSplits(String tableName,
SortedSet<org.apache.hadoop.io.Text> partitionKeys)
Ensures that tablets are split along a set of keys.
|
void |
TableOperationsHelper.attachIterator(String tableName,
IteratorSetting setting) |
void |
TableOperations.attachIterator(String tableName,
IteratorSetting setting)
Add an iterator to a table on all scopes.
|
void |
TableOperationsImpl.attachIterator(String tableName,
IteratorSetting setting,
EnumSet<org.apache.accumulo.core.iterators.IteratorUtil.IteratorScope> scopes) |
void |
TableOperationsHelper.attachIterator(String tableName,
IteratorSetting setting,
EnumSet<org.apache.accumulo.core.iterators.IteratorUtil.IteratorScope> scopes) |
void |
TableOperations.attachIterator(String tableName,
IteratorSetting setting,
EnumSet<org.apache.accumulo.core.iterators.IteratorUtil.IteratorScope> scopes)
Add an iterator to a table on the given scopes.
|
void |
TableOperationsImpl.cancelCompaction(String tableName) |
void |
TableOperations.cancelCompaction(String tableName)
Cancels a user initiated major compaction of a table initiated with
TableOperations.compact(String, Text, Text, boolean, boolean) or
TableOperations.compact(String, Text, Text, List, boolean, boolean) . |
void |
TableOperationsHelper.checkIteratorConflicts(String tableName,
IteratorSetting setting,
EnumSet<org.apache.accumulo.core.iterators.IteratorUtil.IteratorScope> scopes) |
void |
TableOperations.checkIteratorConflicts(String tableName,
IteratorSetting setting,
EnumSet<org.apache.accumulo.core.iterators.IteratorUtil.IteratorScope> scopes)
Check whether a given iterator configuration conflicts with existing configuration; in particular, determine if the name or priority are already in use for
the specified scopes.
|
void |
TableOperationsImpl.clearLocatorCache(String tableName)
Clears the tablet locator cache for a specified table
|
void |
TableOperations.clearLocatorCache(String tableName)
Clears the tablet locator cache for a specified table
|
void |
TableOperationsImpl.clone(String srcTableName,
String newTableName,
boolean flush,
Map<String,String> propertiesToSet,
Set<String> propertiesToExclude) |
void |
TableOperations.clone(String srcTableName,
String newTableName,
boolean flush,
Map<String,String> propertiesToSet,
Set<String> propertiesToExclude)
Clone a table from an existing table.
|
void |
TableOperationsImpl.compact(String tableName,
org.apache.hadoop.io.Text start,
org.apache.hadoop.io.Text end,
boolean flush,
boolean wait) |
void |
TableOperations.compact(String tableName,
org.apache.hadoop.io.Text start,
org.apache.hadoop.io.Text end,
boolean flush,
boolean wait)
Starts a full major compaction of the tablets in the range (start, end].
|
void |
TableOperationsImpl.compact(String tableName,
org.apache.hadoop.io.Text start,
org.apache.hadoop.io.Text end,
List<IteratorSetting> iterators,
boolean flush,
boolean wait) |
void |
TableOperations.compact(String tableName,
org.apache.hadoop.io.Text start,
org.apache.hadoop.io.Text end,
List<IteratorSetting> iterators,
boolean flush,
boolean wait)
Starts a full major compaction of the tablets in the range (start, end].
|
void |
TableOperationsImpl.delete(String tableName)
Delete a table
|
void |
TableOperations.delete(String tableName)
Delete a table
|
void |
TableOperationsImpl.deleteRows(String tableName,
org.apache.hadoop.io.Text start,
org.apache.hadoop.io.Text end) |
void |
TableOperations.deleteRows(String tableName,
org.apache.hadoop.io.Text start,
org.apache.hadoop.io.Text end)
Delete rows between (start, end]
|
void |
TableOperationsImpl.exportTable(String tableName,
String exportDir) |
void |
TableOperations.exportTable(String tableName,
String exportDir)
Exports a table.
|
static org.apache.hadoop.io.Text |
FindMax.findMax(Scanner scanner,
org.apache.hadoop.io.Text start,
boolean is,
org.apache.hadoop.io.Text end,
boolean ie) |
void |
TableOperationsImpl.flush(String tableName,
org.apache.hadoop.io.Text start,
org.apache.hadoop.io.Text end,
boolean wait)
Flush a table
|
void |
TableOperations.flush(String tableName,
org.apache.hadoop.io.Text start,
org.apache.hadoop.io.Text end,
boolean wait)
Flush a table's data that is currently in memory.
|
IteratorSetting |
TableOperationsHelper.getIteratorSetting(String tableName,
String name,
org.apache.accumulo.core.iterators.IteratorUtil.IteratorScope scope) |
IteratorSetting |
TableOperations.getIteratorSetting(String tableName,
String name,
org.apache.accumulo.core.iterators.IteratorUtil.IteratorScope scope)
Get the settings for an iterator.
|
Map<String,Set<org.apache.hadoop.io.Text>> |
TableOperationsImpl.getLocalityGroups(String tableName)
Gets the locality groups currently set for a table.
|
Map<String,Set<org.apache.hadoop.io.Text>> |
TableOperations.getLocalityGroups(String tableName)
Gets the locality groups currently set for a table.
|
org.apache.hadoop.io.Text |
TableOperationsImpl.getMaxRow(String tableName,
Authorizations auths,
org.apache.hadoop.io.Text startRow,
boolean startInclusive,
org.apache.hadoop.io.Text endRow,
boolean endInclusive) |
org.apache.hadoop.io.Text |
TableOperations.getMaxRow(String tableName,
Authorizations auths,
org.apache.hadoop.io.Text startRow,
boolean startInclusive,
org.apache.hadoop.io.Text endRow,
boolean endInclusive)
Finds the max row within a given range.
|
Iterable<Map.Entry<String,String>> |
TableOperationsImpl.getProperties(String tableName)
Gets properties of a table
|
Iterable<Map.Entry<String,String>> |
TableOperations.getProperties(String tableName)
Gets properties of a table.
|
Collection<org.apache.hadoop.io.Text> |
TableOperationsImpl.getSplits(String tableName)
Deprecated.
|
Collection<org.apache.hadoop.io.Text> |
TableOperations.getSplits(String tableName)
Deprecated.
since 1.5.0; use
TableOperations.listSplits(String) instead. |
Collection<org.apache.hadoop.io.Text> |
TableOperationsImpl.getSplits(String tableName,
int maxSplits)
Deprecated.
|
Collection<org.apache.hadoop.io.Text> |
TableOperations.getSplits(String tableName,
int maxSplits)
Deprecated.
since 1.5.0; use
TableOperations.listSplits(String, int) instead. |
String |
ActiveCompaction.getTable() |
void |
TableOperationsImpl.importDirectory(String tableName,
String dir,
String failureDir,
boolean setTime) |
void |
TableOperations.importDirectory(String tableName,
String dir,
String failureDir,
boolean setTime)
Bulk import all the files in a directory into a table.
|
Map<String,Integer> |
TableOperationsHelper.listConstraints(String tableName) |
Map<String,Integer> |
TableOperations.listConstraints(String tableName)
List constraints on a table with their assigned numbers.
|
Map<String,EnumSet<org.apache.accumulo.core.iterators.IteratorUtil.IteratorScope>> |
TableOperationsHelper.listIterators(String tableName) |
Map<String,EnumSet<org.apache.accumulo.core.iterators.IteratorUtil.IteratorScope>> |
TableOperations.listIterators(String tableName)
Get a list of iterators for this table.
|
Collection<org.apache.hadoop.io.Text> |
TableOperationsImpl.listSplits(String tableName) |
Collection<org.apache.hadoop.io.Text> |
TableOperations.listSplits(String tableName) |
Collection<org.apache.hadoop.io.Text> |
TableOperationsImpl.listSplits(String tableName,
int maxSplits) |
Collection<org.apache.hadoop.io.Text> |
TableOperations.listSplits(String tableName,
int maxSplits) |
void |
TableOperationsImpl.merge(String tableName,
org.apache.hadoop.io.Text start,
org.apache.hadoop.io.Text end) |
void |
TableOperations.merge(String tableName,
org.apache.hadoop.io.Text start,
org.apache.hadoop.io.Text end)
Merge tablets between (start, end]
|
void |
TableOperationsImpl.offline(String tableName) |
void |
TableOperations.offline(String tableName) |
void |
TableOperationsImpl.online(String tableName) |
void |
TableOperations.online(String tableName) |
void |
TableOperationsHelper.removeIterator(String tableName,
String name,
EnumSet<org.apache.accumulo.core.iterators.IteratorUtil.IteratorScope> scopes) |
void |
TableOperations.removeIterator(String tableName,
String name,
EnumSet<org.apache.accumulo.core.iterators.IteratorUtil.IteratorScope> scopes)
Remove an iterator from a table by name.
|
void |
TableOperationsImpl.rename(String oldTableName,
String newTableName)
Rename a table
|
void |
TableOperations.rename(String oldTableName,
String newTableName)
Rename a table
|
void |
TableOperationsImpl.setLocalityGroups(String tableName,
Map<String,Set<org.apache.hadoop.io.Text>> groups)
Sets a tables locality groups.
|
void |
TableOperations.setLocalityGroups(String tableName,
Map<String,Set<org.apache.hadoop.io.Text>> groups)
Sets a table's locality groups.
|
Set<Range> |
TableOperationsImpl.splitRangeByTablets(String tableName,
Range range,
int maxSplits) |
Set<Range> |
TableOperations.splitRangeByTablets(String tableName,
Range range,
int maxSplits) |
boolean |
TableOperationsImpl.testClassLoad(String tableName,
String className,
String asTypeName) |
boolean |
TableOperations.testClassLoad(String tableName,
String className,
String asTypeName)
Test to see if the instance can load the given class as the given type.
|
Modifier and Type | Method and Description |
---|---|
protected static org.apache.accumulo.core.client.impl.TabletLocator |
InputFormatBase.getTabletLocator(org.apache.hadoop.mapred.JobConf job)
Initializes an Accumulo
TabletLocator based on the configuration. |
Modifier and Type | Method and Description |
---|---|
protected static org.apache.accumulo.core.client.impl.TabletLocator |
InputFormatBase.getTabletLocator(org.apache.hadoop.conf.Configuration conf)
Deprecated.
since 1.5.0; Use
InputFormatBase.getTabletLocator(JobContext) instead. |
protected static org.apache.accumulo.core.client.impl.TabletLocator |
InputFormatBase.getTabletLocator(org.apache.hadoop.mapreduce.JobContext context)
Initializes an Accumulo
TabletLocator based on the configuration. |
Modifier and Type | Method and Description |
---|---|
static org.apache.accumulo.core.client.impl.TabletLocator |
InputConfigurator.getTabletLocator(Class<?> implementingClass,
org.apache.hadoop.conf.Configuration conf)
Initializes an Accumulo
TabletLocator based on the configuration. |
Modifier and Type | Method and Description |
---|---|
void |
MockTableOperations.addSplits(String tableName,
SortedSet<org.apache.hadoop.io.Text> partitionKeys) |
void |
MockTabletLocator.binMutations(List<Mutation> mutations,
Map<String,org.apache.accumulo.core.client.impl.TabletLocator.TabletServerMutations> binnedMutations,
List<Mutation> failures,
org.apache.accumulo.core.security.thrift.TCredentials credentials) |
List<Range> |
MockTabletLocator.binRanges(List<Range> ranges,
Map<String,Map<KeyExtent,List<Range>>> binnedRanges,
org.apache.accumulo.core.security.thrift.TCredentials credentials) |
void |
MockTableOperations.cancelCompaction(String tableName) |
void |
MockTableOperations.clearLocatorCache(String tableName) |
void |
MockTableOperations.clone(String srcTableName,
String newTableName,
boolean flush,
Map<String,String> propertiesToSet,
Set<String> propertiesToExclude) |
void |
MockTableOperations.compact(String tableName,
org.apache.hadoop.io.Text start,
org.apache.hadoop.io.Text end,
boolean flush,
boolean wait) |
void |
MockTableOperations.compact(String tableName,
org.apache.hadoop.io.Text start,
org.apache.hadoop.io.Text end,
List<IteratorSetting> iterators,
boolean flush,
boolean wait) |
BatchDeleter |
MockConnector.createBatchDeleter(String tableName,
Authorizations authorizations,
int numQueryThreads,
BatchWriterConfig config) |
BatchDeleter |
MockConnector.createBatchDeleter(String tableName,
Authorizations authorizations,
int numQueryThreads,
long maxMemory,
long maxLatency,
int maxWriteThreads)
Deprecated.
|
BatchScanner |
MockConnector.createBatchScanner(String tableName,
Authorizations authorizations,
int numQueryThreads) |
BatchWriter |
MockConnector.createBatchWriter(String tableName,
BatchWriterConfig config) |
BatchWriter |
MockConnector.createBatchWriter(String tableName,
long maxMemory,
long maxLatency,
int maxWriteThreads)
Deprecated.
|
Scanner |
MockConnector.createScanner(String tableName,
Authorizations authorizations) |
void |
MockBatchDeleter.delete() |
void |
MockTableOperations.delete(String tableName) |
void |
MockTableOperations.deleteRows(String tableName,
org.apache.hadoop.io.Text start,
org.apache.hadoop.io.Text end) |
void |
MockTableOperations.exportTable(String tableName,
String exportDir) |
void |
MockTableOperations.flush(String tableName,
org.apache.hadoop.io.Text start,
org.apache.hadoop.io.Text end,
boolean wait) |
BatchWriter |
MockMultiTableBatchWriter.getBatchWriter(String table) |
Map<String,Set<org.apache.hadoop.io.Text>> |
MockTableOperations.getLocalityGroups(String tableName) |
org.apache.hadoop.io.Text |
MockTableOperations.getMaxRow(String tableName,
Authorizations auths,
org.apache.hadoop.io.Text startRow,
boolean startInclusive,
org.apache.hadoop.io.Text endRow,
boolean endInclusive) |
Iterable<Map.Entry<String,String>> |
MockTableOperations.getProperties(String tableName) |
Collection<org.apache.hadoop.io.Text> |
MockTableOperations.getSplits(String tableName)
Deprecated.
|
Collection<org.apache.hadoop.io.Text> |
MockTableOperations.getSplits(String tableName,
int maxSplits)
Deprecated.
|
void |
MockTableOperations.importDirectory(String tableName,
String dir,
String failureDir,
boolean setTime) |
Collection<org.apache.hadoop.io.Text> |
MockTableOperations.listSplits(String tableName) |
Collection<org.apache.hadoop.io.Text> |
MockTableOperations.listSplits(String tableName,
int maxSplits) |
org.apache.accumulo.core.client.impl.TabletLocator.TabletLocation |
MockTabletLocator.locateTablet(org.apache.hadoop.io.Text row,
boolean skipRow,
boolean retry,
org.apache.accumulo.core.security.thrift.TCredentials credentials) |
void |
MockTableOperations.merge(String tableName,
org.apache.hadoop.io.Text start,
org.apache.hadoop.io.Text end) |
void |
MockTableOperations.offline(String tableName) |
void |
MockTableOperations.online(String tableName) |
void |
MockTableOperations.rename(String oldTableName,
String newTableName) |
void |
MockTableOperations.setLocalityGroups(String tableName,
Map<String,Set<org.apache.hadoop.io.Text>> groups) |
Set<Range> |
MockTableOperations.splitRangeByTablets(String tableName,
Range range,
int maxSplits) |
boolean |
MockTableOperations.testClassLoad(String tableName,
String className,
String asTypeName) |
Copyright © 2011-2016 The Apache Software Foundation. All Rights Reserved.