Uses of Interface
org.apache.hadoop.conf.Configurable

Packages that use Configurable
org.apache.hadoop.conf Configuration of system parameters. 
org.apache.hadoop.dfs A distributed implementation of FileSystem
org.apache.hadoop.examples Hadoop example code. 
org.apache.hadoop.examples.dancing This package is a distributed implementation of Knuth's dancing links algorithm that can run under Hadoop. 
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.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.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.serializer This package provides a mechanism for using different serialization frameworks in Hadoop. 
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.net Network-related classes. 
org.apache.hadoop.util Common utilities. 
 

Uses of Configurable in org.apache.hadoop.conf
 

Classes in org.apache.hadoop.conf that implement Configurable
 class Configured
          Base class for things that may be configured with a Configuration.
 

Uses of Configurable in org.apache.hadoop.dfs
 

Classes in org.apache.hadoop.dfs that implement Configurable
 class Balancer
          The balancer is a tool that balances disk space usage on an HDFS cluster when some datanodes become full or when new empty nodes join the cluster.
 class ChecksumDistributedFileSystem
          An implementation of ChecksumFileSystem over DistributedFileSystem.
 class DataNode
          DataNode is a class (and program) that stores a set of blocks for a DFS deployment.
 class DFSAdmin
          This class provides some DFS administrative access.
 class DFSck
          This class provides rudimentary checking of DFS volumes for errors and sub-optimal conditions.
 class DistributedFileSystem
          Implementation of the abstract FileSystem for the DFS system.
 class HftpFileSystem
          An implementation of a protocol for accessing filesystems over HTTP.
 class HsftpFileSystem
          An implementation of a protocol for accessing filesystems over HTTPS.
 

Uses of Configurable in org.apache.hadoop.examples
 

Classes in org.apache.hadoop.examples that implement Configurable
 class Grep
           
 class Join
          This is the trivial map/reduce program that does absolutely nothing other than use the framework to fragment and sort the input values.
 class MultiFileWordCount
          MultiFileWordCount is an example to demonstrate the usage of MultiFileInputFormat.
 class PiEstimator
          A Map-reduce program to estimaate the valu eof Pi using monte-carlo method.
 class RandomTextWriter
          This program uses map/reduce to just run a distributed job where there is no interaction between the tasks and each task writes a large unsorted random sequence of words.
 class RandomWriter
          This program uses map/reduce to just run a distributed job where there is no interaction between the tasks and each task write a large unsorted random binary sequence file of BytesWritable.
 class SleepJob
          Dummy class for testing MR framefork.
 class Sort
          This is the trivial map/reduce program that does absolutely nothing other than use the framework to fragment and sort the input values.
 class WordCount
          This is an example Hadoop Map/Reduce application.
 

Uses of Configurable in org.apache.hadoop.examples.dancing
 

Classes in org.apache.hadoop.examples.dancing that implement Configurable
 class DistributedPentomino
          Launch a distributed pentomino solver.
 

Uses of Configurable in org.apache.hadoop.fs
 

Classes in org.apache.hadoop.fs that implement Configurable
 class ChecksumFileSystem
          Abstract Checksumed FileSystem.
 class FileSystem
          An abstract base class for a fairly generic filesystem.
 class FilterFileSystem
          A FilterFileSystem contains some other file system, which it uses as its basic file system, possibly transforming the data along the way or providing additional functionality.
 class FsShell
          Provide command line access to a FileSystem.
 class HarFileSystem
          This is an implementation of the Hadoop Archive Filesystem.
 class InMemoryFileSystem
          Deprecated. 
 class LocalFileSystem
          Implement the FileSystem API for the checksumed local filesystem.
 class RawLocalFileSystem
          Implement the FileSystem API for the raw local filesystem.
 class Trash
          Provides a trash feature.
 

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

Classes in org.apache.hadoop.fs.ftp that implement Configurable
 class FTPFileSystem
           A FileSystem backed by an FTP client provided by Apache Commons Net.
 

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

