|
||||||||||
PREV NEXT | FRAMES NO FRAMES |
Packages that use Configured | |
---|---|
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.examples.terasort | This package consists of 3 map/reduce applications for Hadoop to compete in the annual terabyte sort competition. |
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.fs.shell | |
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.pipes | Hadoop Pipes allows C++ code to use Hadoop DFS and map/reduce. |
org.apache.hadoop.mapred.tools | |
org.apache.hadoop.mapreduce.lib.partition | |
org.apache.hadoop.util | Common utilities. |
Uses of Configured in org.apache.hadoop.examples |
---|
Subclasses of Configured in org.apache.hadoop.examples | |
---|---|
class |
DBCountPageView
This is a demonstrative program, which uses DBInputFormat for reading the input data from a database, and DBOutputFormat for writing the data to the database. |
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 estimate the value of Pi using quasi-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. |
static class |
SleepJob.SleepInputFormat
|
class |
Sort<K,V>
This is the trivial map/reduce program that does absolutely nothing other than use the framework to fragment and sort the input values. |
Uses of Configured in org.apache.hadoop.examples.dancing |
---|
Subclasses of Configured in org.apache.hadoop.examples.dancing | |
---|---|
class |
DistributedPentomino
Launch a distributed pentomino solver. |
Uses of Configured in org.apache.hadoop.examples.terasort |
---|
Subclasses of Configured in org.apache.hadoop.examples.terasort | |
---|---|
class |
TeraGen
Generate the official terasort input data set. |
class |
TeraSort
Generates the sampled split points, launches the job, and waits for it to finish. |
class |
TeraValidate
Generate 1 mapper per a file that checks to make sure the keys are sorted within each file. |
Uses of Configured in org.apache.hadoop.fs |
---|
Subclasses of Configured in org.apache.hadoop.fs | |
---|---|
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 Configured in org.apache.hadoop.fs.ftp |
---|
Subclasses of Configured in org.apache.hadoop.fs.ftp | |
---|---|
class |
FTPFileSystem
A FileSystem backed by an FTP client provided by Apache Commons Net. |
Uses of Configured in org.apache.hadoop.fs.kfs |
---|
Subclasses of Configured in org.apache.hadoop.fs.kfs | |
---|---|
class |
KosmosFileSystem
A FileSystem backed by KFS. |
Uses of Configured in org.apache.hadoop.fs.s3 |
---|
Subclasses of Configured in org.apache.hadoop.fs.s3 | |
---|---|
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 Configured in org.apache.hadoop.fs.s3native |
---|
Subclasses of Configured in org.apache.hadoop.fs.s3native | |
---|---|
class |
NativeS3FileSystem
A FileSystem for reading and writing files stored on
Amazon S3. |
Uses of Configured in org.apache.hadoop.fs.shell |
---|
Subclasses of Configured in org.apache.hadoop.fs.shell | |
---|---|
class |
Command
An abstract class for the execution of a file system command |
class |
Count
Count the number of directories, files, bytes, quota, and remaining quota. |
Uses of Configured in org.apache.hadoop.io.serializer |
---|
Subclasses of Configured in org.apache.hadoop.io.serializer | |
---|---|
class |
SerializationFactory
A factory for Serialization s. |
class |
WritableSerialization
A Serialization for Writable s that delegates to
Writable.write(java.io.DataOutput) and
Writable.readFields(java.io.DataInput) . |
Uses of Configured in org.apache.hadoop.mapred |
---|
Subclasses of Configured in org.apache.hadoop.mapred | |
---|---|
class |
JobClient
JobClient is the primary interface for the user-job to interact
with the JobTracker . |
Uses of Configured in org.apache.hadoop.mapred.pipes |
---|
Subclasses of Configured in org.apache.hadoop.mapred.pipes | |
---|---|
class |
Submitter
The main entry point and job submitter. |
Uses of Configured in org.apache.hadoop.mapred.tools |
---|
Subclasses of Configured in org.apache.hadoop.mapred.tools | |
---|---|
class |
MRAdmin
Administrative access to Hadoop Map-Reduce. |
Uses of Configured in org.apache.hadoop.mapreduce.lib.partition |
---|
Subclasses of Configured in org.apache.hadoop.mapreduce.lib.partition | |
---|---|
class |
InputSampler<K,V>
Utility for collecting samples and writing a partition file for TotalOrderPartitioner . |
Uses of Configured in org.apache.hadoop.util |
---|
Subclasses of Configured in org.apache.hadoop.util | |
---|---|
class |
LinuxMemoryCalculatorPlugin
Deprecated. Use LinuxResourceCalculatorPlugin
instead |
class |
LinuxResourceCalculatorPlugin
Plugin to calculate resource information on Linux systems. |
class |
MemoryCalculatorPlugin
Deprecated. Use ResourceCalculatorPlugin
instead |
class |
ResourceCalculatorPlugin
Plugin to calculate resource information on the system. |
|
||||||||||
PREV NEXT | FRAMES NO FRAMES |