Uses of Class
org.apache.accumulo.core.conf.AccumuloConfiguration

Packages that use AccumuloConfiguration
org.apache.accumulo.core   
org.apache.accumulo.core.client   
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.file   
org.apache.accumulo.core.file.map   
org.apache.accumulo.core.file.rfile   
org.apache.accumulo.core.iterators   
org.apache.accumulo.core.iterators.system   
org.apache.accumulo.core.security.crypto   
org.apache.accumulo.core.util   
 

Uses of AccumuloConfiguration in org.apache.accumulo.core
 

Methods in org.apache.accumulo.core with parameters of type AccumuloConfiguration
static String Constants.getBaseDir(AccumuloConfiguration conf)
           
static org.apache.hadoop.fs.Path Constants.getDataVersionLocation(AccumuloConfiguration conf)
           
static String Constants.getMetadataTableDir(AccumuloConfiguration conf)
           
static String Constants.getRecoveryDir(AccumuloConfiguration conf)
           
static String Constants.getRootTabletDir(AccumuloConfiguration conf)
           
static String Constants.getTablesDir(AccumuloConfiguration conf)
           
static String Constants.getWalDirectory(AccumuloConfiguration conf)
           
 

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

Methods in org.apache.accumulo.core.client that return AccumuloConfiguration
 AccumuloConfiguration Instance.getConfiguration()
          Returns the AccumuloConfiguration to use when interacting with this instance.
 AccumuloConfiguration ZooKeeperInstance.getConfiguration()
           
 

Methods in org.apache.accumulo.core.client with parameters of type AccumuloConfiguration
 void Instance.setConfiguration(AccumuloConfiguration conf)
          Set the AccumuloConfiguration to use when interacting with this instance.
 void ZooKeeperInstance.setConfiguration(AccumuloConfiguration conf)
           
 

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

Methods in org.apache.accumulo.core.client.impl with parameters of type AccumuloConfiguration
 org.apache.thrift.transport.TTransport ThriftTransportPool.getTransportWithDefaultTimeout(InetSocketAddress addr, AccumuloConfiguration conf)
           
 org.apache.thrift.transport.TTransport ThriftTransportPool.getTransportWithDefaultTimeout(String location, int port, AccumuloConfiguration conf)
           
static List<KeyValue> ThriftScanner.scan(Instance instance, TCredentials credentials, ThriftScanner.ScanState scanState, int timeOut, AccumuloConfiguration conf)
           
 

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

Methods in org.apache.accumulo.core.client.mapred that return AccumuloConfiguration
protected static AccumuloConfiguration AccumuloFileOutputFormat.getAccumuloConfiguration(org.apache.hadoop.mapred.JobConf job)
          This helper method provides an AccumuloConfiguration object constructed from the Accumulo defaults, and overridden with Accumulo properties that have been stored in the Job's configuration.
 

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

Methods in org.apache.accumulo.core.client.mapreduce that return AccumuloConfiguration
protected static AccumuloConfiguration AccumuloFileOutputFormat.getAccumuloConfiguration(org.apache.hadoop.mapreduce.JobContext context)
          This helper method provides an AccumuloConfiguration object constructed from the Accumulo defaults, and overridden with Accumulo properties that have been stored in the Job's configuration.
 

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

Methods in org.apache.accumulo.core.client.mapreduce.lib.util that return AccumuloConfiguration
static AccumuloConfiguration FileOutputConfigurator.getAccumuloConfiguration(Class<?> implementingClass, org.apache.hadoop.conf.Configuration conf)
          This helper method provides an AccumuloConfiguration object constructed from the Accumulo defaults, and overridden with Accumulo properties that have been stored in the Job's configuration.
 

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

Methods in org.apache.accumulo.core.client.mock that return AccumuloConfiguration
 AccumuloConfiguration MockInstance.getConfiguration()
           
 

Methods in org.apache.accumulo.core.client.mock with parameters of type AccumuloConfiguration
 void MockInstance.setConfiguration(AccumuloConfiguration conf)
           
 

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

Subclasses of AccumuloConfiguration in org.apache.accumulo.core.conf
 class ConfigurationCopy
           
 class DefaultConfiguration
           
 class SiteConfiguration
           
 

Methods in org.apache.accumulo.core.conf that return AccumuloConfiguration
static AccumuloConfiguration AccumuloConfiguration.getSiteConfiguration()
          Deprecated. not for client use