Classes in org.apache.hadoop.fs.kfs that implement Configurable
 class KosmosFileSystem
          A FileSystem backed by KFS.
 

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

Classes in org.apache.hadoop.fs.s3 that implement Configurable
 class MigrationTool
           This class is a tool for migrating data from an older to a newer version of an S3 filesystem.
 class S3FileSystem
           A block-based FileSystem backed by Amazon S3.
 

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

Classes in org.apache.hadoop.fs.s3native that implement Configurable
 class NativeS3FileSystem
           A FileSystem for reading and writing files stored on Amazon S3.
 

Uses of Configurable in org.apache.hadoop.io
 

Classes in org.apache.hadoop.io that implement Configurable
 class AbstractMapWritable
          Abstract base class for MapWritable and SortedMapWritable Unlike org.apache.nutch.crawl.MapWritable, this class allows creation of MapWritable<Writable, MapWritable> so the CLASS_TO_ID and ID_TO_CLASS maps travel with the class instead of being static.
 class GenericWritable
          A wrapper for Writable instances.
 class MapWritable
          A Writable Map.
 class ObjectWritable
          A polymorphic Writable that writes an instance with it's class name.
 class SortedMapWritable
          A Writable SortedMap.
 

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

Classes in org.apache.hadoop.io.compress that implement Configurable
 class DefaultCodec
           
 class GzipCodec
          This class creates gzip compressors/decompressors.
 class LzoCodec
          A CompressionCodec for a streaming lzo compression/decompression pair.
 

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

Classes in org.apache.hadoop.io.serializer that implement Configurable
 class SerializationFactory
           A factory for Serializations.
 class WritableSerialization
          A Serialization for Writables that delegates to Writable.write(java.io.DataOutput) and Writable.readFields(java.io.DataInput).
 

Uses of Configurable in org.apache.hadoop.mapred
 

Subinterfaces of Configurable in org.apache.hadoop.mapred
static interface SequenceFileInputFilter.Filter
          filter interface
 

Classes in org.apache.hadoop.mapred that implement Configurable
 class JobClient
          JobClient is the primary interface for the user-job to interact with the JobTracker.
 class JobShell
          Provide command line parsing for JobSubmission job submission looks like hadoop jar -libjars -archives -files inputjar args
static class SequenceFileInputFilter.FilterBase
          base class for Filters
static class SequenceFileInputFilter.MD5Filter
          This class returns a set of records by examing the MD5 digest of its key against a filtering frequency f.
static class SequenceFileInputFilter.PercentFilter
          This class returns a percentage of records The percentage is determined by a filtering frequency f using the criteria record# % f == 0.
static class SequenceFileInputFilter.RegexFilter
          Records filter by matching key to regex
 

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

Classes in org.apache.hadoop.mapred.join that implement Configurable
 class CompositeRecordReader<K extends WritableComparable,V extends Writable,X extends Writable>
          A RecordReader that can effect joins of RecordReaders sharing a common key type and partitioning.
 class InnerJoinRecordReader<K extends WritableComparable>
          Full inner join.
 class JoinRecordReader<K extends WritableComparable>
          Base class for Composite joins returning Tuples of arbitrary Writables.
 class MultiFilterRecordReader<K extends WritableComparable,V extends Writable>
          Base class for Composite join returning values derived from multiple sources, but generally not tuples.
 class OuterJoinRecordReader<K extends WritableComparable>
          Full outer join.
 class OverrideRecordReader<K extends WritableComparable,V extends Writable>
          Prefer the "rightmost" data source for this key.
 

Uses of Configurable in org.apache.hadoop.net
 

Classes in org.apache.hadoop.net that implement Configurable
 class ScriptBasedMapping
          This class implements the DNSToSwitchMapping interface using a script configured via topology.script.file.name .
 class SocksSocketFactory
          Specialized SocketFactory to create sockets with a SOCKS proxy
 

Uses of Configurable in org.apache.hadoop.util
 

Subinterfaces of Configurable in org.apache.hadoop.util
 interface Tool
          A tool interface that supports handling of generic command-line options.
 



Copyright © 2008 The Apache Software Foundation