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 ConditionalWriter |
Connector.createConditionalWriter(String tableName,
ConditionalWriterConfig config)
Factory method to create a ConditionalWriter connected to Accumulo.
|
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 |
TableOperations.addConstraint(String tableName,
String constraintClassName)
Add a new constraint to a table.
|
void |
TableOperations.addSplits(String tableName,
SortedSet<org.apache.hadoop.io.Text> partitionKeys)
Ensures that tablets are split along a set of keys.
|
void |
TableOperations.attachIterator(String tableName,
IteratorSetting setting)
Add an iterator to a table on all 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 |
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 |
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 |
TableOperations.clearLocatorCache(String tableName)
Clears the tablet locator cache for a specified table
|
void |
TableOperations.clone(String srcTableName,
String newTableName,
boolean flush,
Map<String,String> propertiesToSet,
Set<String> propertiesToExclude)
Clone a table from an existing table.
|
void |
TableOperations.compact(String tableName,
CompactionConfig config)
Starts a full major compaction of the tablets in the range (start, end].
|
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 |
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 |
TableOperations.delete(String tableName)
Delete a table
|
void |
TableOperations.deleteRows(String tableName,
org.apache.hadoop.io.Text start,
org.apache.hadoop.io.Text end)
Delete rows between (start, end]
|
void |
ReplicationOperations.drain(String tableName)
Waits for a table to be fully replicated, given the state of files pending replication for the provided table at the point in time which this method is
invoked.
|
void |
ReplicationOperations.drain(String tableName,
Set<String> files)
Given the provided set of files that are pending replication for a table, wait for those files to be fully replicated to all configured peers.
|
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 |
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.
|
List<DiskUsage> |
TableOperations.getDiskUsage(Set<String> tables)
Gets the number of bytes being used in the files for a set of tables
|
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>> |
TableOperations.getLocalityGroups(String tableName)
Gets the locality groups currently set for a table.
|
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>> |
TableOperations.getProperties(String tableName)
Gets properties of a table.
|
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> |
TableOperations.getSplits(String tableName,
int maxSplits)
Deprecated.
since 1.5.0; use
TableOperations.listSplits(String, int) instead. |
abstract String |
ActiveCompaction.getTable() |
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> |
TableOperations.listConstraints(String tableName)
List constraints on a table with their assigned numbers.
|
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> |
TableOperations.listSplits(String tableName) |
Collection<org.apache.hadoop.io.Text> |
TableOperations.listSplits(String tableName,
int maxSplits) |
void |
TableOperations.merge(String tableName,
org.apache.hadoop.io.Text start,
org.apache.hadoop.io.Text end)
Merge tablets between (start, end]
|
void |
TableOperations.offline(String tableName)
Initiates taking a table offline, but does not wait for action to complete
|
void |
TableOperations.offline(String tableName,
boolean wait) |
void |
TableOperations.online(String tableName)
Initiates bringing a table online, but does not wait for action to complete
|
void |
TableOperations.online(String tableName,
boolean wait) |
Set<String> |
ReplicationOperations.referencedFiles(String tableName)
Gets all of the referenced files for a table from the metadata table.
|
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 |
TableOperations.rename(String oldTableName,
String newTableName)
Rename a table
|
void |
TableOperations.setLocalityGroups(String tableName,
Map<String,Set<org.apache.hadoop.io.Text>> groups)
Sets a table's locality groups.
|
Set<Range> |
TableOperations.splitRangeByTablets(String tableName,
Range range,
int maxSplits) |
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)
Deprecated.
since 1.6.0
|
protected static org.apache.accumulo.core.client.impl.TabletLocator |
AbstractInputFormat.getTabletLocator(org.apache.hadoop.mapred.JobConf job,
String tableId)
Deprecated.
since 1.7.0 This method returns a type that is not part of the public API and is not guaranteed to be stable. The method was deprecated to
discourage its use.
|
Modifier and Type | Method and Description |
---|---|
protected static org.apache.accumulo.core.client.impl.TabletLocator |
InputFormatBase.getTabletLocator(org.apache.hadoop.mapreduce.JobContext context)
Deprecated.
since 1.6.0
|
protected static org.apache.accumulo.core.client.impl.TabletLocator |
AbstractInputFormat.getTabletLocator(org.apache.hadoop.mapreduce.JobContext context,
String table)
Deprecated.
since 1.7.0 This method returns a type that is not part of the public API and is not guaranteed to be stable. The method was deprecated to
discourage its use.
|
Modifier and Type | Method and Description |
---|---|
static org.apache.accumulo.core.client.impl.TabletLocator |
InputConfigurator.getTabletLocator(Class<?> implementingClass,
org.apache.hadoop.conf.Configuration conf)
Deprecated.
since 1.6.0; Configure your job with the appropriate InputFormat or OutputFormat.
|
Modifier and Type | Method and Description |
---|---|
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.
|
ConditionalWriter |
MockConnector.createConditionalWriter(String tableName,
ConditionalWriterConfig config) |
Scanner |
MockConnector.createScanner(String tableName,
Authorizations authorizations) |
void |
MockBatchDeleter.delete() |
BatchWriter |
MockMultiTableBatchWriter.getBatchWriter(String table) |
Copyright © 2011–2018 The Apache Software Foundation. All rights reserved.