Uses of Class
org.apache.accumulo.core.client.TableNotFoundException

Packages that use TableNotFoundException
org.apache.accumulo.core.client   
org.apache.accumulo.core.client.admin   
org.apache.accumulo.core.client.impl   
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   
org.apache.accumulo.core.conf   
org.apache.accumulo.core.util   
org.apache.accumulo.core.util.shell.commands   
org.apache.accumulo.examples.simple.client   
org.apache.accumulo.examples.simple.dirlist   
org.apache.accumulo.examples.simple.filedata   
org.apache.accumulo.examples.simple.helloworld   
org.apache.accumulo.examples.simple.mapreduce.bulk   
org.apache.accumulo.server.security.handler   
org.apache.accumulo.test   
org.apache.accumulo.test.functional   
org.apache.accumulo.test.randomwalk.security   
 

Uses of TableNotFoundException in org.apache.accumulo.core.client
 

Methods in org.apache.accumulo.core.client that throw TableNotFoundException
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).
 BatchWriter MultiTableBatchWriter.getBatchWriter(String table)
          Returns a BatchWriter for a particular table.
 

Uses of TableNotFoundException in org.apache.accumulo.core.client.admin
 

Methods in org.apache.accumulo.core.client.admin that throw TableNotFoundException
 int TableOperationsHelper.addConstraint(String tableName, String constraintClassName)
           
 int TableOperationsImpl.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)
           
 void TableOperationsHelper.attachIterator(String tableName, IteratorSetting setting)
           
 void TableOperations.attachIterator(String tableName, IteratorSetting setting)
          Add an iterator to a table on all scopes.
 void TableOperationsHelper.attachIterator(String tableName, IteratorSetting setting, EnumSet<IteratorUtil.IteratorScope> scopes)
           
 void TableOperationsImpl.attachIterator(String tableName, IteratorSetting setting, EnumSet<IteratorUtil.IteratorScope> scopes)
           
 void TableOperations.attachIterator(String tableName, IteratorSetting setting, EnumSet<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<IteratorUtil.IteratorScope> scopes)
           
 void TableOperations.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.
 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, IteratorUtil.IteratorScope scope)
           
 IteratorSetting TableOperations.getIteratorSetting(String tableName, String name, 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)
           
 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)
           
 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<IteratorUtil.IteratorScope>> TableOperationsHelper.listIterators(String tableName)
           
 Map<String,EnumSet<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<IteratorUtil.IteratorScope> scopes)
           
 void TableOperations.removeIterator(String tableName, String name, EnumSet<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.
 

Uses of TableNotFoundException in org.apache.accumulo.core.client.impl
 

Methods in org.apache.accumulo.core.client.impl that throw TableNotFoundException
protected  TabletLocator.TabletLocation TabletLocatorImpl._locateTablet(org.apache.hadoop.io.Text row, boolean skipRow, boolean retry, boolean lock, TCredentials credentials)
           
 void RootTabletLocator.binMutations(List<Mutation> mutations, Map<String,TabletLocator.TabletServerMutations> binnedMutations, List<Mutation> failures, TCredentials credentials)
           
 void TabletLocatorImpl.binMutations(List<Mutation> mutations, Map<String,TabletLocator.TabletServerMutations> binnedMutations, List<Mutation> failures, TCredentials credentials)
           
abstract  void TabletLocator.binMutations(List<Mutation> mutations, Map<String,TabletLocator.TabletServerMutations> binnedMutations, List<Mutation> failures, TCredentials credentials)
           
 void TimeoutTabletLocator.binMutations(List<Mutation> mutations, Map<String,TabletLocator.TabletServerMutations> binnedMutations, List<Mutation> failures, TCredentials credentials)
           
 List<Range> RootTabletLocator.binRanges(List<Range> ranges, Map<String,Map<KeyExtent,List<Range>>> binnedRanges, TCredentials credentials)
           
 List<Range> TabletLocatorImpl.binRanges(List<Range> ranges, Map<String,Map<KeyExtent,List<Range>>> binnedRanges, TCredentials credentials)
           
abstract  List<Range> TabletLocator.binRanges(List<Range> ranges, Map<String,Map<KeyExtent,List<Range>>> binnedRanges, TCredentials credentials)
           
 List<Range> TimeoutTabletLocator.binRanges(List<Range> ranges, Map<String,Map<KeyExtent,List<Range>>> binnedRanges, TCredentials credentials)
           
 BatchDeleter ConnectorImpl.createBatchDeleter(String tableName, Authorizations authorizations, int numQueryThreads, BatchWriterConfig config)
           
 BatchDeleter ConnectorImpl.createBatchDeleter(String tableName, Authorizations authorizations, int numQueryThreads, long maxMemory, long maxLatency, int maxWriteThreads)
          Deprecated. 
 BatchScanner ConnectorImpl.createBatchScanner(String tableName, Authorizations authorizations, int numQueryThreads)
           
 BatchWriter ConnectorImpl.createBatchWriter(String tableName, BatchWriterConfig config)
           
 BatchWriter ConnectorImpl.createBatchWriter(String tableName, long maxMemory, long maxLatency, int maxWriteThreads)
          Deprecated. 
 Scanner ConnectorImpl.createScanner(String tableName, Authorizations authorizations)
           
 void TabletServerBatchDeleter.delete()
           
 BatchWriter MultiTableBatchWriterImpl.getBatchWriter(String tableName)
           
static String Tables.getTableId(Instance instance, String tableName)
           
static String Tables.getTableName(Instance instance, String tableId)
           
 TabletLocator.TabletLocation RootTabletLocator.locateTablet(org.apache.hadoop.io.Text row, boolean skipRow, boolean retry, TCredentials credentials)
           
 TabletLocator.TabletLocation TabletLocatorImpl.locateTablet(org.apache.hadoop.io.Text row, boolean skipRow, boolean retry, TCredentials credentials)
           
abstract  TabletLocator.TabletLocation TabletLocator.locateTablet(org.apache.hadoop.io.Text row, boolean skipRow, boolean retry, TCredentials credentials)
           
 TabletLocator.TabletLocation TimeoutTabletLocator.locateTablet(org.apache.hadoop.io.Text row, boolean skipRow, boolean retry, TCredentials credentials)
           
static List<KeyValue> ThriftScanner.scan(Instance instance, TCredentials credentials, ThriftScanner.ScanState scanState, int timeOut, AccumuloConfiguration conf)
           
 void Writer.update(Mutation m)
           
 

Constructors in org.apache.accumulo.core.client.impl that throw TableNotFoundException
TabletServerBatchDeleter(Instance instance, TCredentials credentials, String tableId, Authorizations authorizations, int numQueryThreads, BatchWriterConfig bwConfig)
           
 

Uses of TableNotFoundException in org.apache.accumulo.core.client.mapred
 

Methods in org.apache.accumulo.core.client.mapred that throw TableNotFoundException
protected static TabletLocator InputFormatBase.getTabletLocator(org.apache.hadoop.mapred.JobConf job)
          Initializes an Accumulo TabletLocator based on the configuration.
 

Uses of TableNotFoundException in org.apache.accumulo.core.client.mapreduce
 

Methods in org.apache.accumulo.core.client.mapreduce that throw TableNotFoundException
protected static TabletLocator InputFormatBase.getTabletLocator(org.apache.hadoop.conf.Configuration conf)
          Deprecated. since 1.5.0; Use InputFormatBase.getTabletLocator(JobContext) instead.
protected static TabletLocator InputFormatBase.getTabletLocator(org.apache.hadoop.mapreduce.JobContext context)
          Initializes an Accumulo TabletLocator based on the configuration.
 

Uses of TableNotFoundException in org.apache.accumulo.core.client.mapreduce.lib.util
 

Methods in org.apache.accumulo.core.client.mapreduce.lib.util that throw TableNotFoundException
static TabletLocator InputConfigurator.getTabletLocator(Class<?> implementingClass, org.apache.hadoop.conf.Configuration conf)
          Initializes an Accumulo TabletLocator based on the configuration.
 

Uses of TableNotFoundException in org.apache.accumulo.core.client.mock
 

Methods in org.apache.accumulo.core.client.mock that throw TableNotFoundException
 void MockTableOperations.addSplits(String tableName, SortedSet<org.apache.hadoop.io.Text> partitionKeys)
           
 void MockTabletLocator.binMutations(List<Mutation> mutations, Map<String,TabletLocator.TabletServerMutations> binnedMutations, List<Mutation> failures, TCredentials credentials)
           
 List<Range> MockTabletLocator.binRanges(List<Range> ranges, Map<String,Map<KeyExtent,List<Range>>> binnedRanges, 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)
           
 Collection<org.apache.hadoop.io.Text> MockTableOperations.getSplits(String tableName, int maxSplits)
           
 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)
           
 TabletLocator.TabletLocation MockTabletLocator.locateTablet(org.apache.hadoop.io.Text row, boolean skipRow, boolean retry, 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)
           
 

