Uses of Class
org.apache.hadoop.conf.Configuration

Packages that use Configuration
org.apache.hadoop.conf Configuration of system parameters. 
org.apache.hadoop.contrib.failmon   
org.apache.hadoop.contrib.index.example   
org.apache.hadoop.contrib.index.lucene   
org.apache.hadoop.contrib.index.mapred   
org.apache.hadoop.examples Hadoop example code. 
org.apache.hadoop.filecache   
org.apache.hadoop.fs An abstract file system API. 
org.apache.hadoop.fs.ftp   
org.apache.hadoop.fs.kfs A client for the Kosmos filesystem (KFS) 
org.apache.hadoop.fs.permission   
org.apache.hadoop.fs.s3 A distributed, block-based implementation of FileSystem that uses Amazon S3 as a backing store. 
org.apache.hadoop.fs.s3native A distributed implementation of FileSystem for reading and writing files on Amazon S3
org.apache.hadoop.fs.shell   
org.apache.hadoop.http   
org.apache.hadoop.io Generic i/o code for use when reading and writing data to the network, to databases, and to files. 
org.apache.hadoop.io.compress   
org.apache.hadoop.io.compress.zlib   
org.apache.hadoop.io.file.tfile   
org.apache.hadoop.io.serializer This package provides a mechanism for using different serialization frameworks in Hadoop. 
org.apache.hadoop.ipc Tools to help define network clients and servers. 
org.apache.hadoop.mapred A software framework for easily writing applications which process vast amounts of data (multi-terabyte data-sets) parallelly on large clusters (thousands of nodes) built of commodity hardware in a reliable, fault-tolerant manner. 
org.apache.hadoop.mapred.join Given a set of sorted datasets keyed with the same class and yielding equal partitions, it is possible to effect a join of those datasets prior to the map. 
org.apache.hadoop.mapred.lib Library of generally useful mappers, reducers, and partitioners. 
org.apache.hadoop.mapred.pipes Hadoop Pipes allows C++ code to use Hadoop DFS and map/reduce. 
org.apache.hadoop.mapred.tools   
org.apache.hadoop.mapreduce   
org.apache.hadoop.mapreduce.lib.input   
org.apache.hadoop.net Network-related classes. 
org.apache.hadoop.security   
org.apache.hadoop.security.authorize   
org.apache.hadoop.streaming Hadoop Streaming is a utility which allows users to create and run Map-Reduce jobs with any executables (e.g. 
org.apache.hadoop.util Common utilities. 
org.apache.hadoop.util.hash   
 

Uses of Configuration in org.apache.hadoop.conf
 

Methods in org.apache.hadoop.conf that return Configuration
 Configuration Configured.getConf()
           
 Configuration Configurable.getConf()
          Return the configuration used by this object.
 

Methods in org.apache.hadoop.conf with parameters of type Configuration
 void Configured.setConf(Configuration conf)
           
 void Configurable.setConf(Configuration conf)
          Set the configuration to be used by this object.
 

Constructors in org.apache.hadoop.conf with parameters of type Configuration
Configuration(Configuration other)
          A new configuration with the same settings cloned from another.
Configured(Configuration conf)
          Construct a Configured.
 

Uses of Configuration in org.apache.hadoop.contrib.failmon
 

Constructors in org.apache.hadoop.contrib.failmon with parameters of type Configuration
Executor(Configuration conf)
          Create an instance of the class and read the configuration file to determine the set of jobs that will be run and the maximum interval for which the thread can sleep before it wakes up to execute a monitoring job on the node.
 

Uses of Configuration in org.apache.hadoop.contrib.index.example
 

Constructors in org.apache.hadoop.contrib.index.example with parameters of type Configuration
LineDocRecordReader(Configuration job, FileSplit split)
          Constructor
 

Uses of Configuration in org.apache.hadoop.contrib.index.lucene
 

Constructors in org.apache.hadoop.contrib.index.lucene with parameters of type Configuration
FileSystemDirectory(FileSystem fs, Path directory, boolean create, Configuration conf)
          Constructor
 

Uses of Configuration in org.apache.hadoop.contrib.index.mapred
 

Methods in org.apache.hadoop.contrib.index.mapred that return Configuration
 Configuration IndexUpdateConfiguration.getConfiguration()
          Get the underlying configuration object.
 

Methods in org.apache.hadoop.contrib.index.mapred with parameters of type Configuration
 void IndexUpdater.run(Configuration conf, Path[] inputPaths, Path outputPath, int numMapTasks, Shard[] shards)
           
 void IIndexUpdater.run(Configuration conf, Path[] inputPaths, Path outputPath, int numMapTasks, Shard[] shards)
          Create a Map/Reduce job configuration and run the Map/Reduce job to analyze documents and update Lucene instances in parallel.
 

Constructors in org.apache.hadoop.contrib.index.mapred with parameters of type Configuration
IndexUpdateConfiguration(Configuration conf)
          Constructor
 

Uses of Configuration in org.apache.hadoop.examples
 

Constructors in org.apache.hadoop.examples with parameters of type Configuration
MultiFileWordCount.MultiFileLineRecordReader(Configuration conf, MultiFileSplit split)
           
 

Uses of Configuration in org.apache.hadoop.filecache
 

Methods in org.apache.hadoop.filecache with parameters of type Configuration
static void DistributedCache.addArchiveToClassPath(Path archive, Configuration conf)
          Add an archive path to the current set of classpath entries.
static void DistributedCache.addCacheArchive(URI uri, Configuration conf)
          Add a archives to be localized to the conf
static void DistributedCache.addCacheFile(URI uri, Configuration conf)
          Add a file to be localized to the conf
static void DistributedCache.addFileToClassPath(Path file, Configuration conf)
          Add an file path to the current set of classpath entries It adds the file to cache as well.
static void DistributedCache.createAllSymlink(Configuration conf, File jobCacheDir, File workDir)
          This method create symlinks for all files in a given dir in another directory
static void DistributedCache.createSymlink(Configuration conf)
          This method allows you to create symlinks in the current working directory of the task to all the cache files/archives
static Path[] DistributedCache.getArchiveClassPaths(Configuration conf)
          Get the archive entries in classpath as an array of Path
static String[] DistributedCache.getArchiveTimestamps(Configuration conf)
          Get the timestamps of the archives
static URI[] DistributedCache.getCacheArchives(Configuration conf)
          Get cache archives set in the Configuration
static URI[] DistributedCache.getCacheFiles(Configuration conf)
          Get cache files set in the Configuration
static Path[] DistributedCache.getFileClassPaths(Configuration conf)
          Get the file entries in classpath as an array of Path
static String[] DistributedCache.getFileTimestamps(Configuration conf)
          Get the timestamps of the files
static Path DistributedCache.getLocalCache(URI cache, Configuration conf, Path baseDir, boolean isArchive, long confFileStamp, Path currentWorkDir)
          Get the locally cached file or archive; it could either be previously cached (and valid) or copy it from the FileSystem now.
static Path DistributedCache.getLocalCache(URI cache, Configuration conf, Path baseDir, FileStatus fileStatus, boolean isArchive, long confFileStamp, Path currentWorkDir)
          Get the locally cached file or archive; it could either be previously cached (and valid) or copy it from the FileSystem now.
static Path DistributedCache.getLocalCache(URI cache, Configuration conf, Path baseDir, FileStatus fileStatus, boolean isArchive, long confFileStamp, Path currentWorkDir, boolean honorSymLinkConf)
          Get the locally cached file or archive; it could either be previously cached (and valid) or copy it from the FileSystem now.
static Path[] DistributedCache.getLocalCacheArchives(Configuration conf)
          Return the path array of the localized caches
static Path[] DistributedCache.getLocalCacheFiles(Configuration conf)
          Return the path array of the localized files
static boolean DistributedCache.getSymlink(Configuration conf)
          This method checks to see if symlinks are to be create for the localized cache files in the current working directory
static long DistributedCache.getTimestamp(Configuration conf, URI cache)
          Returns mtime of a given cache file on hdfs.
static String DistributedCache.makeRelative(URI cache, Configuration conf)
           
static void DistributedCache.purgeCache(Configuration conf)
          Clear the entire contents of the cache and delete the backing files.
static void DistributedCache.releaseCache(URI cache, Configuration conf)
          This is the opposite of getlocalcache.
static void DistributedCache.setArchiveTimestamps(Configuration conf, String timestamps)
          This is to check the timestamp of the archives to be localized
static void DistributedCache.setCacheArchives(URI[] archives, Configuration conf)
          Set the configuration with the given set of archives
static void DistributedCache.setCacheFiles(URI[] files, Configuration conf)
          Set the configuration with the given set of files
static void DistributedCache.setFileTimestamps(Configuration conf, String timestamps)
          This is to check the timestamp of the files to be localized
static void DistributedCache.setLocalArchives(Configuration conf, String str)
          Set the conf to contain the location for localized archives
static void DistributedCache.setLocalFiles(Configuration conf, String str)
          Set the conf to contain the location for localized files
 

Uses of Configuration in org.apache.hadoop.fs
 

Methods in org.apache.hadoop.fs that return Configuration
 Configuration FilterFileSystem.getConf()
           
 

Methods in org.apache.hadoop.fs with parameters of type Configuration
static boolean FileUtil.copy(File src, FileSystem dstFS, Path dst, boolean deleteSource, Configuration conf)
          Copy local files to a FileSystem.
static boolean FileUtil.copy(FileSystem srcFS, Path[] srcs, FileSystem dstFS, Path dst, boolean deleteSource, boolean overwrite, Configuration conf)
           
static boolean FileUtil.copy(FileSystem srcFS, Path src, File dst, boolean deleteSource, Configuration conf)
          Copy FileSystem files to local files.
static boolean FileUtil.copy(FileSystem srcFS, Path src, FileSystem dstFS, Path dst, boolean deleteSource, boolean overwrite, Configuration conf)
          Copy files between FileSystems.
static boolean FileUtil.copy(FileSystem srcFS, Path src, FileSystem dstFS, Path dst, boolean deleteSource, Configuration conf)
          Copy files between FileSystems.
static boolean FileUtil.copyMerge(FileSystem srcFS, Path srcDir, FileSystem dstFS, Path dstFile, boolean deleteSource, Configuration conf, String addString)
          Copy all files in a directory to one output file (merge).
 File LocalDirAllocator.createTmpFileForWrite(String pathStr, long size, Configuration conf)
          Creates a temporary file in the local FS.
static FileSystem FileSystem.get(Configuration conf)
          Returns the configured filesystem implementation.
static FileSystem FileSystem.get(URI uri, Configuration conf)
          Returns the FileSystem for this URI's scheme and authority.
static URI FileSystem.getDefaultUri(Configuration conf)
          Get the default filesystem URI from a configuration.
 FileSystem Path.getFileSystem(Configuration conf)
          Return the FileSystem that owns this Path.
static LocalFileSystem FileSystem.getLocal(Configuration conf)
          Get the local file syste
 Path LocalDirAllocator.getLocalPathForWrite(String pathStr, Configuration conf)
          Get a path from the local FS.
 Path LocalDirAllocator.getLocalPathForWrite(String pathStr, long size, Configuration conf)
          Get a path from the local FS.
 Path LocalDirAllocator.getLocalPathToRead(String pathStr, Configuration conf)
          Get a path from the local FS for reading.
static FileSystem FileSystem.getNamed(String name, Configuration conf)
          Deprecated. call #get(URI,Configuration) instead.
 boolean LocalDirAllocator.ifExists(String pathStr, Configuration conf)
          We search through all the configured dirs for the file's existence and return true when we find
 void RawLocalFileSystem.initialize(URI uri, Configuration conf)
           
 void HarFileSystem.initialize(URI name, Configuration conf)
          Initialize a Har filesystem per har archive.
 void FilterFileSystem.initialize(URI name, Configuration conf)
          Called after a new FileSystem instance is constructed.
 void FileSystem.initialize(URI name, Configuration conf)
          Called after a new FileSystem instance is constructed.
 void ChecksumFileSystem.setConf(Configuration conf)
           
static void FileSystem.setDefaultUri(Configuration conf, String uri)
          Set the default filesystem URI in a configuration.
static void FileSystem.setDefaultUri(Configuration conf, URI uri)
          Set the default filesystem URI in a configuration.
 

Constructors in org.apache.hadoop.fs with parameters of type Configuration
DF(File path, Configuration conf)
           
DU(File path, Configuration conf)
          Keeps track of disk usage.
FsShell(Configuration conf)
           
FsUrlStreamHandlerFactory(Configuration conf)
           
InMemoryFileSystem(URI uri, Configuration conf)
          Deprecated.  
Trash(Configuration conf)
          Construct a trash can accessor.
Trash(FileSystem fs, Configuration conf)
          Construct a trash can accessor for the FileSystem provided.
 

Uses of Configuration in org.apache.hadoop.fs.ftp
 

Methods in org.apache.hadoop.fs.ftp with parameters of type Configuration
 void FTPFileSystem.initialize(URI uri, Configuration conf)
           
 

Uses of Configuration in org.apache.hadoop.fs.kfs
 

Methods in org.apache.hadoop.fs.kfs with parameters of type Configuration
 void KosmosFileSystem.initialize(URI uri, Configuration conf)
           
 

Uses of Configuration in org.apache.hadoop.fs.permission
 

Methods in org.apache.hadoop.fs.permission with parameters of type Configuration
static FsPermission FsPermission.getUMask(Configuration conf)
          Get the user file creation mask (umask)
static void FsPermission.setUMask(Configuration conf, FsPermission umask)
          Set the user file creation mask (umask)
 

Uses of Configuration in org.apache.hadoop.fs.s3
 

Methods in org.apache.hadoop.fs.s3 with parameters of type Configuration
 void S3FileSystem.initialize(URI uri, Configuration conf)
           
 void S3Credentials.initialize(URI uri, Configuration conf)
           
 void FileSystemStore.initialize(URI uri, Configuration conf)
           
 

Uses of Configuration in org.apache.hadoop.fs.s3native
 

Methods in org.apache.hadoop.fs.s3native with parameters of type Configuration
 void NativeS3FileSystem.initialize(URI uri, Configuration conf)
           
 

Uses of Configuration in org.apache.hadoop.fs.shell
 

Constructors in org.apache.hadoop.fs.shell with parameters of type Configuration
Command(Configuration conf)
          Constructor
Count(String[] cmd, int pos, Configuration conf)
          Constructor
 

Uses of Configuration in org.apache.hadoop.http
 

Methods in org.apache.hadoop.http with parameters of type Configuration
 void HttpServer.addSslListener(InetSocketAddress addr, Configuration sslConf, boolean needClientAuth)
          Configure an ssl listener on the server.
protected  org.mortbay.jetty.Connector HttpServer.createBaseListener(Configuration conf)
          Create a required listener for the Jetty instance listening on the port provided.
 

Constructors in org.apache.hadoop.http with parameters of type Configuration
HttpServer(String name, String bindAddress, int port, boolean findPort, Configuration conf)
          Create a status server on the given port.
 

Uses of Configuration in org.apache.hadoop.io
 

Methods in org.apache.hadoop.io that return Configuration
 Configuration ObjectWritable.getConf()
           
 Configuration GenericWritable.getConf()
           
 Configuration AbstractMapWritable.getConf()
           
 

Methods in org.apache.hadoop.io with parameters of type Configuration
static
<T extends Writable>
T
WritableUtils.clone(T orig, Configuration conf)
          Make a copy of a writable object using serialization to a buffer.
static void IOUtils.copyBytes(InputStream in, OutputStream out, Configuration conf)
          Copies from one stream to another.
static void IOUtils.copyBytes(InputStream in, OutputStream out, Configuration conf, boolean close)
          Copies from one stream to another.
protected  SequenceFile.Reader MapFile.Reader.createDataFileReader(FileSystem fs, Path dataFile, Configuration conf)
          Override this method to specialize the type of SequenceFile.Reader returned.
static SequenceFile.Writer SequenceFile.createWriter(Configuration conf, FSDataOutputStream out, Class keyClass, Class valClass, SequenceFile.CompressionType compressionType, CompressionCodec codec)
          Construct the preferred type of 'raw' SequenceFile Writer.
static SequenceFile.Writer SequenceFile.createWriter(Configuration conf, FSDataOutputStream out, Class keyClass, Class valClass, SequenceFile.CompressionType compressionType, CompressionCodec codec, SequenceFile.Metadata metadata)
          Construct the preferred type of 'raw' SequenceFile Writer.
static SequenceFile.Writer SequenceFile.createWriter(FileSystem fs, Configuration conf, Path name, Class keyClass, Class valClass)
          Construct the preferred type of SequenceFile Writer.
static SequenceFile.Writer SequenceFile.createWriter(FileSystem fs, Configuration conf, Path name, Class keyClass, Class valClass, int bufferSize, short replication, long blockSize, SequenceFile.CompressionType compressionType, CompressionCodec codec, Progressable progress, SequenceFile.Metadata metadata)
          Construct the preferred type of SequenceFile Writer.
static SequenceFile.Writer SequenceFile.createWriter(FileSystem fs, Configuration conf, Path name, Class keyClass, Class valClass, SequenceFile.CompressionType compressionType)
          Construct the preferred type of SequenceFile Writer.
static SequenceFile.Writer SequenceFile.createWriter(FileSystem fs, Configuration conf, Path name, Class keyClass, Class valClass, SequenceFile.CompressionType compressionType, CompressionCodec codec)
          Construct the preferred type of SequenceFile Writer.
static SequenceFile.Writer SequenceFile.createWriter(FileSystem fs, Configuration conf, Path name, Class keyClass, Class valClass, SequenceFile.CompressionType compressionType, CompressionCodec codec, Progressable progress)
          Construct the preferred type of SequenceFile Writer.
static SequenceFile.Writer SequenceFile.createWriter(FileSystem fs, Configuration conf, Path name, Class keyClass, Class valClass, SequenceFile.CompressionType compressionType, CompressionCodec codec, Progressable progress, SequenceFile.Metadata metadata)
          Construct the preferred type of SequenceFile Writer.
static SequenceFile.Writer SequenceFile.createWriter(FileSystem fs, Configuration conf, Path name, Class keyClass, Class valClass, SequenceFile.CompressionType compressionType, Progressable progress)
          Construct the preferred type of SequenceFile Writer.
static long MapFile.fix(FileSystem fs, Path dir, Class<? extends Writable> keyClass, Class<? extends Writable> valueClass, boolean dryrun, Configuration conf)
          This method attempts to fix a corrupt MapFile by re-creating its index.
static Class<?> WritableName.getClass(String name, Configuration conf)
          Return the class for a name.
static SequenceFile.CompressionType SequenceFile.getCompressionType(Configuration job)
          Deprecated. Use SequenceFileOutputFormat.getOutputCompressionType(org.apache.hadoop.mapred.JobConf) to get SequenceFile.CompressionType for job-outputs.
static
<K> K
DefaultStringifier.load(Configuration conf, String keyName, Class<K> itemClass)
          Restores the object from the configuration.
static
<K> K[]
DefaultStringifier.loadArray(Configuration conf, String keyName, Class<K> itemClass)
          Restores the array of objects from the configuration.
static Writable WritableFactories.newInstance(Class<? extends Writable> c, Configuration conf)
          Create a new instance of a class with a defined factory.
protected  void MapFile.Reader.open(FileSystem fs, String dirName, WritableComparator comparator, Configuration conf)
           
static Object ObjectWritable.readObject(DataInput in, Configuration conf)
          Read a Writable, String, primitive type, or an array of the preceding.
static Object ObjectWritable.readObject(DataInput in, ObjectWritable objectWritable, Configuration conf)
          Read a Writable, String, primitive type, or an array of the preceding.
static void SequenceFile.setCompressionType(Configuration job, SequenceFile.CompressionType val)
          Deprecated. Use the one of the many SequenceFile.createWriter methods to specify the SequenceFile.CompressionType while creating the SequenceFile or SequenceFileOutputFormat.setOutputCompressionType(org.apache.hadoop.mapred.JobConf, org.apache.hadoop.io.SequenceFile.CompressionType) to specify the SequenceFile.CompressionType for job-outputs. or
 void ObjectWritable.setConf(Configuration conf)
           
 void GenericWritable.setConf(Configuration conf)
           
 void AbstractMapWritable.setConf(Configuration conf)
           
static void MapFile.Writer.setIndexInterval(Configuration conf, int interval)
          Sets the index interval and stores it in conf
static
<K> void
DefaultStringifier.store(Configuration conf, K item, String keyName)
          Stores the item in the configuration with the given keyName.
static
<K> void
DefaultStringifier.storeArray(Configuration conf, K[] items, String keyName)
          Stores the array of items in the configuration with the given keyName.
static void ObjectWritable.writeObject(DataOutput out, Object instance, Class declaredClass, Configuration conf)
          Write a Writable, String, primitive type, or an array of the preceding.
 

Constructors in org.apache.hadoop.io with parameters of type Configuration
ArrayFile.Reader(FileSystem fs, String file, Configuration conf)
          Construct an array reader for the named file.
ArrayFile.Writer(Configuration conf, FileSystem fs, String file, Class<? extends Writable> valClass)
          Create the named file for values of the named class.
ArrayFile.Writer(Configuration conf, FileSystem fs, String file, Class<? extends Writable> valClass, SequenceFile.CompressionType compress, Progressable progress)
          Create the named file for values of the named class.
BloomMapFile.Reader(FileSystem fs, String dirName, Configuration conf)
           
BloomMapFile.Reader(FileSystem fs, String dirName, WritableComparator comparator, Configuration conf)
           
BloomMapFile.Reader(FileSystem fs, String dirName, WritableComparator comparator, Configuration conf, boolean open)
           
BloomMapFile.Writer(Configuration conf, FileSystem fs, String dirName, Class<? extends WritableComparable> keyClass, Class valClass)
           
BloomMapFile.Writer(Configuration conf, FileSystem fs, String dirName, Class<? extends WritableComparable> keyClass, Class<? extends Writable> valClass, SequenceFile.CompressionType compress, CompressionCodec codec, Progressable progress)
           
BloomMapFile.Writer(Configuration conf, FileSystem fs, String dirName, Class<? extends WritableComparable> keyClass, Class valClass, SequenceFile.CompressionType compress)
           
BloomMapFile.Writer(Configuration conf, FileSystem fs, String dirName, Class<? extends WritableComparable> keyClass, Class valClass, SequenceFile.CompressionType compress, Progressable progress)
           
BloomMapFile.Writer(Configuration conf, FileSystem fs, String dirName, WritableComparator comparator, Class valClass)
           
BloomMapFile.Writer(Configuration conf, FileSystem fs, String dirName, WritableComparator comparator, Class valClass, SequenceFile.CompressionType compress)
           
BloomMapFile.Writer(Configuration conf, FileSystem fs, String dirName, WritableComparator comparator, Class valClass, SequenceFile.CompressionType compress, CompressionCodec codec, Progressable progress)
           
BloomMapFile.Writer(Configuration conf, FileSystem fs, String dirName, WritableComparator comparator, Class valClass, SequenceFile.CompressionType compress, Progressable progress)
           
DefaultStringifier(Configuration conf, Class<T> c)
           
MapFile.Reader(FileSystem fs, String dirName, Configuration conf)
          Construct a map reader for the named map.
MapFile.Reader(FileSystem fs, String dirName, WritableComparator comparator, Configuration conf)
          Construct a map reader for the named map using the named comparator.
MapFile.Reader(FileSystem fs, String dirName, WritableComparator comparator, Configuration conf, boolean open)
          Hook to allow subclasses to defer opening streams until further initialization is complete.
MapFile.Writer(Configuration conf, FileSystem fs, String dirName, Class<? extends WritableComparable> keyClass, Class valClass)
          Create the named map for keys of the named class.
MapFile.Writer(Configuration conf, FileSystem fs, String dirName, Class<? extends WritableComparable> keyClass, Class valClass, SequenceFile.CompressionType compress)
          Create the named map for keys of the named class.
MapFile.Writer(Configuration conf, FileSystem fs, String dirName, Class<? extends WritableComparable> keyClass, Class valClass, SequenceFile.CompressionType compress, CompressionCodec codec, Progressable progress)
          Create the named map for keys of the named class.
MapFile.Writer(Configuration conf, FileSystem fs, String dirName, Class<? extends WritableComparable> keyClass, Class valClass, SequenceFile.CompressionType compress, Progressable progress)
          Create the named map for keys of the named class.
MapFile.Writer(Configuration conf, FileSystem fs, String dirName, WritableComparator comparator, Class valClass)
          Create the named map using the named key comparator.
MapFile.Writer(Configuration conf, FileSystem fs, String dirName, WritableComparator comparator, Class valClass, SequenceFile.CompressionType compress)
          Create the named map using the named key comparator.
MapFile.Writer(Configuration conf, FileSystem fs, String dirName, WritableComparator comparator, Class valClass, SequenceFile.CompressionType compress, CompressionCodec codec, Progressable progress)
          Create the named map using the named key comparator.
MapFile.Writer(Configuration conf, FileSystem fs, String dirName, WritableComparator comparator, Class valClass, SequenceFile.CompressionType compress, Progressable progress)
          Create the named map using the named key comparator.
SequenceFile.Reader(FileSystem fs, Path file, Configuration conf)
          Open the named file.
SequenceFile.Sorter(FileSystem fs, Class<? extends WritableComparable> keyClass, Class valClass, Configuration conf)
          Sort and merge files containing the named classes.
SequenceFile.Sorter(FileSystem fs, RawComparator comparator, Class keyClass, Class valClass, Configuration conf)
          Sort and merge using an arbitrary RawComparator.
SequenceFile.Writer(FileSystem fs, Configuration conf, Path name, Class keyClass, Class valClass)
          Create the named file.
SequenceFile.Writer(FileSystem fs, Configuration conf, Path name, Class keyClass, Class valClass, int bufferSize, short replication, long blockSize, Progressable progress, SequenceFile.Metadata metadata)
          Create the named file with write-progress reporter.
SequenceFile.Writer(FileSystem fs, Configuration conf, Path name, Class keyClass, Class valClass, Progressable progress, SequenceFile.Metadata metadata)
          Create the named file with write-progress reporter.
SetFile.Reader(FileSystem fs, String dirName, Configuration conf)
          Construct a set reader for the named set.
SetFile.Reader(FileSystem fs, String dirName, WritableComparator comparator, Configuration conf)
          Construct a set reader for the named set using the named comparator.
SetFile.Writer(Configuration conf, FileSystem fs, String dirName, Class<? extends WritableComparable> keyClass, SequenceFile.CompressionType compress)
          Create a set naming the element class and compression type.
SetFile.Writer(Configuration conf, FileSystem fs, String dirName, WritableComparator comparator, SequenceFile.CompressionType compress)
          Create a set naming the element comparator and compression type.
 

Uses of Configuration in org.apache.hadoop.io.compress
 

Methods in org.apache.hadoop.io.compress that return Configuration
 Configuration DefaultCodec.getConf()
           
 

Methods in org.apache.hadoop.io.compress with parameters of type Configuration
static List<Class<? extends CompressionCodec>> CompressionCodecFactory.getCodecClasses(Configuration conf)
          Get the list of codecs listed in the configuration
static void CompressionCodecFactory.setCodecClasses(Configuration conf, List<Class> classes)
          Sets a list of codec classes in the configuration.
 void DefaultCodec.setConf(Configuration conf)
           
 

Constructors in org.apache.hadoop.io.compress with parameters of type Configuration
CompressionCodecFactory(Configuration conf)
          Find the codecs specified in the config value io.compression.codecs and register them.
 

Uses of Configuration in org.apache.hadoop.io.compress.zlib
 

Methods in org.apache.hadoop.io.compress.zlib with parameters of type Configuration
static Compressor ZlibFactory.getZlibCompressor(Configuration conf)
          Return the appropriate implementation of the zlib compressor.
static Class<? extends Compressor> ZlibFactory.getZlibCompressorType(Configuration conf)
          Return the appropriate type of the zlib compressor.
static Decompressor ZlibFactory.getZlibDecompressor(Configuration conf)
          Return the appropriate implementation of the zlib decompressor.
static Class<? extends Decompressor> ZlibFactory.getZlibDecompressorType(Configuration conf)
          Return the appropriate type of the zlib decompressor.
static boolean ZlibFactory.isNativeZlibLoaded(Configuration conf)
          Check if native-zlib code is loaded & initialized correctly and can be loaded for this job.
 

Uses of Configuration in org.apache.hadoop.io.file.tfile
 

Constructors in org.apache.hadoop.io.file.tfile with parameters of type Configuration
TFile.Reader(FSDataInputStream fsdis, long fileLength, Configuration conf)
          Constructor
TFile.Writer(FSDataOutputStream fsdos, int minBlockSize, String compressName, String comparator, Configuration conf)
          Constructor
 

Uses of Configuration in org.apache.hadoop.io.serializer
 

Constructors in org.apache.hadoop.io.serializer with parameters of type Configuration
SerializationFactory(Configuration conf)
           Serializations are found by reading the io.serializations property from conf, which is a comma-delimited list of classnames.
 

Uses of Configuration in org.apache.hadoop.ipc
 

Methods in org.apache.hadoop.ipc with parameters of type Configuration
static Object[] RPC.call(Method method, Object[][] params, InetSocketAddress[] addrs, Configuration conf)
          Deprecated. Use RPC.call(Method, Object[][], InetSocketAddress[], UserGroupInformation, Configuration) instead
static Object[] RPC.call(Method method, Object[][] params, InetSocketAddress[] addrs, UserGroupInformation ticket, Configuration conf)
          Expert: Make multiple, parallel calls to a set of servers.
static VersionedProtocol RPC.getProxy(Class<?> protocol, long clientVersion, InetSocketAddress addr, Configuration conf)
          Construct a client-side proxy object with the default SocketFactory
static VersionedProtocol RPC.getProxy(Class<?> protocol, long clientVersion, InetSocketAddress addr, Configuration conf, SocketFactory factory)
          Construct a client-side proxy object that implements the named protocol, talking to a server at the named address.
static VersionedProtocol RPC.getProxy(Class<?> protocol, long clientVersion, InetSocketAddress addr, UserGroupInformation ticket, Configuration conf, SocketFactory factory)
          Construct a client-side proxy object that implements the named protocol, talking to a server at the named address.
static RPC.Server RPC.getServer(Object instance, String bindAddress, int port, Configuration conf)
          Construct a server for a protocol implementation instance listening on a port and address.
static RPC.Server RPC.getServer(Object instance, String bindAddress, int port, int numHandlers, boolean verbose, Configuration conf)
          Construct a server for a protocol implementation instance listening on a port and address.
static void Client.setPingInterval(Configuration conf, int pingInterval)
          set the ping interval value in configuration
static VersionedProtocol RPC.waitForProxy(Class protocol, long clientVersion, InetSocketAddress addr, Configuration conf)
           
 

Constructors in org.apache.hadoop.ipc with parameters of type Configuration
Client(Class<? extends Writable> valueClass, Configuration conf)
          Construct an IPC client with the default SocketFactory
Client(Class<? extends Writable> valueClass, Configuration conf, SocketFactory factory)
          Construct an IPC client whose values are of the given Writable class.
RPC.Server(Object instance, Configuration conf, String bindAddress, int port)
          Construct an RPC server.
RPC.Server(Object instance, Configuration conf, String bindAddress, int port, int numHandlers, boolean verbose)
          Construct an RPC server.
Server(String bindAddress, int port, Class<? extends Writable> paramClass, int handlerCount, Configuration conf)
           
Server(String bindAddress, int port, Class<? extends Writable> paramClass, int handlerCount, Configuration conf, String serverName)
          Constructs a server listening on the named port and address.
 

Uses of Configuration in org.apache.hadoop.mapred
 

Subclasses of Configuration in org.apache.hadoop.mapred
 class JobConf
          Deprecated. Use Configuration instead
 

Fields in org.apache.hadoop.mapred declared as Configuration
protected  Configuration SequenceFileRecordReader.conf
           
 

Methods in org.apache.hadoop.mapred that return Configuration
 Configuration SequenceFileInputFilter.FilterBase.getConf()
           
 

Methods in org.apache.hadoop.mapred with parameters of type Configuration
static InetSocketAddress JobTracker.getAddress(Configuration conf)
           
static int SkipBadRecords.getAttemptsToStartSkipping(Configuration conf)
          Get the number of Task attempts AFTER which skip mode will be kicked off.
static boolean SkipBadRecords.getAutoIncrMapperProcCount(Configuration conf)
          Get the flag which if set to true, SkipBadRecords.COUNTER_MAP_PROCESSED_RECORDS is incremented by MapRunner after invoking the map function.
static boolean SkipBadRecords.getAutoIncrReducerProcCount(Configuration conf)
          Get the flag which if set to true, SkipBadRecords.COUNTER_REDUCE_PROCESSED_GROUPS is incremented by framework after invoking the reduce function.
static Class<? extends org.apache.hadoop.mapred.TaskTrackerInstrumentation> TaskTracker.getInstrumentationClass(Configuration conf)
           
static Class<? extends org.apache.hadoop.mapred.JobTrackerInstrumentation> JobTracker.getInstrumentationClass(Configuration conf)
           
static long SkipBadRecords.getMapperMaxSkipRecords(Configuration conf)
          Get the number of acceptable skip records surrounding the bad record PER bad record in mapper.
static SequenceFile.Reader[] SequenceFileOutputFormat.getReaders(Configuration conf, Path dir)
          Deprecated. Open the output generated by this format.
static MapFile.Reader[] MapFileOutputFormat.getReaders(FileSystem ignored, Path dir, Configuration conf)
          Open the output generated by this format.
static long SkipBadRecords.getReducerMaxSkipGroups(Configuration conf)
          Get the number of acceptable skip groups surrounding the bad group PER bad group in reducer.
static Path SkipBadRecords.getSkipOutputPath(Configuration conf)
          Get the directory to which skipped records are written.
static void SkipBadRecords.setAttemptsToStartSkipping(Configuration conf, int attemptsToStartSkipping)
          Set the number of Task attempts AFTER which skip mode will be kicked off.
static void SkipBadRecords.setAutoIncrMapperProcCount(Configuration conf, boolean autoIncr)
          Set the flag which if set to true, SkipBadRecords.COUNTER_MAP_PROCESSED_RECORDS is incremented by MapRunner after invoking the map function.
static void SkipBadRecords.setAutoIncrReducerProcCount(Configuration conf, boolean autoIncr)
          Set the flag which if set to true, SkipBadRecords.COUNTER_REDUCE_PROCESSED_GROUPS is incremented by framework after invoking the reduce function.
 void SequenceFileInputFilter.RegexFilter.setConf(Configuration conf)
          configure the Filter by checking the configuration
 void SequenceFileInputFilter.PercentFilter.setConf(Configuration conf)
          configure the filter by checking the configuration
 void SequenceFileInputFilter.MD5Filter.setConf(Configuration conf)
          configure the filter according to configuration
static void SequenceFileInputFilter.setFilterClass(Configuration conf, Class filterClass)
          set the filter class
static void SequenceFileInputFilter.PercentFilter.setFrequency(Configuration conf, int frequency)
          set the frequency and stores it in conf
static void SequenceFileInputFilter.MD5Filter.setFrequency(Configuration conf, int frequency)
          set the filtering frequency in configuration
static void JobTracker.setInstrumentationClass(Configuration conf, Class<? extends org.apache.hadoop.mapred.JobTrackerInstrumentation> t)
           
static void TaskTracker.setInstrumentationClass(Configuration conf, Class<? extends org.apache.hadoop.mapred.TaskTrackerInstrumentation> t)
           
static void SkipBadRecords.setMapperMaxSkipRecords(Configuration conf, long maxSkipRecs)
          Set the number of acceptable skip records surrounding the bad record PER bad record in mapper.
static void SequenceFileInputFilter.RegexFilter.setPattern(Configuration conf, String regex)
          Define the filtering regex and stores it in conf
static void SkipBadRecords.setReducerMaxSkipGroups(Configuration conf, long maxSkipGrps)
          Set the number of acceptable skip groups surrounding the bad group PER bad group in reducer.
 

Constructors in org.apache.hadoop.mapred with parameters of type Configuration
JobClient(InetSocketAddress jobTrackAddr, Configuration conf)
          Build a job client, connect to the indicated job tracker.
JobConf(Configuration conf)
          Deprecated. Construct a map/reduce job configuration.
JobConf(Configuration conf, Class exampleClass)
          Deprecated. Construct a map/reduce job configuration.
KeyValueLineRecordReader(Configuration job, FileSplit split)
           
LineRecordReader.LineReader(InputStream in, Configuration conf)
          Deprecated.  
LineRecordReader(Configuration job, FileSplit split)
          Deprecated.  
LineRecordReader(InputStream in, long offset, long endOffset, Configuration job)
          Deprecated.  
SequenceFileAsBinaryInputFormat.SequenceFileAsBinaryRecordReader(Configuration conf, FileSplit split)
           
SequenceFileAsTextRecordReader(Configuration conf, FileSplit split)
           
SequenceFileRecordReader(Configuration conf, FileSplit split)
           
 

Uses of Configuration in org.apache.hadoop.mapred.join
 

Methods in org.apache.hadoop.mapred.join that return Configuration
 Configuration CompositeRecordReader.getConf()
          Return the configuration used by this object.
 

Methods in org.apache.hadoop.mapred.join with parameters of type Configuration
 void CompositeRecordReader.setConf(Configuration conf)
          Set the configuration to be used by this object.
 

Uses of Configuration in org.apache.hadoop.mapred.lib
 

Methods in org.apache.hadoop.mapred.lib that return Configuration
 Configuration InputSampler.getConf()
           
 

Methods in org.apache.hadoop.mapred.lib with parameters of type Configuration
 void InputSampler.setConf(Configuration conf)
           
 

Uses of Configuration in org.apache.hadoop.mapred.pipes
 

Constructors in org.apache.hadoop.mapred.pipes with parameters of type Configuration
Submitter(Configuration conf)
           
 

Uses of Configuration in org.apache.hadoop.mapred.tools
 

Constructors in org.apache.hadoop.mapred.tools with parameters of type Configuration
MRAdmin(Configuration conf)
           
 

Uses of Configuration in org.apache.hadoop.mapreduce
 

Methods in org.apache.hadoop.mapreduce that return Configuration
 Configuration JobContext.getConfiguration()
          Return the configuration for the job.
 

Constructors in org.apache.hadoop.mapreduce with parameters of type Configuration
Job(Configuration conf)
           
Job(Configuration conf, String jobName)
           
JobContext(Configuration conf, JobID jobId)
           
MapContext(Configuration conf, TaskAttemptID taskid, RecordReader<KEYIN,VALUEIN> reader, RecordWriter<KEYOUT,VALUEOUT> writer, OutputCommitter committer, StatusReporter reporter, InputSplit split)
           
Mapper.Context(Configuration conf, TaskAttemptID taskid, RecordReader<KEYIN,VALUEIN> reader, RecordWriter<KEYOUT,VALUEOUT> writer, OutputCommitter committer, StatusReporter reporter, InputSplit split)
           
ReduceContext(Configuration conf, TaskAttemptID taskid, RawKeyValueIterator input, Counter inputCounter, RecordWriter<KEYOUT,VALUEOUT> output, OutputCommitter committer, StatusReporter reporter, RawComparator<KEYIN> comparator, Class<KEYIN> keyClass, Class<VALUEIN> valueClass)
           
Reducer.Context(Configuration conf, TaskAttemptID taskid, RawKeyValueIterator input, Counter inputCounter, RecordWriter<KEYOUT,VALUEOUT> output, OutputCommitter committer, StatusReporter reporter, RawComparator<KEYIN> comparator, Class<KEYIN> keyClass, Class<VALUEIN> valueClass)
           
TaskAttemptContext(Configuration conf, TaskAttemptID taskId)
           
TaskInputOutputContext(Configuration conf, TaskAttemptID taskid, RecordWriter<KEYOUT,VALUEOUT> output, OutputCommitter committer, StatusReporter reporter)
           
 

Uses of Configuration in org.apache.hadoop.mapreduce.lib.input
 

Fields in org.apache.hadoop.mapreduce.lib.input declared as Configuration
protected  Configuration SequenceFileRecordReader.conf
           
 

Uses of Configuration in org.apache.hadoop.net
 

Methods in org.apache.hadoop.net that return Configuration
 Configuration SocksSocketFactory.getConf()
           
 Configuration ScriptBasedMapping.getConf()
           
 

Methods in org.apache.hadoop.net with parameters of type Configuration
static SocketFactory NetUtils.getDefaultSocketFactory(Configuration conf)
          Get the default socket factory as specified by the configuration parameter hadoop.rpc.socket.factory.default
static String NetUtils.getServerAddress(Configuration conf, String oldBindAddressName, String oldPortName, String newBindAddressName)
          Deprecated. 
static SocketFactory NetUtils.getSocketFactory(Configuration conf, Class<?> clazz)
          Get the socket factory for the given class according to its configuration parameter hadoop.rpc.socket.factory.class.<ClassName>.
static SocketFactory NetUtils.getSocketFactoryFromProperty(Configuration conf, String propValue)
          Get the socket factory corresponding to the given proxy URI.
 void SocksSocketFactory.setConf(Configuration conf)
           
 void ScriptBasedMapping.setConf(Configuration conf)
           
 

Constructors in org.apache.hadoop.net with parameters of type Configuration
ScriptBasedMapping(Configuration conf)
           
 

Uses of Configuration in org.apache.hadoop.security
 

Methods in org.apache.hadoop.security with parameters of type Configuration
static UnixUserGroupInformation UnixUserGroupInformation.login(Configuration conf)
          Equivalent to login(conf, false).
static UserGroupInformation UserGroupInformation.login(Configuration conf)
          Login and return a UserGroupInformation object.
static UnixUserGroupInformation UnixUserGroupInformation.login(Configuration conf, boolean save)
          Get a user's name & its group names from the given configuration; If it is not defined in the configuration, get the current user's information from Unix.
static UserGroupInformation UserGroupInformation.readFrom(Configuration conf)
          Read a UserGroupInformation from conf
static UnixUserGroupInformation UnixUserGroupInformation.readFromConf(Configuration conf, String attr)
          Read a UGI from the given conf The object is expected to store with the property name attr as a comma separated string that starts with the user name followed by group names.
static void UnixUserGroupInformation.saveToConf(Configuration conf, String attr, UnixUserGroupInformation ugi)
          Store the given ugi as a comma separated string in conf as a property attr The String starts with the user name followed by the default group names, and other group names.
 

Uses of Configuration in org.apache.hadoop.security.authorize
 

Methods in org.apache.hadoop.security.authorize that return Configuration
 Configuration ConfiguredPolicy.getConf()
           
 

Methods in org.apache.hadoop.security.authorize with parameters of type Configuration
 void ConfiguredPolicy.setConf(Configuration conf)
           
 

Constructors in org.apache.hadoop.security.authorize with parameters of type Configuration
ConfiguredPolicy(Configuration conf, PolicyProvider policyProvider)
           
 

Uses of Configuration in org.apache.hadoop.streaming
 

Fields in org.apache.hadoop.streaming declared as Configuration
protected  Configuration StreamJob.config_
           
 

Methods in org.apache.hadoop.streaming that return Configuration
 Configuration StreamJob.getConf()
           
 

Methods in org.apache.hadoop.streaming with parameters of type Configuration
static Class StreamUtil.goodClassOrNull(Configuration conf, String className, String defaultPackage)
          It may seem strange to silently switch behaviour when a String is not a classname; the reason is simplified Usage:
 void StreamJob.setConf(Configuration conf)
           
 

Uses of Configuration in org.apache.hadoop.util
 

Methods in org.apache.hadoop.util that return Configuration
 Configuration GenericOptionsParser.getConfiguration()
          Get the modified configuration
 

Methods in org.apache.hadoop.util with parameters of type Configuration
static
<T> T
ReflectionUtils.copy(Configuration conf, T src, T dst)
          Make a copy of the writable object using serialization to a buffer
static URL[] GenericOptionsParser.getLibJars(Configuration conf)
          If libjars are set in the conf, parse the libjars.
 boolean NativeCodeLoader.getLoadNativeLibraries(Configuration conf)
          Return if native hadoop libraries, if present, can be used for this job.
static MemoryCalculatorPlugin MemoryCalculatorPlugin.getMemoryCalculatorPlugin(Class<? extends MemoryCalculatorPlugin> clazz, Configuration conf)
          Get the MemoryCalculatorPlugin from the class name and configure it.
static String[] Shell.getUlimitMemoryCommand(Configuration conf)
          Get the Unix command for setting the maximum virtual memory available to a given child process.
static
<T> T
ReflectionUtils.newInstance(Class<T> theClass, Configuration conf)
          Create an object for the given class and initialize it from conf
static int ToolRunner.run(Configuration conf, Tool tool, String[] args)
          Runs the given Tool by Tool.run(String[]), after parsing with the given generic arguments.
static void ReflectionUtils.setConf(Object theObject, Configuration conf)
          Check and set 'configuration' if necessary.
 void NativeCodeLoader.setLoadNativeLibraries(Configuration conf, boolean loadNativeLibraries)
          Set if native hadoop libraries, if present, can be used for this job.
 

Constructors in org.apache.hadoop.util with parameters of type Configuration
GenericOptionsParser(Configuration conf, org.apache.commons.cli.Options options, String[] args)
          Create a GenericOptionsParser to parse given options as well as generic Hadoop options.
GenericOptionsParser(Configuration conf, String[] args)
          Create a GenericOptionsParser to parse only the generic Hadoop arguments.
LineReader(InputStream in, Configuration conf)
          Create a line reader that reads from the given stream using the io.file.buffer.size specified in the given Configuration.
 

Uses of Configuration in org.apache.hadoop.util.hash
 

Methods in org.apache.hadoop.util.hash with parameters of type Configuration
static int Hash.getHashType(Configuration conf)
          This utility method converts the name of the configured hash type to a symbolic constant.
static Hash Hash.getInstance(Configuration conf)
          Get a singleton instance of hash function of a type defined in the configuration.
 



Copyright © 2009 The Apache Software Foundation