static AccumuloConfiguration AccumuloConfiguration.getTableConfiguration(Connector conn, String tableId)
           
 

Methods in org.apache.accumulo.core.conf with parameters of type AccumuloConfiguration
static
<T> T
Property.createInstanceFromPropertyName(AccumuloConfiguration conf, Property property, Class<T> base, T defaultInstance)
           
static SiteConfiguration SiteConfiguration.getInstance(AccumuloConfiguration parent)
           
static void ConfigSanityCheck.validate(AccumuloConfiguration acuconf)
           
 

Uses of AccumuloConfiguration in org.apache.accumulo.core.file
 

Methods in org.apache.accumulo.core.file with parameters of type AccumuloConfiguration
static double FileUtil.estimatePercentageLTE(org.apache.hadoop.fs.FileSystem fs, AccumuloConfiguration acuconf, org.apache.hadoop.io.Text prevEndRow, org.apache.hadoop.io.Text endRow, Collection<String> mapFiles, org.apache.hadoop.io.Text splitRow)
           
static Map<KeyExtent,Long> FileUtil.estimateSizes(AccumuloConfiguration acuConf, org.apache.hadoop.fs.Path mapFile, long fileSize, List<KeyExtent> extents, org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.FileSystem fs)
           
static org.apache.hadoop.io.WritableComparable<Key> FileUtil.findLastKey(org.apache.hadoop.fs.FileSystem fs, AccumuloConfiguration acuConf, Collection<String> mapFiles)
           
static SortedMap<Double,Key> FileUtil.findMidPoint(org.apache.hadoop.fs.FileSystem fs, AccumuloConfiguration acuConf, org.apache.hadoop.io.Text prevEndRow, org.apache.hadoop.io.Text endRow, Collection<String> mapFiles, double minSplit)
           
static SortedMap<Double,Key> FileUtil.findMidPoint(org.apache.hadoop.fs.FileSystem fs, AccumuloConfiguration acuConf, org.apache.hadoop.io.Text prevEndRow, org.apache.hadoop.io.Text endRow, Collection<String> mapFiles, double minSplit, boolean useIndex)
           
abstract  long FileOperations.getFileSize(String file, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.conf.Configuration conf, AccumuloConfiguration acuconf)
           
static org.apache.hadoop.fs.FileSystem FileUtil.getFileSystem(org.apache.hadoop.conf.Configuration conf, AccumuloConfiguration acuconf)
           
static String FileOperations.getNewFileExtension(AccumuloConfiguration acuconf)
           
abstract  FileSKVIterator FileOperations.openIndex(String file, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.conf.Configuration conf, AccumuloConfiguration acuconf)
           
abstract  FileSKVIterator FileOperations.openIndex(String file, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.conf.Configuration conf, AccumuloConfiguration acuconf, BlockCache dCache, BlockCache iCache)
           
abstract  FileSKVIterator FileOperations.openReader(String file, boolean seekToBeginning, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.conf.Configuration conf, AccumuloConfiguration acuconf)
          Open a reader that fully support seeking and also enable any optimizations related to seeking, like bloom filters.
abstract  FileSKVIterator FileOperations.openReader(String file, boolean seekToBeginning, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.conf.Configuration conf, AccumuloConfiguration acuconf, BlockCache dataCache, BlockCache indexCache)
           
abstract  FileSKVIterator FileOperations.openReader(String file, Range range, Set<ByteSequence> columnFamilies, boolean inclusive, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.conf.Configuration conf, AccumuloConfiguration tableConf)
          Open a reader that will not be seeked giving an initial seek location.
abstract  FileSKVIterator FileOperations.openReader(String file, Range range, Set<ByteSequence> columnFamilies, boolean inclusive, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.conf.Configuration conf, AccumuloConfiguration tableConf, BlockCache dataCache, BlockCache indexCache)
           
abstract  FileSKVWriter FileOperations.openWriter(String file, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.conf.Configuration conf, AccumuloConfiguration acuconf)
           
static Collection<String> FileUtil.reduceFiles(AccumuloConfiguration acuConf, org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.io.Text prevEndRow, org.apache.hadoop.io.Text endRow, Collection<String> mapFiles, int maxFiles, String tmpDir, int pass)
           
static Map<String,FileUtil.FileInfo> FileUtil.tryToGetFirstAndLastRows(org.apache.hadoop.fs.FileSystem fs, AccumuloConfiguration acuConf, Set<String> mapfiles)
           
 