Uses of TableNotFoundException in org.apache.accumulo.core.conf
 

Methods in org.apache.accumulo.core.conf that throw TableNotFoundException
static AccumuloConfiguration AccumuloConfiguration.getTableConfiguration(Connector conn, String tableId)
           
 

Uses of TableNotFoundException in org.apache.accumulo.core.util
 

Methods in org.apache.accumulo.core.util that throw TableNotFoundException
static void MetadataTable.getEntries(Instance instance, TCredentials credentials, String table, boolean isTid, Map<KeyExtent,String> locations, SortedSet<KeyExtent> tablets)
           
static void TableDiskUsage.printDiskUsage(AccumuloConfiguration acuConf, Collection<String> tables, org.apache.hadoop.fs.FileSystem fs, Connector conn, boolean humanReadable)
           
static void TableDiskUsage.printDiskUsage(AccumuloConfiguration acuConf, Collection<String> tables, org.apache.hadoop.fs.FileSystem fs, Connector conn, TableDiskUsage.Printer printer, boolean humanReadable)
           
 

Uses of TableNotFoundException in org.apache.accumulo.core.util.shell.commands
 

Methods in org.apache.accumulo.core.util.shell.commands that throw TableNotFoundException
protected  void FlushCommand.doTableOp(Shell shellState, String tableName)
           
