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

Packages that use Configurable
org.apache.hadoop.conf Configuration of system parameters. 
org.apache.hadoop.fs An abstract file system API. 
org.apache.hadoop.fs.ftp   
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.viewfs   
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.io.serializer.avro This package provides Avro serialization in Hadoop. 
org.apache.hadoop.mapred   
org.apache.hadoop.mapred.join   
org.apache.hadoop.mapred.pipes   
org.apache.hadoop.mapreduce.lib.db   
org.apache.hadoop.mapreduce.lib.partition   
org.apache.hadoop.mapreduce.tools   
org.apache.hadoop.net Network-related classes. 
org.apache.hadoop.util Common utilities. 
org.apache.hadoop.yarn.client.cli   
 

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.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 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 facility which supports pluggable Trash policies.
 class TrashPolicy
          This interface is used for implementing different Trash policies.
 

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.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.fs.viewfs
 

Classes in org.apache.hadoop.fs.viewfs that implement Configurable
 class ViewFileSystem
          ViewFileSystem (extends the FileSystem interface) implements a client-side mount table.
 

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 EnumSetWritable<E extends Enum<E>>
          A Writable wrapper for EnumSet.
 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 BZip2Codec
          This class provides output and input streams for bzip2 compression and decompression.
 class DefaultCodec
           
 class GzipCodec
          This class creates gzip compressors/decompressors.
 

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

Classes in org.apache.hadoop.io.serializer that implement Configurable
 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.io.serializer.avro
 

Classes in org.apache.hadoop.io.serializer.avro that implement Configurable
 class AvroReflectSerialization
          Serialization for Avro Reflect classes.
 class AvroSerialization<T>
          Base class for providing serialization to Avro types.
 class AvroSpecificSerialization
          Serialization for Avro Specific classes.
 

Uses of Configurable in org.apache.hadoop.mapred
 

Classes in org.apache.hadoop.mapred that implement Configurable
 class JobClient
          JobClient is the primary interface for the user-job to interact with the cluster.
 

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.mapred.pipes
 

Classes in org.apache.hadoop.mapred.pipes that implement Configurable
 class Submitter
          The main entry point and job submitter.
 

Uses of Configurable in org.apache.hadoop.mapreduce.lib.db
 

Classes in org.apache.hadoop.mapreduce.lib.db that implement Configurable
 class DataDrivenDBInputFormat<T extends DBWritable>
          A InputFormat that reads input data from an SQL table.
 class DBInputFormat<T extends DBWritable>
          A InputFormat that reads input data from an SQL table.
 class OracleDataDrivenDBInputFormat<T extends DBWritable>
          A InputFormat that reads input data from an SQL table in an Oracle db.
 

Uses of Configurable in org.apache.hadoop.mapreduce.lib.partition
 

Classes in org.apache.hadoop.mapreduce.lib.partition that implement Configurable
 class BinaryPartitioner<V>
          Partition BinaryComparable keys using a configurable part of the bytes array returned by BinaryComparable.getBytes().
 class InputSampler<K,V>
          Utility for collecting samples and writing a partition file for TotalOrderPartitioner.
 class KeyFieldBasedComparator<K,V>
          This comparator implementation provides a subset of the features provided by the Unix/GNU Sort.
 class KeyFieldBasedPartitioner<K2,V2>
          Defines a way to partition keys based on certain key fields (also see KeyFieldBasedComparator.
 class TotalOrderPartitioner<K extends WritableComparable<?>,V>
          Partitioner effecting a total order by reading split points from an externally generated source.
 

Uses of Configurable in org.apache.hadoop.mapreduce.tools
 

Classes in org.apache.hadoop.mapreduce.tools that implement Configurable
 class CLI
          Interprets the map reduce cli options
 

Uses of Configurable in org.apache.hadoop.net
 

Classes in org.apache.hadoop.net that implement Configurable
 class AbstractDNSToSwitchMapping
          This is a base class for DNS to Switch mappings.
 class CachedDNSToSwitchMapping
          A cached implementation of DNSToSwitchMapping that takes an raw DNSToSwitchMapping and stores the resolved network location in a cache.
 class ScriptBasedMapping
          This class implements the DNSToSwitchMapping interface using a script configured via the CommonConfigurationKeysPublic.NET_TOPOLOGY_SCRIPT_FILE_NAME_KEY option.
 class SocksSocketFactory
          Specialized SocketFactory to create sockets with a SOCKS proxy
 class TableMapping
           Simple DNSToSwitchMapping implementation that reads a 2 column text file.
 

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.
 

Uses of Configurable in org.apache.hadoop.yarn.client.cli
 

Classes in org.apache.hadoop.yarn.client.cli that implement Configurable
 class LogsCLI
           
 



Copyright © 2014 Apache Software Foundation. All Rights Reserved.