Uses of Class
org.apache.accumulo.core.client.TableNotFoundException
Packages that use TableNotFoundException
Package
Description
This package provides a place for plugin interfaces related to executing compactions.
-
Uses of TableNotFoundException in org.apache.accumulo.core.client
Methods in org.apache.accumulo.core.client that throw TableNotFoundExceptionModifier and TypeMethodDescriptionAccumuloClient.createBatchDeleter(String tableName, Authorizations authorizations, int numQueryThreads) Factory method to create BatchDeleter.AccumuloClient.createBatchDeleter(String tableName, Authorizations authorizations, int numQueryThreads, BatchWriterConfig config) Factory method to create BatchDeleterabstract BatchDeleterConnector.createBatchDeleter(String tableName, Authorizations authorizations, int numQueryThreads, long maxMemory, long maxLatency, int maxWriteThreads) Deprecated.abstract BatchDeleterConnector.createBatchDeleter(String tableName, Authorizations authorizations, int numQueryThreads, BatchWriterConfig config) Deprecated.Factory method to create BatchDeleterAccumuloClient.createBatchScanner(String tableName) Factory method to create a BatchScanner with all of user's authorizations and the number of query threads configured when AccumuloClient was created.AccumuloClient.createBatchScanner(String tableName, Authorizations authorizations) Factory method to create a BatchScanner connected to Accumulo.AccumuloClient.createBatchScanner(String tableName, Authorizations authorizations, int numQueryThreads) Factory method to create a BatchScanner connected to Accumulo.abstract BatchScannerConnector.createBatchScanner(String tableName, Authorizations authorizations, int numQueryThreads) Deprecated.Factory method to create a BatchScanner connected to Accumulo.AccumuloClient.createBatchWriter(String tableName) Factory method to create a BatchWriter.AccumuloClient.createBatchWriter(String tableName, BatchWriterConfig config) Factory method to create a BatchWriter connected to Accumulo.abstract BatchWriterConnector.createBatchWriter(String tableName, long maxMemory, long maxLatency, int maxWriteThreads) Deprecated.since 1.5.0; UseConnector.createBatchWriter(String, BatchWriterConfig)instead.abstract BatchWriterConnector.createBatchWriter(String tableName, BatchWriterConfig config) Deprecated.Factory method to create a BatchWriter connected to Accumulo.AccumuloClient.createConditionalWriter(String tableName) Factory method to create a ConditionalWriter connected to Accumulo.AccumuloClient.createConditionalWriter(String tableName, ConditionalWriterConfig config) Factory method to create a ConditionalWriter connected to Accumulo.abstract ConditionalWriterConnector.createConditionalWriter(String tableName, ConditionalWriterConfig config) Deprecated.Factory method to create a ConditionalWriter connected to Accumulo.AccumuloClient.createScanner(String tableName) Factory method to create a Scanner with all of the user's authorizations.AccumuloClient.createScanner(String tableName, Authorizations authorizations) Factory method to create a Scanner connected to Accumulo.abstract ScannerConnector.createScanner(String tableName, Authorizations authorizations) Deprecated.Factory method to create a Scanner connected to Accumulo.voidBatchDeleter.delete()Deletes the ranges specified byBatchDeleter.setRanges(java.util.Collection<org.apache.accumulo.core.data.Range>).MultiTableBatchWriter.getBatchWriter(String table) Returns a BatchWriter for a particular table.PluginEnvironment.getTableName(TableId tableId) Many Accumulo plugins are given table IDs as this is what Accumulo uses internally to identify tables. -
Uses of TableNotFoundException in org.apache.accumulo.core.client.admin
Methods in org.apache.accumulo.core.client.admin that throw TableNotFoundExceptionModifier and TypeMethodDescriptionintTableOperations.addConstraint(String tableName, String constraintClassName) Add a new constraint to a table.voidEnsures that tablets are split along a set of keys.default voidTableOperations.addSummarizers(String tableName, SummarizerConfiguration... summarizers) Enables summary generation for this table for future compactions.voidTableOperations.attachIterator(String tableName, IteratorSetting setting) Add an iterator to a table on all scopes.voidTableOperations.attachIterator(String tableName, IteratorSetting setting, EnumSet<IteratorUtil.IteratorScope> scopes) Add an iterator to a table on the given scopes.voidTableOperations.cancelCompaction(String tableName) Cancels a user initiated major compaction of a table initiated withTableOperations.compact(String, Text, Text, boolean, boolean)orTableOperations.compact(String, Text, Text, List, boolean, boolean).voidTableOperations.checkIteratorConflicts(String tableName, IteratorSetting setting, EnumSet<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.voidTableOperations.clearLocatorCache(String tableName) Clears the tablet locator cache for a specified tablevoidTableOperations.clearSamplerConfiguration(String tableName) Clear all sampling configuration properties on the table.voidTableOperations.clone(String srcTableName, String newTableName, boolean flush, Map<String, String> propertiesToSet, Set<String> propertiesToExclude) Clone a table from an existing table.voidTableOperations.clone(String srcTableName, String newTableName, CloneConfiguration config) Clone a table from an existing table.voidTableOperations.compact(String tableName, CompactionConfig config) Starts a full major compaction of the tablets in the range (start, end].voidTableOperations.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].voidTableOperations.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].voidDelete a tablevoidTableOperations.deleteRows(String tableName, org.apache.hadoop.io.Text start, org.apache.hadoop.io.Text end) Delete rows between (start, end]voidDeprecated.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.voidDeprecated.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.voidTableOperations.exportTable(String tableName, String exportDir) Exports a table.static org.apache.hadoop.io.TextFindMax.findMax(Scanner scanner, org.apache.hadoop.io.Text start, boolean is, org.apache.hadoop.io.Text end, boolean ie) voidTableOperations.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.TableOperations.getConfiguration(String tableName) Gets a merged view of the properties of a table with its parent configuration.TableOperations.getDiskUsage(Set<String> tables) Gets the number of bytes being used by the files for a set of tables.TableOperations.getIteratorSetting(String tableName, String name, IteratorUtil.IteratorScope scope) Get the settings for an iterator.TableOperations.getLocalityGroups(String tableName) Gets the locality groups currently set for a table.org.apache.hadoop.io.TextTableOperations.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.TableOperations.getProperties(String tableName) Gets a merged view of the properties of a table with its parent configuration.TableOperations.getSamplerConfiguration(String tableName) Reads the sampling configuration properties for a table.default Collection<org.apache.hadoop.io.Text>Deprecated.since 1.5.0; useTableOperations.listSplits(String)instead.default Collection<org.apache.hadoop.io.Text>Deprecated.since 1.5.0; useTableOperations.listSplits(String, int)instead.abstract StringActiveCompaction.getTable()TableOperations.getTableProperties(String tableName) Gets per-table properties of a table.default TimeTypeTableOperations.getTimeType(String tableName) Return the TimeType for the given tablevoidTableOperations.importDirectory(String tableName, String dir, String failureDir, boolean setTime) Deprecated.since 2.0.0 useTableOperations.importDirectory(String)instead.booleanCheck if a table is online through its current goal state only.TableOperations.listConstraints(String tableName) List constraints on a table with their assigned numbers.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) default List<SummarizerConfiguration>TableOperations.listSummarizers(String tableName) voidTableOperations.ImportOptions.load()Loads the files into the table.TableOperations.locate(String tableName, Collection<Range> ranges) Locates the tablet servers and tablets that would service a collections of ranges.voidTableOperations.merge(String tableName, org.apache.hadoop.io.Text start, org.apache.hadoop.io.Text end) Merge tablets between (start, end]voidInitiates taking a table offline, but does not wait for action to completevoidvoidInitiates bringing a table online, but does not wait for action to completevoidReplicationOperations.referencedFiles(String tableName) Deprecated.Gets all of the referenced files for a table from the metadata table.voidTableOperations.removeIterator(String tableName, String name, EnumSet<IteratorUtil.IteratorScope> scopes) Remove an iterator from a table by name.default voidTableOperations.removeSummarizers(String tableName, Predicate<SummarizerConfiguration> predicate) Removes summary generation for this table for the matching summarizers.voidRename a tableSummaryRetriever.retrieve()voidTableOperations.setLocalityGroups(String tableName, Map<String, Set<org.apache.hadoop.io.Text>> groups) Sets a table's locality groups.voidTableOperations.setSamplerConfiguration(String tableName, SamplerConfiguration samplerConfiguration) Set or update the sampler configuration for a table.TableOperations.splitRangeByTablets(String tableName, Range range, int maxSplits) booleanTableOperations.testClassLoad(String tableName, String className, String asTypeName) Test to see if the instance can load the given class as the given type. -
Uses of TableNotFoundException in org.apache.accumulo.core.spi.compaction
Methods in org.apache.accumulo.core.spi.compaction that throw TableNotFoundException
Connector.createBatchDeleter(String, Authorizations, int, BatchWriterConfig)instead.