Constructors in org.apache.accumulo.core.file with parameters of type AccumuloConfiguration
BloomFilterLayer.Reader(FileSKVIterator reader, AccumuloConfiguration acuconf)
           
 

Uses of AccumuloConfiguration in org.apache.accumulo.core.file.map
 

Methods in org.apache.accumulo.core.file.map with parameters of type AccumuloConfiguration
 long MapFileOperations.getFileSize(String file, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.conf.Configuration conf, AccumuloConfiguration acuconf)
           
 FileSKVIterator MapFileOperations.openIndex(String file, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.conf.Configuration conf, AccumuloConfiguration acuconf)
           
 FileSKVIterator MapFileOperations.openIndex(String file, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.conf.Configuration conf, AccumuloConfiguration acuconf, BlockCache dCache, BlockCache iCache)
           
static org.apache.hadoop.io.MapFile.Reader MapFileUtil.openMapFile(AccumuloConfiguration acuconf, org.apache.hadoop.fs.FileSystem fs, String dirName, org.apache.hadoop.conf.Configuration conf)
           
 FileSKVIterator MapFileOperations.openReader(String file, boolean seekToBeginning, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.conf.Configuration conf, AccumuloConfiguration acuconf)
           
 FileSKVIterator MapFileOperations.openReader(String file, boolean seekToBeginning, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.conf.Configuration conf, AccumuloConfiguration acuconf, BlockCache dataCache, BlockCache indexCache)
           
 FileSKVIterator MapFileOperations.openReader(String file, Range range, Set<ByteSequence> columnFamilies, boolean inclusive, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.conf.Configuration conf, AccumuloConfiguration tableConf)
           
 FileSKVIterator MapFileOperations.openReader(String file, Range range, Set<ByteSequence> columnFamilies, boolean inclusive, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.conf.Configuration conf, AccumuloConfiguration tableConf, BlockCache dataCache, BlockCache indexCache)
           
 FileSKVWriter MapFileOperations.openWriter(String file, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.conf.Configuration conf, AccumuloConfiguration acuconf)
           
 

Uses of AccumuloConfiguration in org.apache.accumulo.core.file.rfile
 

Methods in org.apache.accumulo.core.file.rfile with parameters of type AccumuloConfiguration
 long RFileOperations.getFileSize(String file, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.conf.Configuration conf, AccumuloConfiguration acuconf)
           
 FileSKVIterator RFileOperations.openIndex(String file, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.conf.Configuration conf, AccumuloConfiguration acuconf)
           
 FileSKVIterator RFileOperations.openIndex(String file, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.conf.Configuration conf, AccumuloConfiguration acuconf, BlockCache dataCache, BlockCache indexCache)
           
 FileSKVIterator RFileOperations.openReader(String file, boolean seekToBeginning, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.conf.Configuration conf, AccumuloConfiguration acuconf)
           
 FileSKVIterator RFileOperations.openReader(String file, boolean seekToBeginning, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.conf.Configuration conf, AccumuloConfiguration acuconf, BlockCache dataCache, BlockCache indexCache)
           
 FileSKVIterator RFileOperations.openReader(String file, Range range, Set<ByteSequence> columnFamilies, boolean inclusive, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.conf.Configuration conf, AccumuloConfiguration tableConf)
           
 FileSKVIterator RFileOperations.openReader(String file, Range range, Set<ByteSequence> columnFamilies, boolean inclusive, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.conf.Configuration conf, AccumuloConfiguration tableConf, BlockCache dataCache, BlockCache indexCache)
           
 FileSKVWriter RFileOperations.openWriter(String file, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.conf.Configuration conf, AccumuloConfiguration acuconf)
           
 

Uses of AccumuloConfiguration in org.apache.accumulo.core.iterators
 

Methods in org.apache.accumulo.core.iterators that return AccumuloConfiguration
 AccumuloConfiguration IteratorEnvironment.getConfig()
           
 

Methods in org.apache.accumulo.core.iterators with parameters of type AccumuloConfiguration
static String IteratorUtil.findIterator(IteratorUtil.IteratorScope scope, String className, AccumuloConfiguration conf, Map<String,String> opts)
           
static int IteratorUtil.getMaxPriority(IteratorUtil.IteratorScope scope, AccumuloConfiguration conf)
           
static
<K extends org.apache.hadoop.io.WritableComparable<?>,V extends org.apache.hadoop.io.Writable>
SortedKeyValueIterator<K,V>
IteratorUtil.loadIterators(IteratorUtil.IteratorScope scope, SortedKeyValueIterator<K,V> source, KeyExtent extent, AccumuloConfiguration conf, IteratorEnvironment env)
           