protected  void OfflineCommand.doTableOp(Shell shellState, String tableName)
           
protected  void OnlineCommand.doTableOp(Shell shellState, String tableName)
           
 int SetIterCommand.execute(String fullCommand, org.apache.commons.cli.CommandLine cl, Shell shellState)
           
 int DUCommand.execute(String fullCommand, org.apache.commons.cli.CommandLine cl, Shell shellState)
           
 int CloneTableCommand.execute(String fullCommand, org.apache.commons.cli.CommandLine cl, Shell shellState)
           
 int InsertCommand.execute(String fullCommand, org.apache.commons.cli.CommandLine cl, Shell shellState)
           
 int SetScanIterCommand.execute(String fullCommand, org.apache.commons.cli.CommandLine cl, Shell shellState)
           
 int ConfigCommand.execute(String fullCommand, org.apache.commons.cli.CommandLine cl, Shell shellState)
           
 int DeleteCommand.execute(String fullCommand, org.apache.commons.cli.CommandLine cl, Shell shellState)
           
 int ImportDirectoryCommand.execute(String fullCommand, org.apache.commons.cli.CommandLine cl, Shell shellState)
           
 int CreateTableCommand.execute(String fullCommand, org.apache.commons.cli.CommandLine cl, Shell shellState)
           
 int SetShellIterCommand.execute(String fullCommand, org.apache.commons.cli.CommandLine cl, Shell shellState)
           
 int GetSplitsCommand.execute(String fullCommand, org.apache.commons.cli.CommandLine cl, Shell shellState)
           
 int CreateUserCommand.execute(String fullCommand, org.apache.commons.cli.CommandLine cl, Shell shellState)
           
 int RenameTableCommand.execute(String fullCommand, org.apache.commons.cli.CommandLine cl, Shell shellState)
           
 int ImportTableCommand.execute(String fullCommand, org.apache.commons.cli.CommandLine cl, Shell shellState)
           
 int TableCommand.execute(String fullCommand, org.apache.commons.cli.CommandLine cl, Shell shellState)
           
 int ExportTableCommand.execute(String fullCommand, org.apache.commons.cli.CommandLine cl, Shell shellState)
           
static String OptUtil.getTableOpt(org.apache.commons.cli.CommandLine cl, Shell shellState)
           
protected  void SetIterCommand.setTableProperties(org.apache.commons.cli.CommandLine cl, Shell shellState, int priority, Map<String,String> options, String classname, String name)
           
protected  void SetScanIterCommand.setTableProperties(org.apache.commons.cli.CommandLine cl, Shell shellState, int priority, Map<String,String> options, String classname, String name)
           
protected  void SetShellIterCommand.setTableProperties(org.apache.commons.cli.CommandLine cl, Shell shellState, int priority, Map<String,String> options, String classname, String name)
           
 

Uses of TableNotFoundException in org.apache.accumulo.examples.simple.client
 

Methods in org.apache.accumulo.examples.simple.client that throw TableNotFoundException
static void SequentialBatchWriter.main(String[] args)
          Writes a specified number of entries to Accumulo using a BatchWriter.
static void RandomBatchWriter.main(String[] args)
          Writes a specified number of entries to Accumulo using a BatchWriter.
static void RowOperations.main(String[] args)
           
static void RandomBatchScanner.main(String[] args)
          Scans over a specified number of entries to Accumulo using a BatchScanner.
 

Uses of TableNotFoundException in org.apache.accumulo.examples.simple.dirlist
 

Methods in org.apache.accumulo.examples.simple.dirlist that throw TableNotFoundException
 Map<String,String> QueryUtil.getData(String path)
          Scans over the directory table and pulls out stat information about a path.
 Map<String,Map<String,String>> QueryUtil.getDirList(String path)
          Uses the directory table to list the contents of a directory.
 void Viewer.init()
           
 void Viewer.populate(DefaultMutableTreeNode node)
           
 void Viewer.populateChildren(DefaultMutableTreeNode node)
           
 

Uses of TableNotFoundException in org.apache.accumulo.examples.simple.filedata
 

Constructors in org.apache.accumulo.examples.simple.filedata that throw TableNotFoundException
FileDataQuery(String instanceName, String zooKeepers, String user, AuthenticationToken token, String tableName, Authorizations auths)
           
 

Uses of TableNotFoundException in org.apache.accumulo.examples.simple.helloworld
 

Methods in org.apache.accumulo.examples.simple.helloworld that throw TableNotFoundException
static void ReadData.main(String[] args)
           
static void InsertWithBatchWriter.main(String[] args)
           
 

Uses of TableNotFoundException in org.apache.accumulo.examples.simple.mapreduce.bulk
 

Methods in org.apache.accumulo.examples.simple.mapreduce.bulk that throw TableNotFoundException
static void VerifyIngest.main(String[] args)
           
 

Uses of TableNotFoundException in org.apache.accumulo.server.security.handler
 

Methods in org.apache.accumulo.server.security.handler that throw TableNotFoundException
 void InsecurePermHandler.cleanTablePermissions(String table)
           
 void PermissionHandler.cleanTablePermissions(String table)
          Cleans up the permissions for a table.
 void InsecurePermHandler.grantTablePermission(String user, String table, TablePermission permission)
           
 void PermissionHandler.grantTablePermission(String user, String table, TablePermission permission)
          Gives the user the given table permission
 boolean ZKPermHandler.hasCachedTablePermission(String user, String table, TablePermission permission)
           
 boolean InsecurePermHandler.hasCachedTablePermission(String user, String table, TablePermission permission)
           
 boolean PermissionHandler.hasCachedTablePermission(String user, String table, TablePermission permission)
          Used to get the table permission of a user for a table, with caching.
 boolean ZKPermHandler.hasTablePermission(String user, String table, TablePermission permission)
           
 boolean InsecurePermHandler.hasTablePermission(String user, String table, TablePermission permission)
           
 boolean PermissionHandler.hasTablePermission(String user, String table, TablePermission permission)
          Used to get the table permission of a user for a table
 void InsecurePermHandler.revokeTablePermission(String user, String table, TablePermission permission)
           
 void PermissionHandler.revokeTablePermission(String user, String table, TablePermission permission)
          Denies the user the given table permission.
 

Uses of TableNotFoundException in org.apache.accumulo.test
 

Methods in org.apache.accumulo.test that throw TableNotFoundException
static void GCLotsOfCandidatesTest.main(String[] args)
           
static void QueryMetadataTable.main(String[] args)
           
static void BulkImportDirectory.main(String[] args)
           
 

Uses of TableNotFoundException in org.apache.accumulo.test.functional
 

Methods in org.apache.accumulo.test.functional that throw TableNotFoundException
 void PermissionsTest.SystemPermissionsTest.run()
           
 void PermissionsTest.TablePermissionsTest.run()
           
 

Uses of TableNotFoundException in org.apache.accumulo.test.randomwalk.security
 

Methods in org.apache.accumulo.test.randomwalk.security that throw TableNotFoundException
 void WalkingSecurity.cleanTablePermissions(String table)
           
 void WalkingSecurity.grantTablePermission(String user, String table, TablePermission permission)
           
 boolean WalkingSecurity.hasCachedTablePermission(String user, String table, TablePermission permission)
           
 boolean WalkingSecurity.hasTablePermission(String user, String table, TablePermission permission)
           
 void WalkingSecurity.revokeTablePermission(String user, String table, TablePermission permission)
           
 



Copyright © 2013 Apache Accumulo Project. All Rights Reserved.