static
<K extends org.apache.hadoop.io.WritableComparable<?>,V extends org.apache.hadoop.io.Writable>
SortedKeyValueIterator<K,V>
IteratorUtil.loadIterators(IteratorUtil.IteratorScope scope, SortedKeyValueIterator<K,V> source, KeyExtent extent, AccumuloConfiguration conf, List<IteratorSetting> iterators, IteratorEnvironment env)
           
static
<K extends org.apache.hadoop.io.WritableComparable<?>,V extends org.apache.hadoop.io.Writable>
SortedKeyValueIterator<K,V>
IteratorUtil.loadIterators(IteratorUtil.IteratorScope scope, SortedKeyValueIterator<K,V> source, KeyExtent extent, AccumuloConfiguration conf, List<IterInfo> ssiList, Map<String,Map<String,String>> ssio, IteratorEnvironment env)
           
static
<K extends org.apache.hadoop.io.WritableComparable<?>,V extends org.apache.hadoop.io.Writable>
SortedKeyValueIterator<K,V>
IteratorUtil.loadIterators(IteratorUtil.IteratorScope scope, SortedKeyValueIterator<K,V> source, KeyExtent extent, AccumuloConfiguration conf, List<IterInfo> ssiList, Map<String,Map<String,String>> ssio, IteratorEnvironment env, boolean useAccumuloClassLoader)
           
 

Uses of AccumuloConfiguration in org.apache.accumulo.core.iterators.system
 

Constructors in org.apache.accumulo.core.iterators.system with parameters of type AccumuloConfiguration
MapFileIterator(AccumuloConfiguration acuconf, org.apache.hadoop.fs.FileSystem fs, String dir, org.apache.hadoop.conf.Configuration conf)
           
 

Uses of AccumuloConfiguration in org.apache.accumulo.core.security.crypto
 

Methods in org.apache.accumulo.core.security.crypto with parameters of type AccumuloConfiguration
static CryptoModule CryptoModuleFactory.getCryptoModule(AccumuloConfiguration conf)
          Deprecated. This method returns a crypto module based on settings in the given configuration parameter.
static SecretKeyEncryptionStrategy CryptoModuleFactory.getSecretKeyEncryptionStrategy(AccumuloConfiguration conf)
          Deprecated.  
 

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

Methods in org.apache.accumulo.core.util with parameters of type AccumuloConfiguration
static org.apache.thrift.transport.TTransport ThriftUtil.createTransport(InetSocketAddress address, AccumuloConfiguration conf)
          create a transport that is not pooled
static org.apache.thrift.transport.TTransport ThriftUtil.createTransport(String address, int port, AccumuloConfiguration conf)
          create a transport that is not pooled
static void ThriftUtil.execute(String address, AccumuloConfiguration conf, ClientExec<TabletClientService.Client> exec)
           
static
<T> T
ThriftUtil.execute(String address, AccumuloConfiguration conf, ClientExecReturn<T,TabletClientService.Client> exec)
           
static
<T extends org.apache.thrift.TServiceClient>
T
ThriftUtil.getClient(org.apache.thrift.TServiceClientFactory<T> factory, InetSocketAddress address, AccumuloConfiguration conf)
           
static
<T extends org.apache.thrift.TServiceClient>
T
ThriftUtil.getClient(org.apache.thrift.TServiceClientFactory<T> factory, String address, Property property, AccumuloConfiguration configuration)
           
static
<T extends org.apache.thrift.TServiceClient>
T
ThriftUtil.getClient(org.apache.thrift.TServiceClientFactory<T> factory, String address, Property property, long timeout, AccumuloConfiguration configuration)
           
static
<T extends org.apache.thrift.TServiceClient>
T
ThriftUtil.getClient(org.apache.thrift.TServiceClientFactory<T> factory, String address, Property property, Property timeoutProperty, AccumuloConfiguration configuration)
           
static Map<String,Set<ByteSequence>> LocalityGroupUtil.getLocalityGroups(AccumuloConfiguration acuconf)
           
static TabletClientService.Client ThriftUtil.getTServerClient(String address, AccumuloConfiguration conf)
           
static TabletClientService.Client ThriftUtil.getTServerClient(String address, AccumuloConfiguration conf, long timeout)
           
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)
           
 



Copyright © 2013 Apache Accumulo Project. All Rights Reserved.